Package org.apache.hadoop.hbase.mapreduce
package org.apache.hadoop.hbase.mapreduce
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
See HBase and MapReduce in the HBase Reference Guide for mapreduce over hbase documentation.
-
ClassDescriptionA job with a a map and reduce phase to count cells in a table.Mapper that runs the count.Counter enumeration to count the actual rows.Facade to create Cells for HFileOutputFormat.Use to specify the type of serialization for the mappers and reducersEmits sorted Cells.Tool used to copy a table to another one which can be on a different setup.This implementation creates tags by expanding expression using label ordinal.Driver for hbase mapreduce jobs.Export an HBase table.Some helper methods are used by
Exportand org.apache.hadoop.hbase.coprocessor.Export (in hbase-endpooint).Similar to CellSerialization, but includes the sequenceId from an ExtendedCell.Extract grouping columns from input record.Simple MR input format for HFiles.Record reader for HFiles.Writes HFiles.HRegionPartitioner<KEY,VALUE> This is used to partition the output keys into groups of keys.Pass the given key and record as-is to the reduce phase.Import data written byExport.A mapper that just writes out KeyValues.Write table content out to files in hdfs.Deprecated.Deprecated.UseImport.CellReducer.Deprecated.Deprecated.Tool to import data from a TSV file.Example map/reduce job to construct index tables that can be used to quickly find a row based on the value of a column.Internal Mapper to be run by Hadoop.Finds the Jar for a class.Utility methods to interact with a job.Deprecated.UseCellSerialization.Deprecated.UseCellSortReducer.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.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 -columnFamilyName2Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.A base forMultiTableInputFormats.Hadoop output format that writes to one or more HBase tables.Record writer for outputting to multiple HTables.MultiTableSnapshotInputFormat generalizesTableSnapshotInputFormatallowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.Shared implementation of mapreduce code over multiple table snapshots.MultithreadedTableMapper<K2,V2> Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapperPutCombiner<K>Combine Puts.Emits sorted Puts.Computes size of each region for given table and given column families.The following deserializer class is used to load exported file of 0.94Process the return from super-classTableInputFormat(TIF) so as to undo any clumping ofInputSplits around RegionServers.A job with a just a map phase to count rows.Mapper that runs the count.Counter enumeration to count the actual rows.Sample Uploader MapReduceSimpleTotalOrderPartitioner<VALUE>A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.Convert HBase tabular data into a format that is consumable by Map/Reduce.A base forTableInputFormats.TableMapper<KEYOUT,VALUEOUT> Extends the baseMapperclass to add the required input key and value classes.Utility forTableMapperandTableReducerSmall committer class that does not do anything.TableOutputFormat<KEY>Convert Map/Reduce output and write it to an HBase table.Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.TableReducer<KEYIN,VALUEIN, KEYOUT> Extends the basicReducerclass to add the required key and value input/output classes.TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.Hadoop MR API-agnostic implementation for mapreduce over table snapshots.Implementation class for InputSplit logic common between mapred and mapreduce.Implementation class for RecordReader logic common between mapred and mapreduce.A table split corresponds to a key range (low, high) and an optional scanner.Emits Sorted KeyValues.Write table content out to files in hdfs.Write table content out to map output files.Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.SimpleInputFormatforWALfiles.handler for non-deprecated WALKey version.WALInputFormat.WALRecordReader<K extends WALKey>RecordReaderfor anWALfile.InputSplitforWALfiles.A tool to replay WAL files as a M/R job.Enum for map metrics.A mapper that just writes out Cells.Deprecated.A mapper that writes outMutationto be directly applied to a running HBase instance.
Import.CellImporter.