public class ShippableVertexPartition<VD> extends VertexPartitionBase<VD>
EdgeRDD
.Modifier and Type | Class and Description |
---|---|
static class |
ShippableVertexPartition.ShippableVertexPartitionOpsConstructor$
Implicit evidence that
ShippableVertexPartition is a member of the
VertexPartitionBaseOpsConstructor typeclass. |
Constructor and Description |
---|
ShippableVertexPartition(org.apache.spark.util.collection.OpenHashSet<Object> index,
Object values,
org.apache.spark.util.collection.BitSet mask,
RoutingTablePartition routingTable,
scala.reflect.ClassTag<VD> evidence$7) |
Modifier and Type | Method and Description |
---|---|
static <VD> ShippableVertexPartition<VD> |
apply(scala.collection.Iterator<scala.Tuple2<Object,VD>> iter,
scala.reflect.ClassTag<VD> evidence$2)
Construct a `ShippableVertexPartition` from the given vertices without any routing table.
|
static <VD> ShippableVertexPartition<VD> |
apply(scala.collection.Iterator<scala.Tuple2<Object,VD>> iter,
RoutingTablePartition routingTable,
VD defaultVal,
scala.reflect.ClassTag<VD> evidence$3)
Construct a
ShippableVertexPartition from the given vertices with the specified routing
table, filling in missing vertices mentioned in the routing table using defaultVal . |
static <VD> ShippableVertexPartition<VD> |
apply(scala.collection.Iterator<scala.Tuple2<Object,VD>> iter,
RoutingTablePartition routingTable,
VD defaultVal,
scala.Function2<VD,VD,VD> mergeFunc,
scala.reflect.ClassTag<VD> evidence$4)
Construct a
ShippableVertexPartition from the given vertices with the specified routing
table, filling in missing vertices mentioned in the routing table using defaultVal ,
and merging duplicate vertex atrribute with mergeFunc. |
org.apache.spark.util.collection.OpenHashSet<Object> |
index() |
org.apache.spark.util.collection.BitSet |
mask() |
RoutingTablePartition |
routingTable() |
static <VD> ShippableVertexPartitionOps<VD> |
shippablePartitionToOps(ShippableVertexPartition<VD> partition,
scala.reflect.ClassTag<VD> evidence$5)
Implicit conversion to allow invoking
VertexPartitionBase operations directly on a
ShippableVertexPartition . |
scala.collection.Iterator<scala.Tuple2<Object,VertexAttributeBlock<VD>>> |
shipVertexAttributes(boolean shipSrc,
boolean shipDst)
Generate a
VertexAttributeBlock for each edge partition keyed on the edge partition ID. |
scala.collection.Iterator<scala.Tuple2<Object,long[]>> |
shipVertexIds()
Generate a
VertexId array for each edge partition keyed on the edge partition ID. |
Object |
values() |
ShippableVertexPartition<VD> |
withRoutingTable(RoutingTablePartition routingTable_)
Return a new ShippableVertexPartition with the specified routing table.
|
public ShippableVertexPartition(org.apache.spark.util.collection.OpenHashSet<Object> index, Object values, org.apache.spark.util.collection.BitSet mask, RoutingTablePartition routingTable, scala.reflect.ClassTag<VD> evidence$7)
public static <VD> ShippableVertexPartition<VD> apply(scala.collection.Iterator<scala.Tuple2<Object,VD>> iter, scala.reflect.ClassTag<VD> evidence$2)
public static <VD> ShippableVertexPartition<VD> apply(scala.collection.Iterator<scala.Tuple2<Object,VD>> iter, RoutingTablePartition routingTable, VD defaultVal, scala.reflect.ClassTag<VD> evidence$3)
ShippableVertexPartition
from the given vertices with the specified routing
table, filling in missing vertices mentioned in the routing table using defaultVal
.public static <VD> ShippableVertexPartition<VD> apply(scala.collection.Iterator<scala.Tuple2<Object,VD>> iter, RoutingTablePartition routingTable, VD defaultVal, scala.Function2<VD,VD,VD> mergeFunc, scala.reflect.ClassTag<VD> evidence$4)
ShippableVertexPartition
from the given vertices with the specified routing
table, filling in missing vertices mentioned in the routing table using defaultVal
,
and merging duplicate vertex atrribute with mergeFunc.public static <VD> ShippableVertexPartitionOps<VD> shippablePartitionToOps(ShippableVertexPartition<VD> partition, scala.reflect.ClassTag<VD> evidence$5)
VertexPartitionBase
operations directly on a
ShippableVertexPartition
.public org.apache.spark.util.collection.OpenHashSet<Object> index()
index
in class VertexPartitionBase<VD>
public Object values()
values
in class VertexPartitionBase<VD>
public org.apache.spark.util.collection.BitSet mask()
mask
in class VertexPartitionBase<VD>
public RoutingTablePartition routingTable()
public ShippableVertexPartition<VD> withRoutingTable(RoutingTablePartition routingTable_)
public scala.collection.Iterator<scala.Tuple2<Object,VertexAttributeBlock<VD>>> shipVertexAttributes(boolean shipSrc, boolean shipDst)
VertexAttributeBlock
for each edge partition keyed on the edge partition ID. The
VertexAttributeBlock
contains the vertex attributes from the current partition that are
referenced in the specified positions in the edge partition.public scala.collection.Iterator<scala.Tuple2<Object,long[]>> shipVertexIds()
VertexId
array for each edge partition keyed on the edge partition ID. The array
contains the visible vertex ids from the current partition that are referenced in the edge
partition.