public class DirectShuffle<K,V> extends Object implements org.apache.hadoop.mapred.ShuffleConsumerPlugin<K,V>, org.apache.hadoop.mapreduce.task.reduce.ExceptionReporter
Constructor and Description |
---|
DirectShuffle() |
Modifier and Type | Method and Description |
---|---|
void |
close() |
protected org.apache.hadoop.mapreduce.task.reduce.MergeManager<K,V> |
createMergeManager(org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context<K,V> context) |
void |
init(org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context<K,V> context) |
void |
reportException(Throwable t) |
org.apache.hadoop.mapred.RawKeyValueIterator |
run() |
public void reportException(Throwable t)
reportException
in interface org.apache.hadoop.mapreduce.task.reduce.ExceptionReporter
public org.apache.hadoop.mapred.RawKeyValueIterator run() throws IOException, InterruptedException
run
in interface org.apache.hadoop.mapred.ShuffleConsumerPlugin<K,V>
IOException
InterruptedException
public void close()
protected org.apache.hadoop.mapreduce.task.reduce.MergeManager<K,V> createMergeManager(org.apache.hadoop.mapred.ShuffleConsumerPlugin.Context<K,V> context) throws IOException
IOException
Copyright © 2018 Apache Software Foundation. All Rights Reserved.