Uses of Class
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Package
Description
Provides HBase Client
-
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final RpcRetryingCallerFactory
ResultBoundedCompletionService.retryingCallerFactory
private final RpcRetryingCallerFactory
AsyncProcess.rpcCallerFactory
private final RpcRetryingCallerFactory
ConnectionImplementation.rpcCallerFactory
private RpcRetryingCallerFactory
HBaseAdmin.rpcCallerFactory
private final RpcRetryingCallerFactory
HTable.rpcCallerFactory
private final RpcRetryingCallerFactory
RegionCoprocessorRpcChannel.rpcCallerFactory
private final RpcRetryingCallerFactory
RpcRetryingCallerWithReadReplicas.rpcRetryingCallerFactory
Modifier and TypeMethodDescriptionClusterConnection.getNewRpcRetryingCallerFactory
(org.apache.hadoop.conf.Configuration conf) Returns a new RpcRetryingCallerFactory from the givenConfiguration
.ConnectionImplementation.getNewRpcRetryingCallerFactory
(org.apache.hadoop.conf.Configuration conf) ClusterConnection.getRpcRetryingCallerFactory()
Returns Connection's RpcRetryingCallerFactory instanceConnectionImplementation.getRpcRetryingCallerFactory()
static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, MetricsConnection metrics) static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, RetryingCallerInterceptor interceptor, ServerStatisticTracker stats, MetricsConnection metrics) static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, ServerStatisticTracker stats, MetricsConnection metrics) static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, MetricsConnection metrics) Modifier and TypeMethodDescriptionprivate static <C extends RetryingCallable<V> & Closeable,
V>
VHBaseAdmin.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.(package private) static TableDescriptor
HBaseAdmin.getTableDescriptor
(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) ModifierConstructorDescription(package private)
AsyncProcess
(ClusterConnection hc, org.apache.hadoop.conf.Configuration conf, RpcRetryingCallerFactory rpcCaller, RpcControllerFactory rpcFactory) (package private)
AsyncProcess
(ClusterConnection hc, org.apache.hadoop.conf.Configuration conf, RpcRetryingCallerFactory rpcCaller, RpcControllerFactory rpcFactory, int retriesNumber) (package private)
BufferedMutatorImpl
(ClusterConnection conn, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcFactory, BufferedMutatorParams params) ClientAsyncPrefetchScanner
(org.apache.hadoop.conf.Configuration configuration, Scan scan, Scan scanForMetrics, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) ClientScanner
(org.apache.hadoop.conf.Configuration conf, Scan scan, Scan scanForMetrics, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ClientScanner for the specified table Note that the passedScan
's start row maybe changed changed.ClientSimpleScanner
(org.apache.hadoop.conf.Configuration configuration, Scan scan, Scan scanForMetrics, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) protected
HTable
(ConnectionImplementation connection, TableBuilderBase builder, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, Map<String, byte[]> requestAttributes) Creates an object to access a HBase table.ResultBoundedCompletionService
(RpcRetryingCallerFactory retryingCallerFactory, Executor executor, int maxTasks) ReversedClientScanner
(org.apache.hadoop.conf.Configuration conf, Scan scan, Scan scanForMetrics, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ReversibleClientScanner for the specified table Note that the passedScan
's start row maybe changed. -
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate RpcRetryingCallerFactory
HRegionServer.rpcRetryingCallerFactory
-
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final RpcRetryingCallerFactory
RegionReplicaFlushHandler.rpcRetryingCallerFactory
ModifierConstructorDescriptionRegionReplicaFlushHandler
(Server server, ClusterConnection connection, RpcRetryingCallerFactory rpcRetryingCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, HRegion region) -
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescription(package private) RpcRetryingCallerFactory
RegionReplicaReplicationEndpoint.RetryingRpcCallable.factory
(package private) RpcRetryingCallerFactory
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.rpcRetryingCallerFactory
ModifierConstructorDescriptionRetryingRpcCallable
(RpcRetryingCallerFactory factory, RetryingCallable<V> callable, int timeout)