private static class TestClientScanner.MockClientScanner extends org.apache.hadoop.hbase.client.ClientSimpleScanner
Modifier and Type | Field and Description |
---|---|
private boolean |
initialized |
private boolean |
rpcFinished |
private boolean |
rpcFinishedFired |
Constructor and Description |
---|
MockClientScanner(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.client.Scan scan,
org.apache.hadoop.hbase.TableName tableName,
org.apache.hadoop.hbase.client.ClusterConnection connection,
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory,
org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory,
ExecutorService pool,
int primaryOperationTimeout) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
moveToNextRegion() |
void |
setRpcFinished(boolean rpcFinished) |
createScannerCallable, setNewStartKey
addEstimatedSize, close, getCacheCount, getCacheSize, getCaching, getConf, getConnection, getMaxResultSize, getPool, getPrimaryOperationTimeout, getRetries, getScan, getScannerTimeout, getTable, getTimestamp, initCache, initSyncCache, isAnyRPCcancelled, loadCache, next, nextWithSyncCache, renewLease, writeScanMetrics
getScanMetrics, initScanMetrics
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
forEach, spliterator
private boolean rpcFinished
private boolean rpcFinishedFired
private boolean initialized
public MockClientScanner(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory, ExecutorService pool, int primaryOperationTimeout) throws IOException
IOException
protected boolean moveToNextRegion()
moveToNextRegion
in class org.apache.hadoop.hbase.client.ClientScanner
public void setRpcFinished(boolean rpcFinished)
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.