Package org.apache.spark.graphx.impl
Class AggregatingEdgeContext<VD,ED,A>  
Object
org.apache.spark.graphx.EdgeContext<VD,ED,A>
  
org.apache.spark.graphx.impl.AggregatingEdgeContext<VD,ED,A>  
- 
Constructor SummaryConstructorsConstructorDescriptionAggregatingEdgeContext(scala.Function2<A, A, A> mergeMsg, Object aggregates, org.apache.spark.util.collection.BitSet bitset) 
- 
Method SummaryModifier and TypeMethodDescriptionattr()The attribute associated with the edge.dstAttr()The vertex attribute of the edge's destination vertex.longdstId()The vertex id of the edge's destination vertex.voidSends a message to the destination vertex.voidSends a message to the source vertex.voidvoidvoidsetSrcOnly(long srcId, int localSrcId, VD srcAttr) srcAttr()The vertex attribute of the edge's source vertex.longsrcId()The vertex id of the edge's source vertex.Methods inherited from class org.apache.spark.graphx.EdgeContexttoEdgeTriplet, unapply
- 
Constructor Details- 
AggregatingEdgeContext
 
- 
- 
Method Details- 
attrDescription copied from class:EdgeContextThe attribute associated with the edge.- Specified by:
- attrin class- EdgeContext<VD,- ED, - A> 
 
- 
dstAttrDescription copied from class:EdgeContextThe vertex attribute of the edge's destination vertex.- Specified by:
- dstAttrin class- EdgeContext<VD,- ED, - A> 
 
- 
dstIdpublic long dstId()Description copied from class:EdgeContextThe vertex id of the edge's destination vertex.- Specified by:
- dstIdin class- EdgeContext<VD,- ED, - A> 
 
- 
sendToDstDescription copied from class:EdgeContextSends a message to the destination vertex.- Specified by:
- sendToDstin class- EdgeContext<VD,- ED, - A> 
 
- 
sendToSrcDescription copied from class:EdgeContextSends a message to the source vertex.- Specified by:
- sendToSrcin class- EdgeContext<VD,- ED, - A> 
 
- 
set
- 
setDest
- 
setSrcOnly
- 
srcAttrDescription copied from class:EdgeContextThe vertex attribute of the edge's source vertex.- Specified by:
- srcAttrin class- EdgeContext<VD,- ED, - A> 
 
- 
srcIdpublic long srcId()Description copied from class:EdgeContextThe vertex id of the edge's source vertex.- Specified by:
- srcIdin class- EdgeContext<VD,- ED, - A> 
 
 
-