Uses of Interface
org.apache.hadoop.hbase.client.ClusterConnection
Package
Description
Provides HBase Client
-
Uses of org.apache.hadoop.hbase.client.ClusterConnection in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ClusterConnection
Server.getClusterConnection()
Returns a reference to the servers' cluster connection. -
Uses of org.apache.hadoop.hbase.client.ClusterConnection in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.ConnectionImplementation
Main implementation ofConnection
andClusterConnection
interfaces.static final class
org.apache.hadoop.hbase.client.ServerConnectionUtils.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 TypeFieldDescriptionprotected final org.apache.hadoop.hbase.client.ClusterConnection
RpcRetryingCallerWithReadReplicas.cConnection
protected final org.apache.hadoop.hbase.client.ClusterConnection
RegionAdminServiceCallable.connection
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.ClusterConnection
ServerConnectionUtils.createShortCircuitConnection
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user, org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.client.ClusterConnection
ClientScanner.getConnection()
protected org.apache.hadoop.hbase.client.ClusterConnection
RegionServerCallable.getConnection()
ReturnsClusterConnection
instance used by this Callable.Modifier and TypeMethodDescriptionstatic <R> void
HTable.doBatchWithCallback
(List<? extends org.apache.hadoop.hbase.client.Row> actions, Object[] results, org.apache.hadoop.hbase.client.coprocessor.Batch.Callback<R> callback, org.apache.hadoop.hbase.client.ClusterConnection connection, ExecutorService pool, org.apache.hadoop.hbase.TableName tableName, Map<String, byte[]> requestAttributes) static org.apache.hadoop.hbase.RegionLocations
RegionAdminServiceCallable.getRegionLocations
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, int replicaId) static org.apache.hadoop.hbase.client.NonceGenerator
ConnectionUtils.injectNonceGeneratorForTesting
(org.apache.hadoop.hbase.client.ClusterConnection conn, org.apache.hadoop.hbase.client.NonceGenerator cnm) Inject a nonce generator for testing.ModifierConstructorDescriptionClientAsyncPrefetchScanner
(org.apache.hadoop.conf.Configuration configuration, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcCallerFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) ClientScanner
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, org.apache.hadoop.hbase.client.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, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName name, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcCallerFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) FlushRegionCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.client.RegionInfo regionInfo, boolean writeFlushWalMarker) FlushRegionCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, byte[] regionName, byte[] regionStartKey, boolean writeFlushWalMarker) RegionAdminServiceCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.HRegionLocation location, org.apache.hadoop.hbase.TableName tableName, byte[] row) RegionAdminServiceCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.HRegionLocation location, org.apache.hadoop.hbase.TableName tableName, byte[] row, int replicaId) RegionAdminServiceCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, byte[] row) ReversedClientScanner
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.Scan scanForMetrics, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int primaryOperationTimeout, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfiguration, Map<String, byte[]> requestAttributes) Create a new ReversibleClientScanner for the specified table Note that the passedScan
's start row maybe changed.ReversedScannerCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.metrics.ScanMetrics scanMetrics, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcFactory, int replicaId, Map<String, byte[]> requestAttributes) RpcRetryingCallerWithReadReplicas
(org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection cConnection, org.apache.hadoop.hbase.client.Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String, byte[]> requestAttributes) ScannerCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.client.metrics.ScanMetrics scanMetrics, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, int id, Map<String, byte[]> requestAttributes) -
Uses of org.apache.hadoop.hbase.client.ClusterConnection in org.apache.hadoop.hbase.client.trace
ModifierConstructorDescriptionTableOperationSpanBuilder
(org.apache.hadoop.hbase.client.ClusterConnection conn) TableSpanBuilder
(org.apache.hadoop.hbase.client.ClusterConnection conn) -
Uses of org.apache.hadoop.hbase.client.ClusterConnection in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionstatic void
ServerManager.closeRegionSilentlyAndWait
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ServerName server, org.apache.hadoop.hbase.client.RegionInfo region, long timeout) Contacts a region server and waits up to timeout ms to close the region. -
Uses of org.apache.hadoop.hbase.client.ClusterConnection in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.client.ClusterConnection
HRegionServer.clusterConnection
Cluster connection to be shared by services.Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.client.ClusterConnection
HRegionServer.createClusterConnection()
org.apache.hadoop.hbase.client.ClusterConnection
HRegionServer.getClusterConnection()
ModifierConstructorDescriptionBootstrapNodeManager
(org.apache.hadoop.hbase.client.ClusterConnection conn, org.apache.hadoop.hbase.zookeeper.MasterAddressTracker masterAddrTracker)