Modifier and Type | Method and Description |
---|---|
ClusterConnection |
Server.getClusterConnection()
Returns a reference to the servers' cluster connection.
|
Constructor and Description |
---|
ZKTableArchiveClient(org.apache.hadoop.conf.Configuration conf,
ClusterConnection connection) |
Modifier and Type | Class and Description |
---|---|
static class |
ConnectionUtils.ShortCircuitingClusterConnection
A ClusterConnection that will short-circuit RPC making direct invocations against the localhost
if the invocation target is 'this' server; save on network and protobuf invocations.
|
Modifier and Type | Field and Description |
---|---|
protected ClusterConnection |
RpcRetryingCallerWithReadReplicas.cConnection |
protected ClusterConnection |
RegionAdminServiceCallable.connection |
Modifier and Type | Method and Description |
---|---|
static ClusterConnection |
ConnectionUtils.createShortCircuitConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
User user,
ServerName serverName,
AdminProtos.AdminService.BlockingInterface admin,
ClientProtos.ClientService.BlockingInterface client)
Creates a short-circuit connection that can bypass the RPC layer (serialization,
deserialization, networking, etc..) when talking to a local server.
|
protected ClusterConnection |
ClientScanner.getConnection() |
protected ClusterConnection |
RegionServerCallable.getConnection() |
Modifier and Type | Method and Description |
---|---|
static <R> void |
HTable.doBatchWithCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback,
ClusterConnection connection,
ExecutorService pool,
TableName tableName) |
static QuotaProtos.GetQuotaStatesResponse |
QuotaStatusCalls.getMasterQuotaStates(ClusterConnection clusterConn,
int timeout)
|
static QuotaProtos.GetSpaceQuotaRegionSizesResponse |
QuotaStatusCalls.getMasterRegionSizes(ClusterConnection clusterConn,
int timeout)
|
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
static QuotaProtos.GetSpaceQuotaSnapshotsResponse |
QuotaStatusCalls.getRegionServerQuotaSnapshot(ClusterConnection clusterConn,
int timeout,
ServerName sn)
|
static QuotaProtos.GetSpaceQuotaSnapshotsResponse |
QuotaStatusCalls.getRegionServerQuotaSnapshot(ClusterConnection conn,
RpcControllerFactory factory,
int timeout,
ServerName sn)
Executes an RPC to the RegionServer identified by the
ServerName to fetch its view
on space quotas. |
static NonceGenerator |
ConnectionUtils.injectNonceGeneratorForTesting(ClusterConnection conn,
NonceGenerator cnm) |
Constructor and Description |
---|
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) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
RegionInfo regionInfo,
boolean writeFlushWalMarker) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
HRegionLocator(TableName tableName,
ClusterConnection connection) |
HTable(ClusterConnection connection,
org.apache.hadoop.hbase.client.TableBuilderBase builder,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool)
Creates an object to access a HBase table.
|
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row,
int replicaId) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] row) |
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. |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcFactory) |
ReversedScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcFactory,
int replicaId) |
RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
TableName tableName,
ClusterConnection cConnection,
Get get,
ExecutorService pool,
int retries,
int operationTimeout,
int rpcTimeout,
int timeBeforeReplicas) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory) |
ScannerCallable(ClusterConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
RpcControllerFactory rpcControllerFactory,
int id) |
Modifier and Type | Method and Description |
---|---|
static void |
ServerManager.closeRegionSilentlyAndWait(ClusterConnection connection,
ServerName server,
RegionInfo region,
long timeout)
Contacts a region server and waits up to timeout ms
to close the region.
|
Modifier and Type | Field and Description |
---|---|
protected ClusterConnection |
HRegionServer.clusterConnection
Cluster connection to be shared by services.
|
Modifier and Type | Method and Description |
---|---|
protected ClusterConnection |
HRegionServer.createClusterConnection()
Create a 'smarter' Connection, one that is capable of by-passing RPC if the request is to
the local server; i.e.
|
ClusterConnection |
HRegionServer.getClusterConnection() |
Constructor and Description |
---|
RegionReplicaFlushHandler(Server server,
ClusterConnection connection,
RpcRetryingCallerFactory rpcRetryingCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
HRegion region) |
Constructor and Description |
---|
ReplicationSinkManager(ClusterConnection conn,
String peerClusterId,
HBaseReplicationEndpoint endpoint,
org.apache.hadoop.conf.Configuration conf)
Instantiate for a single replication peer cluster.
|
Modifier and Type | Method and Description |
---|---|
boolean |
MetaTableLocator.verifyMetaRegionLocation(ClusterConnection hConnection,
ZKWatcher zkw,
long timeout)
Verify
hbase:meta is deployed and accessible. |
boolean |
MetaTableLocator.verifyMetaRegionLocation(ClusterConnection connection,
ZKWatcher zkw,
long timeout,
int replicaId)
Verify
hbase:meta is deployed and accessible. |
Copyright © 2007–2019 Cloudera. All rights reserved.