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

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

    Fields in org.apache.hadoop.hbase declared as org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.client.AsyncClusterConnection
    HBaseServerBase.asyncClusterConnection
    The asynchronous cluster connection to be shared by services.
    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.AsyncClusterConnection
    HBaseServerBase.getAsyncClusterConnection()
     
    org.apache.hadoop.hbase.client.AsyncClusterConnection
    MockRegionServerServices.getAsyncClusterConnection()
     
    org.apache.hadoop.hbase.client.AsyncClusterConnection
    Server.getAsyncClusterConnection()
    Returns a reference to the servers' async cluster connection.
    org.apache.hadoop.hbase.client.AsyncClusterConnection
    HBaseTestingUtility.getAsyncConnection()
    Deprecated.
    Get a shared AsyncClusterConnection to the cluster.
    org.apache.hadoop.hbase.client.AsyncClusterConnection
    HBaseTestingUtility.getAsyncConnection(org.apache.hadoop.hbase.security.User user)
    Deprecated.
    Get a assigned AsyncClusterConnection to the cluster.
  • Uses of org.apache.hadoop.hbase.client.AsyncClusterConnection in org.apache.hadoop.hbase.client

    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.AsyncClusterConnection
    ClusterConnectionFactory.createAsyncClusterConnection(URI uri, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user)
    Create a new AsyncClusterConnection instance.
    static org.apache.hadoop.hbase.client.AsyncClusterConnection
    ClusterConnectionFactory.createAsyncClusterConnection(org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user)
    Create a new AsyncClusterConnection instance.
    static org.apache.hadoop.hbase.client.AsyncClusterConnection
    ClusterConnectionFactory.createAsyncClusterConnection(org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint endpoint, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user)
    Create a new AsyncClusterConnection instance to be used at server side where we have a ConnectionRegistryEndpoint.
  • Uses of org.apache.hadoop.hbase.client.AsyncClusterConnection in org.apache.hadoop.hbase.master

    Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier and Type
    Method
    Description
    static void
    ServerManager.closeRegionSilentlyAndWait(org.apache.hadoop.hbase.client.AsyncClusterConnection 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.AsyncClusterConnection in org.apache.hadoop.hbase.regionserver

    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier
    Constructor
    Description
     
    BootstrapNodeManager(org.apache.hadoop.hbase.client.AsyncClusterConnection conn, org.apache.hadoop.hbase.zookeeper.MasterAddressTracker masterAddrTracker)
     
  • Uses of org.apache.hadoop.hbase.client.AsyncClusterConnection in org.apache.hadoop.hbase.regionserver.regionreplication

    Constructors in org.apache.hadoop.hbase.regionserver.regionreplication with parameters of type org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier
    Constructor
    Description
     
    RegionReplicationSink(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.RegionInfo primary, org.apache.hadoop.hbase.client.TableDescriptor td, org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager manager, Runnable flushRequester, org.apache.hadoop.hbase.client.AsyncClusterConnection conn)
     
  • Uses of org.apache.hadoop.hbase.client.AsyncClusterConnection in org.apache.hadoop.hbase.replication

    Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.client.AsyncClusterConnection in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.client.AsyncClusterConnection
    HBaseReplicationEndpoint.createConnection(URI clusterURI, org.apache.hadoop.conf.Configuration conf)
    Some implementations of HBaseInterClusterReplicationEndpoint may require instantiate different Connection implementations, or initialize it in a different way, so defining createConnection as protected for possible overridings.