Uses of Interface
org.apache.hadoop.hbase.client.ClusterConnection

Packages that use org.apache.hadoop.hbase.client.ClusterConnection
  • Uses of org.apache.hadoop.hbase.client.ClusterConnection in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Method
    Description
    org.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

    Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.client.ConnectionImplementation
    Main implementation of Connection and ClusterConnection 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.
    Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.client.ClusterConnection
    RpcRetryingCallerWithReadReplicas.cConnection
     
    protected final org.apache.hadoop.hbase.client.ClusterConnection
    RegionAdminServiceCallable.connection
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Method
    Description
    static 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()
    Returns ClusterConnection instance used by this Callable.
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Method
    Description
    static <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.
    Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier
    Constructor
    Description
     
    ClientAsyncPrefetchScanner(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 passed Scan'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 passed Scan'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

    Constructors in org.apache.hadoop.hbase.client.trace with parameters of type org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier
    Constructor
    Description
     
    TableOperationSpanBuilder(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

    Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Method
    Description
    static 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

    Fields in org.apache.hadoop.hbase.regionserver declared as org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.client.ClusterConnection
    HRegionServer.clusterConnection
    Cluster connection to be shared by services.
    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.client.ClusterConnection
    HRegionServer.createClusterConnection()
     
    org.apache.hadoop.hbase.client.ClusterConnection
    HRegionServer.getClusterConnection()
     
    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.ClusterConnection in in
    Modifier
    Constructor
    Description
     
    BootstrapNodeManager(org.apache.hadoop.hbase.client.ClusterConnection conn, org.apache.hadoop.hbase.zookeeper.MasterAddressTracker masterAddrTracker)