org.apache.spark.graphx.impl
Class AggregatingEdgeContext<VD,ED,A>

Object
  extended by org.apache.spark.graphx.EdgeContext<VD,ED,A>
      extended by org.apache.spark.graphx.impl.AggregatingEdgeContext<VD,ED,A>

public class AggregatingEdgeContext<VD,ED,A>
extends EdgeContext<VD,ED,A>


Constructor Summary
AggregatingEdgeContext(scala.Function2<A,A,A> mergeMsg, Object aggregates, org.apache.spark.util.collection.BitSet bitset)
           
 
Method Summary
 ED attr()
          The attribute associated with the edge.
 VD dstAttr()
          The vertex attribute of the edge's destination vertex.
 long dstId()
          The vertex id of the edge's destination vertex.
 void sendToDst(A msg)
          Sends a message to the destination vertex.
 void sendToSrc(A msg)
          Sends a message to the source vertex.
 void set(long srcId, long dstId, int localSrcId, int localDstId, VD srcAttr, VD dstAttr, ED attr)
           
 void setRest(long dstId, int localDstId, VD dstAttr, ED attr)
           
 void setSrcOnly(long srcId, int localSrcId, VD srcAttr)
           
 VD srcAttr()
          The vertex attribute of the edge's source vertex.
 long srcId()
          The vertex id of the edge's source vertex.
 
Methods inherited from class org.apache.spark.graphx.EdgeContext
toEdgeTriplet, unapply
 
Methods inherited from class Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Constructor Detail

AggregatingEdgeContext

public AggregatingEdgeContext(scala.Function2<A,A,A> mergeMsg,
                              Object aggregates,
                              org.apache.spark.util.collection.BitSet bitset)
Method Detail

set

public void set(long srcId,
                long dstId,
                int localSrcId,
                int localDstId,
                VD srcAttr,
                VD dstAttr,
                ED attr)

setSrcOnly

public void setSrcOnly(long srcId,
                       int localSrcId,
                       VD srcAttr)

setRest

public void setRest(long dstId,
                    int localDstId,
                    VD dstAttr,
                    ED attr)

srcId

public long srcId()
Description copied from class: EdgeContext
The vertex id of the edge's source vertex.

Specified by:
srcId in class EdgeContext<VD,ED,A>

dstId

public long dstId()
Description copied from class: EdgeContext
The vertex id of the edge's destination vertex.

Specified by:
dstId in class EdgeContext<VD,ED,A>

srcAttr

public VD srcAttr()
Description copied from class: EdgeContext
The vertex attribute of the edge's source vertex.

Specified by:
srcAttr in class EdgeContext<VD,ED,A>

dstAttr

public VD dstAttr()
Description copied from class: EdgeContext
The vertex attribute of the edge's destination vertex.

Specified by:
dstAttr in class EdgeContext<VD,ED,A>

attr

public ED attr()
Description copied from class: EdgeContext
The attribute associated with the edge.

Specified by:
attr in class EdgeContext<VD,ED,A>

sendToSrc

public void sendToSrc(A msg)
Description copied from class: EdgeContext
Sends a message to the source vertex.

Specified by:
sendToSrc in class EdgeContext<VD,ED,A>

sendToDst

public void sendToDst(A msg)
Description copied from class: EdgeContext
Sends a message to the destination vertex.

Specified by:
sendToDst in class EdgeContext<VD,ED,A>