Package org.apache.hadoop.hbase.util
Class MultiThreadedWriterBase
java.lang.Object
org.apache.hadoop.hbase.util.MultiThreadedAction
org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- Direct Known Subclasses:
- MultiThreadedUpdater,- MultiThreadedWriter
Creates multiple threads that write key/values into the
- 
Nested Class SummaryNested ClassesModifier and TypeClassDescriptionprivate classA thread that keeps track of the highest key in the contiguous range of inserted/updated keys.Nested classes/interfaces inherited from class org.apache.hadoop.hbase.util.MultiThreadedActionMultiThreadedAction.DefaultDataGenerator
- 
Field SummaryFieldsModifier and TypeFieldDescriptionThe sorted set of keys NOT inserted/updated by the writersprivate static final org.slf4j.Loggerprotected AtomicLongThis is the current key to be inserted/updated by any thread.protected booleanEnable this if used in conjunction with a concurrent reader.protected AtomicLongThe total size of the temporary inserted/updated key set that have not yet lined up in a our contiguous sequence starting from startKey.protected BlockingQueue<Long>A temporary place to keep track of inserted/updated keys.protected AtomicLongThe highest key in the contiguous range of keys .Fields inherited from class org.apache.hadoop.hbase.util.MultiThreadedActionconf, connection, dataGenerator, endKey, numCols, numKeys, numThreads, numThreadsWorking, REPORTING_INTERVAL_MS, startKey, tableName, totalOpTimeMs, verbose
- 
Constructor SummaryConstructorsConstructorDescriptionMultiThreadedWriterBase(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, TableName tableName, String actionLetter) 
- 
Method SummaryModifier and TypeMethodDescriptionprotected BlockingQueue<Long>createWriteKeysQueue(org.apache.hadoop.conf.Configuration conf) booleanfailedToWriteKey(long k) intprotected StringgetRegionDebugInfoSafe(Table table, byte[] rowKey) protected StringReturns a task-specific progress stringvoidsetTrackWroteKeys(boolean enable) Used for a joint write/read workload.voidstart(long startKey, long endKey, int numThreads) longThe max key until which all keys have been inserted/updated (successfully or not).Methods inherited from class org.apache.hadoop.hbase.util.MultiThreadedActionappendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGenerator, waitForFinish
- 
Field Details- 
LOG
- 
wroteKeysA temporary place to keep track of inserted/updated keys. This is written to by all writers and is drained on a separate thread that populateswroteUpToKey, the maximum key in the contiguous range of keys being inserted/updated. This queue is supposed to stay small.
- 
nextKeyToWriteThis is the current key to be inserted/updated by any thread. Each thread does an atomic get and increment operation and inserts the current value.
- 
wroteUpToKeyThe highest key in the contiguous range of keys .
- 
failedKeySetThe sorted set of keys NOT inserted/updated by the writers
- 
wroteKeyQueueSizeThe total size of the temporary inserted/updated key set that have not yet lined up in a our contiguous sequence starting from startKey. Supposed to stay small.
- 
trackWroteKeysEnable this if used in conjunction with a concurrent reader.
 
- 
- 
Constructor Details- 
MultiThreadedWriterBasepublic MultiThreadedWriterBase(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, TableName tableName, String actionLetter) throws IOException - Throws:
- IOException
 
 
- 
- 
Method Details- 
createWriteKeysQueue
- 
start- Overrides:
- startin class- MultiThreadedAction
- Throws:
- IOException
 
- 
getRegionDebugInfoSafe
- 
getNumWriteFailures
- 
wroteUpToKeyThe max key until which all keys have been inserted/updated (successfully or not).- Returns:
- the last key that we have inserted/updated all keys up to (inclusive)
 
- 
failedToWriteKey
- 
progressInfoDescription copied from class:MultiThreadedActionReturns a task-specific progress string- Specified by:
- progressInfoin class- MultiThreadedAction
 
- 
setTrackWroteKeysUsed for a joint write/read workload. Enables tracking the last inserted/updated key, which requires a blocking queue and a consumer thread.- Parameters:
- enable- whether to enable tracking the last inserted/updated key
 
 
-