| Modifier and Type | Method and Description | 
|---|---|
RecordReader<K,V> | 
CombineFileInputFormat.createRecordReader(InputSplit split,
                                    TaskAttemptContext context)  | 
| Modifier and Type | Method and Description | 
|---|---|
abstract RecordReader<K,V> | 
InputFormat.createRecordReader(InputSplit split,
                                    TaskAttemptContext context)
Create a record reader for a given split. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DataDrivenDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a SQL table,
 using data-driven WHERE clause splits. 
 | 
class  | 
DBRecordReader<T extends DBWritable>
A RecordReader that reads records from a SQL table. 
 | 
class  | 
MySQLDataDrivenDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a MySQL table via DataDrivenDBRecordReader 
 | 
class  | 
MySQLDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a MySQL table. 
 | 
class  | 
OracleDataDrivenDBRecordReader<T extends DBWritable>
A RecordReader that reads records from a Oracle table via DataDrivenDBRecordReader 
 | 
class  | 
OracleDBRecordReader<T extends DBWritable>
A RecordReader that reads records from an Oracle SQL table. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected RecordReader<LongWritable,T> | 
DBInputFormat.createDBRecordReader(org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit split,
                                        Configuration conf)  | 
protected RecordReader<LongWritable,T> | 
OracleDataDrivenDBInputFormat.createDBRecordReader(org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit split,
                                        Configuration conf)  | 
protected RecordReader<LongWritable,T> | 
DataDrivenDBInputFormat.createDBRecordReader(org.apache.hadoop.mapreduce.lib.db.DBInputFormat.DBInputSplit split,
                                        Configuration conf)  | 
RecordReader<LongWritable,T> | 
DBInputFormat.createRecordReader(InputSplit split,
                                    TaskAttemptContext context)
Create a record reader for a given split. 
 | 
| 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. 
 | 
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 SequenceFiles. | 
| Modifier and Type | Field and Description | 
|---|---|
protected RecordReader<K,V> | 
CombineFileRecordReader.curReader  | 
| Modifier and Type | Field and Description | 
|---|---|
protected Constructor<? extends RecordReader<K,V>> | 
CombineFileRecordReader.rrConstructor  | 
| Constructor and Description | 
|---|
CombineFileRecordReader(CombineFileSplit split,
                                              TaskAttemptContext context,
                                              Class<? extends RecordReader<K,V>> rrClass)
A generic RecordReader that can hand out different recordReaders
 for each chunk in the CombineFileSplit. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ComposableRecordReader<K extends WritableComparable<?>,V extends Writable>
Additional operations required of a RecordReader to participate in a join. 
 | 
class  | 
CompositeRecordReader<K extends WritableComparable<?>,V extends Writable,X extends Writable>
A RecordReader that can effect joins of RecordReaders sharing a common key
 type and partitioning. 
 | 
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 | Method and Description | 
|---|---|
RecordReader<K,TupleWritable> | 
CompositeInputFormat.createRecordReader(InputSplit split,
                                    TaskAttemptContext taskContext)
Construct a CompositeRecordReader for the children of this InputFormat
 as defined in the init expression. 
 | 
Copyright © 2016 Apache Software Foundation. All rights reserved.