Uses of Class
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Packages that use RpcRetryingCallerFactory
Package
Description
Provides HBase Client
-
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as RpcRetryingCallerFactoryModifier and TypeFieldDescriptionprivate final RpcRetryingCallerFactoryResultBoundedCompletionService.retryingCallerFactoryprivate final RpcRetryingCallerFactoryAsyncProcess.rpcCallerFactoryprivate final RpcRetryingCallerFactoryConnectionImplementation.rpcCallerFactoryprivate RpcRetryingCallerFactoryHBaseAdmin.rpcCallerFactoryprivate final RpcRetryingCallerFactoryHTable.rpcCallerFactoryprivate final RpcRetryingCallerFactoryRegionCoprocessorRpcChannel.rpcCallerFactoryprivate final RpcRetryingCallerFactoryRpcRetryingCallerWithReadReplicas.rpcRetryingCallerFactoryMethods in org.apache.hadoop.hbase.client that return RpcRetryingCallerFactoryModifier 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 RpcRetryingCallerFactoryRpcRetryingCallerFactory.instantiate(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, MetricsConnection metrics) static RpcRetryingCallerFactoryRpcRetryingCallerFactory.instantiate(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, RetryingCallerInterceptor interceptor, ServerStatisticTracker stats, MetricsConnection metrics) static RpcRetryingCallerFactoryRpcRetryingCallerFactory.instantiate(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, ServerStatisticTracker stats, MetricsConnection metrics) static RpcRetryingCallerFactoryRpcRetryingCallerFactory.instantiate(org.apache.hadoop.conf.Configuration configuration, MetricsConnection metrics) Methods in org.apache.hadoop.hbase.client with parameters of type RpcRetryingCallerFactoryModifier and TypeMethodDescriptionprivate static <C extends RetryingCallable<V> & Closeable,V>
VHBaseAdmin.executeCallable(C callable, RpcRetryingCallerFactory rpcCallerFactory, int operationTimeout, int rpcTimeout) (package private) static HTableDescriptorHBaseAdmin.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 TableDescriptorHBaseAdmin.getTableDescriptor(TableName tableName, Connection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, int rpcTimeout) Constructors in org.apache.hadoop.hbase.client with parameters of type RpcRetryingCallerFactoryModifierConstructorDescription(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) protectedHTable(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
Fields in org.apache.hadoop.hbase.regionserver declared as RpcRetryingCallerFactoryModifier and TypeFieldDescriptionprivate RpcRetryingCallerFactoryHRegionServer.rpcRetryingCallerFactory -
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as RpcRetryingCallerFactoryModifier and TypeFieldDescriptionprivate final RpcRetryingCallerFactoryRegionReplicaFlushHandler.rpcRetryingCallerFactoryConstructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type RpcRetryingCallerFactoryModifierConstructorDescriptionRegionReplicaFlushHandler(Server server, ClusterConnection connection, RpcRetryingCallerFactory rpcRetryingCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, HRegion region) -
Uses of RpcRetryingCallerFactory in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as RpcRetryingCallerFactoryModifier and TypeFieldDescription(package private) RpcRetryingCallerFactoryRegionReplicaReplicationEndpoint.RetryingRpcCallable.factory(package private) RpcRetryingCallerFactoryRegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.rpcRetryingCallerFactoryConstructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type RpcRetryingCallerFactoryModifierConstructorDescriptionRetryingRpcCallable(RpcRetryingCallerFactory factory, RetryingCallable<V> callable, int timeout)