| 修飾子とタイプ | メソッドと説明 | 
|---|---|
| RecordReader<K,V> | CombineFileInputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context) | 
| 修飾子とタイプ | メソッドと説明 | 
|---|---|
| abstract RecordReader<K,V> | InputFormat. createRecordReader(InputSplit split,
                  TaskAttemptContext context)Create a record reader for a given split. | 
| 修飾子とタイプ | クラスと説明 | 
|---|---|
| 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. | 
| 修飾子とタイプ | メソッドと説明 | 
|---|---|
| protected RecordReader<LongWritable,T> | DBInputFormat. 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) | 
| protected RecordReader<LongWritable,T> | OracleDataDrivenDBInputFormat. 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. | 
| 修飾子とタイプ | クラスと説明 | 
|---|---|
| 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  | KeyValueLineRecordReaderThis class treats a line in the input as a key/value pair separated by a 
 separator character. | 
| class  | SequenceFileAsTextRecordReaderThis class converts the input keys and values to their String forms by
 calling toString() method. | 
| class  | SequenceFileRecordReader<K,V>An  RecordReaderforSequenceFiles. | 
| 修飾子とタイプ | フィールドと説明 | 
|---|---|
| protected RecordReader<K,V> | CombineFileRecordReader. curReader | 
| 修飾子とタイプ | フィールドと説明 | 
|---|---|
| protected Constructor<? extends RecordReader<K,V>> | CombineFileRecordReader. rrConstructor | 
| コンストラクタと説明 | 
|---|
| 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. | 
| 修飾子とタイプ | クラスと説明 | 
|---|---|
| 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. | 
| 修飾子とタイプ | メソッドと説明 | 
|---|---|
| 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.