Class AggregatingEdgeContext<VD,ED,A>

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

public class AggregatingEdgeContext<VD,ED,A> extends EdgeContext<VD,ED,A>
  • Constructor Summary

    Constructors
    Constructor
    Description
    AggregatingEdgeContext(scala.Function2<A,A,A> mergeMsg, Object aggregates, org.apache.spark.util.collection.BitSet bitset)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    The attribute associated with the edge.
    The vertex attribute of the edge's destination vertex.
    long
    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
    setDest(long dstId, int localDstId, VD dstAttr, ED attr)
     
    void
    setSrcOnly(long srcId, int localSrcId, VD srcAttr)
     
    The vertex attribute of the edge's source vertex.
    long
    The vertex id of the edge's source vertex.

    Methods inherited from class org.apache.spark.graphx.EdgeContext

    toEdgeTriplet, unapply

    Methods inherited from class java.lang.Object

    equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Constructor Details

    • AggregatingEdgeContext

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

    • attr

      public ED attr()
      Description copied from class: EdgeContext
      The attribute associated with the edge.
      Specified by:
      attr 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>
    • 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>
    • 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>
    • 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>
    • set

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

      public void setDest(long dstId, int localDstId, VD dstAttr, ED attr)
    • setSrcOnly

      public void setSrcOnly(long srcId, int localSrcId, VD srcAttr)
    • 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>
    • 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>