@InterfaceAudience.Private public class ClientSimpleScanner extends ClientScanner
cache, caching, callable, caller, closed, conf, currentRegion, lastNext, lastResult, maxScannerResultSize, pool, primaryOperationTimeout, readRpcTimeout, rpcControllerFactory, scan, scanMetricsPublished, scannerTimeout, span, tableName
scanMetrics
Constructor and Description |
---|
ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration,
Scan scan,
TableName name,
ClusterConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool,
int scanReadRpcTimeout,
int scannerTimeout,
int replicaCallTimeoutMicroSecondScan) |
Modifier and Type | Method and Description |
---|---|
protected ScannerCallable |
createScannerCallable()
Will be called in moveToNextRegion to create ScannerCallable.
|
protected boolean |
setNewStartKey()
Will be called in moveToNextRegion when currentRegion is null.
|
addEstimatedSize, close, getCacheCount, getCacheSize, getCaching, getConf, getConnection, getMaxResultSize, getPool, getPrimaryOperationTimeout, getRetries, getScan, getScannerTimeout, getScanReplicaId, getTable, getTimestamp, initCache, initSyncCache, isAnyRPCcancelled, loadCache, moveToNextRegion, next, nextWithSyncCache, renewLease, writeScanMetrics
getScanMetrics, initScanMetrics
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
iterator, next
forEach, spliterator
public ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration, Scan scan, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int scanReadRpcTimeout, int scannerTimeout, int replicaCallTimeoutMicroSecondScan) throws IOException
IOException
protected boolean setNewStartKey()
ClientScanner
setNewStartKey
in class ClientScanner
false
if we have reached the stop row. Otherwise true
.protected ScannerCallable createScannerCallable()
ClientScanner
createScannerCallable
in class ClientScanner
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.