Uses of Interface
org.apache.hadoop.hbase.client.AsyncClusterConnection
Packages that use AsyncClusterConnection
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of AsyncClusterConnection in org.apache.hadoop.hbase
Fields in org.apache.hadoop.hbase declared as AsyncClusterConnectionModifier and TypeFieldDescriptionprotected AsyncClusterConnectionHBaseServerBase.asyncClusterConnectionThe asynchronous cluster connection to be shared by services.Fields in org.apache.hadoop.hbase with type parameters of type AsyncClusterConnectionModifier and TypeFieldDescriptionprivate final AtomicReference<AsyncClusterConnection>HBaseTestingUtility.asyncConnectionDeprecated.Methods in org.apache.hadoop.hbase that return AsyncClusterConnectionModifier 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
Classes in org.apache.hadoop.hbase.client that implement AsyncClusterConnectionModifier and TypeClassDescription(package private) classThe implementation of AsyncClusterConnection.Methods in org.apache.hadoop.hbase.client that return AsyncClusterConnectionModifier and TypeMethodDescriptionstatic AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(URI uri, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, User user) Create a newAsyncClusterConnectioninstance.static AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, User user) Create a newAsyncClusterConnectioninstance.private static AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(org.apache.hadoop.conf.Configuration conf, ConnectionRegistry registry, SocketAddress localAddress, User user) static AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(ConnectionRegistryEndpoint endpoint, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, User user) Create a newAsyncClusterConnectioninstance to be used at server side where we have aConnectionRegistryEndpoint. -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as AsyncClusterConnectionModifier and TypeFieldDescriptionprivate AsyncClusterConnectionRegionPlacementMaintainer.connectionMethods in org.apache.hadoop.hbase.master that return AsyncClusterConnectionModifier and TypeMethodDescriptionprivate AsyncClusterConnectionRegionPlacementMaintainer.getConnection()Methods in org.apache.hadoop.hbase.master with parameters of type AsyncClusterConnectionModifier and TypeMethodDescriptionstatic voidServerManager.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
Fields in org.apache.hadoop.hbase.regionserver declared as AsyncClusterConnectionConstructors in org.apache.hadoop.hbase.regionserver with parameters of type AsyncClusterConnectionModifierConstructorDescriptionBootstrapNodeManager(AsyncClusterConnection conn, MasterAddressTracker masterAddrTracker) -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as AsyncClusterConnectionModifier and TypeFieldDescriptionprivate final AsyncClusterConnectionRegionReplicaFlushHandler.connection -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.regionserver.regionreplication
Fields in org.apache.hadoop.hbase.regionserver.regionreplication declared as AsyncClusterConnectionConstructors in org.apache.hadoop.hbase.regionserver.regionreplication with parameters of type AsyncClusterConnectionModifierConstructorDescriptionRegionReplicationSink(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
Fields in org.apache.hadoop.hbase.replication declared as AsyncClusterConnectionMethods in org.apache.hadoop.hbase.replication that return AsyncClusterConnectionModifier and TypeMethodDescriptionprivate AsyncClusterConnectionHBaseReplicationEndpoint.connect()protected AsyncClusterConnectionHBaseReplicationEndpoint.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
Fields in org.apache.hadoop.hbase.replication.regionserver declared as AsyncClusterConnectionModifier and TypeFieldDescriptionprivate AsyncClusterConnectionHFileReplicator.connectionprivate AsyncClusterConnectionReplicationSink.sharedConnMethods in org.apache.hadoop.hbase.replication.regionserver that return AsyncClusterConnectionModifier and TypeMethodDescriptionReplicationSyncUp.DummyServer.getAsyncClusterConnection()private AsyncClusterConnectionReplicationSink.getConnection()Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type AsyncClusterConnectionModifierConstructorDescriptionHFileReplicator(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
Fields in org.apache.hadoop.hbase.rsgroup declared as AsyncClusterConnectionModifier and TypeFieldDescriptionprivate final AsyncClusterConnectionRSGroupInfoManagerImpl.conn -
Uses of AsyncClusterConnection in org.apache.hadoop.hbase.tool
Methods in org.apache.hadoop.hbase.tool with parameters of type AsyncClusterConnectionModifier and TypeMethodDescriptionprotected voidBulkLoadHFilesTool.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 voidBulkLoadHFilesTool.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) voidBulkLoadHFilesTool.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 voidBulkLoadHFilesTool.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 ofLoadQueueItemfrom 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 voidBulkLoadHFilesTool.prepareHFileQueue(AsyncClusterConnection conn, TableName tableName, Map<byte[], List<org.apache.hadoop.fs.Path>> map, Deque<BulkLoadHFiles.LoadQueueItem> queue, boolean silence) Prepare a collection ofLoadQueueItemfrom 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 voidBulkLoadHFilesTool.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.