Class EdgeRDD<ED>

Object
org.apache.spark.rdd.RDD<Edge<ED>>
org.apache.spark.graphx.EdgeRDD<ED>
All Implemented Interfaces:
Serializable, org.apache.spark.internal.Logging, scala.Serializable
Direct Known Subclasses:
EdgeRDDImpl

public abstract class EdgeRDD<ED> extends RDD<Edge<ED>>
EdgeRDD[ED, VD] extends RDD[Edge[ED} by storing the edges in columnar format on each partition for performance. It may additionally store the vertex attributes associated with each edge to provide the triplet view. Shipping of the vertex attributes is managed by impl.ReplicatedVertexView.
See Also:
  • Constructor Details

  • Method Details

    • fromEdges

      public static <ED, VD> EdgeRDDImpl<ED,VD> fromEdges(RDD<Edge<ED>> edges, scala.reflect.ClassTag<ED> evidence$4, scala.reflect.ClassTag<VD> evidence$5)
      Creates an EdgeRDD from a set of edges.

      Parameters:
      edges - (undocumented)
      evidence$4 - (undocumented)
      evidence$5 - (undocumented)
      Returns:
      (undocumented)
    • compute

      public scala.collection.Iterator<Edge<ED>> compute(Partition part, TaskContext context)
      Description copied from class: RDD
      :: DeveloperApi :: Implemented by subclasses to compute a given partition.
      Specified by:
      compute in class RDD<Edge<ED>>
      Parameters:
      part - (undocumented)
      context - (undocumented)
      Returns:
      (undocumented)
    • mapValues

      public abstract <ED2> EdgeRDD<ED2> mapValues(scala.Function1<Edge<ED>,ED2> f, scala.reflect.ClassTag<ED2> evidence$1)
      Map the values in an edge partitioning preserving the structure but changing the values.

      Parameters:
      f - the function from an edge to a new edge value
      evidence$1 - (undocumented)
      Returns:
      a new EdgeRDD containing the new edge values
    • reverse

      public abstract EdgeRDD<ED> reverse()
      Reverse all the edges in this RDD.

      Returns:
      a new EdgeRDD containing all the edges reversed
    • innerJoin

      public abstract <ED2, ED3> EdgeRDD<ED3> innerJoin(EdgeRDD<ED2> other, scala.Function4<Object,Object,ED,ED2,ED3> f, scala.reflect.ClassTag<ED2> evidence$2, scala.reflect.ClassTag<ED3> evidence$3)
      Inner joins this EdgeRDD with another EdgeRDD, assuming both are partitioned using the same PartitionStrategy.

      Parameters:
      other - the EdgeRDD to join with
      f - the join function applied to corresponding values of this and other
      evidence$2 - (undocumented)
      evidence$3 - (undocumented)
      Returns:
      a new EdgeRDD containing only edges that appear in both this and other, with values supplied by f