@InterfaceAudience.Private public class ClientAsyncPrefetchScanner extends ClientSimpleScanner
prefetchCondition()
.cache, caching, callable, caller, closed, conf, currentRegion, lastNext, lastResult, maxScannerResultSize, pool, primaryOperationTimeout, rpcControllerFactory, scan, scanMetricsPublished, scannerTimeout, tableName
scanMetrics
Constructor and Description |
---|
ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration,
Scan scan,
TableName name,
ClusterConnection connection,
RpcRetryingCallerFactory rpcCallerFactory,
RpcControllerFactory rpcControllerFactory,
ExecutorService pool,
int replicaCallTimeoutMicroSecondScan) |
Modifier and Type | Method and Description |
---|---|
protected void |
addEstimatedSize(long estimatedSize) |
void |
close()
Closes the scanner and releases any resources it has allocated
|
protected void |
initCache() |
Result |
next()
Grab the next row's worth of values.
|
createScannerCallable, setNewStartKey
getCacheCount, getCacheSize, getCaching, getConf, getConnection, getMaxResultSize, getPool, getPrimaryOperationTimeout, getRetries, getScan, getScannerTimeout, getTable, getTimestamp, initSyncCache, loadCache, moveToNextRegion, nextWithSyncCache, renewLease, writeScanMetrics
getScanMetrics, initScanMetrics
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
iterator, next
forEach, spliterator
public ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration, Scan scan, TableName name, ClusterConnection connection, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool, int replicaCallTimeoutMicroSecondScan) throws IOException
IOException
protected void initCache()
initCache
in class ClientScanner
public Result next() throws IOException
ResultScanner
next
in interface ResultScanner
next
in class ClientScanner
IOException
- epublic void close()
ResultScanner
close
in interface Closeable
close
in interface AutoCloseable
close
in interface ResultScanner
close
in class ClientScanner
protected void addEstimatedSize(long estimatedSize)
addEstimatedSize
in class ClientScanner
Copyright © 2007–2019 Cloudera. All rights reserved.