public class MultiThreadedReaderWithACL extends MultiThreadedReader
Modifier and Type | Class and Description |
---|---|
class |
MultiThreadedReaderWithACL.HBaseReaderThreadWithACL |
MultiThreadedReader.HBaseReaderThread
MultiThreadedAction.DefaultDataGenerator
Modifier and Type | Field and Description |
---|---|
private static String |
COMMA |
private static org.slf4j.Logger |
LOG |
private String[] |
userNames |
private Map<String,org.apache.hadoop.hbase.security.User> |
users |
private Map<String,org.apache.hadoop.hbase.client.Table> |
userVsTable
Maps user with Table instance.
|
aborted, DEFAULT_BATCH_SIZE, DEFAULT_KEY_WINDOW, DEFAULT_MAX_ERRORS, nullResult, numKeysVerified, numReadErrors, numReadFailures, readers, writer
conf, connection, dataGenerator, endKey, numCols, numKeys, numThreads, numThreadsWorking, REPORTING_INTERVAL_MS, startKey, tableName, totalOpTimeMs, verbose
Constructor and Description |
---|
MultiThreadedReaderWithACL(LoadTestDataGenerator dataGen,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.TableName tableName,
double verifyPercent,
String userNames) |
Modifier and Type | Method and Description |
---|---|
protected void |
addReaderThreads(int numThreads) |
createReaderThread, getNullResultsCount, getNumKeysVerified, getNumReadErrors, getNumReadFailures, getNumUniqueKeysVerified, linkToWriter, progressInfo, setKeyWindow, setMaxErrors, setMultiGetBatchSize, setRegionReplicaId, start
appendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGenerator, waitForFinish
private static final org.slf4j.Logger LOG
private static final String COMMA
private Map<String,org.apache.hadoop.hbase.client.Table> userVsTable
public MultiThreadedReaderWithACL(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double verifyPercent, String userNames) throws IOException
IOException
protected void addReaderThreads(int numThreads) throws IOException
addReaderThreads
in class MultiThreadedReader
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.