| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.handler | |
| org.apache.hadoop.hbase.replication.regionserver | 
| Modifier and Type | Field and Description | 
|---|---|
| private RpcRetryingCallerFactory | ResultBoundedCompletionService. retryingCallerFactory | 
| private RpcRetryingCallerFactory | HTable. rpcCallerFactory | 
| private RpcRetryingCallerFactory | AsyncProcess. rpcCallerFactory | 
| private RpcRetryingCallerFactory | ConnectionImplementation. rpcCallerFactory | 
| private RpcRetryingCallerFactory | RegionCoprocessorRpcChannel. rpcCallerFactory | 
| private RpcRetryingCallerFactory | HBaseAdmin. rpcCallerFactory | 
| private RpcRetryingCallerFactory | RpcRetryingCallerWithReadReplicas. rpcRetryingCallerFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| RpcRetryingCallerFactory | ClusterConnection. getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)Returns a new RpcRetryingCallerFactory from the given  Configuration. | 
| RpcRetryingCallerFactory | ConnectionImplementation. getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf) | 
| RpcRetryingCallerFactory | ClusterConnection. getRpcRetryingCallerFactory() | 
| RpcRetryingCallerFactory | ConnectionImplementation. getRpcRetryingCallerFactory() | 
| static RpcRetryingCallerFactory | RpcRetryingCallerFactory. instantiate(org.apache.hadoop.conf.Configuration configuration) | 
| static RpcRetryingCallerFactory | RpcRetryingCallerFactory. instantiate(org.apache.hadoop.conf.Configuration configuration,
           RetryingCallerInterceptor interceptor,
           ServerStatisticTracker stats) | 
| static RpcRetryingCallerFactory | RpcRetryingCallerFactory. instantiate(org.apache.hadoop.conf.Configuration configuration,
           ServerStatisticTracker stats) | 
| Modifier and Type | Method and Description | 
|---|---|
| private static <C extends RetryingCallable<V> & Closeable,V> | HBaseAdmin. executeCallable(C callable,
               RpcRetryingCallerFactory rpcCallerFactory,
               int operationTimeout,
               int rpcTimeout) | 
| (package private) static HTableDescriptor | HBaseAdmin. getHTableDescriptor(TableName tableName,
                   Connection connection,
                   RpcRetryingCallerFactory rpcCallerFactory,
                   RpcControllerFactory rpcControllerFactory,
                   int operationTimeout,
                   int rpcTimeout)Deprecated. 
 since 2.0 version and will be removed in 3.0 version.
             use  HBaseAdmin.getTableDescriptor(TableName,
             Connection, RpcRetryingCallerFactory,RpcControllerFactory,int,int) | 
| static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse | QuotaStatusCalls. getMasterQuotaStates(Connection conn,
                    RpcControllerFactory factory,
                    RpcRetryingCallerFactory rpcCaller,
                    int timeout)Executes an RPC tot he HBase master to fetch its view on space quotas. | 
| static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesResponse | QuotaStatusCalls. getMasterRegionSizes(Connection conn,
                    RpcControllerFactory factory,
                    RpcRetryingCallerFactory rpcCaller,
                    int timeout)Executes an RPC to the HBase master to fetch its view on the Region sizes. | 
| (package private) static TableDescriptor | HBaseAdmin. getTableDescriptor(TableName tableName,
                  Connection connection,
                  RpcRetryingCallerFactory rpcCallerFactory,
                  RpcControllerFactory rpcControllerFactory,
                  int operationTimeout,
                  int rpcTimeout) | 
| Constructor and Description | 
|---|
| AsyncProcess(ClusterConnection hc,
            org.apache.hadoop.conf.Configuration conf,
            RpcRetryingCallerFactory rpcCaller,
            RpcControllerFactory rpcFactory) | 
| BufferedMutatorImpl(ClusterConnection conn,
                   RpcRetryingCallerFactory rpcCallerFactory,
                   RpcControllerFactory rpcFactory,
                   BufferedMutatorParams params) | 
| ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration,
                          Scan scan,
                          TableName name,
                          ClusterConnection connection,
                          RpcRetryingCallerFactory rpcCallerFactory,
                          RpcControllerFactory rpcControllerFactory,
                          ExecutorService pool,
                          int replicaCallTimeoutMicroSecondScan) | 
| ClientScanner(org.apache.hadoop.conf.Configuration conf,
             Scan scan,
             TableName tableName,
             ClusterConnection connection,
             RpcRetryingCallerFactory rpcFactory,
             RpcControllerFactory controllerFactory,
             ExecutorService pool,
             int primaryOperationTimeout)Create a new ClientScanner for the specified table Note that the passed  Scan's start
 row maybe changed changed. | 
| ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration,
                   Scan scan,
                   TableName name,
                   ClusterConnection connection,
                   RpcRetryingCallerFactory rpcCallerFactory,
                   RpcControllerFactory rpcControllerFactory,
                   ExecutorService pool,
                   int replicaCallTimeoutMicroSecondScan) | 
| HTable(ClusterConnection connection,
      TableBuilderBase builder,
      RpcRetryingCallerFactory rpcCallerFactory,
      RpcControllerFactory rpcControllerFactory,
      ExecutorService pool)Creates an object to access a HBase table. | 
| ResultBoundedCompletionService(RpcRetryingCallerFactory retryingCallerFactory,
                              Executor executor,
                              int maxTasks) | 
| ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
                     Scan scan,
                     TableName tableName,
                     ClusterConnection connection,
                     RpcRetryingCallerFactory rpcFactory,
                     RpcControllerFactory controllerFactory,
                     ExecutorService pool,
                     int primaryOperationTimeout)Create a new ReversibleClientScanner for the specified table Note that the passed
  Scan's start row maybe changed. | 
| Modifier and Type | Field and Description | 
|---|---|
| private RpcRetryingCallerFactory | HRegionServer. rpcRetryingCallerFactory | 
| Modifier and Type | Field and Description | 
|---|---|
| private RpcRetryingCallerFactory | RegionReplicaFlushHandler. rpcRetryingCallerFactory | 
| Constructor and Description | 
|---|
| RegionReplicaFlushHandler(Server server,
                         ClusterConnection connection,
                         RpcRetryingCallerFactory rpcRetryingCallerFactory,
                         RpcControllerFactory rpcControllerFactory,
                         int operationTimeout,
                         HRegion region) | 
| Modifier and Type | Field and Description | 
|---|---|
| (package private) RpcRetryingCallerFactory | RegionReplicaReplicationEndpoint.RetryingRpcCallable. factory | 
| (package private) RpcRetryingCallerFactory | RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter. rpcRetryingCallerFactory | 
| Constructor and Description | 
|---|
| RetryingRpcCallable(RpcRetryingCallerFactory factory,
                   RetryingCallable<V> callable,
                   int timeout) | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.