| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.client.trace | |
| org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
 src/main/protobufdefinition files. | 
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.shaded.protobuf | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | MetaTableAccessor. getScanForTableName(org.apache.hadoop.conf.Configuration conf,
                   TableName tableName)This method creates a Scan object that will only scan catalog rows that belong to the specified
 table. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ImmutableScanImmutable version of Scan | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Scan | ClientScanner. scan | 
| protected Scan | ScannerCallable. 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 | ImmutableScan. addColumn(byte[] family,
         byte[] qualifier) | 
| Scan | Scan. addFamily(byte[] family)Get all columns from the specified family. | 
| Scan | ImmutableScan. addFamily(byte[] family) | 
| static Scan | Scan. createScanFromCursor(Cursor cursor)Create a new Scan with a cursor. | 
| protected Scan | ClientScanner. getScan() | 
| protected Scan | ScannerCallable. getScan() | 
| Scan | Scan. readAllVersions()Get all available versions. | 
| Scan | ImmutableScan. readAllVersions() | 
| Scan | Scan. readVersions(int versions)Get up to the specified number of versions of each column. | 
| Scan | ImmutableScan. readVersions(int versions) | 
| Scan | Scan. setACL(Map<String,Permission> perms) | 
| Scan | ImmutableScan. setACL(Map<String,Permission> perms) | 
| Scan | Scan. setACL(String user,
      Permission perms) | 
| Scan | ImmutableScan. setACL(String user,
      Permission perms) | 
| Scan | Scan. setAllowPartialResults(boolean allowPartialResults)Setting whether the caller wants to see the partial results when server returns
 less-than-expected cells. | 
| Scan | ImmutableScan. setAllowPartialResults(boolean allowPartialResults) | 
| Scan | Scan. setAsyncPrefetch(boolean asyncPrefetch) | 
| Scan | ImmutableScan. setAsyncPrefetch(boolean asyncPrefetch)Deprecated.  | 
| Scan | Scan. setAttribute(String name,
            byte[] value) | 
| Scan | ImmutableScan. setAttribute(String name,
            byte[] value) | 
| Scan | Scan. setAuthorizations(Authorizations authorizations) | 
| Scan | ImmutableScan. setAuthorizations(Authorizations authorizations) | 
| Scan | Scan. setBatch(int batch)Set the maximum number of cells to return for each call to next(). | 
| Scan | ImmutableScan. setBatch(int batch) | 
| Scan | Scan. setCacheBlocks(boolean cacheBlocks)Set whether blocks should be cached for this Scan. | 
| Scan | ImmutableScan. setCacheBlocks(boolean cacheBlocks) | 
| Scan | Scan. setCaching(int caching)Set the number of rows for caching that will be passed to scanners. | 
| Scan | ImmutableScan. setCaching(int caching) | 
| Scan | Scan. setColumnFamilyTimeRange(byte[] cf,
                        long minStamp,
                        long maxStamp) | 
| Scan | ImmutableScan. setColumnFamilyTimeRange(byte[] cf,
                        long minStamp,
                        long maxStamp) | 
| Scan | Scan. setConsistency(Consistency consistency) | 
| Scan | ImmutableScan. setConsistency(Consistency consistency) | 
| Scan | Scan. setEnableScanMetricsByRegion(boolean enable)Enables region level scan metrics. | 
| Scan | ImmutableScan. setEnableScanMetricsByRegion(boolean enable) | 
| Scan | Scan. setFamilyMap(Map<byte[],NavigableSet<byte[]>> familyMap)Setting the familyMap | 
| Scan | ImmutableScan. setFamilyMap(Map<byte[],NavigableSet<byte[]>> familyMap) | 
| Scan | Scan. setFilter(Filter filter) | 
| Scan | ImmutableScan. setFilter(Filter filter) | 
| Scan | Scan. setId(String id) | 
| Scan | ImmutableScan. setId(String id) | 
| Scan | Scan. setIsolationLevel(IsolationLevel level) | 
| Scan | ImmutableScan. setIsolationLevel(IsolationLevel level) | 
| Scan | Scan. setLimit(int limit)Set the limit of rows for this scan. | 
| Scan | ImmutableScan. setLimit(int limit) | 
| Scan | Scan. setLoadColumnFamiliesOnDemand(boolean value) | 
| Scan | ImmutableScan. setLoadColumnFamiliesOnDemand(boolean value) | 
| Scan | Scan. setMaxResultSize(long maxResultSize)Set the maximum result size. | 
| Scan | ImmutableScan. setMaxResultSize(long maxResultSize) | 
| Scan | Scan. setMaxResultsPerColumnFamily(int limit)Set the maximum number of values to return per row per Column Family | 
| Scan | ImmutableScan. setMaxResultsPerColumnFamily(int limit) | 
| Scan | Scan. setMaxVersions()Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. It is easy to misunderstand with column
             family's max versions, so use  readAllVersions()instead. | 
| Scan | Scan. setMaxVersions(int maxVersions)Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. It is easy to misunderstand with column
             family's max versions, so use  readVersions(int)instead. | 
| Scan | Scan. setNeedCursorResult(boolean needCursorResult)When the server is slow or we scan a table with many deleted data or we use a sparse filter,
 the server will response heartbeat to prevent timeout. | 
| Scan | ImmutableScan. setNeedCursorResult(boolean needCursorResult) | 
| Scan | Scan. setOneRowLimit()Call this when you only want to get one row. | 
| Scan | ImmutableScan. setOneRowLimit() | 
| Scan | Scan. setPriority(int priority) | 
| Scan | ImmutableScan. setPriority(int priority) | 
| Scan | Scan. setRaw(boolean raw)Enable/disable "raw" mode for this scan. | 
| Scan | ImmutableScan. setRaw(boolean raw) | 
| Scan | Scan. setReadType(Scan.ReadType readType)Set the read type for this scan. | 
| Scan | ImmutableScan. setReadType(Scan.ReadType readType) | 
| Scan | Scan. setReplicaId(int Id) | 
| Scan | ImmutableScan. setReplicaId(int id) | 
| Scan | Scan. setReversed(boolean reversed)Set whether this scan is a reversed one | 
| Scan | ImmutableScan. setReversed(boolean reversed) | 
| Scan | Scan. setRowOffsetPerColumnFamily(int offset)Set offset for the row per Column Family. | 
| Scan | ImmutableScan. setRowOffsetPerColumnFamily(int offset) | 
| Scan | Scan. setRowPrefixFilter(byte[] rowPrefix)Deprecated. 
 since 2.5.0, will be removed in 4.0.0. The name of this method is considered to be
             confusing as it does not use a  Filterbut uses setting the startRow and
             stopRow instead. UsesetStartStopRowForPrefixScan(byte[])instead. | 
| Scan | Scan. setScanMetricsEnabled(boolean enabled)Enable collection of  ScanMetrics. | 
| Scan | ImmutableScan. setScanMetricsEnabled(boolean enabled) | 
| Scan | Scan. setSmall(boolean small)Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. Use  setLimit(int)andsetReadType(ReadType)instead. And for the one rpc optimization, now we
             will also fetch data when openScanner, and if the number of rows reaches the limit
             then we will close the scanner automatically which means we will fall back to one
             rpc. | 
| Scan | ImmutableScan. setSmall(boolean small)Deprecated.  | 
| Scan | Scan. setStartRow(byte[] startRow)Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. Use  withStartRow(byte[])instead. This method may change the inclusive of the stop row to keep compatible
             with the old behavior. | 
| Scan | Scan. setStartStopRowForPrefixScan(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 | ImmutableScan. setStartStopRowForPrefixScan(byte[] rowPrefix) | 
| Scan | Scan. setStopRow(byte[] stopRow)Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. Use  withStopRow(byte[])instead.
             This method may change the inclusive of the stop row to keep compatible with the
             old behavior. | 
| Scan | Scan. setTimeRange(long minStamp,
            long maxStamp)Get versions of columns only within the specified timestamp range, [minStamp, maxStamp). | 
| Scan | ImmutableScan. setTimeRange(long minStamp,
            long maxStamp) | 
| Scan | Scan. setTimestamp(long timestamp)Get versions of columns with the specified timestamp. | 
| Scan | ImmutableScan. setTimestamp(long timestamp) | 
| Scan | Scan. setTimeStamp(long timestamp)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              setTimestamp(long)instead | 
| Scan | ImmutableScan. setTimeStamp(long timestamp)Deprecated.  | 
| Scan | Scan. withStartRow(byte[] startRow)Set the start row of the scan. | 
| Scan | ImmutableScan. withStartRow(byte[] startRow) | 
| Scan | Scan. withStartRow(byte[] startRow,
            boolean inclusive)Set the start row of the scan. | 
| Scan | ImmutableScan. withStartRow(byte[] startRow,
            boolean inclusive) | 
| Scan | Scan. withStopRow(byte[] stopRow)Set the stop row of the scan. | 
| Scan | ImmutableScan. withStopRow(byte[] stopRow) | 
| Scan | Scan. withStopRow(byte[] stopRow,
           boolean inclusive)Set the stop row of the scan. | 
| Scan | ImmutableScan. withStopRow(byte[] stopRow,
           boolean inclusive) | 
| Modifier and Type | Method and Description | 
|---|---|
| Optional<Scan> | OnlineLogRecord. getScan()If "hbase.slowlog.scan.payload.enabled" is enabled then
 this value may be present and should represent the Scan that produced the given
  OnlineLogRecord | 
| Modifier and Type | Method and Description | 
|---|---|
| static org.apache.hadoop.hbase.client.ScanResultCache | ConnectionUtils. createScanResultCache(Scan scan) | 
| static long | PackagePrivateFieldAccessor. getMvccReadPoint(Scan scan) | 
| ResultScanner | AsyncTable. 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. | 
| default ResultScanner | Table. getScanner(Scan scan)Returns a scanner on the current table as specified by the  Scanobject. | 
| protected void | AbstractClientScanner. initScanMetrics(Scan scan)Check and initialize if application wants to collect scan metrics | 
| void | AsyncTable. scan(Scan scan,
    C consumer)The scan API uses the observer pattern. | 
| CompletableFuture<List<Result>> | AsyncTable. scanAll(Scan scan)Return all the results that match the given scan object. | 
| static void | PackagePrivateFieldAccessor. setMvccReadPoint(Scan scan,
                long mvccReadPoint) | 
| OnlineLogRecord.OnlineLogRecordBuilder | OnlineLogRecord.OnlineLogRecordBuilder. setScan(Scan scan) | 
| Constructor and Description | 
|---|
| ClientAsyncPrefetchScanner(org.apache.hadoop.conf.Configuration configuration,
                          Scan scan,
                          Scan scanForMetrics,
                          TableName name,
                          ClusterConnection connection,
                          RpcRetryingCallerFactory rpcCallerFactory,
                          RpcControllerFactory rpcControllerFactory,
                          ExecutorService pool,
                          int scanReadRpcTimeout,
                          int scannerTimeout,
                          int replicaCallTimeoutMicroSecondScan,
                          ConnectionConfiguration connectionConfiguration,
                          Map<String,byte[]> requestAttributes) | 
| ClientScanner(org.apache.hadoop.conf.Configuration conf,
             Scan scan,
             Scan scanForMetrics,
             TableName tableName,
             ClusterConnection connection,
             RpcRetryingCallerFactory rpcFactory,
             RpcControllerFactory controllerFactory,
             ExecutorService pool,
             int scanReadRpcTimeout,
             int scannerTimeout,
             int primaryOperationTimeout,
             ConnectionConfiguration connectionConfiguration,
             Map<String,byte[]> requestAttributes)Create a new ClientScanner for the specified table Note that the passed  Scan's start
 row maybe changed changed. | 
| ClientSimpleScanner(org.apache.hadoop.conf.Configuration configuration,
                   Scan scan,
                   Scan scanForMetrics,
                   TableName name,
                   ClusterConnection connection,
                   RpcRetryingCallerFactory rpcCallerFactory,
                   RpcControllerFactory rpcControllerFactory,
                   ExecutorService pool,
                   int scanReadRpcTimeout,
                   int scannerTimeout,
                   int replicaCallTimeoutMicroSecondScan,
                   ConnectionConfiguration connectionConfiguration,
                   Map<String,byte[]> requestAttributes) | 
| ImmutableScan(Scan scan)Create Immutable instance of Scan from given Scan object | 
| ReversedClientScanner(org.apache.hadoop.conf.Configuration conf,
                     Scan scan,
                     Scan scanForMetrics,
                     TableName tableName,
                     ClusterConnection connection,
                     RpcRetryingCallerFactory rpcFactory,
                     RpcControllerFactory controllerFactory,
                     ExecutorService pool,
                     int scanReadRpcTimeout,
                     int scannerTimeout,
                     int primaryOperationTimeout,
                     ConnectionConfiguration connectionConfiguration,
                     Map<String,byte[]> requestAttributes)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,
                       RpcControllerFactory rpcFactory,
                       int replicaId,
                       Map<String,byte[]> requestAttributes) | 
| 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,
               int id,
               Map<String,byte[]> requestAttributes) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableOperationSpanBuilder | TableOperationSpanBuilder. setOperation(Scan scan) | 
| 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.Scan | ProtobufUtil. toScan(Scan scan)Convert a client Scan to a protocol buffer Scan | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | QuotaTableUtil. makeQuotaSnapshotScan()Creates a  Scanwhich returns only quota snapshots from the quota table. | 
| static Scan | QuotaTableUtil. makeQuotaSnapshotScanForTable(TableName tn)Creates a  Scanwhich returns onlySpaceQuotaSnapshotfrom the quota table for a
 specific table. | 
| static Scan | QuotaTableUtil. makeScan(QuotaFilter filter) | 
| Constructor and Description | 
|---|
| QuotaRetriever(Connection conn,
              Scan scan) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | ProtobufUtil. toScan(org.apache.hadoop.hbase.shaded.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.shaded.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.shaded.protobuf.generated.ClientProtos.Scan | ProtobufUtil. toScan(Scan scan)Convert a client Scan to a protocol buffer Scan | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.