| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.mapred | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| 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. | 
| static Scan | Scan. createScanFromCursor(Cursor cursor)Create a new Scan with a cursor. | 
| Scan | Scan. readAllVersions()Get all available versions. | 
| Scan | Scan. readVersions(int versions)Get up to the specified number of versions of each column. | 
| Scan | Scan. setACL(Map<String,org.apache.hadoop.hbase.security.access.Permission> perms) | 
| Scan | Scan. setACL(String user,
      org.apache.hadoop.hbase.security.access.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 | Scan. setAsyncPrefetch(boolean asyncPrefetch) | 
| Scan | Scan. setAttribute(String name,
            byte[] value) | 
| Scan | Scan. setAuthorizations(org.apache.hadoop.hbase.security.visibility.Authorizations authorizations) | 
| Scan | Scan. setBatch(int batch)Set the maximum number of cells 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. setLimit(int limit)Set the limit of rows for this scan. | 
| Scan | Scan. setLoadColumnFamiliesOnDemand(boolean value) | 
| 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()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 | Scan. setOneRowLimit()Call this when you only want to get one row. | 
| Scan | Scan. setPriority(int priority) | 
| Scan | Scan. setRaw(boolean raw)Enable/disable "raw" mode for this scan. | 
| Scan | Scan. setReadType(Scan.ReadType readType)Set the read type 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)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 | 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. 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 | Scan. setTimestamp(long timestamp)Get versions of columns with the specified 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 | Scan. withStartRow(byte[] startRow)Set the start row of the scan. | 
| Scan | Scan. withStartRow(byte[] startRow,
            boolean inclusive)Set the start row of the scan. | 
| Scan | Scan. withStopRow(byte[] stopRow)Set the stop row of the scan. | 
| Scan | Scan. withStopRow(byte[] stopRow,
           boolean inclusive)Set the stop row of the scan. | 
| Modifier and Type | Method and Description | 
|---|---|
| default ResultScanner | Table. getScanner(Scan scan)Returns a scanner on the current table as specified by the  Scanobject. | 
| ResultScanner | AsyncTable. getScanner(Scan scan)Returns a scanner on the current table as specified by the  Scanobject. | 
| 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. | 
| Constructor and Description | 
|---|
| Scan(Scan scan)Creates a new instance of this class while copying all values. | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | TableMapReduceUtil. initMultiTableSnapshotMapperJob(Map<String,Collection<Scan>> snapshotScans,
                               Class<? extends TableMap> mapper,
                               Class<?> outputKeyClass,
                               Class<?> outputValueClass,
                               org.apache.hadoop.mapred.JobConf job,
                               boolean addDependencyJars,
                               org.apache.hadoop.fs.Path tmpRestoreDir)Sets up the job for reading from one or more multiple table snapshots, with one or more scans
 per snapshot. | 
| static void | MultiTableSnapshotInputFormat. setInput(org.apache.hadoop.conf.Configuration conf,
        Map<String,Collection<Scan>> snapshotScans,
        org.apache.hadoop.fs.Path restoreDir) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Scan | TableMapReduceUtil. convertStringToScan(String base64)Converts the given Base64 string back into a Scan instance. | 
| static Scan | TableInputFormat. createScanFromConfiguration(org.apache.hadoop.conf.Configuration conf)Sets up a  Scaninstance, applying settings from the configuration property
 constants defined inTableInputFormat. | 
| Scan | TableSplit. getScan()Returns a Scan object from the stored string representation. | 
| Scan | TableInputFormatBase. getScan()Gets the scan defining the actual details like columns etc. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<Scan> | MultiTableInputFormatBase. getScans()Allows subclasses to get the list of  Scanobjects. | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | TableInputFormat. addColumns(Scan scan,
          byte[][] columns)Adds an array of columns specified using old format, family:qualifier. | 
| static String | TableMapReduceUtil. convertScanToString(Scan scan)Writes the given scan into a Base64 encoded string. | 
| static void | IdentityTableMapper. initJob(String table,
       Scan scan,
       Class<? extends TableMapper> mapper,
       org.apache.hadoop.mapreduce.Job job)Use this before submitting a TableMap job. | 
| static void | GroupingTableMapper. initJob(String table,
       Scan scan,
       String groupColumns,
       Class<? extends TableMapper> mapper,
       org.apache.hadoop.mapreduce.Job job)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(byte[] table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(byte[] table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(byte[] table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars,
                  Class<? extends org.apache.hadoop.mapreduce.InputFormat> inputFormatClass)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(String table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(String table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(String table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars,
                  boolean initCredentials,
                  Class<? extends org.apache.hadoop.mapreduce.InputFormat> inputFormatClass)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(String table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars,
                  Class<? extends org.apache.hadoop.mapreduce.InputFormat> inputFormatClass)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(TableName table,
                  Scan scan,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job)Use this before submitting a TableMap job. | 
| static void | TableMapReduceUtil. initTableSnapshotMapperJob(String snapshotName,
                          Scan scan,
                          Class<? extends TableMapper> mapper,
                          Class<?> outputKeyClass,
                          Class<?> outputValueClass,
                          org.apache.hadoop.mapreduce.Job job,
                          boolean addDependencyJars,
                          org.apache.hadoop.fs.Path tmpRestoreDir)Sets up the job for reading from a table snapshot. | 
| static void | TableMapReduceUtil. initTableSnapshotMapperJob(String snapshotName,
                          Scan scan,
                          Class<? extends TableMapper> mapper,
                          Class<?> outputKeyClass,
                          Class<?> outputValueClass,
                          org.apache.hadoop.mapreduce.Job job,
                          boolean addDependencyJars,
                          org.apache.hadoop.fs.Path tmpRestoreDir,
                          org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm splitAlgo,
                          int numSplitsPerRegion)Sets up the job for reading from a table snapshot. | 
| void | TableRecordReaderImpl. setScan(Scan scan)Sets the scan defining the actual details like columns etc. | 
| void | TableRecordReader. setScan(Scan scan)Sets the scan defining the actual details like columns etc. | 
| void | TableInputFormatBase. setScan(Scan scan)Sets the scan defining the actual details like columns etc. | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | TableMapReduceUtil. initMultiTableSnapshotMapperJob(Map<String,Collection<Scan>> snapshotScans,
                               Class<? extends TableMapper> mapper,
                               Class<?> outputKeyClass,
                               Class<?> outputValueClass,
                               org.apache.hadoop.mapreduce.Job job,
                               boolean addDependencyJars,
                               org.apache.hadoop.fs.Path tmpRestoreDir)Sets up the job for reading from one or more table snapshots, with one or more scans
 per snapshot. | 
| static void | TableMapReduceUtil. initTableMapperJob(List<Scan> scans,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job)Use this before submitting a Multi TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(List<Scan> scans,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars)Use this before submitting a Multi TableMap job. | 
| static void | TableMapReduceUtil. initTableMapperJob(List<Scan> scans,
                  Class<? extends TableMapper> mapper,
                  Class<?> outputKeyClass,
                  Class<?> outputValueClass,
                  org.apache.hadoop.mapreduce.Job job,
                  boolean addDependencyJars,
                  boolean initCredentials)Use this before submitting a Multi TableMap job. | 
| static void | MultiTableSnapshotInputFormat. setInput(org.apache.hadoop.conf.Configuration configuration,
        Map<String,Collection<Scan>> snapshotScans,
        org.apache.hadoop.fs.Path tmpRestoreDir) | 
| protected void | MultiTableInputFormatBase. setScans(List<Scan> scans)Allows subclasses to set the list of  Scanobjects. | 
| Constructor and Description | 
|---|
| TableSplit(TableName tableName,
          Scan scan,
          byte[] startRow,
          byte[] endRow,
          String location)Creates a new instance while assigning all variables. | 
| TableSplit(TableName tableName,
          Scan scan,
          byte[] startRow,
          byte[] endRow,
          String location,
          long length)Creates a new instance while assigning all variables. | 
| TableSplit(TableName tableName,
          Scan scan,
          byte[] startRow,
          byte[] endRow,
          String location,
          String encodedRegionName,
          long length)Creates a new instance while assigning all variables. | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.