Package | Description |
---|---|
org.apache.hadoop.mapred | |
org.apache.hadoop.mapred.join | |
org.apache.hadoop.mapred.lib | |
org.apache.hadoop.mapred.lib.db |
Modifier and Type | Class and Description |
---|---|
class |
KeyValueLineRecordReader
This class treats a line in the input as a key/value pair separated by a
separator character.
|
class |
SequenceFileAsTextRecordReader
This class converts the input keys and values to their String forms by calling toString()
method.
|
class |
SequenceFileRecordReader<K,V>
An
RecordReader for SequenceFile s. |
Modifier and Type | Method and Description |
---|---|
RecordReader<K,V> |
InputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Get the
RecordReader for the given InputSplit . |
RecordReader<LongWritable,Text> |
TextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<K,V> |
SequenceFileInputFilter.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Create a record reader for the given split
|
RecordReader<Text,Text> |
SequenceFileAsTextInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
abstract RecordReader<K,V> |
FileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<BytesWritable,BytesWritable> |
SequenceFileAsBinaryInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<Text,Text> |
KeyValueTextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<K,V> |
SequenceFileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<LongWritable,BytesWritable> |
FixedLengthInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
abstract RecordReader<K,V> |
MultiFileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
void |
MapRunner.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter) |
void |
MapRunnable.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter)
Start mapping input <key, value> pairs.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ComposableRecordReader<K extends WritableComparable,V extends Writable>
Additional operations required of a RecordReader to participate in a join.
|
Modifier and Type | Class and Description |
---|---|
class |
InnerJoinRecordReader<K extends WritableComparable>
Full inner join.
|
class |
JoinRecordReader<K extends WritableComparable>
Base class for Composite joins returning Tuples of arbitrary Writables.
|
class |
MultiFilterRecordReader<K extends WritableComparable,V extends Writable>
Base class for Composite join returning values derived from multiple
sources, but generally not tuples.
|
class |
OuterJoinRecordReader<K extends WritableComparable>
Full outer join.
|
class |
OverrideRecordReader<K extends WritableComparable,V extends Writable>
Prefer the "rightmost" data source for this key.
|
class |
WrappedRecordReader<K extends WritableComparable,U extends Writable>
Proxy class for a RecordReader participating in the join framework.
|
Modifier and Type | Class and Description |
---|---|
class |
CombineFileRecordReader<K,V>
A generic RecordReader that can hand out different recordReaders
for each chunk in a
CombineFileSplit . |
class |
CombineFileRecordReaderWrapper<K,V>
A wrapper class for a record reader that handles a single file split.
|
Modifier and Type | Field and Description |
---|---|
protected RecordReader<K,V> |
CombineFileRecordReader.curReader |
Modifier and Type | Field and Description |
---|---|
protected Constructor<RecordReader<K,V>> |
CombineFileRecordReader.rrConstructor |
Modifier and Type | Method and Description |
---|---|
abstract RecordReader<K,V> |
CombineFileInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
This is not implemented yet.
|
RecordReader<K,V> |
CombineSequenceFileInputFormat.getRecordReader(InputSplit split,
JobConf conf,
Reporter reporter) |
RecordReader<LongWritable,Text> |
CombineTextInputFormat.getRecordReader(InputSplit split,
JobConf conf,
Reporter reporter) |
RecordReader<LongWritable,Text> |
NLineInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
void |
MultithreadedMapRunner.run(RecordReader<K1,V1> input,
OutputCollector<K2,V2> output,
Reporter reporter) |
Constructor and Description |
---|
CombineFileRecordReader(JobConf job,
CombineFileSplit split,
Reporter reporter,
Class<RecordReader<K,V>> rrClass)
A generic RecordReader that can hand out different recordReaders
for each chunk in the CombineFileSplit.
|
Modifier and Type | Method and Description |
---|---|
RecordReader<LongWritable,T> |
DBInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter)
Get the
RecordReader for the given InputSplit . |
Copyright © 2015 Apache Software Foundation. All rights reserved.