| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.mapreduce.replication | |
| org.apache.hadoop.hbase.mob.mapreduce | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) static class  | CellCounter.CellCounterMapperMapper that runs the count. | 
| class  | GroupingTableMapperExtract grouping columns from input record. | 
| static class  | HashTable.HashMapper | 
| class  | IdentityTableMapperPass the given key and record as-is to the reduce phase. | 
| static class  | Import.CellImporterA mapper that just writes out KeyValues. | 
| static class  | Import.CellSortImporter | 
| static class  | Import.ImporterWrite table content out to files in hdfs. | 
| static class  | Import.KeyValueImporterDeprecated. 
 Use  Import.CellImporter. Will be removed from 3.0 onwards | 
| static class  | Import.KeyValueSortImporterDeprecated. 
 Use  Import.CellSortImporter. Will be removed from 3.0 onwards | 
| class  | MultithreadedTableMapper<K2,V2>Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper | 
| (package private) static class  | RowCounter.RowCounterMapperMapper that runs the count. | 
| static class  | SyncTable.SyncMapper | 
| Modifier and Type | Method and Description | 
|---|---|
| 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. 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(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(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 | 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,
                          RegionSplitter.SplitAlgorithm splitAlgo,
                          int numSplitsPerRegion)Sets up the job for reading from a table snapshot. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | VerifyReplication.VerifierMap-only comparator for 2 tables | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | MobRefReporter.MobRefMapper | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.