Package org.apache.hadoop.hbase.test
Class IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
java.lang.Object
org.apache.hadoop.hbase.util.MultiThreadedAction
org.apache.hadoop.hbase.util.MultiThreadedReader
org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
- Enclosing class:
- IntegrationTestTimeBoundedRequestsWithRegionReplicas
public static class IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
extends MultiThreadedReader
-
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionclassprivate static classNested classes/interfaces inherited from class org.apache.hadoop.hbase.util.MultiThreadedReader
MultiThreadedReader.HBaseReaderThreadNested classes/interfaces inherited from class org.apache.hadoop.hbase.util.MultiThreadedAction
MultiThreadedAction.DefaultDataGenerator -
Field Summary
FieldsModifier and TypeFieldDescriptionprotected longprotected AtomicLongprotected AtomicLongprotected longprotected ThreadFields inherited from class org.apache.hadoop.hbase.util.MultiThreadedReader
aborted, DEFAULT_BATCH_SIZE, DEFAULT_KEY_WINDOW, DEFAULT_MAX_ERRORS, nullResult, numKeysVerified, numReadErrors, numReadFailures, readers, writerFields inherited from class org.apache.hadoop.hbase.util.MultiThreadedAction
conf, connection, dataGenerator, endKey, numCols, numKeys, numThreads, numThreadsWorking, REPORTING_INTERVAL_MS, startKey, tableName, totalOpTimeMs, verbose -
Constructor Summary
ConstructorsConstructorDescriptionTimeBoundedMultiThreadedReader(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double verifyPercent) -
Method Summary
Modifier and TypeMethodDescriptionprotected MultiThreadedReader.HBaseReaderThreadcreateReaderThread(int readerId) protected StringReturns a task-specific progress stringvoidstart(long startKey, long endKey, int numThreads) voidMethods inherited from class org.apache.hadoop.hbase.util.MultiThreadedReader
addReaderThreads, getNullResultsCount, getNumKeysVerified, getNumReadErrors, getNumReadFailures, getNumUniqueKeysVerified, linkToWriter, setKeyWindow, setMaxErrors, setMultiGetBatchSize, setRegionReplicaIdMethods inherited from class org.apache.hadoop.hbase.util.MultiThreadedAction
appendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGenerator
-
Field Details
-
timeoutNano
-
timedOutReads
-
runTime
-
timeoutThread
-
staleReads
-
-
Constructor Details
-
TimeBoundedMultiThreadedReader
public TimeBoundedMultiThreadedReader(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double verifyPercent) throws IOException - Throws:
IOException
-
-
Method Details
-
waitForFinish
- Overrides:
waitForFinishin classMultiThreadedAction
-
progressInfo
Description copied from class:MultiThreadedActionReturns a task-specific progress string- Overrides:
progressInfoin classMultiThreadedReader
-
start
- Overrides:
startin classMultiThreadedReader- Throws:
IOException
-
createReaderThread
- Overrides:
createReaderThreadin classMultiThreadedReader- Throws:
IOException
-