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.
-
ClassDescriptionorg.apache.hadoop.hbase.mapreduce.CellCounterA job with a a map and reduce phase to count cells in a table.org.apache.hadoop.hbase.mapreduce.CellCreatorFacade to create Cells for HFileOutputFormat.org.apache.hadoop.hbase.mapreduce.CellSerializationorg.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializerorg.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializerorg.apache.hadoop.hbase.mapreduce.CellSortReducerEmits sorted Cells.org.apache.hadoop.hbase.mapreduce.CopyTableTool used to copy a table to another one which can be on a different setup.org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolverThis implementation creates tags by expanding expression using label ordinal.org.apache.hadoop.hbase.mapreduce.DriverDriver for hbase mapreduce jobs.org.apache.hadoop.hbase.mapreduce.ExportExport an HBase table.org.apache.hadoop.hbase.mapreduce.ExportUtilsSome helper methods are used by
Export
and org.apache.hadoop.hbase.coprocessor.Export (in hbase-endpooint).org.apache.hadoop.hbase.mapreduce.ExtendedCellSerializationSimilar to CellSerialization, but includes the sequenceId from an ExtendedCell.org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializerorg.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializerorg.apache.hadoop.hbase.mapreduce.GroupingTableMapperExtract grouping columns from input record.org.apache.hadoop.hbase.mapreduce.HashTableorg.apache.hadoop.hbase.mapreduce.HashTable.HashMapperorg.apache.hadoop.hbase.mapreduce.HashTable.TableHashorg.apache.hadoop.hbase.mapreduce.HFileInputFormatSimple MR input format for HFiles.org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2Writes HFiles.org.apache.hadoop.hbase.mapreduce.HRegionPartitioner<KEY,VALUE> This is used to partition the output keys into groups of keys.org.apache.hadoop.hbase.mapreduce.IdentityTableMapperPass the given key and record as-is to the reduce phase.org.apache.hadoop.hbase.mapreduce.IdentityTableReducerConvenience class that simply writes all values (which must bePut
orDelete
instances) passed to it out to the configured HBase table.org.apache.hadoop.hbase.mapreduce.ImportImport data written byExport
.org.apache.hadoop.hbase.mapreduce.Import.CellImporterA mapper that just writes out KeyValues.org.apache.hadoop.hbase.mapreduce.Import.CellReducerorg.apache.hadoop.hbase.mapreduce.Import.CellSortImporterorg.apache.hadoop.hbase.mapreduce.Import.CellWritableComparableorg.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparatororg.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitionerorg.apache.hadoop.hbase.mapreduce.Import.ImporterWrite table content out to files in hdfs.org.apache.hadoop.hbase.mapreduce.ImportTsvTool to import data from a TSV file.org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParserorg.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineExceptionorg.apache.hadoop.hbase.mapreduce.IndexBuilderExample map/reduce job to construct index tables that can be used to quickly find a row based on the value of a column.org.apache.hadoop.hbase.mapreduce.IndexBuilder.MapInternal Mapper to be run by Hadoop.org.apache.hadoop.hbase.mapreduce.JarFinderFinds the Jar for a class.org.apache.hadoop.hbase.mapreduce.JobUtilUtility methods to interact with a job.org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormatCreate 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 -columnFamilyName2org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatConvert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBaseA base forMultiTableInputFormat
s.org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormatHadoop output format that writes to one or more HBase tables.org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriterRecord writer for outputting to multiple HTables.org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatMultiTableSnapshotInputFormat generalizesTableSnapshotInputFormat
allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImplShared implementation of mapreduce code over multiple table snapshots.org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper<K2,V2> Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapperorg.apache.hadoop.hbase.mapreduce.MutationSerializationorg.apache.hadoop.hbase.mapreduce.PutCombiner<K>Combine Puts.org.apache.hadoop.hbase.mapreduce.PutSortReducerEmits sorted Puts.org.apache.hadoop.hbase.mapreduce.RegionSizeCalculatorComputes size of each region for given table and given column families.org.apache.hadoop.hbase.mapreduce.ResultSerializationorg.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormatProcess the return from super-classTableInputFormat
(TIF) so as to undo any clumping ofInputSplit
s around RegionServers.org.apache.hadoop.hbase.mapreduce.RowCounterA job with a just a map phase to count rows.org.apache.hadoop.hbase.mapreduce.SampleUploaderSample Uploader MapReduceorg.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner<VALUE>A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.org.apache.hadoop.hbase.mapreduce.SyncTableorg.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapperorg.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counterorg.apache.hadoop.hbase.mapreduce.TableInputFormatConvert HBase tabular data into a format that is consumable by Map/Reduce.org.apache.hadoop.hbase.mapreduce.TableInputFormatBaseA base forTableInputFormat
s.org.apache.hadoop.hbase.mapreduce.TableMapper<KEYOUT,VALUEOUT> Extends the baseMapper
class to add the required input key and value classes.org.apache.hadoop.hbase.mapreduce.TableMapReduceUtilUtility forTableMapper
andTableReducer
org.apache.hadoop.hbase.mapreduce.TableOutputCommitterSmall committer class that does not do anything.org.apache.hadoop.hbase.mapreduce.TableOutputFormat<KEY>Convert Map/Reduce output and write it to an HBase table.org.apache.hadoop.hbase.mapreduce.TableRecordReaderIterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.org.apache.hadoop.hbase.mapreduce.TableRecordReaderImplIterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.org.apache.hadoop.hbase.mapreduce.TableReducer<KEYIN,VALUEIN, KEYOUT> Extends the basicReducer
class to add the required key and value input/output classes.org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatTableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplitorg.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImplHadoop MR API-agnostic implementation for mapreduce over table snapshots.org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplitImplementation class for InputSplit logic common between mapred and mapreduce.org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReaderImplementation class for RecordReader logic common between mapred and mapreduce.org.apache.hadoop.hbase.mapreduce.TableSplitA table split corresponds to a key range (low, high) and an optional scanner.org.apache.hadoop.hbase.mapreduce.TextSortReducerEmits Sorted KeyValues.org.apache.hadoop.hbase.mapreduce.TsvImporterMapperWrite table content out to files in hdfs.org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapperWrite table content out to map output files.org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolverInterface to convert visibility expressions into Tags for storing along with Cells in HFiles.org.apache.hadoop.hbase.mapreduce.WALInputFormatSimpleInputFormat
forWAL
files.org.apache.hadoop.hbase.mapreduce.WALPlayerA tool to replay WAL files as a M/R job.org.apache.hadoop.hbase.mapreduce.WALPlayer.CounterEnum for map metrics.org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapperA mapper that writes outMutation
to be directly applied to a running HBase instance.