Class TestAsyncProcess.MyAsyncProcess

java.lang.Object
org.apache.hadoop.hbase.client.TestAsyncProcess.MyAsyncProcess
Direct Known Subclasses:
TestAsyncProcess.AsyncProcessWithFailure, TestAsyncProcess.MyAsyncProcessWithReplicas
Enclosing class:
TestAsyncProcess

  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    List<org.apache.hadoop.hbase.client.AsyncRequestFuture>
     
     
    private org.apache.hadoop.conf.Configuration
     
    (package private) final org.apache.hadoop.hbase.client.ClusterConnection
     
    (package private) final org.apache.hadoop.hbase.client.ConnectionConfiguration
     
    static final int
     
    (package private) final long
     
    static final String
     
    static final String
     
    (package private) final boolean
     
    (package private) final AtomicInteger
     
    (package private) final AtomicInteger
     
    (package private) final int
     
    private long
     
    static final String
     
    (package private) final long
     
    (package private) final org.apache.hadoop.hbase.client.RequestController
     
    (package private) final org.apache.hadoop.hbase.ipc.RpcControllerFactory
     
    (package private) long
     
    (package private) final ExecutorService
     
    static final String
     
    (package private) final int
     
  • Constructor Summary

    Constructors
    Constructor
    Description
    MyAsyncProcess(org.apache.hadoop.hbase.client.ClusterConnection hc, org.apache.hadoop.conf.Configuration conf)
     
    MyAsyncProcess(org.apache.hadoop.hbase.client.ClusterConnection hc, org.apache.hadoop.conf.Configuration conf, AtomicInteger nbThreads)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    (package private) static void
    addAction(org.apache.hadoop.hbase.ServerName arg0, byte[] arg1, org.apache.hadoop.hbase.client.Action arg2, Map<org.apache.hadoop.hbase.ServerName,org.apache.hadoop.hbase.client.MultiAction> arg3, long arg4)
     
    protected <Res> org.apache.hadoop.hbase.client.AsyncRequestFutureImpl<Res>
    createAsyncRequestFuture(org.apache.hadoop.hbase.client.AsyncProcessTask task, List<org.apache.hadoop.hbase.client.Action> actions, long nonceGroup)
     
    protected org.apache.hadoop.hbase.client.RpcRetryingCaller<org.apache.hadoop.hbase.client.AbstractResponse>
    createCaller(org.apache.hadoop.hbase.client.CancellableRegionServerCallable callable, int rpcTimeout)
     
    (package private) org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
     
    (package private) void
    decTaskCounters(Collection<byte[]> arg0, org.apache.hadoop.hbase.ServerName arg1)
     
    (package private) void
    incTaskCounters(Collection<byte[]> arg0, org.apache.hadoop.hbase.ServerName arg1)
     
    (package private) static boolean
    isReplicaGet(org.apache.hadoop.hbase.client.Row arg0)
     
    <CResult> org.apache.hadoop.hbase.client.AsyncRequestFuture
    submit(ExecutorService pool, org.apache.hadoop.hbase.TableName tableName, List<? extends org.apache.hadoop.hbase.client.Row> rows, boolean atLeastOne, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<CResult> callback, boolean needResults)
     
    <Res> org.apache.hadoop.hbase.client.AsyncRequestFuture
    submit(org.apache.hadoop.hbase.client.AsyncProcessTask<Res> task)
     
    <CResult> org.apache.hadoop.hbase.client.AsyncRequestFuture
    submit(org.apache.hadoop.hbase.TableName tableName, List<? extends org.apache.hadoop.hbase.client.Row> rows, boolean atLeastOne, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<CResult> callback, boolean needResults)
     
    (package private) <CResult extends Object>
    org.apache.hadoop.hbase.client.AsyncRequestFuture
    submitMultiActions(org.apache.hadoop.hbase.client.AsyncProcessTask arg0, List<org.apache.hadoop.hbase.client.Action> arg1, long arg2, List<Exception> arg3, List<Integer> arg4, Map<org.apache.hadoop.hbase.ServerName,org.apache.hadoop.hbase.client.MultiAction> arg5)
     
    protected void
    waitForMaximumCurrentTasks(int arg0, org.apache.hadoop.hbase.TableName arg1)
     

    Methods inherited from class java.lang.Object

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

    • nbMultiResponse

    • nbActions

    • allReqs

      public List<org.apache.hadoop.hbase.client.AsyncRequestFuture> allReqs
    • callsCt

    • conf

      private org.apache.hadoop.conf.Configuration conf
    • previousTimeout

      private long previousTimeout
    • service

    • PRIMARY_CALL_TIMEOUT_KEY

      public static final String PRIMARY_CALL_TIMEOUT_KEY
      See Also:
    • START_LOG_ERRORS_AFTER_COUNT_KEY

      public static final String START_LOG_ERRORS_AFTER_COUNT_KEY
      See Also:
    • DEFAULT_START_LOG_ERRORS_AFTER_COUNT

      public static final int DEFAULT_START_LOG_ERRORS_AFTER_COUNT
      See Also:
    • LOG_DETAILS_FOR_BATCH_ERROR

      public static final String LOG_DETAILS_FOR_BATCH_ERROR
      See Also:
    • id

      final long id
    • connection

      final org.apache.hadoop.hbase.client.ClusterConnection connection
    • connectionConfiguration

      final org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration
    • rpcFactory

      final org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcFactory
    • startLogErrorsCnt

      final int startLogErrorsCnt
    • numTries

      final int numTries
    • serverTrackerTimeout

      long serverTrackerTimeout
    • primaryCallTimeoutMicroseconds

      final long primaryCallTimeoutMicroseconds
    • logBatchErrorDetails

      final boolean logBatchErrorDetails
    • requestController

      final org.apache.hadoop.hbase.client.RequestController requestController
    • LOG_DETAILS_PERIOD

      public static final String LOG_DETAILS_PERIOD
      See Also:
  • Constructor Details

    • MyAsyncProcess

      public MyAsyncProcess(org.apache.hadoop.hbase.client.ClusterConnection hc, org.apache.hadoop.conf.Configuration conf)
    • MyAsyncProcess

      public MyAsyncProcess(org.apache.hadoop.hbase.client.ClusterConnection hc, org.apache.hadoop.conf.Configuration conf, AtomicInteger nbThreads)
  • Method Details

    • createAsyncRequestFuture

      protected <Res> org.apache.hadoop.hbase.client.AsyncRequestFutureImpl<Res> createAsyncRequestFuture(org.apache.hadoop.hbase.client.AsyncProcessTask task, List<org.apache.hadoop.hbase.client.Action> actions, long nonceGroup)
    • submit

      public <CResult> org.apache.hadoop.hbase.client.AsyncRequestFuture submit(ExecutorService pool, org.apache.hadoop.hbase.TableName tableName, List<? extends org.apache.hadoop.hbase.client.Row> rows, boolean atLeastOne, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<CResult> callback, boolean needResults) throws InterruptedIOException
      Throws:
      InterruptedIOException
    • submit

      public <CResult> org.apache.hadoop.hbase.client.AsyncRequestFuture submit(org.apache.hadoop.hbase.TableName tableName, List<? extends org.apache.hadoop.hbase.client.Row> rows, boolean atLeastOne, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<CResult> callback, boolean needResults) throws InterruptedIOException
      Throws:
      InterruptedIOException
    • submit

      public <Res> org.apache.hadoop.hbase.client.AsyncRequestFuture submit(org.apache.hadoop.hbase.client.AsyncProcessTask<Res> task) throws InterruptedIOException
      Throws:
      InterruptedIOException
    • createCaller

      protected org.apache.hadoop.hbase.client.RpcRetryingCaller<org.apache.hadoop.hbase.client.AbstractResponse> createCaller(org.apache.hadoop.hbase.client.CancellableRegionServerCallable callable, int rpcTimeout)
    • submitMultiActions

      <CResult extends Object> org.apache.hadoop.hbase.client.AsyncRequestFuture submitMultiActions(org.apache.hadoop.hbase.client.AsyncProcessTask arg0, List<org.apache.hadoop.hbase.client.Action> arg1, long arg2, List<Exception> arg3, List<Integer> arg4, Map<org.apache.hadoop.hbase.ServerName,org.apache.hadoop.hbase.client.MultiAction> arg5)
    • addAction

      static void addAction(org.apache.hadoop.hbase.ServerName arg0, byte[] arg1, org.apache.hadoop.hbase.client.Action arg2, Map<org.apache.hadoop.hbase.ServerName,org.apache.hadoop.hbase.client.MultiAction> arg3, long arg4)
    • waitForMaximumCurrentTasks

      protected void waitForMaximumCurrentTasks(int arg0, org.apache.hadoop.hbase.TableName arg1) throws InterruptedIOException
      Throws:
      InterruptedIOException
    • incTaskCounters

      void incTaskCounters(Collection<byte[]> arg0, org.apache.hadoop.hbase.ServerName arg1)
    • decTaskCounters

      void decTaskCounters(Collection<byte[]> arg0, org.apache.hadoop.hbase.ServerName arg1)
    • createServerErrorTracker

      org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker createServerErrorTracker()
    • isReplicaGet

      static boolean isReplicaGet(org.apache.hadoop.hbase.client.Row arg0)