| Package | Description | 
|---|---|
| org.apache.hadoop.mapred | |
| org.apache.hadoop.mapred.join | |
| org.apache.hadoop.mapred.lib | |
| org.apache.hadoop.mapred.lib.aggregate | |
| org.apache.hadoop.mapred.lib.db | 
| Modifier and Type | Field and Description | 
|---|---|
| static Reporter | Reporter. NULLA constant of Reporter type that does nothing. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RecordWriter. close(Reporter reporter)Close this  RecordWriterto future operations. | 
| RecordReader<Text,Text> | SequenceFileAsTextInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| abstract RecordReader<K,V> | FileInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<Text,Text> | KeyValueTextInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<LongWritable,Text> | TextInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<BytesWritable,BytesWritable> | SequenceFileAsBinaryInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<K,V> | SequenceFileInputFilter. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter)Create a record reader for the given split | 
| RecordReader<K,V> | InputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter)Get the  RecordReaderfor the givenInputSplit. | 
| RecordReader<K,V> | SequenceFileInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| abstract RecordReader<K,V> | MultiFileInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<LongWritable,BytesWritable> | FixedLengthInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| void | Mapper. map(K1 key,
      V1 value,
      OutputCollector<K2,V2> output,
      Reporter reporter)Maps a single input key/value pair into an intermediate key/value pair. | 
| void | Reducer. reduce(K2 key,
            Iterator<V2> values,
            OutputCollector<K3,V3> output,
            Reporter reporter)Reduces values for a given key. | 
| 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 | Method and Description | 
|---|---|
| ComposableRecordReader<K,TupleWritable> | CompositeInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter)Construct a CompositeRecordReader for the children of this InputFormat
 as defined in the init expression. | 
| ComposableRecordReader<K,V> | ComposableInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Reporter | CombineFileRecordReader. reporter | 
| Modifier and Type | Method and Description | 
|---|---|
| OutputCollector | MultipleOutputs. getCollector(String namedOutput,
                        Reporter reporter)Gets the output collector for a named output. | 
| OutputCollector | MultipleOutputs. getCollector(String namedOutput,
                        String multiName,
                        Reporter reporter)Gets the output collector for a multi named output. | 
| RecordReader<K,V> | CombineSequenceFileInputFormat. getRecordReader(InputSplit split,
                              JobConf conf,
                              Reporter reporter) | 
| abstract RecordReader<K,V> | CombineFileInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter)This is not implemented yet. | 
| RecordReader<LongWritable,Text> | NLineInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<LongWritable,Text> | CombineTextInputFormat. getRecordReader(InputSplit split,
                              JobConf conf,
                              Reporter reporter) | 
| void | RegexMapper. map(K key,
      Text value,
      OutputCollector<Text,LongWritable> output,
      Reporter reporter) | 
| void | TokenCountMapper. map(K key,
      Text value,
      OutputCollector<Text,LongWritable> output,
      Reporter reporter) | 
| void | IdentityMapper. map(K key,
      V val,
      OutputCollector<K,V> output,
      Reporter reporter)The identify function. | 
| void | FieldSelectionMapReduce. map(K key,
      V val,
      OutputCollector<Text,Text> output,
      Reporter reporter)The identify function. | 
| void | InverseMapper. map(K key,
      V value,
      OutputCollector<V,K> output,
      Reporter reporter)The inverse function. | 
| void | ChainMapper. map(Object key,
      Object value,
      OutputCollector output,
      Reporter reporter)Chains the  map(...)methods of the Mappers in the chain. | 
| void | LongSumReducer. reduce(K key,
            Iterator<LongWritable> values,
            OutputCollector<K,LongWritable> output,
            Reporter reporter) | 
| void | IdentityReducer. reduce(K key,
            Iterator<V> values,
            OutputCollector<K,V> output,
            Reporter reporter)Writes all keys and values directly to output. | 
| void | ChainReducer. reduce(Object key,
            Iterator values,
            OutputCollector output,
            Reporter reporter)Chains the  reduce(...)method of the Reducer with themap(...) methods of the Mappers in the chain. | 
| void | FieldSelectionMapReduce. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| 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. | 
| CombineFileRecordReaderWrapper(FileInputFormat<K,V> inputFormat,
                                                            CombineFileSplit split,
                                                            Configuration conf,
                                                            Reporter reporter,
                                                            Integer idx) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ValueAggregatorReducer. map(K1 arg0,
      V1 arg1,
      OutputCollector<Text,Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorMapper. map(K1 key,
      V1 value,
      OutputCollector<Text,Text> output,
      Reporter reporter)the map function. | 
| void | ValueAggregatorCombiner. map(K1 arg0,
      V1 arg1,
      OutputCollector<Text,Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | ValueAggregatorMapper. reduce(Text arg0,
            Iterator<Text> arg1,
            OutputCollector<Text,Text> arg2,
            Reporter arg3)Do nothing. | 
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter)Combines values for a given key. | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordReader<LongWritable,T> | DBInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter)Get the  RecordReaderfor the givenInputSplit. | 
Copyright © 2015 Apache Software Foundation. All Rights Reserved.