Uses of Interface
org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Uses of RpcRetryingCaller in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprotected RpcRetryingCaller<Result[]>
ClientScanner.caller
private final RpcRetryingCaller<Result[]>
ScannerCallableWithReplicas.caller
(package private) RpcRetryingCaller<Result[]>
ScannerCallableWithReplicas.RetryingRPC.caller
private final RpcRetryingCaller<T>
ResultBoundedCompletionService.QueueingFuture.retryingCaller
Modifier and TypeMethodDescriptionprotected RpcRetryingCaller<AbstractResponse>
AsyncProcess.createCaller
(CancellableRegionServerCallable callable, int rpcTimeout) Create a caller.<T> RpcRetryingCaller<T>
RpcRetryingCallerFactory.newCaller()
Create a new RetryingCaller with configured rpc timeout.<T> RpcRetryingCaller<T>
RpcRetryingCallerFactory.newCaller
(int rpcTimeout) Create a new RetryingCaller with specific rpc timeout.Modifier and TypeMethodDescriptionprivate Result[]
ClientScanner.call
(ScannerCallableWithReplicas callable, RpcRetryingCaller<Result[]> caller, int scannerTimeout, boolean updateCurrentRegion) ModifierConstructorDescriptionScannerCallableWithReplicas
(TableName tableName, ClusterConnection cConnection, ScannerCallable baseCallable, ExecutorService pool, int timeBeforeReplicas, Scan scan, int retries, int readRpcTimeout, int scannerTimeout, boolean useScannerTimeoutForNextCalls, int caching, org.apache.hadoop.conf.Configuration conf, RpcRetryingCaller<Result[]> caller)