Uses of Class
org.apache.hadoop.mapred.MapOutputFile

Packages that use MapOutputFile
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce.task.reduce   
 

Uses of MapOutputFile in org.apache.hadoop.mapred
 

Subclasses of MapOutputFile in org.apache.hadoop.mapred
 class MROutputFiles
          Manipulate the working area for the transient store for maps and reduces.
 

Fields in org.apache.hadoop.mapred declared as MapOutputFile
protected  MapOutputFile Task.mapOutputFile
           
 

Methods in org.apache.hadoop.mapred that return MapOutputFile
 MapOutputFile Task.getMapOutputFile()
           
 MapOutputFile ShuffleConsumerPlugin.Context.getMapOutputFile()
           
 

Constructors in org.apache.hadoop.mapred with parameters of type MapOutputFile
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 MapOutputFile in org.apache.hadoop.mapreduce.task.reduce
 

Fields in org.apache.hadoop.mapreduce.task.reduce declared as MapOutputFile
protected  MapOutputFile MergeManagerImpl.mapOutputFile
           
 

Constructors in org.apache.hadoop.mapreduce.task.reduce with parameters of type MapOutputFile
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.