public static class IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader extends MultiThreadedReader
| Modifier and Type | Class and Description |
|---|---|
class |
IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeBoundedMultiThreadedReaderThread |
private class |
IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeoutThread |
MultiThreadedReader.HBaseReaderThreadMultiThreadedAction.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, writerconf, 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, setRegionReplicaIdappendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGeneratorprotected 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
IOExceptionpublic void waitForFinish()
waitForFinish in class MultiThreadedActionprotected String progressInfo()
MultiThreadedActionprogressInfo in class MultiThreadedReaderpublic void start(long startKey, long endKey, int numThreads) throws IOException
start in class MultiThreadedReaderIOExceptionprotected MultiThreadedReader.HBaseReaderThread createReaderThread(int readerId) throws IOException
createReaderThread in class MultiThreadedReaderIOExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.