Uses of Interface
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
-
Uses of AdvancedScanResultConsumer in org.apache.hadoop.hbase
Modifier and TypeClassDescriptionprivate static final class
Modifier and TypeMethodDescriptionstatic CompletableFuture<List<HRegionLocation>>
AsyncMetaTableAccessor.getTableHRegionLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName) Used to get all region locations for the specific tableprivate static CompletableFuture<List<Pair<RegionInfo,
ServerName>>> AsyncMetaTableAccessor.getTableRegionsAndLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, boolean excludeOfflinedSplitParents) Used to get table regions' info and server.private static CompletableFuture<Void>
AsyncMetaTableAccessor.scanMeta
(AsyncTable<AdvancedScanResultConsumer> metaTable, byte[] startRow, byte[] stopRow, MetaTableAccessor.QueryType type, int maxRows, MetaTableAccessor.Visitor visitor) Performs a scan of META table for given table.private static CompletableFuture<Void>
AsyncMetaTableAccessor.scanMeta
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, MetaTableAccessor.QueryType type, MetaTableAccessor.Visitor visitor) Performs a scan of META table for given table. -
Uses of AdvancedScanResultConsumer in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
TheResultScanner
implementation forRawAsyncTableImpl
.Modifier and TypeFieldDescriptionprivate final AdvancedScanResultConsumer
AsyncClientScanner.consumer
private AdvancedScanResultConsumer
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.consumer
private final AdvancedScanResultConsumer
AsyncScanSingleRegionRpcRetryingCaller.consumer
Modifier and TypeFieldDescriptionprivate final AsyncTable<AdvancedScanResultConsumer>
RawAsyncHBaseAdmin.metaTable
Modifier and TypeMethodDescriptiondefault AsyncTable<AdvancedScanResultConsumer>
Retrieve anAsyncTable
implementation for accessing a table.AsyncConnection.getTableBuilder
(TableName tableName) Returns anAsyncTableBuilder
for creatingAsyncTable
.AsyncConnectionImpl.getTableBuilder
(TableName tableName) Modifier and TypeMethodDescriptionAsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.consumer
(AdvancedScanResultConsumer consumer) void
RawAsyncTableImpl.scan
(Scan scan, AdvancedScanResultConsumer consumer) ModifierConstructorDescriptionAsyncClientScanner
(Scan scan, AdvancedScanResultConsumer consumer, TableName tableName, AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncScanSingleRegionRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, Scan scan, ScanMetrics scanMetrics, long scannerId, ScanResultCache resultCache, AdvancedScanResultConsumer consumer, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, HRegionLocation loc, boolean isRegionServerRemote, int priority, long scannerLeaseTimeoutPeriodNs, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes)