@InterfaceAudience.Public
@InterfaceStability.Stable
public class ClientScanner
extends org.apache.hadoop.hbase.client.AbstractClientScanner
Modifier and Type | Field and Description |
---|---|
protected LinkedList<Result> |
cache |
protected int |
caching |
protected org.apache.hadoop.hbase.client.ScannerCallable |
callable |
protected org.apache.hadoop.hbase.client.RpcRetryingCaller<Result[]> |
caller |
protected boolean |
closed |
protected HRegionInfo |
currentRegion |
protected long |
lastNext |
protected Result |
lastResult |
protected long |
maxScannerResultSize |
protected org.apache.hadoop.hbase.ipc.RpcControllerFactory |
rpcControllerFactory |
protected Scan |
scan |
protected boolean |
scanMetricsPublished |
protected int |
scannerTimeout |
Constructor and Description |
---|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
byte[] tableName)
Deprecated.
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
byte[] tableName,
HConnection connection)
Deprecated.
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName)
Deprecated.
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ClientScanner for the specified table
Note that the passed
Scan 's start row maybe changed changed. |
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory)
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory,
org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory)
Create a new ClientScanner for the specified table Note that the passed
Scan 's start
row maybe changed changed. |
Modifier and Type | Method and Description |
---|---|
protected boolean |
checkScanStopRow(byte[] endKey) |
void |
close()
Closes the scanner and releases any resources it has allocated
|
protected HConnection |
getConnection() |
protected Scan |
getScan() |
protected TableName |
getTable() |
protected byte[] |
getTableName()
Deprecated.
Since 0.96.0; use
getTable() |
protected long |
getTimestamp() |
protected void |
initializeScannerInConstruction() |
Result |
next()
Grab the next row's worth of values.
|
protected boolean |
nextScanner(int nbRows,
boolean done) |
protected void |
writeScanMetrics()
Publish the scan metrics.
|
protected Scan scan
protected boolean closed
protected HRegionInfo currentRegion
protected org.apache.hadoop.hbase.client.ScannerCallable callable
protected final LinkedList<Result> cache
protected final int caching
protected long lastNext
protected Result lastResult
protected final long maxScannerResultSize
protected final int scannerTimeout
protected boolean scanMetricsPublished
protected org.apache.hadoop.hbase.client.RpcRetryingCaller<Result[]> caller
protected org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory
@Deprecated public ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName) throws IOException
Scan
's start row maybe changed changed.conf
- The Configuration
to use.scan
- Scan
to use in this scannertableName
- The table that we wish to scanIOException
@Deprecated public ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, byte[] tableName) throws IOException
ClientScanner(Configuration, Scan, TableName)
IOException
public ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection) throws IOException
Scan
's start row maybe changed changed.conf
- The Configuration
to use.scan
- Scan
to use in this scannertableName
- The table that we wish to scanconnection
- Connection identifying the clusterIOException
@Deprecated public ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, byte[] tableName, HConnection connection) throws IOException
ClientScanner(Configuration, Scan, TableName, HConnection)
IOException
@Deprecated public ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory) throws IOException
ClientScanner(Configuration, Scan, TableName, HConnection,
RpcRetryingCallerFactory, RpcControllerFactory)
insteadIOException
public ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection, org.apache.hadoop.hbase.client.RpcRetryingCallerFactory rpcFactory, org.apache.hadoop.hbase.ipc.RpcControllerFactory controllerFactory) throws IOException
Scan
's start
row maybe changed changed.conf
- The Configuration
to use.scan
- Scan
to use in this scannertableName
- The table that we wish to scanconnection
- Connection identifying the clusterIOException
protected void initializeScannerInConstruction() throws IOException
IOException
protected HConnection getConnection()
@Deprecated protected byte[] getTableName()
getTable()
protected TableName getTable()
protected Scan getScan()
protected long getTimestamp()
protected boolean checkScanStopRow(byte[] endKey)
protected boolean nextScanner(int nbRows, boolean done) throws IOException
IOException
protected void writeScanMetrics()
public Result next() throws IOException
ResultScanner
IOException
- epublic void close()
ResultScanner
Copyright © 2014 The Apache Software Foundation. All rights reserved.