Uses of Interface
org.apache.hadoop.hbase.client.AsyncTable
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of AsyncTable in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprivate AsyncTable<?>
PerformanceEvaluation.AsyncScanTest.asyncTable
protected AsyncTable<?>
PerformanceEvaluation.AsyncTableTest.table
Modifier and TypeMethodDescriptionprivate static Scan
ClientMetaTableAccessor.getMetaScan
(AsyncTable<?> metaTable, int rowUpperLimit) static CompletableFuture<Optional<HRegionLocation>>
ClientMetaTableAccessor.getRegionLocation
(AsyncTable<?> metaTable, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic CompletableFuture<Optional<HRegionLocation>>
ClientMetaTableAccessor.getRegionLocationWithEncodedName
(AsyncTable<?> metaTable, byte[] encodedRegionName) Returns the HRegionLocation from meta for the given encoded region namestatic CompletableFuture<List<HRegionLocation>>
ClientMetaTableAccessor.getTableHRegionLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName) Used to get all region locations for the specific tableprivate static CompletableFuture<List<Pair<RegionInfo,
ServerName>>> ClientMetaTableAccessor.getTableRegionsAndLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, boolean excludeOfflinedSplitParents) Used to get table regions' info and server.static CompletableFuture<Optional<TableState>>
ClientMetaTableAccessor.getTableState
(AsyncTable<?> metaTable, TableName tableName) private static CompletableFuture<Void>
ClientMetaTableAccessor.scanMeta
(AsyncTable<AdvancedScanResultConsumer> metaTable, byte[] startRow, byte[] stopRow, ClientMetaTableAccessor.QueryType type, int maxRows, ClientMetaTableAccessor.Visitor visitor) Performs a scan of META table for given table.private static CompletableFuture<Void>
ClientMetaTableAccessor.scanMeta
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, ClientMetaTableAccessor.QueryType type, ClientMetaTableAccessor.Visitor visitor) Performs a scan of META table for given table.static CompletableFuture<Boolean>
ClientMetaTableAccessor.tableExists
(AsyncTable<?> metaTable, TableName tableName) -
Uses of AsyncTable in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
Just a wrapper ofRawAsyncTableImpl
.(package private) class
The implementation of RawAsyncTable.Modifier and TypeFieldDescriptionprivate final AsyncTable<AdvancedScanResultConsumer>
RawAsyncHBaseAdmin.metaTable
private final AsyncTable<?>
AsyncBufferedMutatorImpl.table
private final AsyncTable<?>
TableOverAsyncTable.table
Modifier and TypeMethodDescriptionAsyncTableBuilder.build()
Create theAsyncTable
instance.default AsyncTable<AdvancedScanResultConsumer>
Retrieve anAsyncTable
implementation for accessing a table.default AsyncTable<ScanResultConsumer>
AsyncConnection.getTable
(TableName tableName, ExecutorService pool) Retrieve anAsyncTable
implementation for accessing a table.ModifierConstructorDescription(package private)
AsyncBufferedMutatorImpl
(org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer periodicalFlushTimer, AsyncTable<?> table, long writeBufferSize, long periodicFlushTimeoutNs, int maxKeyValueSize) (package private)
TableOverAsyncTable
(AsyncConnectionImpl conn, AsyncTable<?> table, IOExceptionSupplier<ExecutorService> poolSupplier) -
Uses of AsyncTable in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionprivate void
TableReplicationQueueStorage.addLastSeqIdsPut
(org.apache.hadoop.hbase.shaded.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder builder, String peerId, Map<String, Long> lastSeqIds, AsyncTable<?> table)