Uses of Interface
org.apache.hadoop.hbase.client.ClusterConnection
Packages that use ClusterConnection
Package
Description
Provides HBase Client
-
Uses of ClusterConnection in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return ClusterConnectionModifier and TypeMethodDescriptionServer.getClusterConnection()Returns a reference to the servers' cluster connection. -
Uses of ClusterConnection in org.apache.hadoop.hbase.backup.example
Fields in org.apache.hadoop.hbase.backup.example declared as ClusterConnectionConstructors in org.apache.hadoop.hbase.backup.example with parameters of type ClusterConnectionModifierConstructorDescriptionZKTableArchiveClient(org.apache.hadoop.conf.Configuration conf, ClusterConnection connection) -
Uses of ClusterConnection in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement ClusterConnectionModifier and TypeClassDescriptionclassMain implementation ofConnectionandClusterConnectioninterfaces.(package private) static classSome tests shut down the master.static final classA 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.Fields in org.apache.hadoop.hbase.client declared as ClusterConnectionModifier and TypeFieldDescriptionprotected final ClusterConnectionRpcRetryingCallerWithReadReplicas.cConnectionprivate final ClusterConnectionScannerCallableWithReplicas.cConnectionprivate final ClusterConnectionHTableMultiplexer.connDeprecated.private final ClusterConnectionRegionCoprocessorRpcChannel.conn(package private) final ClusterConnectionAsyncProcess.connectionprivate final ClusterConnectionClientScanner.connectionprivate ClusterConnectionHBaseAdmin.connectionprivate final ClusterConnectionHTable.connectionprotected final ClusterConnectionMasterCallable.connectionprotected final ClusterConnectionRegionAdminServiceCallable.connectionMethods in org.apache.hadoop.hbase.client that return ClusterConnectionModifier and TypeMethodDescriptionstatic ClusterConnectionServerConnectionUtils.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 ClusterConnectionClientScanner.getConnection()(package private) ClusterConnectionHTableMultiplexer.getConnection()Deprecated.protected ClusterConnectionRegionServerCallable.getConnection()ReturnsClusterConnectioninstance used by this Callable.Methods in org.apache.hadoop.hbase.client with parameters of type ClusterConnectionModifier and TypeMethodDescriptionstatic <R> voidHTable.doBatchWithCallback(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String, byte[]> requestAttributes) static RegionLocationsRegionAdminServiceCallable.getRegionLocations(ClusterConnection connection, TableName tableName, byte[] row, boolean useCache, int replicaId) (package private) static RegionLocationsRpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache, int replicaId, ClusterConnection cConnection, TableName tableName, byte[] row) (package private) static NonceGeneratorConnectionImplementation.injectNonceGeneratorForTesting(ClusterConnection conn, NonceGenerator cnm) static NonceGeneratorConnectionUtils.injectNonceGeneratorForTesting(ClusterConnection conn, NonceGenerator cnm) Inject a nonce generator for testing.Constructors in org.apache.hadoop.hbase.client with parameters of type ClusterConnectionModifierConstructorDescription(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
Methods in org.apache.hadoop.hbase.client.trace with parameters of type ClusterConnectionModifier and TypeMethodDescription(package private) static voidConnectionSpanBuilder.populateConnectionAttributes(Map<io.opentelemetry.api.common.AttributeKey<?>, Object> attributes, ClusterConnection conn) Constructors in org.apache.hadoop.hbase.client.trace with parameters of type ClusterConnectionModifierConstructorDescription -
Uses of ClusterConnection in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as ClusterConnectionMethods in org.apache.hadoop.hbase.master with parameters of type ClusterConnectionModifier and TypeMethodDescriptionstatic voidServerManager.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
Fields in org.apache.hadoop.hbase.regionserver declared as ClusterConnectionModifier and TypeFieldDescriptionprotected ClusterConnectionHRegionServer.clusterConnectionCluster connection to be shared by services.private final ClusterConnectionBootstrapNodeManager.connMethods in org.apache.hadoop.hbase.regionserver that return ClusterConnectionModifier and TypeMethodDescriptionprotected ClusterConnectionHRegionServer.createClusterConnection()HRegionServer.getClusterConnection()Constructors in org.apache.hadoop.hbase.regionserver with parameters of type ClusterConnectionModifierConstructorDescriptionBootstrapNodeManager(ClusterConnection conn, MasterAddressTracker masterAddrTracker) -
Uses of ClusterConnection in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as ClusterConnectionModifier and TypeFieldDescriptionprivate final ClusterConnectionRegionReplicaFlushHandler.connectionConstructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type ClusterConnectionModifierConstructorDescriptionRegionReplicaFlushHandler(Server server, ClusterConnection connection, RpcRetryingCallerFactory rpcRetryingCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, HRegion region) -
Uses of ClusterConnection in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as ClusterConnectionModifier and TypeFieldDescriptionprivate ClusterConnectionHBaseInterClusterReplicationEndpoint.connprivate ClusterConnectionRegionReplicaReplicationEndpoint.connection(package private) ClusterConnectionRegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.connectionMethods in org.apache.hadoop.hbase.replication.regionserver that return ClusterConnectionModifier and TypeMethodDescriptionReplicationSyncUp.DummyServer.getClusterConnection()ReplicationSyncUp.DummyServer.getConnection()Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type ClusterConnectionModifierConstructorDescriptionRegionReplicaOutputSink(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
Fields in org.apache.hadoop.hbase.util declared as ClusterConnectionModifier and TypeFieldDescriptionprivate ClusterConnectionHBaseFsck.connectionDeprecated.private final ClusterConnectionHBaseFsck.WorkItemRegion.connectionConstructors in org.apache.hadoop.hbase.util with parameters of type ClusterConnectionModifierConstructorDescription(package private)WorkItemRegion(HBaseFsck hbck, ServerName info, HbckErrorReporter errors, ClusterConnection connection)