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.
|
| HadoopSecurityEnabledUserProviderForTesting |
A
UserProvider that always says hadoop security is enabled, regardless of the underlying
configuration. |
| HashTable | |
| HashTable.HashMapper | |
| HashTable.TableHash | |
| HFileInputFormat |
Simple MR input format for HFiles.
|
| 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.
|
| 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.
|
| IntegrationTestBulkLoad |
Test Bulk Load and MR on a distributed cluster.
|
| IntegrationTestBulkLoad.CompositeKeyComparator |
Comparator used to order linkKeys so that they are passed to a reducer in order.
|
| IntegrationTestBulkLoad.EmptySplit | |
| IntegrationTestBulkLoad.FixedRecordReader<K,V> | |
| IntegrationTestBulkLoad.ITBulkLoadInputFormat | |
| IntegrationTestBulkLoad.LinkChain |
Writable used as the value emitted from a pass over the hbase table.
|
| IntegrationTestBulkLoad.LinkedListCheckingMapper |
Mapper to pass over the table.
|
| IntegrationTestBulkLoad.LinkedListCheckingReducer |
Class that does the actual checking of the links.
|
| IntegrationTestBulkLoad.LinkedListCreationMapper |
Mapper that creates a linked list of KeyValues.
|
| IntegrationTestBulkLoad.LinkKey |
Writable class used as the key to group links in the linked list.
|
| IntegrationTestBulkLoad.NaturalKeyGroupingComparator |
Comparator used to figure out if a linkKey should be grouped together.
|
| IntegrationTestBulkLoad.NaturalKeyPartitioner |
Class to figure out what partition to send a link in the chain to.
|
| IntegrationTestBulkLoad.SlowMeCoproScanOperations | |
| IntegrationTestImportTsv |
Validate ImportTsv + LoadIncrementalHFiles on a distributed cluster.
|
| IntegrationTestTableMapReduceUtil |
Test that we add tmpjars correctly including the named dependencies.
|
| IntegrationTestTableSnapshotInputFormat |
An integration test to test
TableSnapshotInputFormat which enables
reading directly from snapshot files without going through hbase servers. |
| 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.
|
| MapreduceTestingShim |
This class provides shims for HBase to interact with the Hadoop 1.0.x and the
Hadoop 0.23.x series.
|
| 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.
|
| MultithreadedTableMapper<K2,V2> |
Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper
|
| MutationSerialization | |
| NMapInputFormat |
Input format that creates a configurable number of map tasks
each provided with a single row of NullWritables.
|
| 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
TableInputFormats. |
| 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.
|
| TableSnapshotInputFormatTestBase | |
| TableSplit |
A table split corresponds to a key range (low, high) and an optional scanner.
|
| TestCellCounter | |
| TestCopyTable |
Basic test for the CopyTable M/R tool
|
| TestGroupingTableMapper | |
| TestHashTable |
Basic test for the HashTable M/R tool
|
| TestHFileOutputFormat |
Simple test for
KeyValueSortReducer and HFileOutputFormat. |
| TestHFileOutputFormat2 |
Simple test for
CellSortReducer and HFileOutputFormat2. |
| TestHLogRecordReader |
JUnit tests for the record reader in HLogInputFormat
|
| TestHRegionPartitioner | |
| TestImportExport |
Tests the table import and table export MR job functionality
|
| TestImportTsv | |
| TestImportTsvParser |
Tests for
ImportTsv.TsvParser. |
| TestImportTSVWithOperationAttributes | |
| TestImportTSVWithOperationAttributes.OperationAttributesTestController | |
| TestImportTSVWithTTLs | |
| TestImportTSVWithTTLs.TTLCheckingObserver | |
| TestImportTSVWithVisibilityLabels | |
| TestJarFinder |
This file was forked from hadoop/common/branches/branch-2@1350012.
|
| TestLoadIncrementalHFiles |
Test cases for the "load" half of the HFileOutputFormat bulk load
functionality.
|
| TestLoadIncrementalHFilesSplitRecovery |
Test cases for the atomic load error handling of the bulk load functionality.
|
| TestLoadIncrementalHFilesUseSecurityEndPoint | |
| TestMapReduceExamples | |
| TestMultiTableInputFormat |
Tests various scan start and stop row scenarios.
|
| TestMultiTableInputFormat.ScanMapper |
Pass the key and value to reducer.
|
| TestMultiTableInputFormat.ScanReducer |
Checks the last and first keys seen against the scanner boundaries.
|
| TestMultithreadedTableMapper |
Test Map/Reduce job over HBase tables.
|
| TestMultithreadedTableMapper.ProcessContentsMapper |
Pass the given key and processed record reduce
|
| TestRowCounter |
Test the rowcounter map reduce job.
|
| TestSecureLoadIncrementalHFiles |
Reruns TestLoadIncrementalHFiles using LoadIncrementalHFiles in secure mode.
|
| TestSecureLoadIncrementalHFilesSplitRecovery |
Reruns TestSecureLoadIncrementalHFilesSplitRecovery
using LoadIncrementalHFiles in secure mode.
|
| TestSerialization | |
| TestSimpleTotalOrderPartitioner |
Test of simple partitioner.
|
| TestSyncTable |
Basic test for the SyncTable M/R tool
|
| TestTableInputFormat |
This tests the TableInputFormat and its recovery semantics
|
| TestTableInputFormat.ExampleDeprecatedTIF | |
| TestTableInputFormat.ExampleJobConfigurableTIF | |
| TestTableInputFormat.ExampleTIF | |
| TestTableInputFormat.ExampleVerifier | |
| TestTableInputFormatBase | |
| TestTableInputFormatScan1 |
TestTableInputFormatScan part 1.
|
| TestTableInputFormatScan2 |
TestTableInputFormatScan part 2.
|
| TestTableInputFormatScanBase |
Tests various scan start and stop row scenarios.
|
| TestTableInputFormatScanBase.ScanMapper |
Pass the key and value to reduce.
|
| TestTableInputFormatScanBase.ScanReducer |
Checks the last and first key seen against the scanner boundaries.
|
| TestTableMapReduce |
Test Map/Reduce job over HBase tables.
|
| TestTableMapReduceBase |
A base class for a test Map/Reduce job over HBase tables.
|
| TestTableMapReduceUtil |
Test different variants of initTableMapperJob method
|
| TestTableSnapshotInputFormat | |
| TestTableSnapshotInputFormat.TestTableSnapshotMapper | |
| TestTableSnapshotInputFormat.TestTableSnapshotReducer | |
| TestTableSplit | |
| TestTimeRangeMapRed | |
| TestWALPlayer |
Basic test for the WALPlayer M/R tool
|
| TestWALRecordReader |
JUnit tests for the WALRecordReader
|
| TextSortReducer |
Emits Sorted KeyValues.
|
| TsvImporterCustomTestMapper |
Dummy mapper used for unit tests to verify that the mapper can be injected.
|
| TsvImporterCustomTestMapperForOprAttr |
Just shows a simple example of how the attributes can be extracted and added
to the puts
|
| 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 | |
| TestTableSnapshotInputFormat.TestTableSnapshotCounters |
| Exception | Description |
|---|---|
| ImportTsv.TsvParser.BadTsvLineException |
See HBase and MapReduce in the HBase Reference Guide for mapreduce over hbase documentation.