Uses of Interface
org.apache.hadoop.hbase.client.AsyncClusterConnection
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of AsyncClusterConnection in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprotected AsyncClusterConnection
HBaseServerBase.asyncClusterConnection
The asynchronous cluster connection to be shared by services.Modifier and TypeFieldDescriptionprivate final AtomicReference<AsyncClusterConnection>
HBaseTestingUtility.asyncConnection
Deprecated.Modifier and TypeMethodDescriptionHBaseServerBase.getAsyncClusterConnection()
MockRegionServerServices.getAsyncClusterConnection()
Server.getAsyncClusterConnection()
Returns a reference to the servers' async cluster connection.HBaseTestingUtility.getAsyncConnection()
Deprecated.Get a shared AsyncClusterConnection to the cluster.HBaseTestingUtility.getAsyncConnection
(User user) Deprecated.Get a assigned AsyncClusterConnection to the cluster. -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
The implementation of AsyncClusterConnection.Modifier and TypeMethodDescriptionstatic AsyncClusterConnection
ClusterConnectionFactory.createAsyncClusterConnection
(URI uri, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, User user) Create a newAsyncClusterConnection
instance.static AsyncClusterConnection
ClusterConnectionFactory.createAsyncClusterConnection
(org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, User user) Create a newAsyncClusterConnection
instance.private static AsyncClusterConnection
ClusterConnectionFactory.createAsyncClusterConnection
(org.apache.hadoop.conf.Configuration conf, ConnectionRegistry registry, SocketAddress localAddress, User user) static AsyncClusterConnection
ClusterConnectionFactory.createAsyncClusterConnection
(ConnectionRegistryEndpoint endpoint, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, User user) Create a newAsyncClusterConnection
instance to be used at server side where we have aConnectionRegistryEndpoint
. -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionprivate AsyncClusterConnection
RegionPlacementMaintainer.connection
Modifier and TypeMethodDescriptionprivate AsyncClusterConnection
RegionPlacementMaintainer.getConnection()
Modifier and TypeMethodDescriptionstatic void
ServerManager.closeRegionSilentlyAndWait
(AsyncClusterConnection connection, ServerName server, RegionInfo region, long timeout) Contacts a region server and waits up to timeout ms to close the region. -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.regionserver
ModifierConstructorDescriptionBootstrapNodeManager
(AsyncClusterConnection conn, MasterAddressTracker masterAddrTracker) -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final AsyncClusterConnection
RegionReplicaFlushHandler.connection
-
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.regionserver.regionreplication
ModifierConstructorDescriptionRegionReplicationSink
(org.apache.hadoop.conf.Configuration conf, RegionInfo primary, TableDescriptor td, RegionReplicationBufferManager manager, Runnable flushRequester, AsyncClusterConnection conn) -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionprivate AsyncClusterConnection
HBaseReplicationEndpoint.connect()
protected 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. -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate AsyncClusterConnection
HFileReplicator.connection
private AsyncClusterConnection
ReplicationSink.sharedConn
Modifier and TypeMethodDescriptionReplicationSyncUp.DummyServer.getAsyncClusterConnection()
private AsyncClusterConnection
ReplicationSink.getConnection()
ModifierConstructorDescriptionHFileReplicator
(org.apache.hadoop.conf.Configuration sourceClusterConf, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath, Map<String, List<Pair<byte[], List<String>>>> tableQueueMap, org.apache.hadoop.conf.Configuration conf, AsyncClusterConnection connection, List<String> sourceClusterIds) -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.rsgroup
Modifier and TypeFieldDescriptionprivate final AsyncClusterConnection
RSGroupInfoManagerImpl.conn
-
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionprotected void
BulkLoadHFilesTool.bulkLoadPhase
(AsyncClusterConnection conn, TableName tableName, Deque<BulkLoadHFiles.LoadQueueItem> queue, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer, BulkLoadHFiles.LoadQueueItem> regionGroups, boolean copyFiles, Map<BulkLoadHFiles.LoadQueueItem, ByteBuffer> item2RegionMap) This takes the LQI's grouped by likely regions and attempts to bulk load them.private void
BulkLoadHFilesTool.cleanup
(AsyncClusterConnection conn, TableName tableName, Deque<BulkLoadHFiles.LoadQueueItem> queue, ExecutorService pool) private Map<BulkLoadHFiles.LoadQueueItem,
ByteBuffer> BulkLoadHFilesTool.doBulkLoad
(AsyncClusterConnection conn, TableName tableName, Map<byte[], List<org.apache.hadoop.fs.Path>> map, boolean silence, boolean copyFile) Perform a bulk load of the given map of families to hfiles into the given pre-existing table.private Map<BulkLoadHFiles.LoadQueueItem,
ByteBuffer> BulkLoadHFilesTool.doBulkLoad
(AsyncClusterConnection conn, TableName tableName, org.apache.hadoop.fs.Path hfofDir, boolean silence, boolean copyFile) Perform a bulk load of the given directory into the given pre-existing table.protected Pair<List<BulkLoadHFiles.LoadQueueItem>,
String> BulkLoadHFilesTool.groupOrSplit
(AsyncClusterConnection conn, TableName tableName, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer, BulkLoadHFiles.LoadQueueItem> regionGroups, BulkLoadHFiles.LoadQueueItem item, List<Pair<byte[], byte[]>> startEndKeys) Attempt to assign the given load queue item into its target region group.private Pair<org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,
BulkLoadHFiles.LoadQueueItem>, Set<String>> BulkLoadHFilesTool.groupOrSplitPhase
(AsyncClusterConnection conn, TableName tableName, ExecutorService pool, Deque<BulkLoadHFiles.LoadQueueItem> queue, List<Pair<byte[], byte[]>> startEndKeys) void
BulkLoadHFilesTool.loadHFileQueue
(AsyncClusterConnection conn, TableName tableName, Deque<BulkLoadHFiles.LoadQueueItem> queue, boolean copyFiles) Used by the replication sink to load the hfiles from the source cluster.private Map<BulkLoadHFiles.LoadQueueItem,
ByteBuffer> BulkLoadHFilesTool.performBulkLoad
(AsyncClusterConnection conn, TableName tableName, Deque<BulkLoadHFiles.LoadQueueItem> queue, ExecutorService pool, boolean copyFile) static void
BulkLoadHFilesTool.prepareHFileQueue
(org.apache.hadoop.conf.Configuration conf, AsyncClusterConnection conn, TableName tableName, org.apache.hadoop.fs.Path hfilesDir, Deque<BulkLoadHFiles.LoadQueueItem> queue, boolean validateHFile, boolean silence) Prepare a collection ofLoadQueueItem
from list of source hfiles contained in the passed directory and validates whether the prepared queue has all the valid table column families in it.static void
BulkLoadHFilesTool.prepareHFileQueue
(AsyncClusterConnection conn, TableName tableName, Map<byte[], List<org.apache.hadoop.fs.Path>> map, Deque<BulkLoadHFiles.LoadQueueItem> queue, boolean silence) Prepare a collection ofLoadQueueItem
from list of source hfiles contained in the passed directory and validates whether the prepared queue has all the valid table column families in it.private void
BulkLoadHFilesTool.tableExists
(AsyncClusterConnection conn, TableName tableName) protected CompletableFuture<Collection<BulkLoadHFiles.LoadQueueItem>>
BulkLoadHFilesTool.tryAtomicRegionLoad
(AsyncClusterConnection conn, TableName tableName, boolean copyFiles, byte[] first, Collection<BulkLoadHFiles.LoadQueueItem> lqis) Attempts to do an atomic load of many hfiles into a region.