public abstract class EdgeContext<VD,ED,A>
extends Object
Graph.aggregateMessages(scala.Function1<org.apache.spark.graphx.EdgeContext<VD, ED, A>, scala.runtime.BoxedUnit>, scala.Function2<A, A, A>, org.apache.spark.graphx.TripletFields, scala.reflect.ClassTag<A>)
.Constructor and Description |
---|
EdgeContext() |
Modifier and Type | Method and Description |
---|---|
abstract ED |
attr()
The attribute associated with the edge.
|
abstract VD |
dstAttr()
The vertex attribute of the edge's destination vertex.
|
abstract long |
dstId()
The vertex id of the edge's destination vertex.
|
abstract void |
sendToDst(A msg)
Sends a message to the destination vertex.
|
abstract void |
sendToSrc(A msg)
Sends a message to the source vertex.
|
abstract VD |
srcAttr()
The vertex attribute of the edge's source vertex.
|
abstract long |
srcId()
The vertex id of the edge's source vertex.
|
EdgeTriplet<VD,ED> |
toEdgeTriplet()
Converts the edge and vertex properties into an
EdgeTriplet for convenience. |
static <VD,ED,A> scala.Some<scala.Tuple5<Object,Object,VD,VD,ED>> |
unapply(EdgeContext<VD,ED,A> edge)
Extractor mainly used for Graph#aggregateMessages*.
|
public static <VD,ED,A> scala.Some<scala.Tuple5<Object,Object,VD,VD,ED>> unapply(EdgeContext<VD,ED,A> edge)
val messages = graph.aggregateMessages(
case ctx @ EdgeContext(_, _, _, _, attr) =>
ctx.sendToDst(attr)
, _ + _)
edge
- (undocumented)public abstract long srcId()
public abstract long dstId()
public abstract VD srcAttr()
public abstract VD dstAttr()
public abstract ED attr()
public abstract void sendToSrc(A msg)
public abstract void sendToDst(A msg)
public EdgeTriplet<VD,ED> toEdgeTriplet()
EdgeTriplet
for convenience.