@InterfaceAudience.LimitedPrivate(value="mapreduce") @InterfaceStability.Unstable public static class ShuffleConsumerPlugin.Context<K,V> extends Object
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 | Method and Description |
---|---|
org.apache.hadoop.io.compress.CompressionCodec |
getCodec() |
Task.CombineOutputCollector<K,V> |
getCombineCollector() |
Class<? extends Reducer> |
getCombinerClass() |
org.apache.hadoop.util.Progress |
getCopyPhase() |
Counters.Counter |
getFailedShuffleCounter() |
JobConf |
getJobConf() |
org.apache.hadoop.fs.LocalDirAllocator |
getLocalDirAllocator() |
org.apache.hadoop.fs.FileSystem |
getLocalFS() |
Map<TaskAttemptID,MapOutputFile> |
getLocalMapFiles() |
MapOutputFile |
getMapOutputFile() |
Counters.Counter |
getMergedMapOutputsCounter() |
org.apache.hadoop.util.Progress |
getMergePhase() |
Counters.Counter |
getReduceCombineInputCounter() |
TaskAttemptID |
getReduceId() |
Counters.Counter |
getReduceShuffleBytes() |
Task |
getReduceTask() |
Reporter |
getReporter() |
Counters.Counter |
getShuffledMapsCounter() |
Counters.Counter |
getSpilledRecordsCounter() |
TaskStatus |
getStatus() |
TaskUmbilicalProtocol |
getUmbilical() |
public 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)
public TaskAttemptID getReduceId()
public JobConf getJobConf()
public org.apache.hadoop.fs.FileSystem getLocalFS()
public TaskUmbilicalProtocol getUmbilical()
public org.apache.hadoop.fs.LocalDirAllocator getLocalDirAllocator()
public Reporter getReporter()
public org.apache.hadoop.io.compress.CompressionCodec getCodec()
public Task.CombineOutputCollector<K,V> getCombineCollector()
public Counters.Counter getSpilledRecordsCounter()
public Counters.Counter getReduceCombineInputCounter()
public Counters.Counter getShuffledMapsCounter()
public Counters.Counter getReduceShuffleBytes()
public Counters.Counter getFailedShuffleCounter()
public Counters.Counter getMergedMapOutputsCounter()
public TaskStatus getStatus()
public org.apache.hadoop.util.Progress getCopyPhase()
public org.apache.hadoop.util.Progress getMergePhase()
public Task getReduceTask()
public MapOutputFile getMapOutputFile()
public Map<TaskAttemptID,MapOutputFile> getLocalMapFiles()
Copyright © 2018 Apache Software Foundation. All Rights Reserved.