Class/Object

org.apache.flink.graph.scala

Graph

Related Docs: object Graph | package scala

Permalink

final class Graph[K, VV, EV] extends AnyRef

Represents a graph consisting of Edge edges and Vertex vertices.

K

the key type for vertex and edge identifiers

VV

the value type for vertices

EV

the value type for edges

See also

org.apache.flink.graph.Vertex

org.apache.flink.graph.Edge

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Graph
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new Graph(jgraph: graph.Graph[K, VV, EV])(implicit arg0: TypeInformation[K], arg1: ClassTag[K], arg2: TypeInformation[VV], arg3: ClassTag[VV], arg4: TypeInformation[EV], arg5: ClassTag[EV])

    Permalink

    jgraph

    the underlying java api Graph.

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def addEdge(source: Vertex[K, VV], target: Vertex[K, VV], edgeValue: EV): Graph[K, VV, EV]

    Permalink

    Adds the given edge to the graph.

    Adds the given edge to the graph. If the source and target vertices do not exist in the graph, they will also be added.

    source

    the source vertex of the edge

    target

    the target vertex of the edge

    edgeValue

    the edge value

    returns

    the new graph containing the existing vertices and edges plus the newly added edge

  5. def addEdges(edges: List[Edge[K, EV]]): Graph[K, VV, EV]

    Permalink

    Adds the given list edges to the graph.

    Adds the given list edges to the graph.

    When adding an edge for a non-existing set of vertices, the edge is considered invalid and ignored.

    edges

    the data set of edges to be added

    returns

    a new graph containing the existing edges plus the newly added edges.

  6. def addVertex(vertex: Vertex[K, VV]): Graph[K, VV, EV]

    Permalink

    Adds the input vertex to the graph.

    Adds the input vertex to the graph. If the vertex already exists in the graph, it will not be added again.

    vertex

    the vertex to be added

    returns

    the new graph containing the existing vertices as well as the one just added

  7. def addVertices(vertices: List[Vertex[K, VV]]): Graph[K, VV, EV]

    Permalink

    Adds the list of vertices, passed as input, to the graph.

    Adds the list of vertices, passed as input, to the graph. If the vertices already exist in the graph, they will not be added once more.

    vertices

    the list of vertices to add

    returns

    the new graph containing the existing and newly added vertices

  8. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  9. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  10. def difference(graph: Graph[K, VV, EV]): Graph[K, VV, EV]

    Permalink

    Performs Difference on the vertex and edge sets of the input graphs removes common vertices and edges.

    Performs Difference on the vertex and edge sets of the input graphs removes common vertices and edges. If a source/target vertex is removed, its corresponding edge will also be removed

    graph

    the graph to perform difference with

    returns

    a new graph where the common vertices and edges have been removed

  11. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  12. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  13. def filterOnEdges(edgeFilterFun: (Edge[K, EV]) ⇒ Boolean): Graph[K, VV, EV]

    Permalink

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.

    edgeFilterFun

    the filter function for edges.

    returns

    the resulting sub-graph.

  14. def filterOnEdges(edgeFilter: FilterFunction[Edge[K, EV]]): Graph[K, VV, EV]

    Permalink

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.

    edgeFilter

    the filter function for edges.

    returns

    the resulting sub-graph.

  15. def filterOnVertices(vertexFilterFun: (Vertex[K, VV]) ⇒ Boolean): Graph[K, VV, EV]

    Permalink

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.

    vertexFilterFun

    the filter function for vertices.

    returns

    the resulting sub-graph.

  16. def filterOnVertices(vertexFilter: FilterFunction[Vertex[K, VV]]): Graph[K, VV, EV]

    Permalink

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.

    Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.

    vertexFilter

    the filter function for vertices.

    returns

    the resulting sub-graph.

  17. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  18. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  19. def getDegrees(): DataSet[(K, LongValue)]

    Permalink

    Return the degree of all vertices in the graph

    Return the degree of all vertices in the graph

    returns

    A DataSet of Tuple2<vertexId, degree>

  20. def getEdgeIds(): DataSet[(K, K)]

    Permalink

    returns

    The IDs of the edges as DataSet

  21. def getEdges: DataSet[Edge[K, EV]]

    Permalink

    returns

    the edge DataSet.

  22. def getEdgesAsTuple3(): DataSet[(K, K, EV)]

    Permalink

    returns

    the edge DataSet as Tuple3.

  23. def getTriplets(): DataSet[Triplet[K, VV, EV]]

    Permalink

    returns

    a DataSet of Triplets, consisting of (srcVertexId, trgVertexId, srcVertexValue, trgVertexValue, edgeValue)

  24. def getUndirected(): Graph[K, VV, EV]

    Permalink

    This operation adds all inverse-direction edges to the graph.

    This operation adds all inverse-direction edges to the graph.

    returns

    the undirected graph.

  25. def getVertexIds(): DataSet[K]

    Permalink

    returns

    The IDs of the vertices as DataSet

  26. def getVertices: DataSet[Vertex[K, VV]]

    Permalink

    returns

    the vertex DataSet.

  27. def getVerticesAsTuple2(): DataSet[(K, VV)]

    Permalink

    returns

    the vertex DataSet as Tuple2.

  28. def groupReduceOnEdges[T](edgesFunction: EdgesFunction[K, EV, T], direction: EdgeDirection)(implicit arg0: TypeInformation[T], arg1: ClassTag[T]): DataSet[T]

    Permalink

    Compute an aggregate over the edges of each vertex.

    Compute an aggregate over the edges of each vertex. The function applied on the edges has access to the vertex value.

    T

    the output type

    edgesFunction

    the function to apply to the neighborhood

    direction

    the edge direction (in-, out-, all-)

    returns

    a dataset of a T

  29. def groupReduceOnEdges[T](edgesFunction: EdgesFunctionWithVertexValue[K, VV, EV, T], direction: EdgeDirection)(implicit arg0: TypeInformation[T], arg1: ClassTag[T]): DataSet[T]

    Permalink

    Compute an aggregate over the edges of each vertex.

    Compute an aggregate over the edges of each vertex. The function applied on the edges has access to the vertex value.

    T

    the output type

    edgesFunction

    the function to apply to the neighborhood

    direction

    the edge direction (in-, out-, all-)

    returns

    a dataset of a T

  30. def groupReduceOnNeighbors[T](neighborsFunction: NeighborsFunction[K, VV, EV, T], direction: EdgeDirection)(implicit arg0: TypeInformation[T], arg1: ClassTag[T]): DataSet[T]

    Permalink

    Compute an aggregate over the neighbors (edges and vertices) of each vertex.

    Compute an aggregate over the neighbors (edges and vertices) of each vertex.

    T

    the output type

    neighborsFunction

    the function to apply to the neighborhood

    direction

    the edge direction (in-, out-, all-)

    returns

    a dataset of a T

  31. def groupReduceOnNeighbors[T](neighborsFunction: NeighborsFunctionWithVertexValue[K, VV, EV, T], direction: EdgeDirection)(implicit arg0: TypeInformation[T], arg1: ClassTag[T]): DataSet[T]

    Permalink

    Compute an aggregate over the neighbors (edges and vertices) of each vertex.

    Compute an aggregate over the neighbors (edges and vertices) of each vertex. The function applied on the neighbors has access to the vertex value.

    T

    the output type

    neighborsFunction

    the function to apply to the neighborhood

    direction

    the edge direction (in-, out-, all-)

    returns

    a dataset of a T

  32. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  33. def inDegrees(): DataSet[(K, LongValue)]

    Permalink

    Return the in-degree of all vertices in the graph

    Return the in-degree of all vertices in the graph

    returns

    A DataSet of Tuple2<vertexId, inDegree>

  34. def intersect(graph: Graph[K, VV, EV], distinctEdges: Boolean): Graph[K, NullValue, EV]

    Permalink

    Performs intersect on the edge sets of the input graphs.

    Performs intersect on the edge sets of the input graphs. Edges are considered equal, if they have the same source identifier, target identifier and edge value.

    The method computes pairs of equal edges from the input graphs. If the same edge occurs multiple times in the input graphs, there will be multiple edge pairs to be considered. Each edge instance can only be part of one pair. If the given parameter distinctEdges is set to true, there will be exactly one edge in the output graph representing all pairs of equal edges. If the parameter is set to false, both edges of each pair will be in the output.

    Vertices in the output graph will have no vertex values.

    graph

    the graph to perform intersect with

    distinctEdges

    if set to { @code true}, there will be exactly one edge in the output graph representing all pairs of equal edges, otherwise, for each pair, both edges will be in the output graph

    returns

    a new graph which contains only common vertices and edges from the input graphs

  35. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  36. def joinWithEdges[T](inputDataSet: DataSet[(K, K, T)], fun: (EV, T) ⇒ EV)(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records.

    Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records. The first two fields of the input DataSet are used as join keys.

    T

    the type of the third field of the input Tuple3 DataSet.

    inputDataSet

    the DataSet to join with. The first two fields of the Tuple3 are used as the composite join key and the third field is passed as a parameter to the transformation function.

    fun

    the transformation function to apply. The first parameter is the current edge value and the second parameter is the value of the matched Tuple3 from the input DataSet.

    returns

    a new Graph, where the edge values have been updated according to the result of the edgeJoinFunction.

  37. def joinWithEdges[T](inputDataSet: DataSet[(K, K, T)], edgeJoinFunction: EdgeJoinFunction[EV, T])(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records.

    Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records. The first two fields of the input DataSet are used as join keys.

    T

    the type of the third field of the input Tuple3 DataSet.

    inputDataSet

    the DataSet to join with. The first two fields of the Tuple3 are used as the composite join key and the third field is passed as a parameter to the transformation function.

    edgeJoinFunction

    the transformation function to apply. The first parameter is the current edge value and the second parameter is the value of the matched Tuple3 from the input DataSet.

    returns

    a new Graph, where the edge values have been updated according to the result of the edgeJoinFunction.

  38. def joinWithEdgesOnSource[T](inputDataSet: DataSet[(K, T)], fun: (EV, T) ⇒ EV)(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records. The source ID of the edges input and the first field of the input DataSet are used as join keys.

    T

    the type of the second field of the input Tuple2 DataSet.

    inputDataSet

    the DataSet to join with. The first field of the Tuple2 is used as the join key and the second field is passed as a parameter to the transformation function.

    fun

    the transformation function to apply. The first parameter is the current edge value and the second parameter is the value of the matched Tuple2 from the input DataSet.

    returns

    a new Graph, where the edge values have been updated according to the result of the edgeJoinFunction.

  39. def joinWithEdgesOnSource[T](inputDataSet: DataSet[(K, T)], edgeJoinFunction: EdgeJoinFunction[EV, T])(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records. The source ID of the edges input and the first field of the input DataSet are used as join keys.

    T

    the type of the second field of the input Tuple2 DataSet.

    inputDataSet

    the DataSet to join with. The first field of the Tuple2 is used as the join key and the second field is passed as a parameter to the transformation function.

    edgeJoinFunction

    the transformation function to apply. The first parameter is the current edge value and the second parameter is the value of the matched Tuple2 from the input DataSet.

    returns

    a new Graph, where the edge values have been updated according to the result of the edgeJoinFunction.

  40. def joinWithEdgesOnTarget[T](inputDataSet: DataSet[(K, T)], fun: (EV, T) ⇒ EV)(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records. The target ID of the edges input and the first field of the input DataSet are used as join keys.

    T

    the type of the second field of the input Tuple2 DataSet.

    inputDataSet

    the DataSet to join with. The first field of the Tuple2 is used as the join key and the second field is passed as a parameter to the transformation function.

    fun

    the transformation function to apply. The first parameter is the current edge value and the second parameter is the value of the matched Tuple2 from the input DataSet.

    returns

    a new Graph, where the edge values have been updated according to the result of the edgeJoinFunction.

  41. def joinWithEdgesOnTarget[T](inputDataSet: DataSet[(K, T)], edgeJoinFunction: EdgeJoinFunction[EV, T])(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.

    Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records. The target ID of the edges input and the first field of the input DataSet are used as join keys.

    T

    the type of the second field of the input Tuple2 DataSet.

    inputDataSet

    the DataSet to join with. The first field of the Tuple2 is used as the join key and the second field is passed as a parameter to the transformation function.

    edgeJoinFunction

    the transformation function to apply. The first parameter is the current edge value and the second parameter is the value of the matched Tuple2 from the input DataSet.

    returns

    a new Graph, where the edge values have been updated according to the result of the edgeJoinFunction.

  42. def joinWithVertices[T](inputDataSet: DataSet[(K, T)], fun: (VV, T) ⇒ VV)(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.

    Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records. The vertex ID and the first field of the Tuple2 DataSet are used as the join keys.

    T

    the type of the second field of the input Tuple2 DataSet.

    inputDataSet

    the Tuple2 DataSet to join with. The first field of the Tuple2 is used as the join key and the second field is passed as a parameter to the transformation function.

    fun

    the transformation function to apply. The first parameter is the current vertex value and the second parameter is the value of the matched Tuple2 from the input DataSet.

    returns

    a new Graph, where the vertex values have been updated according to the result of the vertexJoinFunction.

  43. def joinWithVertices[T](inputDataSet: DataSet[(K, T)], vertexJoinFunction: VertexJoinFunction[VV, T])(implicit arg0: TypeInformation[T]): Graph[K, VV, EV]

    Permalink

    Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.

    Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records. The vertex ID and the first field of the Tuple2 DataSet are used as the join keys.

    T

    the type of the second field of the input Tuple2 DataSet.

    inputDataSet

    the Tuple2 DataSet to join with. The first field of the Tuple2 is used as the join key and the second field is passed as a parameter to the transformation function.

    vertexJoinFunction

    the transformation function to apply. The first parameter is the current vertex value and the second parameter is the value of the matched Tuple2 from the input DataSet.

    returns

    a new Graph, where the vertex values have been updated according to the result of the vertexJoinFunction.

  44. def mapEdges[NV](fun: (Edge[K, EV]) ⇒ NV)(implicit arg0: TypeInformation[NV], arg1: ClassTag[NV]): Graph[K, VV, NV]

    Permalink

    Apply a function to the attribute of each edge in the graph.

    Apply a function to the attribute of each edge in the graph.

    fun

    the map function to apply.

    returns

    a new graph

  45. def mapEdges[NV](mapper: MapFunction[Edge[K, EV], NV])(implicit arg0: TypeInformation[NV], arg1: ClassTag[NV]): Graph[K, VV, NV]

    Permalink

    Apply a function to the attribute of each edge in the graph.

    Apply a function to the attribute of each edge in the graph.

    mapper

    the map function to apply.

    returns

    a new graph

  46. def mapVertices[NV](fun: (Vertex[K, VV]) ⇒ NV)(implicit arg0: TypeInformation[NV], arg1: ClassTag[NV]): Graph[K, NV, EV]

    Permalink

    Apply a function to the attribute of each vertex in the graph.

    Apply a function to the attribute of each vertex in the graph.

    fun

    the map function to apply.

    returns

    a new graph

  47. def mapVertices[NV](mapper: MapFunction[Vertex[K, VV], NV])(implicit arg0: TypeInformation[NV], arg1: ClassTag[NV]): Graph[K, NV, EV]

    Permalink

    Apply a function to the attribute of each vertex in the graph.

    Apply a function to the attribute of each vertex in the graph.

    mapper

    the map function to apply.

    returns

    a new graph

  48. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  49. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  50. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  51. def numberOfEdges(): Long

    Permalink

    returns

    a long integer representing the number of edges

  52. def numberOfVertices(): Long

    Permalink

    returns

    a long integer representing the number of vertices

  53. def outDegrees(): DataSet[(K, LongValue)]

    Permalink

    Return the out-degree of all vertices in the graph

    Return the out-degree of all vertices in the graph

    returns

    A DataSet of Tuple2<vertexId, outDegree>

  54. def reduceOnEdges(reduceEdgesFunction: ReduceEdgesFunction[EV], direction: EdgeDirection): DataSet[(K, EV)]

    Permalink

    Compute a reduce transformation over the neighbors' vertex values of each vertex.

    Compute a reduce transformation over the neighbors' vertex values of each vertex. For each vertex, the transformation consecutively calls a ReduceNeighborsFunction until only a single value for each vertex remains. The ReduceNeighborsFunction combines a pair of neighbor vertex values into one new value of the same type.

    reduceEdgesFunction

    the reduce function to apply to the edges of each vertex.

    direction

    the edge direction (in-, out-, all-)

    returns

    a Dataset of Tuple2, with one tuple per vertex. The first field of the Tuple2 is the vertex ID and the second field is the aggregate value computed by the provided ReduceNeighborsFunction.

  55. def reduceOnNeighbors(reduceNeighborsFunction: ReduceNeighborsFunction[VV], direction: EdgeDirection): DataSet[(K, VV)]

    Permalink

    Compute a reduce transformation over the neighbors' vertex values of each vertex.

    Compute a reduce transformation over the neighbors' vertex values of each vertex. For each vertex, the transformation consecutively calls a ReduceNeighborsFunction until only a single value for each vertex remains. The ReduceNeighborsFunction combines a pair of neighbor vertex values into one new value of the same type.

    reduceNeighborsFunction

    the reduce function to apply to the neighbors of each vertex.

    direction

    the edge direction (in-, out-, all-)

    returns

    a Dataset of Tuple2, with one tuple per vertex. The first field of the Tuple2 is the vertex ID and the second field is the aggregate value computed by the provided ReduceNeighborsFunction.

  56. def removeEdge(edge: Edge[K, EV]): Graph[K, VV, EV]

    Permalink

    Removes all edges that match the given edge from the graph.

    Removes all edges that match the given edge from the graph.

    edge

    the edge to remove

    returns

    the new graph containing the existing vertices and edges without the removed edges

  57. def removeEdges(edges: List[Edge[K, EV]]): Graph[K, VV, EV]

    Permalink

    Removes all the edges that match the edges in the given data set from the graph.

    Removes all the edges that match the edges in the given data set from the graph.

    edges

    the list of edges to be removed

    returns

    a new graph where the edges have been removed and in which the vertices remained intact

  58. def removeVertex(vertex: Vertex[K, VV]): Graph[K, VV, EV]

    Permalink

    Removes the given vertex and its edges from the graph.

    Removes the given vertex and its edges from the graph.

    vertex

    the vertex to remove

    returns

    the new graph containing the existing vertices and edges without the removed vertex and its edges

  59. def removeVertices(vertices: List[Vertex[K, VV]]): Graph[K, VV, EV]

    Permalink

    Removes the given vertex and its edges from the graph.

    Removes the given vertex and its edges from the graph.

    vertices

    list of vertices to remove

    returns

    the new graph containing the existing vertices and edges without the removed vertex and its edges

  60. def reverse(): Graph[K, VV, EV]

    Permalink

    Reverse the direction of the edges in the graph

    Reverse the direction of the edges in the graph

    returns

    a new graph with all edges reversed

    Exceptions thrown
  61. def run[T](analytic: GraphAnalytic[K, VV, EV, T])(implicit arg0: TypeInformation[T], arg1: ClassTag[T]): GraphAnalytic[K, VV, EV, T]

    Permalink

    A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators.

    A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators. A Flink program has a single point of execution. A GraphAnalytic defers execution to the user to allow composing multiple analytics and algorithms into a single program.

    analytic

    the analytic to run on the Graph

  62. def run[T](algorithm: GraphAlgorithm[K, VV, EV, T])(implicit arg0: TypeInformation[T], arg1: ClassTag[T]): T

    Permalink

    algorithm

    the algorithm to run on the Graph

    returns

    the result of the graph algorithm

  63. def runGatherSumApplyIteration[M](gatherFunction: GatherFunction[VV, EV, M], sumFunction: SumFunction[VV, EV, M], applyFunction: ApplyFunction[K, VV, M], maxIterations: Int, parameters: GSAConfiguration): Graph[K, VV, EV]

    Permalink

    Runs a Gather-Sum-Apply iteration on the graph with configuration options.

    Runs a Gather-Sum-Apply iteration on the graph with configuration options.

    M

    the intermediate type used between gather, sum and apply

    gatherFunction

    the gather function collects information about adjacent vertices and edges

    sumFunction

    the sum function aggregates the gathered information

    applyFunction

    the apply function updates the vertex values with the aggregates

    maxIterations

    maximum number of iterations to perform

    parameters

    the iteration configuration parameters

    returns

    the updated Graph after the gather-sum-apply iteration has converged or after maximumNumberOfIterations.

  64. def runGatherSumApplyIteration[M](gatherFunction: GatherFunction[VV, EV, M], sumFunction: SumFunction[VV, EV, M], applyFunction: ApplyFunction[K, VV, M], maxIterations: Int): Graph[K, VV, EV]

    Permalink

    Runs a Gather-Sum-Apply iteration on the graph.

    Runs a Gather-Sum-Apply iteration on the graph. No configuration options are provided.

    M

    the intermediate type used between gather, sum and apply

    gatherFunction

    the gather function collects information about adjacent vertices and edges

    sumFunction

    the sum function aggregates the gathered information

    applyFunction

    the apply function updates the vertex values with the aggregates

    maxIterations

    maximum number of iterations to perform

    returns

    the updated Graph after the gather-sum-apply iteration has converged or after maximumNumberOfIterations.

  65. def runScatterGatherIteration[M](scatterFunction: ScatterFunction[K, VV, M, EV], gatherFunction: GatherFunction[K, VV, M], maxIterations: Int, parameters: ScatterGatherConfiguration): Graph[K, VV, EV]

    Permalink

    Runs a scatter-gather iteration on the graph with configuration options.

    Runs a scatter-gather iteration on the graph with configuration options.

    scatterFunction

    the scatter function

    gatherFunction

    the gather function

    maxIterations

    maximum number of iterations to perform

    parameters

    the iteration configuration parameters

    returns

    the updated Graph after the scatter-gather iteration has converged or after maximumNumberOfIterations.

  66. def runScatterGatherIteration[M](scatterFunction: ScatterFunction[K, VV, M, EV], gatherFunction: GatherFunction[K, VV, M], maxIterations: Int): Graph[K, VV, EV]

    Permalink

    Runs a scatter-gather iteration on the graph.

    Runs a scatter-gather iteration on the graph. No configuration options are provided.

    scatterFunction

    the scatter function

    gatherFunction

    the gather function

    maxIterations

    maximum number of iterations to perform

    returns

    the updated Graph after the scatter-gather iteration has converged or after maximumNumberOfIterations.

  67. def runVertexCentricIteration[M](computeFunction: ComputeFunction[K, VV, EV, M], combineFunction: MessageCombiner[K, M], maxIterations: Int, parameters: VertexCentricConfiguration): Graph[K, VV, EV]

    Permalink

    Runs a vertex-centric iteration on the graph with configuration options.

    Runs a vertex-centric iteration on the graph with configuration options.

    computeFunction

    the compute function

    combineFunction

    the optional message combiner function

    maxIterations

    maximum number of iterations to perform

    parameters

    the iteration configuration parameters

    returns

    the updated Graph after the vertex-centric iteration has converged or after maximumNumberOfIterations.

  68. def runVertexCentricIteration[M](computeFunction: ComputeFunction[K, VV, EV, M], combineFunction: MessageCombiner[K, M], maxIterations: Int): Graph[K, VV, EV]

    Permalink

    Runs a vertex-centric iteration on the graph.

    Runs a vertex-centric iteration on the graph. No configuration options are provided.

    computeFunction

    the compute function

    combineFunction

    the optional message combiner function

    maxIterations

    maximum number of iterations to perform

    returns

    the updated Graph after the vertex-centric iteration has converged or after maximumNumberOfIterations.

  69. def subgraph(vertexFilterFun: (Vertex[K, VV]) ⇒ Boolean, edgeFilterFun: (Edge[K, EV]) ⇒ Boolean): Graph[K, VV, EV]

    Permalink

    Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.

    Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.

    vertexFilterFun

    the filter function for vertices.

    edgeFilterFun

    the filter function for edges.

    returns

    the resulting sub-graph.

  70. def subgraph(vertexFilter: FilterFunction[Vertex[K, VV]], edgeFilter: FilterFunction[Edge[K, EV]]): Graph[K, VV, EV]

    Permalink

    Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.

    Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.

    vertexFilter

    the filter function for vertices.

    edgeFilter

    the filter function for edges.

    returns

    the resulting sub-graph.

  71. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  72. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  73. def translateEdgeValues[NEW](fun: (EV, NEW) ⇒ NEW)(implicit arg0: TypeInformation[NEW], arg1: ClassTag[NEW]): Graph[K, VV, NEW]

    Permalink

    Translate edge values using the given function.

    Translate edge values using the given function.

    fun

    implements conversion from EV to NEW

    returns

    graph with translated edge values

  74. def translateEdgeValues[NEW](translator: TranslateFunction[EV, NEW])(implicit arg0: TypeInformation[NEW], arg1: ClassTag[NEW]): Graph[K, VV, NEW]

    Permalink

    Translate edge values using the given MapFunction.

    Translate edge values using the given MapFunction.

    translator

    implements conversion from EV to NEW

    returns

    graph with translated edge values

  75. def translateGraphIds[NEW](fun: (K, NEW) ⇒ NEW)(implicit arg0: TypeInformation[NEW], arg1: ClassTag[NEW]): Graph[NEW, VV, EV]

    Permalink

    Translate vertex and edge IDs using the given function.

    Translate vertex and edge IDs using the given function.

    fun

    implements conversion from K to NEW

    returns

    graph with translated vertex and edge IDs

  76. def translateGraphIds[NEW](translator: TranslateFunction[K, NEW])(implicit arg0: TypeInformation[NEW], arg1: ClassTag[NEW]): Graph[NEW, VV, EV]

    Permalink

    Translate vertex and edge IDs using the given MapFunction.

    Translate vertex and edge IDs using the given MapFunction.

    translator

    implements conversion from K to NEW

    returns

    graph with translated vertex and edge IDs

  77. def translateVertexValues[NEW](fun: (VV, NEW) ⇒ NEW)(implicit arg0: TypeInformation[NEW], arg1: ClassTag[NEW]): Graph[K, NEW, EV]

    Permalink

    Translate vertex values using the given function.

    Translate vertex values using the given function.

    fun

    implements conversion from VV to NEW

    returns

    graph with translated vertex values

  78. def translateVertexValues[NEW](translator: TranslateFunction[VV, NEW])(implicit arg0: TypeInformation[NEW], arg1: ClassTag[NEW]): Graph[K, NEW, EV]

    Permalink

    Translate vertex values using the given MapFunction.

    Translate vertex values using the given MapFunction.

    translator

    implements conversion from VV to NEW

    returns

    graph with translated vertex values

  79. def union(graph: Graph[K, VV, EV]): Graph[K, VV, EV]

    Permalink

    Performs union on the vertices and edges sets of the input graphs removing duplicate vertices but maintaining duplicate edges.

    Performs union on the vertices and edges sets of the input graphs removing duplicate vertices but maintaining duplicate edges.

    graph

    the graph to perform union with

    returns

    a new graph

  80. def validate(validator: GraphValidator[K, VV, EV]): Boolean

    Permalink
  81. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  82. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  83. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from AnyRef

Inherited from Any

Ungrouped