Class IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter

java.lang.Object
org.apache.hadoop.hbase.util.MultiThreadedAction
org.apache.hadoop.hbase.util.MultiThreadedWriterBase
org.apache.hadoop.hbase.util.MultiThreadedWriter
org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter
Enclosing class:
IntegrationTestRegionReplicaReplication

public static class IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter extends org.apache.hadoop.hbase.util.MultiThreadedWriter
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer threads to become available to the MultiThradedReader threads. We add this delay because of the async nature of the wal replication to region replicas.
  • Nested Class Summary

    Nested classes/interfaces inherited from class org.apache.hadoop.hbase.util.MultiThreadedWriter

    org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread

    Nested classes/interfaces inherited from class org.apache.hadoop.hbase.util.MultiThreadedAction

    org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private long
     

    Fields inherited from class org.apache.hadoop.hbase.util.MultiThreadedWriter

    isMultiPut, writers

    Fields inherited from class org.apache.hadoop.hbase.util.MultiThreadedWriterBase

    failedKeySet, nextKeyToWrite, trackWroteKeys, wroteKeyQueueSize, wroteKeys, wroteUpToKey

    Fields 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

    Constructors
    Constructor
    Description
    DelayingMultiThreadedWriter(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    protected BlockingQueue<Long>
    createWriteKeysQueue(org.apache.hadoop.conf.Configuration conf)
     

    Methods inherited from class org.apache.hadoop.hbase.util.MultiThreadedWriter

    createWriterThreads, setMultiPut, start, waitForFinish

    Methods inherited from class org.apache.hadoop.hbase.util.MultiThreadedWriterBase

    failedToWriteKey, getNumWriteFailures, getRegionDebugInfoSafe, progressInfo, setTrackWroteKeys, wroteUpToKey

    Methods inherited from class org.apache.hadoop.hbase.util.MultiThreadedAction

    appendToStatus, appendToStatus, close, getEndKey, isDone, startThreads, verifyResultAgainstDataGenerator, verifyResultAgainstDataGenerator

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Field Details

  • Constructor Details

    • DelayingMultiThreadedWriter

      public DelayingMultiThreadedWriter(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) throws IOException
      Throws:
      IOException
  • Method Details

    • createWriteKeysQueue

      protected BlockingQueue<Long> createWriteKeysQueue(org.apache.hadoop.conf.Configuration conf)
      Overrides:
      createWriteKeysQueue in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase