| Package | Description | 
|---|---|
| org.apache.hadoop.mapred | |
| org.apache.hadoop.mapred.lib | |
| org.apache.hadoop.mapred.lib.aggregate | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | Task.CombineOutputCollector<K,V>OutputCollector for the combiner. | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract void | Task.CombinerRunner. combine(RawKeyValueIterator iterator,
       OutputCollector<K,V> collector)Run the combiner over a set of inputs. | 
| void | Task.OldCombinerRunner. combine(RawKeyValueIterator kvIter,
       OutputCollector<K,V> combineCollector) | 
| void | Task.NewCombinerRunner. combine(RawKeyValueIterator iterator,
       OutputCollector<K,V> collector) | 
| 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 | 
|---|---|
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DelegatingMapper. map(K1 key,
   V1 value,
   OutputCollector<K2,V2> outputCollector,
   Reporter reporter) | 
| void | RegexMapper. map(K key,
   org.apache.hadoop.io.Text value,
   OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.LongWritable> output,
   Reporter reporter) | 
| void | TokenCountMapper. map(K key,
   org.apache.hadoop.io.Text value,
   OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.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<org.apache.hadoop.io.Text,org.apache.hadoop.io.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<org.apache.hadoop.io.LongWritable> values,
      OutputCollector<K,org.apache.hadoop.io.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(org.apache.hadoop.io.Text key,
      Iterator<org.apache.hadoop.io.Text> values,
      OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> output,
      Reporter reporter) | 
| void | MultithreadedMapRunner. run(RecordReader<K1,V1> input,
   OutputCollector<K2,V2> output,
   Reporter reporter) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ValueAggregatorMapper. map(K1 key,
   V1 value,
   OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> output,
   Reporter reporter)the map function. | 
| void | ValueAggregatorReducer. map(K1 arg0,
   V1 arg1,
   OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> arg2,
   Reporter arg3)Do nothing. | 
| void | ValueAggregatorCombiner. map(K1 arg0,
   V1 arg1,
   OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> arg2,
   Reporter arg3)Do nothing. | 
| void | ValueAggregatorMapper. reduce(org.apache.hadoop.io.Text arg0,
      Iterator<org.apache.hadoop.io.Text> arg1,
      OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorReducer. reduce(org.apache.hadoop.io.Text key,
      Iterator<org.apache.hadoop.io.Text> values,
      OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> output,
      Reporter reporter) | 
| void | ValueAggregatorCombiner. reduce(org.apache.hadoop.io.Text key,
      Iterator<org.apache.hadoop.io.Text> values,
      OutputCollector<org.apache.hadoop.io.Text,org.apache.hadoop.io.Text> output,
      Reporter reporter)Combines values for a given key. | 
Copyright © 2022 Apache Software Foundation. All rights reserved.