Package org.apache.hadoop.hbase.client
Interface AsyncClusterConnection
- All Superinterfaces:
AsyncConnection
,AutoCloseable
,Closeable
- All Known Implementing Classes:
AsyncClusterConnectionImpl
The asynchronous connection for internal usage.
-
Method Summary
Modifier and TypeMethodDescriptionbulkLoad
(TableName tableName, List<Pair<byte[], String>> familyPaths, byte[] row, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken, boolean copyFiles, List<String> clusterIds, boolean replicate) Securely bulk load a list of HFiles, passing additional list of clusters ids tracking clusters where the given bulk load has already been processed (important for bulk loading replication).cleanupBulkLoad
(TableName tableName, String bulkToken) Clean up after finishing bulk load, no matter success or not.CompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
flush
(byte[] regionName, boolean writeFlushWALMarker) Flush a region and get the response.getAllBootstrapNodes
(ServerName regionServer) Get the bootstrap node list of another region server.getLiveRegionServers
(MasterAddressTracker masterAddrTracker, int count) Get live region servers from masters.Get the nonce generator for this connection.getRegionLocations
(TableName tableName, byte[] row, boolean reload) Return all the replicas for a region.getRegionServerAdmin
(ServerName serverName) Get the admin service for the given region server.Get the rpc client we used to communicate with other servers.prepareBulkLoad
(TableName tableName) Return the token for this bulk load.replicate
(RegionInfo replica, List<WAL.Entry> entries, int numRetries, long rpcTimeoutNs, long operationTimeoutNs) Replicate wal edits to a secondary replica.Methods inherited from interface org.apache.hadoop.hbase.client.AsyncConnection
clearRegionLocationCache, getAdmin, getAdmin, getAdminBuilder, getAdminBuilder, getBufferedMutator, getBufferedMutator, getBufferedMutatorBuilder, getBufferedMutatorBuilder, getConfiguration, getHbck, getHbck, getRegionLocator, getTable, getTable, getTableBuilder, getTableBuilder, isClosed, toConnection
-
Method Details
-
getRegionServerAdmin
Get the admin service for the given region server. -
getNonceGenerator
Get the nonce generator for this connection. -
getRpcClient
Get the rpc client we used to communicate with other servers. -
flush
CompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse> flush(byte[] regionName, boolean writeFlushWALMarker) Flush a region and get the response. -
getRegionLocations
CompletableFuture<RegionLocations> getRegionLocations(TableName tableName, byte[] row, boolean reload) Return all the replicas for a region. Used for region replica replication. -
prepareBulkLoad
Return the token for this bulk load. -
bulkLoad
CompletableFuture<Boolean> bulkLoad(TableName tableName, List<Pair<byte[], String>> familyPaths, byte[] row, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken, boolean copyFiles, List<String> clusterIds, boolean replicate) Securely bulk load a list of HFiles, passing additional list of clusters ids tracking clusters where the given bulk load has already been processed (important for bulk loading replication). Defined as default here to avoid breaking callers who rely on the bulkLoad version that does not expect additional clusterIds param.- Parameters:
tableName
- the target tablefamilyPaths
- hdfs path for the the table family dirs containg files to be loaded.row
- row key.assignSeqNum
- seq num for the event on WAL.userToken
- user token.bulkToken
- bulk load token.copyFiles
- flag for copying the loaded hfiles.clusterIds
- list of cluster ids where the given bulk load has already been processed.replicate
- flags if the bulkload is targeted for replication.
-
cleanupBulkLoad
Clean up after finishing bulk load, no matter success or not. -
getLiveRegionServers
CompletableFuture<List<ServerName>> getLiveRegionServers(MasterAddressTracker masterAddrTracker, int count) Get live region servers from masters. -
getAllBootstrapNodes
Get the bootstrap node list of another region server. -
replicate
CompletableFuture<Void> replicate(RegionInfo replica, List<WAL.Entry> entries, int numRetries, long rpcTimeoutNs, long operationTimeoutNs) Replicate wal edits to a secondary replica.
-