|
|||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | ||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
Object org.apache.spark.rdd.RDD<scala.Tuple2<K,scala.collection.Iterable<Object>[]>> org.apache.spark.rdd.CoGroupedRDD<K>
public class CoGroupedRDD<K>
:: DeveloperApi :: A RDD that cogroups its parents. For each key k in parent RDDs, the resulting RDD contains a tuple with the list of values for that key.
Note: This is an internal API. We recommend users use RDD.cogroup(...) instead of instantiating this directly.
param: rdds parent RDDs. param: part partitioner used to partition the shuffle output
Constructor Summary | |
---|---|
CoGroupedRDD(scala.collection.Seq<RDD<? extends scala.Product2<K,?>>> rdds,
Partitioner part)
|
Method Summary | |
---|---|
void |
clearDependencies()
Clears the dependencies of this RDD. |
scala.collection.Iterator<scala.Tuple2<K,scala.collection.Iterable<Object>[]>> |
compute(Partition s,
TaskContext context)
:: DeveloperApi :: Implemented by subclasses to compute a given partition. |
scala.collection.Seq<Dependency<?>> |
getDependencies()
Implemented by subclasses to return how this RDD depends on parent RDDs. |
Partition[] |
getPartitions()
Implemented by subclasses to return the set of partitions in this RDD. |
scala.Some<Partitioner> |
partitioner()
Optionally overridden by subclasses to specify how they are partitioned. |
scala.collection.Seq<RDD<? extends scala.Product2<K,?>>> |
rdds()
|
CoGroupedRDD<K> |
setSerializer(Serializer serializer)
Set a serializer for this RDD's shuffle, or null to use the default (spark.serializer) |
Methods inherited from class Object |
---|
equals, getClass, hashCode, notify, notifyAll, wait, wait, wait |
Methods inherited from interface org.apache.spark.Logging |
---|
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning |
Constructor Detail |
---|
public CoGroupedRDD(scala.collection.Seq<RDD<? extends scala.Product2<K,?>>> rdds, Partitioner part)
Method Detail |
---|
public scala.collection.Seq<RDD<? extends scala.Product2<K,?>>> rdds()
public CoGroupedRDD<K> setSerializer(Serializer serializer)
public scala.collection.Seq<Dependency<?>> getDependencies()
RDD
public Partition[] getPartitions()
RDD
public scala.Some<Partitioner> partitioner()
RDD
partitioner
in class RDD<scala.Tuple2<K,scala.collection.Iterable<Object>[]>>
public scala.collection.Iterator<scala.Tuple2<K,scala.collection.Iterable<Object>[]>> compute(Partition s, TaskContext context)
RDD
compute
in class RDD<scala.Tuple2<K,scala.collection.Iterable<Object>[]>>
s
- (undocumented)context
- (undocumented)
public void clearDependencies()
RDD
UnionRDD
for an example.
|
|||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | ||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |