Uses of Interface
org.apache.hadoop.mapred.OutputCollector

Packages that use OutputCollector
org.apache.hadoop.contrib.utils.join   
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.mapred A system for scalable, fault-tolerant, distributed computation over large data collections. 
org.apache.hadoop.mapred.lib Library of generally useful mappers, reducers, and partitioners. 
org.apache.hadoop.mapred.lib.aggregate Classes for performing various counting and aggregations. 
org.apache.hadoop.streaming   
org.apache.hadoop.tools   
org.apache.hadoop.util Common utilities. 
 

Uses of OutputCollector in org.apache.hadoop.contrib.utils.join
 

Methods in org.apache.hadoop.contrib.utils.join with parameters of type OutputCollector
protected  void DataJoinReducerBase.collect(WritableComparable key, TaggedMapOutput aRecord, OutputCollector output, Reporter reporter)
          The subclass can overwrite this method to perform additional filtering and/or other processing logic before a value is collected.
 void DataJoinMapperBase.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void DataJoinReducerBase.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
           
 void DataJoinMapperBase.reduce(WritableComparable arg0, Iterator arg1, OutputCollector arg2, Reporter arg3)
           
 void DataJoinReducerBase.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 

Uses of OutputCollector in org.apache.hadoop.examples
 

Methods in org.apache.hadoop.examples with parameters of type OutputCollector
 void PiEstimator.PiMapper.map(WritableComparable key, Writable val, OutputCollector out, Reporter reporter)
          Map method.
 void WordCount.MapClass.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void PiEstimator.PiReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Reduce method.
 void WordCount.Reduce.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 

Uses of OutputCollector in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred with parameters of type OutputCollector
 void Mapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
          Maps a single input key/value pair into intermediate key/value pairs.
 void Reducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Combines values for a given key.
 void MapRunner.run(RecordReader input, OutputCollector output, Reporter reporter)
           
 void MapRunnable.run(RecordReader input, OutputCollector output, Reporter reporter)
          Called to execute mapping.
 

Uses of OutputCollector in org.apache.hadoop.mapred.lib
 

Methods in org.apache.hadoop.mapred.lib with parameters of type OutputCollector
 void FieldSelectionMapReduce.map(WritableComparable key, Writable val, OutputCollector output, Reporter reporter)
          The identify function.
 void IdentityMapper.map(WritableComparable key, Writable val, OutputCollector output, Reporter reporter)
          The identify function.
 void RegexMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void InverseMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
          The inverse function.
 void TokenCountMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void LongSumReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void FieldSelectionMapReduce.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void IdentityReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Writes all keys and values directly to output.
 void MultithreadedMapRunner.run(RecordReader input, OutputCollector output, Reporter reporter)
           
 

Uses of OutputCollector in org.apache.hadoop.mapred.lib.aggregate
 

Methods in org.apache.hadoop.mapred.lib.aggregate with parameters of type OutputCollector
 void ValueAggregatorMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
          the map function.
 void ValueAggregatorReducer.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
          Do nothing.
 void ValueAggregatorCombiner.map(WritableComparable arg0, Writable arg1, OutputCollector arg2, Reporter arg3)
          Do nothing.
 void ValueAggregatorMapper.reduce(WritableComparable arg0, Iterator arg1, OutputCollector arg2, Reporter arg3)
          Do nothing.
 void ValueAggregatorReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 void ValueAggregatorCombiner.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
          Combines values for a given key.
 

Uses of OutputCollector in org.apache.hadoop.streaming
 

Methods in org.apache.hadoop.streaming with parameters of type OutputCollector
 void PipeMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 void PipeReducer.reduce(WritableComparable key, Iterator values, OutputCollector output, Reporter reporter)
           
 

Uses of OutputCollector in org.apache.hadoop.tools
 

Methods in org.apache.hadoop.tools with parameters of type OutputCollector
 void Logalyzer.LogRegexMapper.map(WritableComparable key, Writable value, OutputCollector output, Reporter reporter)
           
 

Uses of OutputCollector in org.apache.hadoop.util
 

Methods in org.apache.hadoop.util with parameters of type OutputCollector
 void CopyFiles.FSCopyFilesMapper.map(WritableComparable key, Writable value, OutputCollector out, Reporter reporter)
          Map method.
 void CopyFiles.HTTPCopyFilesMapper.map(WritableComparable key, Writable val, OutputCollector out, Reporter reporter)
           
 



Copyright © 2006 The Apache Software Foundation