Package org.apache.hadoop.hbase.client
Class TestClientScanner.MockClientScanner
java.lang.Object
org.apache.hadoop.hbase.client.AbstractClientScanner
org.apache.hadoop.hbase.client.ClientScanner
org.apache.hadoop.hbase.client.ClientSimpleScanner
org.apache.hadoop.hbase.client.TestClientScanner.MockClientScanner
- All Implemented Interfaces:
Closeable
,AutoCloseable
,Iterable<org.apache.hadoop.hbase.client.Result>
,org.apache.hadoop.hbase.client.ResultScanner
- Enclosing class:
- TestClientScanner
private static class TestClientScanner.MockClientScanner
extends org.apache.hadoop.hbase.client.ClientSimpleScanner
-
Field Summary
Modifier and TypeFieldDescriptionprivate boolean
private boolean
private boolean
Fields inherited from class org.apache.hadoop.hbase.client.ClientScanner
cache, caching, callable, caller, closed, conf, currentRegion, lastNext, lastResult, maxScannerResultSize, pool, primaryOperationTimeout, readRpcTimeout, requestAttributes, rpcControllerFactory, scan, scanMetricsPublished, scannerTimeout, span, tableName
Fields inherited from class org.apache.hadoop.hbase.client.AbstractClientScanner
scanMetrics
-
Constructor Summary
ConstructorDescriptionMockClientScanner
(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, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfig) -
Method Summary
Methods inherited from class org.apache.hadoop.hbase.client.ClientSimpleScanner
createScannerCallable, setNewStartKey
Methods inherited from class org.apache.hadoop.hbase.client.ClientScanner
addEstimatedSize, close, getCacheCount, getCacheSize, getCaching, getConf, getConnection, getMaxResultSize, getPool, getPrimaryOperationTimeout, getRetries, getScan, getScannerTimeout, getScanReplicaId, getTable, getTimestamp, initCache, initSyncCache, isAnyRPCcancelled, loadCache, next, nextWithSyncCache, renewLease, writeScanMetrics
Methods inherited from class org.apache.hadoop.hbase.client.AbstractClientScanner
getScanMetrics, initScanMetrics
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface java.lang.Iterable
forEach, spliterator
Methods inherited from interface org.apache.hadoop.hbase.client.ResultScanner
iterator, next
-
Field Details
-
rpcFinished
-
rpcFinishedFired
-
initialized
-
-
Constructor Details
-
MockClientScanner
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, org.apache.hadoop.hbase.client.ConnectionConfiguration connectionConfig) throws IOException - Throws:
IOException
-
-
Method Details
-
moveToNextRegion
- Overrides:
moveToNextRegion
in classorg.apache.hadoop.hbase.client.ClientScanner
-
setRpcFinished
-