Package | Description |
---|---|
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.mob.mapreduce |
Class and Description |
---|
TableSnapshotInputFormatImpl.RecordReader
Implementation class for RecordReader logic common between mapred and mapreduce.
|
Class and Description |
---|
CellCounter.CellCounterMapper.Counters
Counter enumeration to count the actual rows.
|
CellCreator
Facade to create Cells for HFileOutputFormat.
|
CellSerialization.CellDeserializer |
CellSerialization.CellSerializer |
HashTable.ResultHasher |
HashTable.TableHash |
HashTable.TableHash.Reader |
HFileOutputFormat2
Writes HFiles.
|
HFileOutputFormat2.TableInfo |
Import.CellWritableComparable |
Import.KeyValueWritableComparable |
ImportTsv.TsvParser |
ImportTsv.TsvParser.BadTsvLineException |
ImportTsv.TsvParser.ParsedLine |
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
MultiTableInputFormat s. |
MultiTableSnapshotInputFormatImpl
Shared implementation of mapreduce code over multiple table snapshots.
|
RegionSizeCalculator
Computes size of each region for given table and given column families.
|
RowCounter.RowCounterMapper.Counters
Counter enumeration to count the actual rows.
|
SyncTable.SyncMapper.CellScanner |
SyncTable.SyncMapper.Counter |
TableInputFormatBase
A base for
TableInputFormat s. |
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.
|
TableRecordReaderImpl
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.
|
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.
|
TableSplit.Version |
VisibilityExpressionResolver
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
|
WALInputFormat.WALRecordReader
RecordReader for an WAL file. |
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. |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.