public abstract class VertexPartitionBaseOps<VD,Self extends VertexPartitionBase<Object>> extends Object implements scala.Serializable, Logging
VertexPartitionBaseOpsConstructor
typeclass (for
example, VertexPartition.VertexPartitionOpsConstructor
).Constructor and Description |
---|
VertexPartitionBaseOps(Self self,
scala.reflect.ClassTag<VD> evidence$1,
VertexPartitionBaseOpsConstructor<Self> evidence$2) |
Modifier and Type | Method and Description |
---|---|
<VD2> Self |
aggregateUsingIndex(scala.collection.Iterator<scala.Product2<Object,VD2>> iter,
scala.Function2<VD2,VD2,VD2> reduceFunc,
scala.reflect.ClassTag<VD2> evidence$14) |
<VD2> Self |
createUsingIndex(scala.collection.Iterator<scala.Product2<Object,VD2>> iter,
scala.reflect.ClassTag<VD2> evidence$13)
Similar effect as aggregateUsingIndex((a, b) => a)
|
Self |
diff(Self other)
Hides vertices that are the same between this and other.
|
Self |
filter(scala.Function2<Object,VD,Object> pred)
Restrict the vertex set to the set of vertices satisfying the given predicate.
|
<U,VD2> Self |
innerJoin(scala.collection.Iterator<scala.Product2<Object,U>> iter,
scala.Function3<Object,VD,U,VD2> f,
scala.reflect.ClassTag<U> evidence$11,
scala.reflect.ClassTag<VD2> evidence$12)
Inner join an iterator of messages.
|
<U,VD2> Self |
innerJoin(Self other,
scala.Function3<Object,VD,U,VD2> f,
scala.reflect.ClassTag<U> evidence$9,
scala.reflect.ClassTag<VD2> evidence$10)
Inner join another VertexPartition.
|
Self |
innerJoinKeepLeft(scala.collection.Iterator<scala.Product2<Object,VD>> iter)
Similar to innerJoin, but vertices from the left side that don't appear in iter will remain in
the partition, hidden by the bitmask.
|
<VD2,VD3> Self |
leftJoin(scala.collection.Iterator<scala.Tuple2<Object,VD2>> other,
scala.Function3<Object,VD,scala.Option<VD2>,VD3> f,
scala.reflect.ClassTag<VD2> evidence$7,
scala.reflect.ClassTag<VD3> evidence$8)
Left outer join another iterator of messages.
|
<VD2,VD3> Self |
leftJoin(Self other,
scala.Function3<Object,VD,scala.Option<VD2>,VD3> f,
scala.reflect.ClassTag<VD2> evidence$5,
scala.reflect.ClassTag<VD3> evidence$6)
Left outer join another VertexPartition.
|
<VD2> Self |
map(scala.Function2<Object,VD,VD2> f,
scala.reflect.ClassTag<VD2> evidence$4)
Pass each vertex attribute along with the vertex id through a map
function and retain the original RDD's partitioning and index.
|
Self |
reindex()
Construct a new VertexPartition whose index contains only the vertices in the mask.
|
abstract Self |
withIndex(org.apache.spark.util.collection.OpenHashSet<Object> index) |
abstract Self |
withMask(org.apache.spark.util.collection.BitSet mask) |
abstract <VD2> Self |
withValues(Object values,
scala.reflect.ClassTag<VD2> evidence$3) |
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public VertexPartitionBaseOps(Self self, scala.reflect.ClassTag<VD> evidence$1, VertexPartitionBaseOpsConstructor<Self> evidence$2)
public abstract Self withIndex(org.apache.spark.util.collection.OpenHashSet<Object> index)
public abstract <VD2> Self withValues(Object values, scala.reflect.ClassTag<VD2> evidence$3)
public abstract Self withMask(org.apache.spark.util.collection.BitSet mask)
public <VD2> Self map(scala.Function2<Object,VD,VD2> f, scala.reflect.ClassTag<VD2> evidence$4)
f
- the function applied to each vertex id and vertex
attribute in the RDD
f
to
each of the entries in the original VertexRDD. The resulting
VertexPartition retains the same index.public Self filter(scala.Function2<Object,VD,Object> pred)
pred
- the user defined predicate
public Self diff(Self other)
other
. The indices of this
and other
must be the same.public <VD2,VD3> Self leftJoin(Self other, scala.Function3<Object,VD,scala.Option<VD2>,VD3> f, scala.reflect.ClassTag<VD2> evidence$5, scala.reflect.ClassTag<VD3> evidence$6)
public <VD2,VD3> Self leftJoin(scala.collection.Iterator<scala.Tuple2<Object,VD2>> other, scala.Function3<Object,VD,scala.Option<VD2>,VD3> f, scala.reflect.ClassTag<VD2> evidence$7, scala.reflect.ClassTag<VD3> evidence$8)
public <U,VD2> Self innerJoin(Self other, scala.Function3<Object,VD,U,VD2> f, scala.reflect.ClassTag<U> evidence$9, scala.reflect.ClassTag<VD2> evidence$10)
public <U,VD2> Self innerJoin(scala.collection.Iterator<scala.Product2<Object,U>> iter, scala.Function3<Object,VD,U,VD2> f, scala.reflect.ClassTag<U> evidence$11, scala.reflect.ClassTag<VD2> evidence$12)
public <VD2> Self createUsingIndex(scala.collection.Iterator<scala.Product2<Object,VD2>> iter, scala.reflect.ClassTag<VD2> evidence$13)
public Self innerJoinKeepLeft(scala.collection.Iterator<scala.Product2<Object,VD>> iter)
public <VD2> Self aggregateUsingIndex(scala.collection.Iterator<scala.Product2<Object,VD2>> iter, scala.Function2<VD2,VD2,VD2> reduceFunc, scala.reflect.ClassTag<VD2> evidence$14)
public Self reindex()