| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| Modifier and Type | Field and Description | 
|---|---|
| private AsyncConnectionImpl | AsyncClientScanner. conn | 
| protected AsyncConnectionImpl | AsyncRpcRetryingCaller. conn | 
| private AsyncConnectionImpl | AsyncNonMetaRegionLocator. conn | 
| private AsyncConnectionImpl | AsyncTableRegionLocatorImpl. conn | 
| private AsyncConnectionImpl | AsyncBatchRpcRetryingCaller. conn | 
| private AsyncConnectionImpl | RawAsyncTableImpl. conn | 
| private AsyncConnectionImpl | AsyncRpcRetryingCallerFactory. conn | 
| private AsyncConnectionImpl | AsyncRegionLocator. conn | 
| private AsyncConnectionImpl | RegionCoprocessorRpcChannelImpl. conn | 
| private AsyncConnectionImpl | RawAsyncHBaseAdmin. connection | 
| Constructor and Description | 
|---|
| AsyncAdminRequestRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                               AsyncConnectionImpl conn,
                               int priority,
                               long pauseNs,
                               long pauseForCQTBENs,
                               int maxAttempts,
                               long operationTimeoutNs,
                               long rpcTimeoutNs,
                               int startLogErrorsCnt,
                               ServerName serverName,
                               AsyncAdminRequestRetryingCaller.Callable<T> callable) | 
| AsyncBatchRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                           AsyncConnectionImpl conn,
                           TableName tableName,
                           List<? extends Row> actions,
                           long pauseNs,
                           long pauseForCQTBENs,
                           int maxAttempts,
                           long operationTimeoutNs,
                           long rpcTimeoutNs,
                           int startLogErrorsCnt) | 
| AsyncClientScanner(Scan scan,
                  AdvancedScanResultConsumer consumer,
                  TableName tableName,
                  AsyncConnectionImpl conn,
                  org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                  long pauseNs,
                  long pauseForCQTBENs,
                  int maxAttempts,
                  long scanTimeoutNs,
                  long rpcTimeoutNs,
                  int startLogErrorsCnt) | 
| AsyncMasterRequestRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                                   AsyncConnectionImpl conn,
                                   AsyncMasterRequestRpcRetryingCaller.Callable<T> callable,
                                   int priority,
                                   long pauseNs,
                                   long pauseForCQTBENs,
                                   int maxRetries,
                                   long operationTimeoutNs,
                                   long rpcTimeoutNs,
                                   int startLogErrorsCnt) | 
| AsyncNonMetaRegionLocator(AsyncConnectionImpl conn) | 
| AsyncRegionLocator(AsyncConnectionImpl conn,
                  org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer) | 
| AsyncRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                      AsyncConnectionImpl conn,
                      int priority,
                      long pauseNs,
                      long pauseForCQTBENs,
                      int maxAttempts,
                      long operationTimeoutNs,
                      long rpcTimeoutNs,
                      int startLogErrorsCnt) | 
| AsyncRpcRetryingCallerFactory(AsyncConnectionImpl conn,
                             org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer) | 
| AsyncScanSingleRegionRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                                      AsyncConnectionImpl conn,
                                      Scan scan,
                                      ScanMetrics scanMetrics,
                                      long scannerId,
                                      ScanResultCache resultCache,
                                      AdvancedScanResultConsumer consumer,
                                      org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub,
                                      HRegionLocation loc,
                                      boolean isRegionServerRemote,
                                      int priority,
                                      long scannerLeaseTimeoutPeriodNs,
                                      long pauseNs,
                                      long pauseForCQTBENs,
                                      int maxAttempts,
                                      long scanTimeoutNs,
                                      long rpcTimeoutNs,
                                      int startLogErrorsCnt) | 
| AsyncServerRequestRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                                   AsyncConnectionImpl conn,
                                   long pauseNs,
                                   long pauseForCQTBENs,
                                   int maxAttempts,
                                   long operationTimeoutNs,
                                   long rpcTimeoutNs,
                                   int startLogErrorsCnt,
                                   ServerName serverName,
                                   AsyncServerRequestRpcRetryingCaller.Callable<T> callable) | 
| AsyncSingleRequestRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                                   AsyncConnectionImpl conn,
                                   TableName tableName,
                                   byte[] row,
                                   int replicaId,
                                   RegionLocateType locateType,
                                   AsyncSingleRequestRpcRetryingCaller.Callable<T> callable,
                                   int priority,
                                   long pauseNs,
                                   long pauseForCQTBENs,
                                   int maxAttempts,
                                   long operationTimeoutNs,
                                   long rpcTimeoutNs,
                                   int startLogErrorsCnt) | 
| AsyncTableImpl(AsyncConnectionImpl conn,
              AsyncTable<AdvancedScanResultConsumer> rawTable,
              ExecutorService pool) | 
| AsyncTableRegionLocatorImpl(TableName tableName,
                           AsyncConnectionImpl conn) | 
| RawAsyncHBaseAdmin(AsyncConnectionImpl connection,
                  org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer,
                  AsyncAdminBuilderBase builder) | 
| RawAsyncTableImpl(AsyncConnectionImpl conn,
                 org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                 AsyncTableBuilderBase<?> builder) | 
| RegionCoprocessorRpcChannelImpl(AsyncConnectionImpl conn,
                               TableName tableName,
                               RegionInfo region,
                               byte[] row,
                               long rpcTimeoutNs,
                               long operationTimeoutNs) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.