See: Description
| Interface | Description | 
|---|---|
| VisibilityExpressionResolver | Interface to convert visibility expressions into Tags for storing along with Cells in HFiles. | 
| Class | Description | 
|---|---|
| CellCounter | A job with a a map and reduce phase to count cells in a table. | 
| CellCounter.CellCounterMapper | Mapper that runs the count. | 
| CellCounter.IntSumReducer<Key> | |
| CellCreator | Facade to create Cells for HFileOutputFormat. | 
| CellSerialization | Use to specify the type of serialization for the mappers and reducers | 
| CellSerialization.CellDeserializer | |
| CellSerialization.CellSerializer | |
| CellSortReducer | Emits sorted Cells. | 
| CopyTable | Tool used to copy a table to another one which can be on a different setup. | 
| DefaultVisibilityExpressionResolver | This implementation creates tags by expanding expression using label ordinal. | 
| Driver | Driver for hbase mapreduce jobs. | 
| Export | Export an HBase table. | 
| ExportUtils | Some helper methods are used by  Exportand org.apache.hadoop.hbase.coprocessor.Export (in hbase-endpooint). | 
| GroupingTableMapper | Extract grouping columns from input record. | 
| HashTable | |
| HashTable.HashMapper | |
| HashTable.ResultHasher | |
| HashTable.TableHash | |
| HFileInputFormat | Simple MR input format for HFiles. | 
| HFileInputFormat.HFileRecordReader | Record reader for HFiles. | 
| HFileOutputFormat2 | Writes HFiles. | 
| HFileOutputFormat2.TableInfo | |
| HFileOutputFormat2.WriterLength | |
| HRegionPartitioner<KEY,VALUE> | This is used to partition the output keys into groups of keys. | 
| IdentityTableMapper | Pass the given key and record as-is to the reduce phase. | 
| IdentityTableReducer | |
| Import | Import data written by  Export. | 
| Import.CellImporter | A mapper that just writes out KeyValues. | 
| Import.CellReducer | |
| Import.CellSortImporter | |
| Import.CellWritableComparable | |
| Import.CellWritableComparable.CellWritableComparator | |
| Import.CellWritableComparablePartitioner | |
| Import.Importer | Write table content out to files in hdfs. | 
| Import.KeyValueImporter | Deprecated Use  Import.CellImporter. | 
| Import.KeyValueReducer | Deprecated Use  Import.CellReducer. | 
| Import.KeyValueSortImporter | Deprecated | 
| Import.KeyValueWritableComparable | |
| Import.KeyValueWritableComparable.KeyValueWritableComparator | |
| Import.KeyValueWritableComparablePartitioner | Deprecated | 
| ImportTsv | Tool to import data from a TSV file. | 
| ImportTsv.TsvParser | |
| IndexBuilder | Example map/reduce job to construct index tables that can be used to quickly
 find a row based on the value of a column. | 
| IndexBuilder.Map | Internal Mapper to be run by Hadoop. | 
| JarFinder | Finds the Jar for a class. | 
| JobUtil | Utility methods to interact with a job. | 
| KeyValueSerialization | Deprecated Use  CellSerialization. | 
| KeyValueSerialization.KeyValueDeserializer | |
| KeyValueSerialization.KeyValueSerializer | |
| KeyValueSortReducer | Deprecated Use  CellSortReducer. | 
| LoadIncrementalHFiles | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| LoadIncrementalHFiles.LoadQueueItem | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| MultiTableHFileOutputFormat | Create 3 level tree directory, first level is using table name as parent
 directory and then use family name as child directory, and all related HFiles
 for one family are under child directory
 -tableName1
     -columnFamilyName1
     -columnFamilyName2
         -HFiles
 -tableName2
     -columnFamilyName1
         -HFiles
     -columnFamilyName2 | 
| MultiTableInputFormat | Convert HBase tabular data from multiple scanners into a format that
 is consumable by Map/Reduce. | 
| MultiTableInputFormatBase | A base for  MultiTableInputFormats. | 
| MultiTableOutputFormat | 
 Hadoop output format that writes to one or more HBase tables. | 
| MultiTableOutputFormat.MultiTableRecordWriter | Record writer for outputting to multiple HTables. | 
| MultiTableSnapshotInputFormat | MultiTableSnapshotInputFormat generalizes
  TableSnapshotInputFormatallowing a MapReduce job to run over one or more table snapshots, with one or more scans
 configured for each. | 
| MultiTableSnapshotInputFormatImpl | Shared implementation of mapreduce code over multiple table snapshots. | 
| MultithreadedTableMapper<K2,V2> | Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper | 
| MutationSerialization | |
| MutationSerialization.MutationDeserializer | |
| MutationSerialization.MutationSerializer | |
| PutCombiner<K> | Combine Puts. | 
| PutSortReducer | Emits sorted Puts. | 
| RegionSizeCalculator | Computes size of each region for given table and given column families. | 
| ResultSerialization | |
| ResultSerialization.Result94Deserializer | The following deserializer class is used to load exported file of 0.94 | 
| ResultSerialization.ResultDeserializer | |
| ResultSerialization.ResultSerializer | |
| RowCounter | A job with a just a map phase to count rows. | 
| RowCounter.RowCounterMapper | Mapper that runs the count. | 
| SampleUploader | Sample Uploader MapReduce | 
| SampleUploader.Uploader | |
| SimpleTotalOrderPartitioner<VALUE> | A partitioner that takes start and end keys and uses bigdecimal to figure
 which reduce a key belongs to. | 
| SyncTable | |
| SyncTable.SyncMapper | |
| SyncTable.SyncMapper.CellScanner | |
| TableInputFormat | Convert HBase tabular data into a format that is consumable by Map/Reduce. | 
| TableInputFormatBase | A base for  TableInputFormats. | 
| TableMapper<KEYOUT,VALUEOUT> | Extends the base  Mapperclass to add the required input key
 and value classes. | 
| TableMapReduceUtil | Utility for  TableMapperandTableReducer | 
| TableOutputCommitter | Small committer class that does not do anything. | 
| TableOutputFormat<KEY> | Convert Map/Reduce output and write it to an HBase table. | 
| TableRecordReader | Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
 pairs. | 
| TableRecordReaderImpl | Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
 pairs. | 
| TableReducer<KEYIN,VALUEIN,KEYOUT> | Extends the basic  Reducerclass to add the required key and
 value input/output classes. | 
| TableSnapshotInputFormat | TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot. | 
| TableSnapshotInputFormat.TableSnapshotRegionRecordReader | |
| TableSnapshotInputFormat.TableSnapshotRegionSplit | |
| TableSnapshotInputFormatImpl | Hadoop MR API-agnostic implementation for mapreduce over table snapshots. | 
| TableSnapshotInputFormatImpl.InputSplit | Implementation class for InputSplit logic common between mapred and mapreduce. | 
| TableSnapshotInputFormatImpl.RecordReader | Implementation class for RecordReader logic common between mapred and mapreduce. | 
| TableSplit | A table split corresponds to a key range (low, high) and an optional scanner. | 
| TextSortReducer | Emits Sorted KeyValues. | 
| TsvImporterMapper | Write table content out to files in hdfs. | 
| TsvImporterTextMapper | Write table content out to map output files. | 
| WALInputFormat | Simple  InputFormatforWALfiles. | 
| WALInputFormat.WALKeyRecordReader | handler for non-deprecated WALKey version. | 
| WALInputFormat.WALRecordReader<K extends WALKey> | RecordReaderfor anWALfile. | 
| WALInputFormat.WALSplit | InputSplitforWALfiles. | 
| WALPlayer | A tool to replay WAL files as a M/R job. | 
| WALPlayer.WALCellMapper | A mapper that just writes out Cells. | 
| WALPlayer.WALKeyValueMapper | Deprecated | 
| WALPlayer.WALMapper | A mapper that writes out  Mutationto be directly applied to
 a running HBase instance. | 
| Enum | Description | 
|---|---|
| CellCounter.CellCounterMapper.Counters | Counter enumeration to count the actual rows. | 
| RowCounter.RowCounterMapper.Counters | Counter enumeration to count the actual rows. | 
| SyncTable.SyncMapper.Counter | |
| TableSplit.Version | 
| Exception | Description | 
|---|---|
| ImportTsv.TsvParser.BadTsvLineException | 
See HBase and MapReduce in the HBase Reference Guide for mapreduce over hbase documentation.
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.