| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.client.coprocessor | Provides client classes for invoking Coprocessor RPC protocols
 Overview
 Example Usage
 | 
| org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
 src/main/protobufdefinition files. | 
| org.apache.hadoop.hbase.quotas | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | MetaTableAccessor. getScanForTableName(TableName tableName)This method creates a Scan object that will only scan catalog rows that
 belong to the specified table. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Scan | ClientScanner. scan | 
| Modifier and Type | Method and Description | 
|---|---|
| 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. setACL(Map<String,Permission> perms) | 
| Scan | Scan. setACL(String user,
      Permission perms) | 
| Scan | Scan. setAllowPartialResults(boolean allowPartialResults)Setting whether the caller wants to see the partial results that may be returned from the
 server. | 
| Scan | Scan. setAttribute(String name,
            byte[] value) | 
| Scan | Scan. setAuthorizations(Authorizations authorizations) | 
| Scan | Scan. setBatch(int batch)Set the maximum number of values to return for each call to next() | 
| Scan | Scan. setCacheBlocks(boolean cacheBlocks)Set whether blocks should be cached for this Scan. | 
| Scan | Scan. setCaching(int caching)Set the number of rows for caching that will be passed to scanners. | 
| Scan | Scan. setColumnFamilyTimeRange(byte[] cf,
                        long minStamp,
                        long maxStamp) | 
| Scan | Scan. setConsistency(Consistency consistency) | 
| Scan | Scan. setFamilyMap(Map<byte[],NavigableSet<byte[]>> familyMap)Setting the familyMap | 
| Scan | Scan. setFilter(Filter filter) | 
| Scan | Scan. setId(String id) | 
| Scan | Scan. setIsolationLevel(IsolationLevel level) | 
| Scan | Scan. setLoadColumnFamiliesOnDemand(boolean value)Set the value indicating whether loading CFs on demand should be allowed (cluster
 default is false). | 
| Scan | Scan. setMaxResultSize(long maxResultSize)Set the maximum result size. | 
| Scan | Scan. setMaxResultsPerColumnFamily(int limit)Set the maximum number of values to return per row per Column Family | 
| 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. setRaw(boolean raw)Enable/disable "raw" mode for this scan. | 
| Scan | Scan. setReplicaId(int Id) | 
| Scan | Scan. setReversed(boolean reversed)Set whether this scan is a reversed one | 
| Scan | Scan. setRowOffsetPerColumnFamily(int offset)Set offset for the row per Column Family. | 
| Scan | Scan. setRowPrefixFilter(byte[] rowPrefix)Set a filter (using stopRow and startRow) so the result set only contains rows where the
 rowKey starts with the specified prefix. | 
| Scan | Scan. setScanMetricsEnabled(boolean enabled)Enable collection of  ScanMetrics. | 
| Scan | Scan. setSmall(boolean small)Set whether this scan is a small scan | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.hbase.client.ScannerCallableWithReplicas | ClientSmallScanner.SmallScannerCallableFactory. getCallable(ClusterConnection connection,
           TableName table,
           Scan scan,
           ScanMetrics scanMetrics,
           byte[] localStartKey,
           int cacheNum,
           RpcControllerFactory controllerFactory,
           ExecutorService pool,
           int primaryOperationTimeout,
           int retries,
           int scannerTimeout,
           org.apache.hadoop.conf.Configuration conf,
           RpcRetryingCaller<Result[]> caller) | 
| ResultScanner | Table. getScanner(Scan scan)Returns a scanner on the current table as specified by the  Scanobject. | 
| ResultScanner | HTable. getScanner(Scan scan)The underlying  HTablemust not be closed. | 
| protected void | AbstractClientScanner. initScanMetrics(Scan scan)Check and initialize if application wants to collect scan metrics | 
| Constructor and Description | 
|---|
| ClientScanner(org.apache.hadoop.conf.Configuration conf,
             Scan scan,
             TableName tableName,
             ClusterConnection connection,
             RpcRetryingCallerFactory rpcFactory,
             RpcControllerFactory controllerFactory,
             ExecutorService pool,
             int primaryOperationTimeout)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,
                          ClusterConnection connection,
                          RpcRetryingCallerFactory rpcFactory,
                          RpcControllerFactory controllerFactory,
                          ExecutorService pool,
                          int primaryOperationTimeout)Create a new ReversibleClientScanner for the specified table. | 
| ClientSmallScanner(org.apache.hadoop.conf.Configuration conf,
                  Scan scan,
                  TableName tableName,
                  ClusterConnection connection,
                  RpcRetryingCallerFactory rpcFactory,
                  RpcControllerFactory controllerFactory,
                  ExecutorService pool,
                  int primaryOperationTimeout)Create a new ShortClientScanner for the specified table. | 
| ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
                     Scan scan,
                     TableName tableName,
                     ClusterConnection connection,
                     RpcRetryingCallerFactory rpcFactory,
                     RpcControllerFactory controllerFactory,
                     ExecutorService pool,
                     int primaryOperationTimeout)Create a new ReversibleClientScanner for the specified table Note that the
 passed  Scan's start row maybe changed. | 
| ReversedScannerCallable(ClusterConnection connection,
                       TableName tableName,
                       Scan scan,
                       ScanMetrics scanMetrics,
                       byte[] locateStartRow) | 
| ReversedScannerCallable(ClusterConnection connection,
                       TableName tableName,
                       Scan scan,
                       ScanMetrics scanMetrics,
                       byte[] locateStartRow,
                       RpcControllerFactory rpcFactory) | 
| ReversedScannerCallable(ClusterConnection connection,
                       TableName tableName,
                       Scan scan,
                       ScanMetrics scanMetrics,
                       byte[] locateStartRow,
                       RpcControllerFactory rpcFactory,
                       int replicaId) | 
| Scan(Scan scan)Creates a new instance of this class while copying all values. | 
| ScannerCallable(ClusterConnection connection,
               TableName tableName,
               Scan scan,
               ScanMetrics scanMetrics,
               RpcControllerFactory rpcControllerFactory) | 
| ScannerCallable(ClusterConnection connection,
               TableName tableName,
               Scan scan,
               ScanMetrics scanMetrics,
               RpcControllerFactory rpcControllerFactory,
               int id) | 
| Modifier and Type | Method and Description | 
|---|---|
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. avg(Table 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. max(Table 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. median(Table 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. min(Table 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. rowCount(Table table,
        ColumnInterpreter<R,S,P,Q,T> ci,
        Scan scan)It gives the row count, by summing up the individual results obtained from
 regions. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. std(Table 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | 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. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. sum(Table table,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)It sums up the value returned from various regions. | 
| <R,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,T extends com.google.protobuf.Message>  | AggregationClient. sum(TableName tableName,
   ColumnInterpreter<R,S,P,Q,T> ci,
   Scan scan)It sums up the value returned from various regions. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | ProtobufUtil. toScan(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan proto)Convert a protocol buffer Scan to a client Scan | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest | RequestConverter. buildScanRequest(byte[] regionName,
                Scan scan,
                int numberOfRows,
                boolean closeScanner)Create a protocol buffer ScanRequest for a client Scan | 
| static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan | ProtobufUtil. toScan(Scan scan)Convert a client Scan to a protocol buffer Scan | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | QuotaTableUtil. makeScan(QuotaFilter filter) | 
Copyright © 2007–2016 The Apache Software Foundation. All rights reserved.