public static class IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader extends MultiThreadedReader
Modifier and Type | Class and Description |
---|---|
class |
IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeBoundedMultiThreadedReaderThread |
private static class |
IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeoutThread |
MultiThreadedReader.HBaseReaderThread
MultiThreadedAction.DefaultDataGenerator
Modifier and Type | Field and Description |
---|---|
protected long |
runTime |
protected AtomicLong |
staleReads |
protected AtomicLong |
timedOutReads |
protected long |
timeoutNano |
protected Thread |
timeoutThread |
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 |
---|
TimeBoundedMultiThreadedReader(LoadTestDataGenerator dataGen,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.TableName tableName,
double verifyPercent) |
Modifier and Type | Method and Description |
---|---|
protected MultiThreadedReader.HBaseReaderThread |
createReaderThread(int readerId) |
protected String |
progressInfo()
Returns a task-specific progress string
|
void |
start(long startKey,
long endKey,
int numThreads) |
void |
waitForFinish() |
addReaderThreads, getNullResultsCount, getNumKeysVerified, getNumReadErrors, getNumReadFailures, getNumUniqueKeysVerified, linkToWriter, setKeyWindow, setMaxErrors, setMultiGetBatchSize, setRegionReplicaId
appendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGenerator
protected long timeoutNano
protected AtomicLong timedOutReads
protected long runTime
protected Thread timeoutThread
protected AtomicLong staleReads
public TimeBoundedMultiThreadedReader(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double verifyPercent) throws IOException
IOException
public void waitForFinish()
waitForFinish
in class MultiThreadedAction
protected String progressInfo()
MultiThreadedAction
progressInfo
in class MultiThreadedReader
public void start(long startKey, long endKey, int numThreads) throws IOException
start
in class MultiThreadedReader
IOException
protected MultiThreadedReader.HBaseReaderThread createReaderThread(int readerId) throws IOException
createReaderThread
in class MultiThreadedReader
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.