Modifier and Type | Method and Description |
---|---|
Vertex<K,VV> |
Triplet.getSrcVertex() |
Vertex<K,VV> |
Triplet.getTrgVertex() |
Modifier and Type | Method and Description |
---|---|
DataSet<Vertex<K,VV>> |
Graph.getVertices() |
Modifier and Type | Method and Description |
---|---|
Graph<K,VV,EV> |
Graph.addEdge(Vertex<K,VV> source,
Vertex<K,VV> target,
EV edgeValue)
Adds the given edge to the graph.
|
Graph<K,VV,EV> |
Graph.addEdge(Vertex<K,VV> source,
Vertex<K,VV> target,
EV edgeValue)
Adds the given edge to the graph.
|
Graph<K,VV,EV> |
Graph.addVertex(Vertex<K,VV> vertex)
Adds the input vertex to the graph.
|
void |
EdgesFunctionWithVertexValue.iterateEdges(Vertex<K,VV> vertex,
Iterable<Edge<K,EV>> edges,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighboring edges
with the specified direction.
|
void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
Iterable<Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
|
Graph<K,VV,EV> |
Graph.removeVertex(Vertex<K,VV> vertex)
Removes the given vertex and its edges from the graph.
|
Modifier and Type | Method and Description |
---|---|
Graph<K,VV,EV> |
Graph.addVertices(List<Vertex<K,VV>> verticesToAdd)
Adds the list of vertices, passed as input, to the graph.
|
Graph<K,VV,EV> |
Graph.filterOnVertices(FilterFunction<Vertex<K,VV>> vertexFilter)
Apply a filtering function to the graph and return a sub-graph that
satisfies the predicates only for the vertices.
|
static <K,VV,EV> Graph<K,VV,EV> |
Graph.fromCollection(Collection<Vertex<K,VV>> vertices,
Collection<Edge<K,EV>> edges,
ExecutionEnvironment context)
Creates a graph from a Collection of vertices and a Collection of edges.
|
static <K,VV,EV> Graph<K,VV,EV> |
Graph.fromDataSet(DataSet<Vertex<K,VV>> vertices,
DataSet<Edge<K,EV>> edges,
ExecutionEnvironment context)
Creates a graph from a DataSet of vertices and a DataSet of edges.
|
void |
NeighborsFunction.iterateNeighbors(Iterable<Tuple3<K,Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
|
void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
Iterable<Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
|
<NV> Graph<K,NV,EV> |
Graph.mapVertices(MapFunction<Vertex<K,VV>,NV> mapper)
Apply a function to the attribute of each vertex in the graph.
|
<NV> Graph<K,NV,EV> |
Graph.mapVertices(MapFunction<Vertex<K,VV>,NV> mapper,
TypeInformation<Vertex<K,NV>> returnType)
Apply a function to the attribute of each vertex in the graph.
|
<NV> Graph<K,NV,EV> |
Graph.mapVertices(MapFunction<Vertex<K,VV>,NV> mapper,
TypeInformation<Vertex<K,NV>> returnType)
Apply a function to the attribute of each vertex in the graph.
|
Graph<K,VV,EV> |
Graph.removeVertices(List<Vertex<K,VV>> verticesToBeRemoved)
Removes the given list of vertices and its edges from the graph.
|
Graph<K,VV,EV> |
Graph.subgraph(FilterFunction<Vertex<K,VV>> vertexFilter,
FilterFunction<Edge<K,EV>> edgeFilter)
Apply filtering functions to the graph and return a sub-graph that
satisfies the predicates for both vertices and edges.
|
Constructor and Description |
---|
Triplet(Vertex<K,VV> srcVertex,
Vertex<K,VV> trgVertex,
Edge<K,EV> edge)
Constructs a Triplet from a given source vertex, target vertex and edge
|
Triplet(Vertex<K,VV> srcVertex,
Vertex<K,VV> trgVertex,
Edge<K,EV> edge)
Constructs a Triplet from a given source vertex, target vertex and edge
|
Modifier and Type | Method and Description |
---|---|
void |
MusicProfiles.GetTopSongPerUser.iterateEdges(Vertex<String,NullValue> vertex,
Iterable<Edge<String,Integer>> edges,
Collector<Tuple2<String,String>> out) |
void |
SingleSourceShortestPaths.MinDistanceMessenger.sendMessages(Vertex<Long,Double> vertex) |
void |
IncrementalSSSP.InvalidateMessenger.sendMessages(Vertex<Long,Double> vertex) |
void |
SingleSourceShortestPaths.VertexDistanceUpdater.updateVertex(Vertex<Long,Double> vertex,
MessageIterator<Double> inMessages) |
void |
IncrementalSSSP.VertexDistanceUpdater.updateVertex(Vertex<Long,Double> vertex,
MessageIterator<Double> inMessages) |
Modifier and Type | Method and Description |
---|---|
static DataSet<Vertex<Long,EuclideanGraphWeighing.Point>> |
EuclideanGraphData.getDefaultVertexDataSet(ExecutionEnvironment env) |
static DataSet<Vertex<Long,Double>> |
IncrementalSSSPData.getDefaultVertexDataSet(ExecutionEnvironment env) |
static DataSet<Vertex<Long,Long>> |
LabelPropagationData.getDefaultVertexSet(ExecutionEnvironment env) |
static DataSet<Vertex<Long,Long>> |
LabelPropagationData.getTieVertexSet(ExecutionEnvironment env) |
static DataSet<Vertex<Long,String>> |
SummarizationData.getVertices(ExecutionEnvironment env)
Creates a set of vertices with attached
String values. |
Modifier and Type | Method and Description |
---|---|
static DataSet<Vertex<Long,Double>> |
ExampleUtils.getLongDoubleVertexData(ExecutionEnvironment env) |
static DataSet<Vertex<Long,NullValue>> |
ExampleUtils.getVertexIds(ExecutionEnvironment env,
long numVertices) |
Modifier and Type | Method and Description |
---|---|
DataSet<Vertex<K,VV>> |
GatherSumApplyIteration.createResult()
Computes the results of the gather-sum-apply iteration
|
Modifier and Type | Method and Description |
---|---|
void |
ApplyFunction.setOutput(Vertex<K,VV> vertex,
Collector<Vertex<K,VV>> out) |
Modifier and Type | Method and Description |
---|---|
void |
GatherSumApplyIteration.setInput(DataSet<Vertex<K,VV>> dataSet)
Sets the input data set for this operator.
|
void |
ApplyFunction.setOutput(Vertex<K,VV> vertex,
Collector<Vertex<K,VV>> out) |
Modifier and Type | Method and Description |
---|---|
Vertex<K,Tuple2<Long,Double>> |
CommunityDetection.AddScoreToVertexValuesMapper.map(Vertex<K,Long> vertex) |
Modifier and Type | Method and Description |
---|---|
DataSet<Vertex<K,Double>> |
SingleSourceShortestPaths.run(Graph<K,Double,Double> input) |
DataSet<Vertex<K,Double>> |
PageRank.run(Graph<K,Double,Double> network) |
DataSet<Vertex<K,Double>> |
GSASingleSourceShortestPaths.run(Graph<K,Double,Double> input) |
DataSet<Vertex<K,Double>> |
GSAPageRank.run(Graph<K,Double,Double> network) |
DataSet<Vertex<K,Long>> |
GSAConnectedComponents.run(Graph<K,Long,EV> graph) |
DataSet<Vertex<K,Long>> |
ConnectedComponents.run(Graph<K,Long,EV> graph) |
DataSet<Vertex<K,VV>> |
LabelPropagation.run(Graph<K,VV,EV> input) |
Modifier and Type | Method and Description |
---|---|
Double |
SingleSourceShortestPaths.InitVerticesMapper.map(Vertex<K,Double> value) |
Double |
GSASingleSourceShortestPaths.InitVerticesMapper.map(Vertex<K,Double> value) |
Vertex<K,Tuple2<Long,Double>> |
CommunityDetection.AddScoreToVertexValuesMapper.map(Vertex<K,Long> vertex) |
Long |
CommunityDetection.RemoveScoreFromVertexValuesMapper.map(Vertex<K,Tuple2<Long,Double>> vertex) |
void |
SingleSourceShortestPaths.MinDistanceMessenger.sendMessages(Vertex<K,Double> vertex) |
void |
PageRank.RankMessenger.sendMessages(Vertex<K,Double> vertex) |
void |
ConnectedComponents.CCMessenger.sendMessages(Vertex<K,Long> vertex) |
void |
CommunityDetection.LabelMessenger.sendMessages(Vertex<K,Tuple2<Long,Double>> vertex) |
void |
LabelPropagation.SendNewLabelToNeighbors.sendMessages(Vertex<K,VV> vertex) |
void |
SingleSourceShortestPaths.VertexDistanceUpdater.updateVertex(Vertex<K,Double> vertex,
MessageIterator<Double> inMessages) |
void |
PageRank.VertexRankUpdater.updateVertex(Vertex<K,Double> vertex,
MessageIterator<Double> inMessages) |
void |
ConnectedComponents.CCUpdater.updateVertex(Vertex<K,Long> vertex,
MessageIterator<Long> messages) |
void |
CommunityDetection.VertexLabelUpdater.updateVertex(Vertex<K,Tuple2<Long,Double>> vertex,
MessageIterator<Tuple2<Long,Double>> inMessages) |
void |
LabelPropagation.UpdateVertexLabel.updateVertex(Vertex<K,VV> vertex,
MessageIterator<VV> inMessages) |
Modifier and Type | Method and Description |
---|---|
DataSet<Vertex<K,VV>> |
Graph.getVertices() |
Modifier and Type | Method and Description |
---|---|
Graph<K,VV,EV> |
Graph.addEdge(Vertex<K,VV> source,
Vertex<K,VV> target,
EV edgeValue)
Adds the given edge to the graph.
|
Graph<K,VV,EV> |
Graph.addEdge(Vertex<K,VV> source,
Vertex<K,VV> target,
EV edgeValue)
Adds the given edge to the graph.
|
Graph<K,VV,EV> |
Graph.addVertex(Vertex<K,VV> vertex)
Adds the input vertex to the graph.
|
abstract void |
EdgesFunctionWithVertexValue.iterateEdges(Vertex<K,VV> v,
scala.collection.Iterable<Edge<K,EV>> edges,
Collector<T> out) |
void |
EdgesFunctionWithVertexValue.iterateEdges(Vertex<K,VV> v,
Iterable<Edge<K,EV>> edges,
Collector<T> out) |
abstract void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
scala.collection.Iterable<scala.Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<T> out) |
void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
Iterable<Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<T> out) |
Graph<K,VV,EV> |
Graph.removeVertex(Vertex<K,VV> vertex)
Removes the given vertex and its edges from the graph.
|
Modifier and Type | Method and Description |
---|---|
Graph<K,VV,EV> |
Graph.addVertices(scala.collection.immutable.List<Vertex<K,VV>> vertices)
Adds the list of vertices, passed as input, to the graph.
|
Graph<K,VV,EV> |
Graph.filterOnVertices(FilterFunction<Vertex<K,VV>> vertexFilter)
Apply a filtering function to the graph and return a sub-graph that
satisfies the predicates only for the vertices.
|
Graph<K,VV,EV> |
Graph.filterOnVertices(scala.Function1<Vertex<K,VV>,Object> vertexFilterFun)
Apply a filtering function to the graph and return a sub-graph that
satisfies the predicates only for the vertices.
|
<K,VV,EV> Graph<K,VV,EV> |
Graph$.fromCollection(scala.collection.Seq<Vertex<K,VV>> vertices,
scala.collection.Seq<Edge<K,EV>> edges,
ExecutionEnvironment env,
TypeInformation<K> evidence$17,
scala.reflect.ClassTag<K> evidence$18,
TypeInformation<VV> evidence$19,
scala.reflect.ClassTag<VV> evidence$20,
TypeInformation<EV> evidence$21,
scala.reflect.ClassTag<EV> evidence$22)
Creates a Graph from a Seq of vertices and a Seq of edges.
|
static <K,VV,EV> Graph<K,VV,EV> |
Graph.fromCollection(scala.collection.Seq<Vertex<K,VV>> vertices,
scala.collection.Seq<Edge<K,EV>> edges,
ExecutionEnvironment env,
TypeInformation<K> evidence$17,
scala.reflect.ClassTag<K> evidence$18,
TypeInformation<VV> evidence$19,
scala.reflect.ClassTag<VV> evidence$20,
TypeInformation<EV> evidence$21,
scala.reflect.ClassTag<EV> evidence$22)
Creates a Graph from a Seq of vertices and a Seq of edges.
|
<K,VV,EV> Graph<K,VV,EV> |
Graph$.fromDataSet(DataSet<Vertex<K,VV>> vertices,
DataSet<Edge<K,EV>> edges,
ExecutionEnvironment env,
TypeInformation<K> evidence$1,
scala.reflect.ClassTag<K> evidence$2,
TypeInformation<VV> evidence$3,
scala.reflect.ClassTag<VV> evidence$4,
TypeInformation<EV> evidence$5,
scala.reflect.ClassTag<EV> evidence$6)
Creates a Graph from a DataSet of vertices and a DataSet of edges.
|
static <K,VV,EV> Graph<K,VV,EV> |
Graph.fromDataSet(DataSet<Vertex<K,VV>> vertices,
DataSet<Edge<K,EV>> edges,
ExecutionEnvironment env,
TypeInformation<K> evidence$1,
scala.reflect.ClassTag<K> evidence$2,
TypeInformation<VV> evidence$3,
scala.reflect.ClassTag<VV> evidence$4,
TypeInformation<EV> evidence$5,
scala.reflect.ClassTag<EV> evidence$6)
Creates a Graph from a DataSet of vertices and a DataSet of edges.
|
abstract void |
NeighborsFunction.iterateNeighbors(scala.collection.Iterable<scala.Tuple3<K,Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<T> out) |
void |
NeighborsFunction.iterateNeighbors(Iterable<Tuple3<K,Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<T> out) |
abstract void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
scala.collection.Iterable<scala.Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<T> out) |
void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
Iterable<Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<T> out) |
<NV> Graph<K,NV,EV> |
Graph.mapVertices(scala.Function1<Vertex<K,VV>,NV> fun,
TypeInformation<NV> evidence$69,
scala.reflect.ClassTag<NV> evidence$70)
Apply a function to the attribute of each vertex in the graph.
|
<NV> Graph<K,NV,EV> |
Graph.mapVertices(MapFunction<Vertex<K,VV>,NV> mapper,
TypeInformation<NV> evidence$67,
scala.reflect.ClassTag<NV> evidence$68)
Apply a function to the attribute of each vertex in the graph.
|
Graph<K,VV,EV> |
Graph.removeVertices(scala.collection.immutable.List<Vertex<K,VV>> vertices)
Removes the given vertex and its edges from the graph.
|
Graph<K,VV,EV> |
Graph.subgraph(FilterFunction<Vertex<K,VV>> vertexFilter,
FilterFunction<Edge<K,EV>> edgeFilter)
Apply filtering functions to the graph and return a sub-graph that
satisfies the predicates for both vertices and edges.
|
Graph<K,VV,EV> |
Graph.subgraph(scala.Function1<Vertex<K,VV>,Object> vertexFilterFun,
scala.Function1<Edge<K,EV>,Object> edgeFilterFun)
Apply filtering functions to the graph and return a sub-graph that
satisfies the predicates for both vertices and edges.
|
Modifier and Type | Method and Description |
---|---|
Vertex<K,VV> |
Tuple2ToVertexMap.map(scala.Tuple2<K,VV> value) |
Modifier and Type | Method and Description |
---|---|
scala.Tuple2<K,VV> |
VertexToTuple2Map.map(Vertex<K,VV> value) |
Modifier and Type | Method and Description |
---|---|
DataSet<Vertex<K,VV>> |
ScatterGatherIteration.createResult()
Creates the operator that represents this scatter-gather graph computation.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
MessagingFunction.sendMessages(Vertex<K,VV> vertex)
This method is invoked once per superstep for each vertex that was changed in that superstep.
|
abstract void |
VertexUpdateFunction.updateVertex(Vertex<K,VV> vertex,
MessageIterator<Message> inMessages)
This method is invoked once per vertex per superstep.
|
Modifier and Type | Method and Description |
---|---|
void |
ScatterGatherIteration.setInput(DataSet<Vertex<K,VV>> inputData)
Sets the input data set for this operator.
|
Modifier and Type | Method and Description |
---|---|
Vertex<K,VV> |
Tuple2ToVertexMap.map(Tuple2<K,VV> vertex) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,VV> |
VertexToTuple2Map.map(Vertex<K,VV> vertex) |
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.