| Package | Description | 
|---|---|
| org.apache.hadoop.mapred | |
| org.apache.hadoop.mapreduce.task.reduce | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MROutputFilesManipulate the working area for the transient store for maps and reduces. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected MapOutputFile | Task. mapOutputFile | 
| Modifier and Type | Method and Description | 
|---|---|
| MapOutputFile | ShuffleConsumerPlugin.Context. getMapOutputFile() | 
| MapOutputFile | Task. getMapOutputFile() | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<TaskAttemptID,MapOutputFile> | ShuffleConsumerPlugin.Context. getLocalMapFiles() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReduceTask. setLocalMapFiles(Map<TaskAttemptID,MapOutputFile> mapFiles)Register the set of mapper outputs created by a LocalJobRunner-based
 job with this ReduceTask so it knows where to fetch from. | 
| Constructor and Description | 
|---|
| 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,
                             Map<TaskAttemptID,MapOutputFile> localMapFiles) | 
| Constructor and Description | 
|---|
| 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,
                             Map<TaskAttemptID,MapOutputFile> localMapFiles) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected MapOutputFile | MergeManagerImpl. mapOutputFile | 
| Constructor and Description | 
|---|
| 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 © 2022 Apache Software Foundation. All rights reserved.