| Modifier and Type | Method and Description | 
|---|---|
| RecordReader<K,V> | CombineFileInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| Modifier and Type | Class and Description | 
|---|---|
| protected class  | DBInputFormat.DBRecordReaderA RecordReader that reads records from a SQL table. | 
| 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 | Method and Description | 
|---|---|
| static <K1,V1,K2,V2>  | ContextFactory. cloneMapContext(MapContext<K1,V1,K2,V2> context,
               org.apache.hadoop.conf.Configuration conf,
               RecordReader<K1,V1> reader,
               RecordWriter<K2,V2> writer)Copy a custom WrappedMapper.Context, optionally replacing 
 the input and output. | 
| 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<org.apache.hadoop.io.LongWritable,T> | DataDrivenDBInputFormat. createDBRecordReader(DBInputFormat.DBInputSplit split,
                    org.apache.hadoop.conf.Configuration conf) | 
| protected RecordReader<org.apache.hadoop.io.LongWritable,T> | DBInputFormat. createDBRecordReader(DBInputFormat.DBInputSplit split,
                    org.apache.hadoop.conf.Configuration conf) | 
| protected RecordReader<org.apache.hadoop.io.LongWritable,T> | OracleDataDrivenDBInputFormat. createDBRecordReader(DBInputFormat.DBInputSplit split,
                    org.apache.hadoop.conf.Configuration conf) | 
| RecordReader<org.apache.hadoop.io.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  | DelegatingRecordReader<K,V>This is a delegating RecordReader, which delegates the functionality to the
 underlying record reader in  TaggedInputSplit | 
| class  | FixedLengthRecordReaderA reader to read fixed length records from a split. | 
| class  | KeyValueLineRecordReaderThis class treats a line in the input as a key/value pair separated by a 
 separator character. | 
| class  | LineRecordReaderTreats keys as offset in file and value as line. | 
| static class  | SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReaderRead records from a SequenceFile as binary (raw) bytes. | 
| class  | SequenceFileAsTextRecordReaderThis class converts the input keys and values to their String forms by
 calling toString() method. | 
| class  | SequenceFileRecordReader<K,V>An  RecordReaderforSequenceFiles. | 
| 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 | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordReader<org.apache.hadoop.io.BytesWritable,org.apache.hadoop.io.BytesWritable> | SequenceFileAsBinaryInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<K,V> | CombineSequenceFileInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| abstract RecordReader<K,V> | CombineFileInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context)This is not implemented yet. | 
| RecordReader<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> | TextInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> | CombineTextInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> | KeyValueTextInputFormat. createRecordReader(InputSplit genericSplit,
                  TaskAttemptContext context) | 
| RecordReader<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text> | NLineInputFormat. createRecordReader(InputSplit genericSplit,
                  TaskAttemptContext context) | 
| RecordReader<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.BytesWritable> | FixedLengthInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> | SequenceFileAsTextInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<K,V> | SequenceFileInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<K,V> | DelegatingInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| RecordReader<K,V> | SequenceFileInputFilter. createRecordReader(InputSplit split,
                  TaskAttemptContext context)Create a record reader for the given split | 
| 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 org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>Additional operations required of a RecordReader to participate in a join. | 
| class  | CompositeRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable,X extends org.apache.hadoop.io.Writable>A RecordReader that can effect joins of RecordReaders sharing a common key
 type and partitioning. | 
| class  | InnerJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>>Full inner join. | 
| class  | JoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>>Base class for Composite joins returning Tuples of arbitrary Writables. | 
| class  | MultiFilterRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>Base class for Composite join returning values derived from multiple
 sources, but generally not tuples. | 
| class  | OuterJoinRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>>Full outer join. | 
| class  | OverrideRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>Prefer the "rightmost" data source for this key. | 
| class  | WrappedRecordReader<K extends org.apache.hadoop.io.WritableComparable<?>,U extends org.apache.hadoop.io.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. | 
| Constructor and Description | 
|---|
| MapContextImpl(org.apache.hadoop.conf.Configuration conf,
              TaskAttemptID taskid,
              RecordReader<KEYIN,VALUEIN> reader,
              RecordWriter<KEYOUT,VALUEOUT> writer,
              OutputCommitter committer,
              StatusReporter reporter,
              InputSplit split) | 
Copyright © 2022 Apache Software Foundation. All rights reserved.