Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
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 |
ConnectionManager.HConnectionImplementation.rpcCallerFactory |
protected RpcRetryingCallerFactory |
AsyncProcess.rpcCallerFactory |
private RpcRetryingCallerFactory |
HBaseAdmin.rpcCallerFactory |
private RpcRetryingCallerFactory |
RpcRetryingCallerWithReadReplicas.rpcRetryingCallerFactory |
Modifier and Type | Method and Description |
---|---|
RpcRetryingCallerFactory |
ConnectionManager.HConnectionImplementation.getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf) |
RpcRetryingCallerFactory |
ConnectionAdapter.getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
RpcRetryingCallerFactory |
ClusterConnection.getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
Returns a new RpcRetryingCallerFactory from the given
Configuration . |
RpcRetryingCallerFactory |
ConnectionManager.HConnectionImplementation.getRpcRetryingCallerFactory() |
RpcRetryingCallerFactory |
ConnectionAdapter.getRpcRetryingCallerFactory()
Deprecated.
|
RpcRetryingCallerFactory |
ClusterConnection.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 <V> V |
HBaseAdmin.executeCallable(MasterCallable<V> callable,
RpcRetryingCallerFactory rpcCallerFactory,
int operationTimeout,
int rpcTimeout) |
(package private) static HTableDescriptor |
HBaseAdmin.getTableDescriptor(TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
int rpcTimeout) |
Constructor and Description |
---|
AsyncProcess(ClusterConnection hc,
org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
RpcRetryingCallerFactory rpcCaller,
boolean useGlobalErrors,
RpcControllerFactory rpcFactory) |
BufferedMutatorImpl(ClusterConnection conn,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcFactory,
BufferedMutatorParams params) |
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. |
ClientSmallReversedScanner(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.
|
ClientSmallReversedScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
ClientSmallReversedScanner.SmallReversedScannerCallableFactory callableFactory)
Create a new ReversibleClientScanner for the specified table.
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ShortClientScanner for the specified table.
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout,
ClientSmallScanner.SmallScannerCallableFactory callableFactory)
Create a new ShortClientScanner for the specified table.
|
HTable(TableName tableName,
ClusterConnection connection,
ConnectionConfiguration tableConfig,
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 |
RegionCoprocessorRpcChannel.rpcCallerFactory |
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 |
---|
RegionReplicaReplicationEndpoint.RetryingRpcCallable(RpcRetryingCallerFactory factory,
RetryingCallable<V> callable,
int timeout) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.