Uses of Interface
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
Packages that use AdvancedScanResultConsumer
-
Uses of AdvancedScanResultConsumer in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement AdvancedScanResultConsumerModifier and TypeClassDescriptionprivate static final class
Method parameters in org.apache.hadoop.hbase with type arguments of type AdvancedScanResultConsumerModifier and TypeMethodDescriptionstatic 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.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. -
Uses of AdvancedScanResultConsumer in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement AdvancedScanResultConsumerModifier and TypeClassDescription(package private) class
TheResultScanner
implementation forRawAsyncTableImpl
.Fields in org.apache.hadoop.hbase.client declared as AdvancedScanResultConsumerModifier and TypeFieldDescriptionprivate final AdvancedScanResultConsumer
AsyncClientScanner.consumer
private AdvancedScanResultConsumer
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.consumer
private final AdvancedScanResultConsumer
AsyncScanSingleRegionRpcRetryingCaller.consumer
Fields in org.apache.hadoop.hbase.client with type parameters of type AdvancedScanResultConsumerModifier and TypeFieldDescriptionprivate final AsyncTable<AdvancedScanResultConsumer>
RawAsyncHBaseAdmin.metaTable
Methods in org.apache.hadoop.hbase.client that return types with arguments of type AdvancedScanResultConsumerModifier and TypeMethodDescriptiondefault AsyncTable<AdvancedScanResultConsumer>
Retrieve anAsyncTable
implementation for accessing a table.AsyncConnection.getTableBuilder
(TableName tableName) Returns anAsyncTableBuilder
for creatingAsyncTable
.AsyncConnectionImpl.getTableBuilder
(TableName tableName) SharedAsyncConnection.getTableBuilder
(TableName tableName) Methods in org.apache.hadoop.hbase.client with parameters of type AdvancedScanResultConsumerModifier and TypeMethodDescriptionAsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.consumer
(AdvancedScanResultConsumer consumer) void
RawAsyncTableImpl.scan
(Scan scan, AdvancedScanResultConsumer consumer) Constructors in org.apache.hadoop.hbase.client with parameters of type AdvancedScanResultConsumerModifierConstructorDescriptionAsyncClientScanner
(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)