Uses of Interface
org.apache.hadoop.hbase.client.ClusterConnection
Package
Description
Provides HBase Client
-
Uses of ClusterConnection in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionServer.getClusterConnection()
Returns a reference to the servers' cluster connection. -
Uses of ClusterConnection in org.apache.hadoop.hbase.backup.example
ModifierConstructorDescriptionZKTableArchiveClient
(org.apache.hadoop.conf.Configuration conf, ClusterConnection connection) -
Uses of ClusterConnection in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
Main implementation ofConnection
andClusterConnection
interfaces.(package private) static class
Some tests shut down the master.static final class
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 TypeFieldDescriptionprotected final ClusterConnection
RpcRetryingCallerWithReadReplicas.cConnection
private final ClusterConnection
ScannerCallableWithReplicas.cConnection
private final ClusterConnection
HTableMultiplexer.conn
Deprecated.private final ClusterConnection
RegionCoprocessorRpcChannel.conn
(package private) final ClusterConnection
AsyncProcess.connection
private final ClusterConnection
ClientScanner.connection
private ClusterConnection
HBaseAdmin.connection
private final ClusterConnection
HTable.connection
protected final ClusterConnection
MasterCallable.connection
protected final ClusterConnection
RegionAdminServiceCallable.connection
Modifier and TypeMethodDescriptionstatic ClusterConnection
ServerConnectionUtils.createShortCircuitConnection
(org.apache.hadoop.conf.Configuration conf, 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, ConnectionRegistry registry) 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()
(package private) ClusterConnection
HTableMultiplexer.getConnection()
Deprecated.protected ClusterConnection
RegionServerCallable.getConnection()
ReturnsClusterConnection
instance used by this Callable.Modifier and TypeMethodDescriptionstatic <R> void
HTable.doBatchWithCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String, byte[]> requestAttributes) static RegionLocations
RegionAdminServiceCallable.getRegionLocations
(ClusterConnection connection, TableName tableName, byte[] row, boolean useCache, int replicaId) (package private) static RegionLocations
RpcRetryingCallerWithReadReplicas.getRegionLocations
(boolean useCache, int replicaId, ClusterConnection cConnection, TableName tableName, byte[] row) (package private) static NonceGenerator
ConnectionImplementation.injectNonceGeneratorForTesting
(ClusterConnection conn, NonceGenerator cnm) static NonceGenerator
ConnectionUtils.injectNonceGeneratorForTesting
(ClusterConnection conn, NonceGenerator cnm) Inject a nonce generator for testing.ModifierConstructorDescription(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, BufferedMutatorParams params, AsyncProcess ap) (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) 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) (package private)
HBaseAdmin
(ClusterConnection connection) (package private)
MultiServerCallable
(ClusterConnection connection, TableName tableName, ServerName location, MultiAction multi, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int rpcTimeout, RetryingTimeTracker tracker, int priority, Map<String, byte[]> requestAttributes) 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) (package private)
RegionCoprocessorRpcChannel
(ClusterConnection conn, TableName table, byte[] row, Map<String, byte[]> requestAttributes) ConstructorReversedClientScanner
(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.ReversedScannerCallable
(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcFactory, int replicaId, Map<String, byte[]> requestAttributes) RpcRetryingCallerWithReadReplicas
(RpcControllerFactory rpcControllerFactory, TableName tableName, ClusterConnection cConnection, Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String, byte[]> requestAttributes) ScannerCallable
(ClusterConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, RpcControllerFactory rpcControllerFactory, int id, Map<String, byte[]> requestAttributes) ScannerCallableWithReplicas
(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) -
Uses of ClusterConnection in org.apache.hadoop.hbase.client.trace
Modifier and TypeMethodDescription(package private) static void
ConnectionSpanBuilder.populateConnectionAttributes
(Map<io.opentelemetry.api.common.AttributeKey<?>, Object> attributes, ClusterConnection conn) ModifierConstructorDescription -
Uses of ClusterConnection in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionstatic 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. -
Uses of ClusterConnection in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprotected ClusterConnection
HRegionServer.clusterConnection
Cluster connection to be shared by services.private final ClusterConnection
BootstrapNodeManager.conn
Modifier and TypeMethodDescriptionprotected ClusterConnection
HRegionServer.createClusterConnection()
HRegionServer.getClusterConnection()
ModifierConstructorDescriptionBootstrapNodeManager
(ClusterConnection conn, MasterAddressTracker masterAddrTracker) -
Uses of ClusterConnection in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final ClusterConnection
RegionReplicaFlushHandler.connection
ModifierConstructorDescriptionRegionReplicaFlushHandler
(Server server, ClusterConnection connection, RpcRetryingCallerFactory rpcRetryingCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, HRegion region) -
Uses of ClusterConnection in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate ClusterConnection
HBaseInterClusterReplicationEndpoint.conn
private ClusterConnection
RegionReplicaReplicationEndpoint.connection
(package private) ClusterConnection
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.connection
Modifier and TypeMethodDescriptionReplicationSyncUp.DummyServer.getClusterConnection()
ReplicationSyncUp.DummyServer.getConnection()
ModifierConstructorDescriptionRegionReplicaOutputSink
(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. -
Uses of ClusterConnection in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprivate ClusterConnection
HBaseFsck.connection
Deprecated.private final ClusterConnection
HBaseFsck.WorkItemRegion.connection
ModifierConstructorDescription(package private)
WorkItemRegion
(HBaseFsck hbck, ServerName info, HbckErrorReporter errors, ClusterConnection connection)