public class DirectInMemoryOutput<K,V>
extends org.apache.hadoop.mapreduce.task.reduce.MapOutput<K,V>
Constructor and Description |
---|
DirectInMemoryOutput(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.mapreduce.TaskAttemptID mapId,
DirectShuffleMergeManagerImpl<K,V> merger,
int size,
org.apache.hadoop.io.compress.CompressionCodec codec,
boolean primaryMapOutput) |
Modifier and Type | Method and Description |
---|---|
void |
abort() |
void |
commit() |
org.apache.hadoop.io.BoundedByteArrayOutputStream |
getArrayStream() |
String |
getDescription() |
byte[] |
getMemory() |
void |
shuffle(org.apache.hadoop.mapreduce.task.reduce.MapHost host,
InputStream input,
long mapOutputLength,
long decompressedLength,
org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics metrics,
org.apache.hadoop.mapred.Reporter reporter) |
public DirectInMemoryOutput(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.mapreduce.TaskAttemptID mapId, DirectShuffleMergeManagerImpl<K,V> merger, int size, org.apache.hadoop.io.compress.CompressionCodec codec, boolean primaryMapOutput)
public void shuffle(org.apache.hadoop.mapreduce.task.reduce.MapHost host, InputStream input, long mapOutputLength, long decompressedLength, org.apache.hadoop.mapreduce.task.reduce.ShuffleClientMetrics metrics, org.apache.hadoop.mapred.Reporter reporter) throws IOException
shuffle
in class org.apache.hadoop.mapreduce.task.reduce.MapOutput<K,V>
IOException
public void commit() throws IOException
commit
in class org.apache.hadoop.mapreduce.task.reduce.MapOutput<K,V>
IOException
public void abort()
public String getDescription()
public byte[] getMemory()
public org.apache.hadoop.io.BoundedByteArrayOutputStream getArrayStream()
Copyright © 2018 Apache Software Foundation. All Rights Reserved.