public static class IntegrationTestRegionReplicaReplication.DelayingMultiThreadedUpdater extends MultiThreadedUpdater
MultiThreadedUpdater.HBaseUpdaterThread
MultiThreadedAction.DefaultDataGenerator
Modifier and Type | Field and Description |
---|---|
private long |
delayMs |
updaters
failedKeySet, nextKeyToWrite, trackWroteKeys, wroteKeyQueueSize, wroteKeys, wroteUpToKey
conf, connection, dataGenerator, endKey, numCols, numKeys, numThreads, numThreadsWorking, REPORTING_INTERVAL_MS, startKey, tableName, totalOpTimeMs, verbose
Constructor and Description |
---|
DelayingMultiThreadedUpdater(LoadTestDataGenerator dataGen,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.TableName tableName,
double updatePercent) |
Modifier and Type | Method and Description |
---|---|
protected BlockingQueue<Long> |
createWriteKeysQueue(org.apache.hadoop.conf.Configuration conf) |
addUpdaterThreads, linkToWriter, mutate, mutate, setBatchUpdate, setIgnoreNonceConflicts, start, waitForFinish
failedToWriteKey, getNumWriteFailures, getRegionDebugInfoSafe, progressInfo, setTrackWroteKeys, wroteUpToKey
appendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGenerator
private long delayMs
public DelayingMultiThreadedUpdater(LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double updatePercent) throws IOException
IOException
protected BlockingQueue<Long> createWriteKeysQueue(org.apache.hadoop.conf.Configuration conf)
createWriteKeysQueue
in class MultiThreadedWriterBase
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.