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.
|
CellCreator |
Facade to create Cells for HFileOutputFormat.
|
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.
|
GroupingTableMapper |
Extract grouping columns from input record.
|
HashTable | |
HashTable.HashMapper | |
HashTable.TableHash | |
HFileOutputFormat | Deprecated
use
HFileOutputFormat2 instead. |
HFileOutputFormat2 |
Writes HFiles.
|
HLogInputFormat | Deprecated
use
WALInputFormat |
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.Importer |
Write table content out to files in hdfs.
|
Import.KeyValueImporter |
A mapper that just writes out KeyValues.
|
Import.KeyValueReducer | |
Import.KeyValueSortImporter | |
Import.KeyValueWritableComparable | |
Import.KeyValueWritableComparable.KeyValueWritableComparator | |
Import.KeyValueWritableComparablePartitioner | |
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 | |
KeyValueSerialization.KeyValueDeserializer | |
KeyValueSerialization.KeyValueSerializer | |
KeyValueSortReducer |
Emits sorted KeyValues.
|
LoadIncrementalHFiles |
Tool to load the output of HFileOutputFormat into an existing table.
|
LoadIncrementalHFiles.LoadQueueItem |
Represents an HFile waiting to be loaded.
|
MultiTableInputFormat |
Convert HBase tabular data from multiple scanners into a format that
is consumable by Map/Reduce.
|
MultiTableInputFormatBase |
A base for
MultiTableInputFormat s. |
MultiTableOutputFormat |
Hadoop output format that writes to one or more HBase tables.
|
MultiTableOutputFormat.MultiTableRecordWriter |
Record writer for outputting to multiple HTables.
|
MultiTableSnapshotInputFormat |
MultiTableSnapshotInputFormat generalizes
TableSnapshotInputFormat
allowing 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 | |
PutCombiner<K> |
Combine Puts.
|
PutSortReducer |
Emits sorted Puts.
|
ResultSerialization | |
RowCounter |
A job with a just a map phase to count rows.
|
SampleUploader |
Sample Uploader MapReduce
|
SimpleTotalOrderPartitioner<VALUE> |
A partitioner that takes start and end keys and uses bigdecimal to figure
which reduce a key belongs to.
|
SyncTable | |
SyncTable.SyncMapper | |
TableInputFormat |
Convert HBase tabular data into a format that is consumable by Map/Reduce.
|
TableInputFormatBase |
A base for
TableInputFormat s. |
TableMapper<KEYOUT,VALUEOUT> |
Extends the base
Mapper class to add the required input key
and value classes. |
TableMapReduceUtil |
Utility for
TableMapper and TableReducer |
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
Reducer class to add the required key and
value input/output classes. |
TableSnapshotInputFormat |
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
|
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
InputFormat for WAL files. |
WALPlayer |
A tool to replay WAL files as a M/R job.
|
WALPlayer.WALMapper |
A mapper that writes out
Mutation to be directly applied to
a running HBase instance. |
Enum | Description |
---|---|
SyncTable.SyncMapper.Counter |
Exception | Description |
---|---|
ImportTsv.TsvParser.BadTsvLineException |
See HBase and MapReduce in the HBase Reference Guide for mapreduce over hbase documentation.
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.