| Package | Description |
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
| 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.test |
| Class and Description |
|---|
| TableMapper
Extends the base
Mapper class to add the required input key
and value classes. |
| Class and Description |
|---|
| MultiTableInputFormatTestBase.ScanMapper
Pass the key and value to reducer.
|
| MultiTableInputFormatTestBase.ScanReducer
Checks the last and first keys seen against the scanner boundaries.
|
| TableMapper
Extends the base
Mapper class to add the required input key
and value classes. |
| TableSnapshotInputFormatImpl.InputSplit
Implementation class for InputSplit logic common between mapred and mapreduce.
|
| TableSnapshotInputFormatTestBase |
| TestMultiTableSnapshotInputFormat |
| TestTableMapReduceBase
A base class for a test Map/Reduce job over HBase tables.
|
| Class and Description |
|---|
| CellCreator
Facade to create Cells for HFileOutputFormat.
|
| CellSerialization.CellDeserializer |
| CellSerialization.CellSerializer |
| HashTable.TableHash |
| HashTable.TableHash.Reader |
| HFileOutputFormat2
Writes HFiles.
|
| Import.CellWritableComparable |
| Import.KeyValueWritableComparable |
| ImportTsv.TsvParser |
| ImportTsv.TsvParser.BadTsvLineException |
| IntegrationTestBulkLoad.LinkChain
Writable used as the value emitted from a pass over the hbase table.
|
| IntegrationTestBulkLoad.LinkKey
Writable class used as the key to group links in the linked list.
|
| KeyValueSerialization.KeyValueDeserializer
Deprecated.
|
| KeyValueSerialization.KeyValueSerializer
Deprecated.
|
| LoadIncrementalHFiles.LoadQueueItem
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
LoadIncrementalHFiles.LoadQueueItem instead. |
| MultiTableInputFormatBase
A base for
MultiTableInputFormats. |
| MultiTableInputFormatTestBase
Base set of tests and setup for input formats touching multiple tables.
|
| SyncTable.SyncMapper.Counter |
| TableInputFormatBase
A base for
TableInputFormats. |
| TableMapper
Extends the base
Mapper class to add the required input key
and value classes. |
| TableRecordReader
Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
pairs.
|
| TableReducer
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.
|
| TableSnapshotInputFormatImpl.InputSplit
Implementation class for InputSplit logic common between mapred and mapreduce.
|
| TableSplit
A table split corresponds to a key range (low, high) and an optional scanner.
|
| TestMultiTableSnapshotInputFormatImpl.ScanWithEquals |
| TestTableInputFormatScanBase
Tests various scan start and stop row scenarios.
|
| TestTableSnapshotInputFormat.TestTableSnapshotCounters |
| TsvImporterMapper
Write table content out to files in hdfs.
|
| VisibilityExpressionResolver
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
|
| Class and Description |
|---|
| TableMapper
Extends the base
Mapper class to add the required input key
and value classes. |
| Class and Description |
|---|
| TableMapper
Extends the base
Mapper class to add the required input key
and value classes. |
| WALPlayer.WALMapper
A mapper that writes out
Mutation to be directly applied to a running HBase instance. |