Package org.apache.spark.graphx


package org.apache.spark.graphx
ALPHA COMPONENT GraphX is a graph processing framework built on top of Spark.
  • Class
    Description
    Edge<ED>
    A single directed edge consisting of a source id, target id, and the data associated with the edge.
    EdgeContext<VD,ED,A>
    Represents an edge along with its neighboring vertices and allows sending messages along the edge.
    The direction of a directed edge relative to a vertex.
    EdgeRDD[ED, VD] extends RDD[Edge[ED} by storing the edges in columnar format on each partition for performance.
    An edge triplet represents an edge along with the vertex attributes of its neighboring vertices.
    Graph<VD,ED>
    The Graph abstractly represents a graph with arbitrary objects associated with vertices and edges.
    Provides utilities for loading Graphs from files.
    GraphOps<VD,ED>
    Contains additional functionality for Graph.
     
    Represents the way edges are assigned to edge partitions based on their source and destination vertex IDs.
    Assigns edges to partitions by hashing the source and destination vertex IDs in a canonical direction, resulting in a random vertex cut that colocates all edges between two vertices, regardless of direction.
    Assigns edges to partitions using only the source vertex ID, colocating edges with the same source.
    Assigns edges to partitions using a 2D partitioning of the sparse edge adjacency matrix, guaranteeing a 2 * sqrt(numParts) bound on vertex replication.
    Assigns edges to partitions by hashing the source and destination vertex IDs, resulting in a random vertex cut that colocates all same-direction edges between two vertices.
    Implements a Pregel-like bulk-synchronous message-passing API.
    Represents a subset of the fields of an [[EdgeTriplet]] or [[EdgeContext]].
    Extends RDD[(VertexId, VD)] by ensuring that there is only one entry for each vertex and by pre-indexing the entries for fast, efficient joins.