public class ShuffleDependency<K,V,C> extends Dependency<scala.Product2<K,V>>
param: _rdd the parent RDD
param: partitioner partitioner used to partition the shuffle output
param: serializer Serializer
to use. If not set
explicitly then the default serializer, as specified by spark.serializer
config option, will be used.
param: keyOrdering key ordering for RDD's shuffles
param: aggregator map/reduce-side aggregator for RDD's shuffle
param: mapSideCombine whether to perform partial aggregation (also known as map-side combine)
param: shuffleWriterProcessor the processor to control the write behavior in ShuffleMapTask
Constructor and Description |
---|
ShuffleDependency(RDD<? extends scala.Product2<K,V>> _rdd,
Partitioner partitioner,
Serializer serializer,
scala.Option<scala.math.Ordering<K>> keyOrdering,
scala.Option<Aggregator<K,V,C>> aggregator,
boolean mapSideCombine,
org.apache.spark.shuffle.ShuffleWriteProcessor shuffleWriterProcessor,
scala.reflect.ClassTag<K> evidence$1,
scala.reflect.ClassTag<V> evidence$2,
scala.reflect.ClassTag<C> evidence$3) |
Modifier and Type | Method and Description |
---|---|
scala.Option<Aggregator<K,V,C>> |
aggregator() |
scala.Option<scala.math.Ordering<K>> |
keyOrdering() |
boolean |
mapSideCombine() |
Partitioner |
partitioner() |
RDD<scala.Product2<K,V>> |
rdd() |
Serializer |
serializer() |
org.apache.spark.shuffle.ShuffleHandle |
shuffleHandle() |
int |
shuffleId() |
org.apache.spark.shuffle.ShuffleWriteProcessor |
shuffleWriterProcessor() |
public ShuffleDependency(RDD<? extends scala.Product2<K,V>> _rdd, Partitioner partitioner, Serializer serializer, scala.Option<scala.math.Ordering<K>> keyOrdering, scala.Option<Aggregator<K,V,C>> aggregator, boolean mapSideCombine, org.apache.spark.shuffle.ShuffleWriteProcessor shuffleWriterProcessor, scala.reflect.ClassTag<K> evidence$1, scala.reflect.ClassTag<V> evidence$2, scala.reflect.ClassTag<C> evidence$3)
public Partitioner partitioner()
public Serializer serializer()
public scala.Option<scala.math.Ordering<K>> keyOrdering()
public scala.Option<Aggregator<K,V,C>> aggregator()
public boolean mapSideCombine()
public org.apache.spark.shuffle.ShuffleWriteProcessor shuffleWriterProcessor()
public RDD<scala.Product2<K,V>> rdd()
rdd
in class Dependency<scala.Product2<K,V>>
public int shuffleId()
public org.apache.spark.shuffle.ShuffleHandle shuffleHandle()