|
|||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | ||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
Objectorg.apache.spark.graphx.EdgeContext<VD,ED,A>
org.apache.spark.graphx.impl.AggregatingEdgeContext<VD,ED,A>
public class AggregatingEdgeContext<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 |
---|
public AggregatingEdgeContext(scala.Function2<A,A,A> mergeMsg, Object aggregates, org.apache.spark.util.collection.BitSet bitset)
Method Detail |
---|
public void set(long srcId, long dstId, int localSrcId, int localDstId, VD srcAttr, VD dstAttr, ED attr)
public void setSrcOnly(long srcId, int localSrcId, VD srcAttr)
public void setRest(long dstId, int localDstId, VD dstAttr, ED attr)
public long srcId()
EdgeContext
srcId
in class EdgeContext<VD,ED,A>
public long dstId()
EdgeContext
dstId
in class EdgeContext<VD,ED,A>
public VD srcAttr()
EdgeContext
srcAttr
in class EdgeContext<VD,ED,A>
public VD dstAttr()
EdgeContext
dstAttr
in class EdgeContext<VD,ED,A>
public ED attr()
EdgeContext
attr
in class EdgeContext<VD,ED,A>
public void sendToSrc(A msg)
EdgeContext
sendToSrc
in class EdgeContext<VD,ED,A>
public void sendToDst(A msg)
EdgeContext
sendToDst
in class EdgeContext<VD,ED,A>
|
|||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | ||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |