Package org.apache.spark.graphx
Class EdgeContext<VD,ED,A>  
Object
org.apache.spark.graphx.EdgeContext<VD,ED,A>  
- Direct Known Subclasses:
- AggregatingEdgeContext
Represents an edge along with its neighboring vertices and allows sending messages along the
 edge. Used in 
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 SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionabstract EDattr()The attribute associated with the edge.abstract VDdstAttr()The vertex attribute of the edge's destination vertex.abstract longdstId()The vertex id of the edge's destination vertex.abstract voidSends a message to the destination vertex.abstract voidSends a message to the source vertex.abstract VDsrcAttr()The vertex attribute of the edge's source vertex.abstract longsrcId()The vertex id of the edge's source vertex.Converts the edge and vertex properties into anEdgeTripletfor convenience.unapply(EdgeContext<VD, ED, A> edge) Extractor mainly used for Graph#aggregateMessages*.
- 
Constructor Details- 
EdgeContextpublic EdgeContext()
 
- 
- 
Method Details- 
unapplypublic static <VD,ED, scala.Some<scala.Tuple5<Object,A> Object, unapplyVD, VD, ED>> (EdgeContext<VD, ED, A> edge) Extractor mainly used for Graph#aggregateMessages*. Example:val messages = graph.aggregateMessages( case ctx @ EdgeContext(_, _, _, _, attr) => ctx.sendToDst(attr) , _ + _)- Parameters:
- edge- (undocumented)
- Returns:
- (undocumented)
 
- 
srcIdpublic abstract long srcId()The vertex id of the edge's source vertex.
- 
dstIdpublic abstract long dstId()The vertex id of the edge's destination vertex.
- 
srcAttrThe vertex attribute of the edge's source vertex.
- 
dstAttrThe vertex attribute of the edge's destination vertex.
- 
attrThe attribute associated with the edge.
- 
sendToSrcSends a message to the source vertex.
- 
sendToDstSends a message to the destination vertex.
- 
toEdgeTripletConverts the edge and vertex properties into anEdgeTripletfor convenience.
 
-