|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Scan | |
---|---|
org.apache.hadoop.hbase.catalog | |
org.apache.hadoop.hbase.client | Provides HBase Client |
org.apache.hadoop.hbase.client.coprocessor | Provides client classes for invoking Coprocessor RPC protocols |
org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
src/main/protobuf definition files. |
Uses of Scan in org.apache.hadoop.hbase.catalog |
---|
Methods in org.apache.hadoop.hbase.catalog that return Scan | |
---|---|
static Scan |
MetaReader.getScanForTableName(TableName tableName)
This method creates a Scan object that will only scan catalog rows that belong to the specified table. |
Uses of Scan in org.apache.hadoop.hbase.client |
---|
Fields in org.apache.hadoop.hbase.client declared as Scan | |
---|---|
protected Scan |
ClientScanner.scan
|
Methods in org.apache.hadoop.hbase.client that return Scan | |
---|---|
Scan |
Scan.addColumn(byte[] family,
byte[] qualifier)
Get the column from the specified family with the specified qualifier. |
Scan |
Scan.addFamily(byte[] family)
Get all columns from the specified family. |
protected Scan |
ScannerCallable.getScan()
|
protected Scan |
ClientScanner.getScan()
|
Scan |
Scan.setFamilyMap(Map<byte[],NavigableSet<byte[]>> familyMap)
Setting the familyMap |
Scan |
Scan.setFilter(Filter filter)
|
Scan |
Scan.setMaxVersions()
Get all available versions. |
Scan |
Scan.setMaxVersions(int maxVersions)
Get up to the specified number of versions of each column. |
Scan |
Scan.setReversed(boolean reversed)
Set whether this scan is a reversed one |
Scan |
Scan.setStartRow(byte[] startRow)
Set the start row of the scan. |
Scan |
Scan.setStopRow(byte[] stopRow)
Set the stop row. |
Scan |
Scan.setTimeRange(long minStamp,
long maxStamp)
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp). |
Scan |
Scan.setTimeStamp(long timestamp)
Get versions of columns with the specified timestamp. |
Methods in org.apache.hadoop.hbase.client with parameters of type Scan | |
---|---|
RegionServerCallable<Result[]> |
ClientSmallScanner.SmallScannerCallableFactory.getCallable(Scan sc,
HConnection connection,
TableName tableName,
ScanMetrics scanMetrics,
byte[] localStartKey,
int cacheNum,
RpcControllerFactory rpcControllerFactory)
|
ResultScanner |
HTable.getScanner(Scan scan)
Returns a scanner on the current table as specified by the Scan
object. |
ResultScanner |
HTableInterface.getScanner(Scan scan)
Returns a scanner on the current table as specified by the Scan
object. |
protected void |
AbstractClientScanner.initScanMetrics(Scan scan)
Check and initialize if application wants to collect scan metrics |
Constructors in org.apache.hadoop.hbase.client with parameters of type Scan | |
---|---|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
byte[] tableName)
Deprecated. Use ClientScanner.ClientScanner(Configuration, Scan, TableName) |
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
byte[] tableName,
HConnection connection)
Deprecated. Use ClientScanner.ClientScanner(Configuration, Scan, TableName, HConnection) |
|
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,
RpcRetryingCallerFactory rpcFactory)
Deprecated. Use ClientScanner.ClientScanner(Configuration, Scan, TableName, HConnection,
RpcRetryingCallerFactory, RpcControllerFactory)
instead |
|
ClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory)
Create a new ClientScanner for the specified table Note that the passed Scan 's start
row maybe changed changed. |
|
ClientSmallReversedScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ReversibleClientScanner for the specified table Note that the passed Scan 's start row maybe changed. |
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName)
Create a new ClientSmallScanner for the specified table. |
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ClientSmallScanner for the specified table. |
|
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection,
RpcRetryingCallerFactory rpcFactory,
RpcControllerFactory controllerFactory)
Create a new ShortClientScanner for the specified table Note that the passed Scan 's start row maybe changed changed. |
|
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
Scan scan,
TableName tableName,
HConnection connection)
Create a new ReversibleClientScanner for the specified table Note that the passed Scan 's start row maybe changed. |
|
ReversedScannerCallable(HConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow)
Deprecated. |
|
ReversedScannerCallable(HConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
byte[] locateStartRow,
PayloadCarryingRpcController rpcFactory)
|
|
Scan(Scan scan)
Creates a new instance of this class while copying all values. |
|
ScannerCallable(HConnection connection,
byte[] tableName,
Scan scan,
ScanMetrics scanMetrics)
Deprecated. Use ScannerCallable.ScannerCallable(HConnection, TableName, Scan,
ScanMetrics, PayloadCarryingRpcController) |
|
ScannerCallable(HConnection connection,
TableName tableName,
Scan scan,
ScanMetrics scanMetrics,
PayloadCarryingRpcController controller)
|
Uses of Scan in org.apache.hadoop.hbase.client.coprocessor |
---|
Methods in org.apache.hadoop.hbase.client.coprocessor with parameters of type Scan | ||
---|---|---|
|
AggregationClient.avg(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the average method for a given cf-cq combination. |
|
|
AggregationClient.avg(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the average method for a given cf-cq combination. |
|
|
AggregationClient.max(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the maximum value of a column for a given column family for the given range. |
|
|
AggregationClient.max(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the maximum value of a column for a given column family for the given range. |
|
|
AggregationClient.median(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handler for calling the median method for a given cf-cq combination. |
|
|
AggregationClient.median(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handler for calling the median method for a given cf-cq combination. |
|
|
AggregationClient.min(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the minimum value of a column for a given column family for the given range. |
|
|
AggregationClient.min(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the minimum value of a column for a given column family for the given range. |
|
|
AggregationClient.rowCount(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the row count, by summing up the individual results obtained from regions. |
|
|
AggregationClient.rowCount(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It gives the row count, by summing up the individual results obtained from regions. |
|
|
AggregationClient.std(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the std method for a given cf-cq combination. |
|
|
AggregationClient.std(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
This is the client side interface/handle for calling the std method for a given cf-cq combination. |
|
|
AggregationClient.sum(HTable table,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It sums up the value returned from various regions. |
|
|
AggregationClient.sum(TableName tableName,
ColumnInterpreter<R,S,P,Q,T> ci,
Scan scan)
It sums up the value returned from various regions. |
Uses of Scan in org.apache.hadoop.hbase.protobuf |
---|
Methods in org.apache.hadoop.hbase.protobuf that return Scan | |
---|---|
static Scan |
ProtobufUtil.toScan(ClientProtos.Scan proto)
Convert a protocol buffer Scan to a client Scan |
Methods in org.apache.hadoop.hbase.protobuf with parameters of type Scan | |
---|---|
static ClientProtos.ScanRequest |
RequestConverter.buildScanRequest(byte[] regionName,
Scan scan,
int numberOfRows,
boolean closeScanner)
Create a protocol buffer ScanRequest for a client Scan |
static ClientProtos.Scan |
ProtobufUtil.toScan(Scan scan)
Convert a client Scan to a protocol buffer Scan |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |