| Modifier and Type | Method and Description | 
|---|---|
ClusterConnection | 
Server.getClusterConnection()
Returns a reference to the servers' cluster connection. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
private ClusterConnection | 
ZKTableArchiveClient.connection  | 
| Constructor and Description | 
|---|
ZKTableArchiveClient(org.apache.hadoop.conf.Configuration conf,
                    ClusterConnection connection)  | 
| Modifier and Type | Class and Description | 
|---|---|
(package private) class  | 
ConnectionImplementation
Main implementation of  
Connection and ClusterConnection interfaces. | 
(package private) static class  | 
ConnectionUtils.MasterlessConnection
Some tests shut down the master. 
 | 
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  | 
(package private) ClusterConnection | 
ScannerCallableWithReplicas.cConnection  | 
private ClusterConnection | 
HTableMultiplexer.conn
Deprecated.  
  | 
private ClusterConnection | 
RegionCoprocessorRpcChannel.conn  | 
private ClusterConnection | 
HBaseAdmin.connection  | 
private ClusterConnection | 
ClientScanner.connection  | 
protected ClusterConnection | 
MasterCallable.connection  | 
(package private) ClusterConnection | 
AsyncProcess.connection  | 
protected ClusterConnection | 
RegionAdminServiceCallable.connection  | 
private ClusterConnection | 
HTable.connection  | 
| Modifier and Type | Method and Description | 
|---|---|
static ClusterConnection | 
ConnectionUtils.createShortCircuitConnection(org.apache.hadoop.conf.Configuration conf,
                            ExecutorService pool,
                            User user,
                            ServerName serverName,
                            org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
                            org.apache.hadoop.hbase.shaded.protobuf.generated.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 | 
RegionServerCallable.getConnection()  | 
(package private) ClusterConnection | 
HTableMultiplexer.getConnection()
Deprecated.  
  | 
protected ClusterConnection | 
ClientScanner.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)  | 
(package private) static RegionLocations | 
RpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache,
                  int replicaId,
                  ClusterConnection cConnection,
                  TableName tableName,
                  byte[] row)  | 
static RegionLocations | 
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
                  TableName tableName,
                  byte[] row,
                  boolean useCache,
                  int replicaId)  | 
(package private) static NonceGenerator | 
ConnectionImplementation.injectNonceGeneratorForTesting(ClusterConnection conn,
                              NonceGenerator cnm)  | 
static NonceGenerator | 
ConnectionUtils.injectNonceGeneratorForTesting(ClusterConnection conn,
                              NonceGenerator cnm)  | 
| Constructor and Description | 
|---|
AsyncProcess(ClusterConnection hc,
            org.apache.hadoop.conf.Configuration conf,
            RpcRetryingCallerFactory rpcCaller,
            RpcControllerFactory rpcFactory)  | 
BufferedMutatorImpl(ClusterConnection conn,
                   BufferedMutatorParams params,
                   AsyncProcess ap)  | 
BufferedMutatorImpl(ClusterConnection conn,
                   RpcRetryingCallerFactory rpcCallerFactory,
                   RpcControllerFactory rpcFactory,
                   BufferedMutatorParams params)  | 
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)  | 
FlushWorker(org.apache.hadoop.conf.Configuration conf,
           ClusterConnection conn,
           HRegionLocation addr,
           HTableMultiplexer htableMultiplexer,
           int perRegionServerBufferQueueSize,
           ExecutorService pool,
           ScheduledExecutorService executor)  | 
HBaseAdmin(ClusterConnection connection)  | 
MultiServerCallable(ClusterConnection connection,
                   TableName tableName,
                   ServerName location,
                   MultiAction multi,
                   org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
                   int rpcTimeout,
                   RetryingTimeTracker tracker,
                   int priority)  | 
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)  | 
RegionCoprocessorRpcChannel(ClusterConnection conn,
                           TableName table,
                           byte[] row)
Constructor 
 | 
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)  | 
ScannerCallableWithReplicas(TableName tableName,
                           ClusterConnection cConnection,
                           ScannerCallable baseCallable,
                           ExecutorService pool,
                           int timeBeforeReplicas,
                           Scan scan,
                           int retries,
                           int scannerTimeout,
                           int caching,
                           org.apache.hadoop.conf.Configuration conf,
                           RpcRetryingCaller<Result[]> caller)  | 
| Modifier and Type | Field and Description | 
|---|---|
private ClusterConnection | 
ServerManager.connection  | 
| 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()  | 
ClusterConnection | 
HRegionServer.getClusterConnection()  | 
| Modifier and Type | Field and Description | 
|---|---|
private ClusterConnection | 
RegionReplicaFlushHandler.connection  | 
| Constructor and Description | 
|---|
RegionReplicaFlushHandler(Server server,
                         ClusterConnection connection,
                         RpcRetryingCallerFactory rpcRetryingCallerFactory,
                         RpcControllerFactory rpcControllerFactory,
                         int operationTimeout,
                         HRegion region)  | 
| Modifier and Type | Field and Description | 
|---|---|
private ClusterConnection | 
HBaseInterClusterReplicationEndpoint.conn  | 
private ClusterConnection | 
RegionReplicaReplicationEndpoint.connection  | 
(package private) ClusterConnection | 
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.connection  | 
| Modifier and Type | Method and Description | 
|---|---|
ClusterConnection | 
ReplicationSyncUp.DummyServer.getClusterConnection()  | 
ClusterConnection | 
ReplicationSyncUp.DummyServer.getConnection()  | 
| Constructor and Description | 
|---|
RegionReplicaOutputSink(WALSplitter.PipelineController controller,
                       TableDescriptors tableDescriptors,
                       EntryBuffers entryBuffers,
                       ClusterConnection connection,
                       ExecutorService pool,
                       int numWriters,
                       int operationTimeout)  | 
RegionReplicaReplayCallable(ClusterConnection connection,
                           RpcControllerFactory rpcControllerFactory,
                           TableName tableName,
                           HRegionLocation location,
                           RegionInfo regionInfo,
                           byte[] row,
                           List<WAL.Entry> entries,
                           AtomicLong skippedEntries)  | 
RegionReplicaSinkWriter(RegionReplicaReplicationEndpoint.RegionReplicaOutputSink sink,
                       ClusterConnection connection,
                       ExecutorService pool,
                       int operationTimeout,
                       TableDescriptors tableDescriptors)  | 
ReplicationSinkManager(ClusterConnection conn,
                      String peerClusterId,
                      HBaseReplicationEndpoint endpoint,
                      org.apache.hadoop.conf.Configuration conf)
Instantiate for a single replication peer cluster. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
private ClusterConnection | 
HBaseFsck.connection
Deprecated.  
  | 
private ClusterConnection | 
HBaseFsck.WorkItemRegion.connection  | 
| Constructor and Description | 
|---|
WorkItemRegion(HBaseFsck hbck,
              ServerName info,
              HbckErrorReporter errors,
              ClusterConnection connection)  | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.