Uses of Class
org.apache.hadoop.mapred.Task.CombineOutputCollector

Packages that use Task.CombineOutputCollector
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce.task.reduce   
 

Uses of Task.CombineOutputCollector in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return Task.CombineOutputCollector
 Task.CombineOutputCollector<K,V> ShuffleConsumerPlugin.Context.getCombineCollector()
           
 

Constructors in org.apache.hadoop.mapred with parameters of type Task.CombineOutputCollector
ShuffleConsumerPlugin.Context(TaskAttemptID reduceId, JobConf jobConf, org.apache.hadoop.fs.FileSystem localFS, TaskUmbilicalProtocol umbilical, org.apache.hadoop.fs.LocalDirAllocator localDirAllocator, Reporter reporter, org.apache.hadoop.io.compress.CompressionCodec codec, Class<? extends Reducer> combinerClass, Task.CombineOutputCollector<K,V> combineCollector, Counters.Counter spilledRecordsCounter, Counters.Counter reduceCombineInputCounter, Counters.Counter shuffledMapsCounter, Counters.Counter reduceShuffleBytes, Counters.Counter failedShuffleCounter, Counters.Counter mergedMapOutputsCounter, TaskStatus status, org.apache.hadoop.util.Progress copyPhase, org.apache.hadoop.util.Progress mergePhase, Task reduceTask, MapOutputFile mapOutputFile)
           
 

Uses of Task.CombineOutputCollector in org.apache.hadoop.mapreduce.task.reduce
 

Constructors in org.apache.hadoop.mapreduce.task.reduce with parameters of type Task.CombineOutputCollector
MergeManagerImpl(TaskAttemptID reduceId, JobConf jobConf, org.apache.hadoop.fs.FileSystem localFS, org.apache.hadoop.fs.LocalDirAllocator localDirAllocator, Reporter reporter, org.apache.hadoop.io.compress.CompressionCodec codec, Class<? extends Reducer> combinerClass, Task.CombineOutputCollector<K,V> combineCollector, Counters.Counter spilledRecordsCounter, Counters.Counter reduceCombineInputCounter, Counters.Counter mergedMapOutputsCounter, ExceptionReporter exceptionReporter, org.apache.hadoop.util.Progress mergePhase, MapOutputFile mapOutputFile)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.