@InterfaceAudience.Private public class ReversedClientScanner extends ClientScanner
cache, caching, callable, caller, closed, conf, currentRegion, lastNext, lastResult, maxScannerResultSize, partialResults, partialResultsRow, pool, primaryOperationTimeout, rpcControllerFactory, scan, scanMetricsPublished, scannerTimeout
scanMetrics
Constructor and Description |
---|
ReversedClientScanner(Configuration conf,
Scan scan,
TableName tableName,
ClusterConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout)
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan 's start row maybe changed. |
Modifier and Type | Method and Description |
---|---|
protected boolean |
checkScanStopRow(byte[] startKey) |
protected org.apache.hadoop.hbase.client.ScannerCallableWithReplicas |
getScannerCallable(byte[] localStartKey,
int nbRows,
byte[] locateStartRow) |
protected boolean |
nextScanner(int nbRows,
boolean done) |
close, createClosestRowBefore, getCacheSize, getCaching, getConf, getConnection, getMaxResultSize, getPool, getPrimaryOperationTimeout, getResultsToAddToCache, getRetries, getScan, getScannerCallable, getScannerTimeout, getTable, getTableName, getTimestamp, initializeScannerInConstruction, loadCache, next, renewLease, writeScanMetrics
getScanMetrics, initScanMetrics, iterator, next
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
forEach, spliterator
public ReversedClientScanner(Configuration conf, Scan scan, TableName tableName, ClusterConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory, ExecutorService pool, int primaryOperationTimeout) throws IOException
Scan
's start row maybe changed.conf
- scan
- tableName
- connection
- pool
- primaryOperationTimeout
- IOException
protected boolean nextScanner(int nbRows, boolean done) throws IOException
nextScanner
in class ClientScanner
IOException
protected org.apache.hadoop.hbase.client.ScannerCallableWithReplicas getScannerCallable(byte[] localStartKey, int nbRows, byte[] locateStartRow)
protected boolean checkScanStopRow(byte[] startKey)
checkScanStopRow
in class ClientScanner