Uses of Interface
org.apache.hadoop.hbase.client.AsyncAdmin
Package
Description
Provides HBase Client
-
Uses of AsyncAdmin in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
Just a wrapper ofRawAsyncHBaseAdmin
.(package private) class
The implementation of AsyncAdmin.Modifier and TypeMethodDescriptionAsyncAdminBuilder.build()
Create aAsyncAdmin
instance.default AsyncAdmin
AsyncConnection.getAdmin()
Retrieve anAsyncAdmin
implementation to administer an HBase cluster.default AsyncAdmin
AsyncConnection.getAdmin
(ExecutorService pool) Retrieve anAsyncAdmin
implementation to administer an HBase cluster.Modifier and TypeMethodDescriptionprivate CompletableFuture<Void>
RawAsyncHBaseAdmin.compareTableWithPeerCluster
(TableName tableName, TableDescriptor tableDesc, ReplicationPeerDescription peer, AsyncAdmin peerAdmin) static <S,
R> CompletableFuture<Map<ServerName, Object>> AsyncAdminClientUtils.coprocessorServiceOnAllRegionServers
(AsyncAdmin asyncAdmin, Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable) Execute the given coprocessor call on all region servers.ModifierConstructorDescription(package private)
ModifyTableProcedureBiConsumer
(AsyncAdmin admin, TableName tableName) (package private)
ModifyTableStoreFileTrackerProcedureBiConsumer
(AsyncAdmin admin, TableName tableName) -
Uses of AsyncAdmin in org.apache.hadoop.hbase.master.http
-
Uses of AsyncAdmin in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
-
Uses of AsyncAdmin in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionprivate void
BulkLoadHFilesTool.createTable
(TableName tableName, org.apache.hadoop.fs.Path hfofDir, AsyncAdmin admin) If the table is created for the first time, then "completebulkload" reads the files twice.