| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| Modifier and Type | Class and Description | 
|---|---|
| private static class  | AsyncMetaTableAccessor.MetaTableScanResultConsumer | 
| Modifier and Type | Method and Description | 
|---|---|
| static CompletableFuture<List<HRegionLocation>> | AsyncMetaTableAccessor. getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
                        TableName tableName)Used to get all region locations for the specific table. | 
| private 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. | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) class  | AsyncTableResultScannerThe  ResultScannerimplementation forAsyncTable. | 
| Modifier and Type | Field and Description | 
|---|---|
| private AdvancedScanResultConsumer | AsyncClientScanner. consumer | 
| private AdvancedScanResultConsumer | AsyncScanSingleRegionRpcRetryingCaller. consumer | 
| private AdvancedScanResultConsumer | AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder. consumer | 
| Modifier and Type | Field and Description | 
|---|---|
| private AsyncTable<AdvancedScanResultConsumer> | RawAsyncHBaseAdmin. metaTable | 
| private AsyncTable<AdvancedScanResultConsumer> | AsyncTableImpl. rawTable | 
| private AsyncTable<AdvancedScanResultConsumer> | AsyncTableResultScanner. rawTable | 
| Modifier and Type | Method and Description | 
|---|---|
| default AsyncTable<AdvancedScanResultConsumer> | AsyncConnection. getTable(TableName tableName)Retrieve an  AsyncTableimplementation for accessing a table. | 
| AsyncTableBuilder<AdvancedScanResultConsumer> | AsyncConnectionImpl. getTableBuilder(TableName tableName) | 
| AsyncTableBuilder<AdvancedScanResultConsumer> | AsyncConnection. getTableBuilder(TableName tableName)Returns an  AsyncTableBuilderfor creatingAsyncTable. | 
| Modifier and Type | Method and Description | 
|---|---|
| AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder | AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder. consumer(AdvancedScanResultConsumer consumer) | 
| void | RawAsyncTableImpl. scan(Scan scan,
    AdvancedScanResultConsumer consumer) | 
| Constructor and Description | 
|---|
| AsyncClientScanner(Scan scan,
                  AdvancedScanResultConsumer consumer,
                  TableName tableName,
                  AsyncConnectionImpl conn,
                  org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
                  long pauseNs,
                  long pauseForCQTBENs,
                  int maxAttempts,
                  long scanTimeoutNs,
                  long rpcTimeoutNs,
                  int startLogErrorsCnt) | 
| 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 pauseForCQTBENs,
                                      int maxAttempts,
                                      long scanTimeoutNs,
                                      long rpcTimeoutNs,
                                      int startLogErrorsCnt) | 
| Constructor and Description | 
|---|
| AsyncTableImpl(AsyncConnectionImpl conn,
              AsyncTable<AdvancedScanResultConsumer> rawTable,
              ExecutorService pool) | 
| AsyncTableResultScanner(AsyncTable<AdvancedScanResultConsumer> table,
                       Scan scan,
                       long maxCacheSize) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.