org.apache.hadoop.mapred
Class ShuffleConsumerPlugin.Context<K,V>
java.lang.Object
org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context<K,V>
- Enclosing interface:
- ShuffleConsumerPlugin<K,V>
@InterfaceAudience.LimitedPrivate(value="mapreduce")
@InterfaceStability.Unstable
public static class ShuffleConsumerPlugin.Context<K,V>
- extends Object
Constructor Summary |
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)
|
Methods inherited from class java.lang.Object |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait |
ShuffleConsumerPlugin.Context
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)
getReduceId
public TaskAttemptID getReduceId()
getJobConf
public JobConf getJobConf()
getLocalFS
public org.apache.hadoop.fs.FileSystem getLocalFS()
getUmbilical
public TaskUmbilicalProtocol getUmbilical()
getLocalDirAllocator
public org.apache.hadoop.fs.LocalDirAllocator getLocalDirAllocator()
getReporter
public Reporter getReporter()
getCodec
public org.apache.hadoop.io.compress.CompressionCodec getCodec()
getCombinerClass
public Class<? extends Reducer> getCombinerClass()
getCombineCollector
public Task.CombineOutputCollector<K,V> getCombineCollector()
getSpilledRecordsCounter
public Counters.Counter getSpilledRecordsCounter()
getReduceCombineInputCounter
public Counters.Counter getReduceCombineInputCounter()
getShuffledMapsCounter
public Counters.Counter getShuffledMapsCounter()
getReduceShuffleBytes
public Counters.Counter getReduceShuffleBytes()
getFailedShuffleCounter
public Counters.Counter getFailedShuffleCounter()
getMergedMapOutputsCounter
public Counters.Counter getMergedMapOutputsCounter()
getStatus
public TaskStatus getStatus()
getCopyPhase
public org.apache.hadoop.util.Progress getCopyPhase()
getMergePhase
public org.apache.hadoop.util.Progress getMergePhase()
getReduceTask
public Task getReduceTask()
getMapOutputFile
public MapOutputFile getMapOutputFile()
getLocalMapFiles
public Map<TaskAttemptID,MapOutputFile> getLocalMapFiles()
Copyright © 2014 Apache Software Foundation. All Rights Reserved.