public class DirectShuffleSchedulerImpl<K,V> extends Object implements org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler<K,V>
Constructor and Description |
---|
DirectShuffleSchedulerImpl(org.apache.hadoop.mapred.JobConf job,
org.apache.hadoop.mapred.TaskStatus status,
org.apache.hadoop.mapreduce.TaskAttemptID reduceId,
org.apache.hadoop.mapreduce.task.reduce.ExceptionReporter reporter,
org.apache.hadoop.util.Progress progress,
org.apache.hadoop.mapred.Counters.Counter shuffledMapsCounter,
org.apache.hadoop.mapred.Counters.Counter reduceShuffleBytes,
org.apache.hadoop.mapred.Counters.Counter failedShuffleCounter) |
Modifier and Type | Method and Description |
---|---|
void |
addKnownMapOutput(String host,
org.apache.hadoop.mapreduce.TaskAttemptID taskId,
org.apache.hadoop.fs.PathId pathId) |
void |
close() |
void |
copyFailed(org.apache.hadoop.mapreduce.TaskAttemptID mapId,
MapOutputLocation loc) |
void |
copySucceeded(org.apache.hadoop.mapreduce.TaskAttemptID mapId,
MapOutputLocation loc,
long bytes,
long millis,
org.apache.hadoop.mapreduce.task.reduce.MapOutput<K,V> output) |
static int |
getClosestPowerOf2(int value) |
MapOutputLocation |
getLocation() |
void |
obsoleteMapOutput(org.apache.hadoop.mapreduce.TaskAttemptID mapId) |
void |
reportLocalError(IOException ioe) |
void |
resolve(org.apache.hadoop.mapred.TaskCompletionEvent event) |
void |
tipFailed(org.apache.hadoop.mapred.TaskID taskId) |
boolean |
waitUntilDone(int millis) |
public DirectShuffleSchedulerImpl(org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.TaskStatus status, org.apache.hadoop.mapreduce.TaskAttemptID reduceId, org.apache.hadoop.mapreduce.task.reduce.ExceptionReporter reporter, org.apache.hadoop.util.Progress progress, org.apache.hadoop.mapred.Counters.Counter shuffledMapsCounter, org.apache.hadoop.mapred.Counters.Counter reduceShuffleBytes, org.apache.hadoop.mapred.Counters.Counter failedShuffleCounter)
public boolean waitUntilDone(int millis) throws InterruptedException
waitUntilDone
in interface org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler<K,V>
InterruptedException
public void resolve(org.apache.hadoop.mapred.TaskCompletionEvent event) throws IOException, InterruptedException
resolve
in interface org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler<K,V>
IOException
InterruptedException
public void addKnownMapOutput(String host, org.apache.hadoop.mapreduce.TaskAttemptID taskId, org.apache.hadoop.fs.PathId pathId)
public void obsoleteMapOutput(org.apache.hadoop.mapreduce.TaskAttemptID mapId)
public void tipFailed(org.apache.hadoop.mapred.TaskID taskId)
public void copySucceeded(org.apache.hadoop.mapreduce.TaskAttemptID mapId, MapOutputLocation loc, long bytes, long millis, org.apache.hadoop.mapreduce.task.reduce.MapOutput<K,V> output) throws IOException
IOException
public void copyFailed(org.apache.hadoop.mapreduce.TaskAttemptID mapId, MapOutputLocation loc)
public static int getClosestPowerOf2(int value)
public void close() throws InterruptedException
close
in interface org.apache.hadoop.mapreduce.task.reduce.ShuffleScheduler<K,V>
InterruptedException
public void reportLocalError(IOException ioe)
public MapOutputLocation getLocation() throws InterruptedException
InterruptedException
Copyright © 2019 Apache Software Foundation. All Rights Reserved.