org.apache.spark

graphx

package graphx

GraphX is a graph processing framework built on top of Spark.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. graphx
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class Edge[ED](srcId: VertexId = 0, dstId: VertexId = 0, attr: ED = null.asInstanceOf[ED]) extends Serializable with Product

    A single directed edge consisting of a source id, target id, and the data associated with the edge.

  2. class EdgeDirection extends Serializable

    The direction of a directed edge relative to a vertex.

  3. class EdgeRDD[ED] extends RDD[Edge[ED]]

    EdgeRDD[ED] extends RDD[Edge[ED]] by storing the edges in columnar format on each partition for performance.

  4. class EdgeTriplet[VD, ED] extends Edge[ED]

    An edge triplet represents an edge along with the vertex attributes of its neighboring vertices.

  5. abstract class Graph[VD, ED] extends Serializable

    The Graph abstractly represents a graph with arbitrary objects associated with vertices and edges.

  6. class GraphKryoRegistrator extends KryoRegistrator

    Registers GraphX classes with Kryo for improved performance.

  7. class GraphOps[VD, ED] extends Serializable

    Contains additional functionality for Graph.

  8. type PartitionID = Int

    Integer identifer of a graph partition.

  9. trait PartitionStrategy extends Serializable

    Represents the way edges are assigned to edge partitions based on their source and destination vertex IDs.

  10. type VertexId = Long

    A 64-bit vertex identifier that uniquely identifies a vertex within a graph.

    A 64-bit vertex identifier that uniquely identifies a vertex within a graph. It does not need to follow any ordering or any constraints other than uniqueness.

  11. class VertexRDD[VD] extends RDD[(VertexId, VD)]

    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.

Value Members

  1. object Edge extends Serializable

  2. object EdgeDirection extends Serializable

    A set of EdgeDirections.

  3. object Graph extends Serializable

    The Graph object contains a collection of routines used to construct graphs from RDDs.

  4. object GraphLoader extends Logging

    Provides utilities for loading Graphs from files.

  5. object PartitionStrategy extends Serializable

    Collection of built-in PartitionStrategy implementations.

  6. object Pregel

    Implements a Pregel-like bulk-synchronous message-passing API.

  7. object VertexRDD extends Serializable

    The VertexRDD singleton is used to construct VertexRDDs.

  8. package impl

  9. package lib

  10. package util

Inherited from AnyRef

Inherited from Any

Ungrouped