Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W 

A

AbstractGeneratorFactory<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator.random
This base class handles the task of dividing the requested work into the appropriate number of blocks of near-equal size.
AbstractGeneratorFactory() - Constructor for class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
AbstractGraphAnalytic<K,VV,EV,T> - Class in org.apache.flink.graph
Base class for GraphAnalytic.
AbstractGraphAnalytic() - Constructor for class org.apache.flink.graph.AbstractGraphAnalytic
 
AbstractGraphGenerator<K,VV,EV> - Class in org.apache.flink.graph.generator
 
AbstractGraphGenerator() - Constructor for class org.apache.flink.graph.generator.AbstractGraphGenerator
 
AdamicAdar<K extends org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.similarity
http://social.cs.uiuc.edu/class/cs591kgk/friendsadamic.pdf
Adamic-Adar measures the similarity between pairs of vertices as the sum of the inverse logarithm of degree over shared neighbors.
AdamicAdar() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar
 
AdamicAdar.Result<T> - Class in org.apache.flink.graph.library.similarity
Wraps the vertex type to encapsulate results from the Adamic-Adar algorithm.
addBroadcastSet(String, DataSet<?>) - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
Adds a data set as a broadcast set to the compute function.
addBroadcastSetForApplyFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the apply function.
addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the gather function.
addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the gather function.
addBroadcastSetForScatterFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the scatter function.
addBroadcastSetForSumFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the sum function.
addDimension(long, boolean) - Method in class org.apache.flink.graph.generator.GridGraph
Required configuration for each dimension of the graph.
addEdge(Vertex<K, VV>, Vertex<K, VV>, EV) - Method in class org.apache.flink.graph.Graph
Adds the given edge to the graph.
addEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Adds the given list edges to the graph.
AddLongValue() - Constructor for class org.apache.flink.graph.utils.GraphUtils.AddLongValue
 
AddScoreToVertexValuesMapper() - Constructor for class org.apache.flink.graph.library.CommunityDetection.AddScoreToVertexValuesMapper
 
addVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.Graph
Adds the input vertex to the graph.
addVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
Adds the list of vertices, passed as input, to the graph.
apply(M, VV) - Method in class org.apache.flink.graph.gsa.ApplyFunction
This method is invoked once per superstep, after the SumFunction in a GatherSumApplyIteration.
ApplyFunction<K,VV,M> - Class in org.apache.flink.graph.gsa
The base class for the third and last step of a GatherSumApplyIteration.
ApplyFunction() - Constructor for class org.apache.flink.graph.gsa.ApplyFunction
 

B

BlockInfo<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator.random
Defines a source of randomness and a unit of work.
BlockInfo(RandomGenerable<T>, int, int, long, long) - Constructor for class org.apache.flink.graph.generator.random.BlockInfo
 

C

CCMessenger(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
CCUpdater() - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCUpdater
 
ChecksumHashCode<K,VV,EV> - Class in org.apache.flink.graph.library.metric
Convenience method to get the count (number of elements) of a Graph as well as the checksum (sum over element hashes).
ChecksumHashCode() - Constructor for class org.apache.flink.graph.library.metric.ChecksumHashCode
 
combine(Iterable<Tuple2<K, Either<NullValue, Message>>>, Collector<Tuple2<K, Either<NullValue, Message>>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration.MessageCombinerUdf
 
combineMessages(MessageIterator<Message>) - Method in class org.apache.flink.graph.pregel.MessageCombiner
Combines messages sent from different vertices to a target vertex.
CommunityDetection<K> - Class in org.apache.flink.graph.library
Community Detection Algorithm.
CommunityDetection(int, double) - Constructor for class org.apache.flink.graph.library.CommunityDetection
Creates a new Community Detection algorithm instance.
CommunityDetection.AddScoreToVertexValuesMapper<K> - Class in org.apache.flink.graph.library
 
CommunityDetection.LabelMessenger<K> - Class in org.apache.flink.graph.library
 
CommunityDetection.RemoveScoreFromVertexValuesMapper<K> - Class in org.apache.flink.graph.library
 
CommunityDetection.VertexLabelUpdater<K> - Class in org.apache.flink.graph.library
 
CompleteGraph - Class in org.apache.flink.graph.generator
 
CompleteGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CompleteGraph
An undirected Graph connecting every distinct pair of vertices.
CompleteGraph.LinkVertexToAll - Class in org.apache.flink.graph.generator
 
compute(Vertex<K, VV>, MessageIterator<Message>) - Method in class org.apache.flink.graph.pregel.ComputeFunction
This method is invoked once per superstep, for each active vertex.
ComputeFunction<K,VV,EV,Message> - Class in org.apache.flink.graph.pregel
The base class for the message-passing functions between vertices as a part of a VertexCentricIteration.
ComputeFunction() - Constructor for class org.apache.flink.graph.pregel.ComputeFunction
 
configure(GSAConfiguration) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Configures this gather-sum-apply iteration with the provided parameters.
configure(VertexCentricConfiguration) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
Configures this vertex-centric iteration with the provided parameters.
configure(ScatterGatherConfiguration) - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Configures this scatter-gather iteration with the provided parameters.
conflictsWith(OptionalBoolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
The conflicting states are true with false and false with true.
ConnectedComponents<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
A scatter-gather implementation of the Weakly Connected Components algorithm.
ConnectedComponents(Integer) - Constructor for class org.apache.flink.graph.library.ConnectedComponents
Creates an instance of the Connected Components algorithm.
ConnectedComponents.CCMessenger<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Sends the current vertex value to all adjacent vertices.
ConnectedComponents.CCUpdater<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Updates the value of a vertex by picking the minimum neighbor value out of all the incoming messages.
copyFrom(TriangleEnumerator.EdgeWithDegrees<K>) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
count(DataSet<T>) - Static method in class org.apache.flink.graph.utils.GraphUtils
Count the number of elements in a DataSet.
createResult() - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Computes the results of the gather-sum-apply iteration
createResult() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
Creates the operator that represents this vertex-centric graph computation.
createResult() - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Creates the operator that represents this scatter-gather graph computation.
CycleGraph - Class in org.apache.flink.graph.generator
 
CycleGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CycleGraph
An undirected Graph where all edges form a single cycle.

D

D1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
D2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
DEFAULT_A - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_B - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_C - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_GROUP_SIZE - Static variable in class org.apache.flink.graph.library.similarity.JaccardIndex
 
DEFAULT_NOISE - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_SEED - Static variable in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
DEFAULT_SEED - Static variable in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
DegreeAnnotationFunctions - Class in org.apache.flink.graph.asm.degree.annotate
 
DegreeAnnotationFunctions() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions
 
DegreeAnnotationFunctions.DegreeCount<K> - Class in org.apache.flink.graph.asm.degree.annotate
Combines the vertex degree count.
DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree<K,EV,D> - Class in org.apache.flink.graph.asm.degree.annotate
Composes the vertex degree with this edge value.
DegreeAnnotationFunctions.JoinEdgeWithVertexDegree<K,EV,D> - Class in org.apache.flink.graph.asm.degree.annotate
Assigns the vertex degree to this edge value.
DegreeAnnotationFunctions.JoinVertexWithVertexDegree<K,VV> - Class in org.apache.flink.graph.asm.degree.annotate
Performs a left outer join to apply a zero count for vertices with out- or in-degree of zero.
DegreeAnnotationFunctions.MapEdgeToSourceId<K,EV> - Class in org.apache.flink.graph.asm.degree.annotate
Emits the source vertex ID along with an initial count.
DegreeAnnotationFunctions.MapEdgeToTargetId<K,EV> - Class in org.apache.flink.graph.asm.degree.annotate
Emits the target vertex ID along with an initial count.
DegreeCount() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.DegreeCount
 
Degrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
Degrees(LongValue, LongValue, LongValue) - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
Delegate<X> - Class in org.apache.flink.graph.utils.proxy
Wraps an object with a proxy delegate whose method handler invokes all method calls on the wrapped object.
Delegate(X) - Constructor for class org.apache.flink.graph.utils.proxy.Delegate
Set the initial delegated object.
Delegate.ReferentProxy<Y> - Interface in org.apache.flink.graph.utils.proxy
This interface provides access via the proxy handler to the original object being proxied.
difference(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
Performs Difference on the vertex and edge sets of the input graphs removes common vertices and edges.

E

Edge<K,V> - Class in org.apache.flink.graph
An Edge represents a link between two vertices, the source and the target and can carry an attached value.
Edge() - Constructor for class org.apache.flink.graph.Edge
 
Edge(K, K, V) - Constructor for class org.apache.flink.graph.Edge
 
EdgeDegreePair<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates edges of an undirected graph with the degree of both the source and target degree vertices.
EdgeDegreePair() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
EdgeDegreesPair<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates edges of a directed graph with the degree, out-degree, and in-degree of both the source and target vertices.
EdgeDegreesPair() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
EdgeDirection - Enum in org.apache.flink.graph
edgeJoin(EV, T) - Method in interface org.apache.flink.graph.EdgeJoinFunction
Applies a transformation on the current edge value and the value of the matched tuple of the input DataSet.
EdgeJoinFunction<EV,T> - Interface in org.apache.flink.graph
EdgeOrder - Enum in org.apache.flink.graph
These bitmasks are used by edge-flipping algorithms to mark the edge order relative to the original edge direction.
edgeReader - Variable in class org.apache.flink.graph.GraphCsvReader
 
EdgesFunction<K,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnEdges(EdgesFunction, EdgeDirection) method.
EdgesFunctionWithVertexValue<K,VV,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnEdges(EdgesFunctionWithVertexValue, EdgeDirection) method.
EdgeSourceDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates edges of an undirected graph with degree of the source vertex.
EdgeSourceDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
EdgeSourceDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates edges of a directed graph with the degree, out-degree, and in-degree of the source vertex.
EdgeSourceDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
EdgeTargetDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates edges of an undirected graph with degree of the target vertex.
EdgeTargetDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
EdgeTargetDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates edges of a directed graph with the degree, out-degree, and in-degree of the target vertex.
EdgeTargetDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
EdgeToTuple3Map<K,EV> - Class in org.apache.flink.graph.utils
Create a Tuple3 DataSet from an Edge DataSet
EdgeToTuple3Map() - Constructor for class org.apache.flink.graph.utils.EdgeToTuple3Map
 
edgeTypes(Class<K>, Class<EV>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input with edge values, but without vertex values.
edgeValue - Variable in class org.apache.flink.graph.GraphCsvReader
 
EdgeValue() - Constructor for class org.apache.flink.graph.library.Summarization.EdgeValue
 
EdgeWithDegrees() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
EmptyGraph - Class in org.apache.flink.graph.generator
 
EmptyGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.EmptyGraph
The Graph containing no edges.
env - Variable in class org.apache.flink.graph.AbstractGraphAnalytic
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
equals(Object) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
 
equals(Object) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
 
execute() - Method in class org.apache.flink.graph.AbstractGraphAnalytic
 
execute(String) - Method in class org.apache.flink.graph.AbstractGraphAnalytic
 
execute() - Method in interface org.apache.flink.graph.GraphAnalytic
Execute the program and return the result.
execute(String) - Method in interface org.apache.flink.graph.GraphAnalytic
Execute the program and return the result.

F

fieldDelimiterEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates fields in a row for the CSV reader used to read the edges (',') is used by default.
fieldDelimiterVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates fields in a row for the CSV reader used to read the vertices (',') is used by default.
filterOnEdges(FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.
filterOnVertices(FilterFunction<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.
flatMap(LongValue, Collector<Edge<LongValue, NullValue>>) - Method in class org.apache.flink.graph.generator.CompleteGraph.LinkVertexToAll
 
flatMap(LongValue, Collector<Edge<LongValue, NullValue>>) - Method in class org.apache.flink.graph.generator.GridGraph.LinkVertexToNeighbors
 
flatMap(LongValue, Collector<Edge<LongValue, NullValue>>) - Method in class org.apache.flink.graph.generator.StarGraph.LinkVertexToCenter
 
fromCollection(Collection<Vertex<K, VV>>, Collection<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a Collection of vertices and a Collection of edges.
fromCollection(Collection<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a Collection of edges.
fromCollection(Collection<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a Collection of edges.
fromCsvReader(String, String, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a Graph from a CSV file of vertices and a CSV file of edges.
fromCsvReader(String, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a CSV file of edges.
fromCsvReader(String, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a CSV file of edges.
fromDataSet(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of vertices and a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple2 objects for edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple2 objects for edges.
fromTupleDataSet(DataSet<Tuple2<K, VV>>, DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple2 objects for vertices and Tuple3 objects for edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple3 objects for edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple3 objects for edges.

G

gather(Neighbor<VV, EV>) - Method in class org.apache.flink.graph.gsa.GatherFunction
This method is invoked once per superstep, for each Neighbor of each Vertex in the beginning of each superstep in a GatherSumApplyIteration.
GatherFunction<VV,EV,M> - Class in org.apache.flink.graph.gsa
The base class for the first step of a GatherSumApplyIteration.
GatherFunction() - Constructor for class org.apache.flink.graph.gsa.GatherFunction
 
GatherFunction<K,VV,Message> - Class in org.apache.flink.graph.spargel
This class must be extended by functions that compute the state of the vertex depending on the old state and the incoming messages.
GatherFunction() - Constructor for class org.apache.flink.graph.spargel.GatherFunction
 
GatherSumApplyIteration<K,VV,EV,M> - Class in org.apache.flink.graph.gsa
This class represents iterative graph computations, programmed in a gather-sum-apply perspective.
generate() - Method in class org.apache.flink.graph.generator.CompleteGraph
 
generate() - Method in class org.apache.flink.graph.generator.CycleGraph
 
generate() - Method in class org.apache.flink.graph.generator.EmptyGraph
 
generate() - Method in interface org.apache.flink.graph.generator.GraphGenerator
Generates the configured graph.
generate() - Method in class org.apache.flink.graph.generator.GridGraph
 
generate() - Method in class org.apache.flink.graph.generator.HypercubeGraph
 
generate() - Method in class org.apache.flink.graph.generator.PathGraph
 
generate() - Method in class org.apache.flink.graph.generator.RMatGraph
 
generate() - Method in class org.apache.flink.graph.generator.SingletonEdgeGraph
 
generate() - Method in class org.apache.flink.graph.generator.StarGraph
 
generator() - Method in interface org.apache.flink.graph.generator.random.RandomGenerable
Returns an initialized RandomGenerator.
get() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Get the boolean state.
getAdamicAdarScore() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
Get the Adamic-Adar score, equal to the sum over common neighbors of the inverse logarithm of degree
getAggregators() - Method in class org.apache.flink.graph.IterationConfiguration
Gets the set of aggregators that are registered for this vertex-centric iteration.
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.link_analysis.HITS
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
getAlgorithmName() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
Algorithms are identified by name rather than by class to allow subclassing.
getAlgorithmName() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
Algorithms are identified by name rather than by class to allow subclassing.
getApplyBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the ApplyFunction.
getAuthorityScore() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
Get the authority score.
getBcastVars() - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
Get the broadcast variables of the compute function.
getBitmask() - Method in enum org.apache.flink.graph.EdgeOrder
Returns a bitmask used for marking whether an edge is in the same direction as in the original edge set (FORWARD), is flipped relative to the original edge set (REVERSE), or both (MUTUAL).
getBlockCount() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getBlockIndex() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.SumFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets the broadcast data set registered under the given name.
getContext() - Method in class org.apache.flink.graph.Graph
 
getDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
getDegree() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Get the vertex degree.
getDegree() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Get the vertex degree.
getDegrees() - Method in class org.apache.flink.graph.Graph
Return the degree of all vertices in the graph
getDirection() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Gets the direction from which the neighbors are to be selected By default the neighbors who are target of the edges are selected
getDirection() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieves the edge direction in which messages are propagated in the scatter-gather iteration.
getDirection() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Gets the direction in which messages are sent in the ScatterFunction.
getDistinctNeighborCount() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
Get the distinct neighbor count.
getEdge() - Method in class org.apache.flink.graph.Triplet
 
getEdgeGroupCount() - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
getEdgeGroupValue() - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
getEdgeIds() - Method in class org.apache.flink.graph.Graph
 
getEdges() - Method in class org.apache.flink.graph.Graph
 
getEdges() - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets an Iterable with all out-going edges.
getEdges() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets an Iterable with all edges.
getEdgesAsTuple3() - Method in class org.apache.flink.graph.Graph
 
getEdgeValue() - Method in class org.apache.flink.graph.gsa.Neighbor
 
getElementCount() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getFirstDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getFirstElement() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getFirstVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getFirstVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
getGatherBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the GatherFunction.
getGatherBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Get the broadcast variables of the GatherFunction.
getGlobalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Get the global clustering coefficient score.
getGlobalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Get the global clustering coefficient score.
getGroupRepresentativeId() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getGroupRepresentativeId() - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
getHubScore() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
Get the hub score.
getId() - Method in class org.apache.flink.graph.Vertex
 
getInDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
getInDegree() - Method in class org.apache.flink.graph.spargel.GatherFunction
Retrieves the vertex in-degree (number of in-coming edges).
getInDegree() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieves the vertex in-degree (number of in-coming edges).
getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.SumFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets the iteration aggregator registered under the given name.
getIterationConfiguration() - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
 
getIterationConfiguration() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
 
getIterationConfiguration() - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
 
getJaccardIndexScore() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
Get the Jaccard Index score, equal to the number of shared neighbors of the source and target vertices divided by the number of distinct neighbors.
getLocalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Get the local clustering coefficient score.
getLocalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Get the local clustering coefficient score.
getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
getName(String) - Method in class org.apache.flink.graph.IterationConfiguration
Gets the name of the iteration.
getNeighborValue() - Method in class org.apache.flink.graph.gsa.Neighbor
 
getNumberOfEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of edges.
getNumberOfEdges() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the number of edges.
getNumberOfTriangles() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Get the number of triangles.
getNumberOfTriangles() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Get the number of triangles.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Get the number of triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Get the number of triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the number of triplets.
getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.ApplyFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.GatherFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.SumFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of vertices.
getNumberOfVertices() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the number of vertices.
getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.GatherFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieves the number of vertices in the graph.
getOutDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
getOutDegree() - Method in class org.apache.flink.graph.spargel.GatherFunction
Retrieve the vertex out-degree (number of out-going edges).
getOutDegree() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieve the vertex out-degree (number of out-going edges).
getParallelism() - Method in class org.apache.flink.graph.IterationConfiguration
Gets the iteration's parallelism.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.SumFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getProducedType() - Method in class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
getProducedType() - Method in class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
getProducedType() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration.MessageCombinerUdf
 
getProxiedObject() - Method in interface org.apache.flink.graph.utils.proxy.Delegate.ReferentProxy
 
getProxy() - Method in class org.apache.flink.graph.utils.proxy.Delegate
Instantiates and returns a proxy object which subclasses the delegated object.
getRandomGenerable() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getRandomGenerables(long, int) - Method in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
getRandomGenerables(long, int) - Method in interface org.apache.flink.graph.generator.random.RandomGenerableFactory
The amount of work (elementCount * cyclerPerElement) is used to generate a list of blocks of work of near-equal size.
getResult() - Method in interface org.apache.flink.graph.GraphAnalytic
This method must be called after the program has executed: 1) "run" analytics and algorithms 2) call ExecutionEnvironment.execute() 3) get analytic results
getResult() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
 
getResult() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleCount
 
getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
 
getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleCount
 
getResult() - Method in class org.apache.flink.graph.library.metric.ChecksumHashCode
 
getResult() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
 
getResult() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
 
getScatterBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Get the broadcast variables of the ScatterFunction.
getSecondDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getSecondVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getSecondVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
getSharedNeighborCount() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
Get the shared neighbor count.
getSource() - Method in class org.apache.flink.graph.Edge
 
getSrcVertex() - Method in class org.apache.flink.graph.Triplet
 
getState() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Get the actual state.
getSumBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the SumFunction.
getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.ApplyFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.GatherFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.SumFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.GatherFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets the number of the superstep, starting at 1.
getTarget() - Method in class org.apache.flink.graph.Edge
 
getThirdVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
getTrgVertex() - Method in class org.apache.flink.graph.Triplet
 
getTriangleCount() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Get the number of triangles containing this vertex; equivalently, this is the number of edges between neighbors of this vertex.
getTriangleCount() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Get the number of triangles containing this vertex; equivalently, this is the number of edges between neighbors of this vertex.
getTriplets() - Method in class org.apache.flink.graph.Graph
This method allows access to the graph's edge values along with its source and target vertex values.
getUndirected() - Method in class org.apache.flink.graph.Graph
This operation adds all inverse-direction edges to the graph.
getValue() - Method in class org.apache.flink.graph.Edge
 
getValue() - Method in class org.apache.flink.graph.Vertex
 
getVertexGroupCount() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getVertexGroupCount() - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
getVertexGroupValue() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getVertexGroupValue() - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
getVertexId() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getVertexIds() - Method in class org.apache.flink.graph.Graph
 
getVertices() - Method in class org.apache.flink.graph.Graph
 
getVerticesAsTuple2() - Method in class org.apache.flink.graph.Graph
 
GlobalClusteringCoefficient<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
The global clustering coefficient measures the connectedness of a graph.
GlobalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
 
GlobalClusteringCoefficient<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
The global clustering coefficient measures the connectedness of a graph.
GlobalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
 
GlobalClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.directed
Wraps global clustering coefficient metrics.
GlobalClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.undirected
Wraps global clustering coefficient metrics.
Graph<K,VV,EV> - Class in org.apache.flink.graph
Represents a Graph consisting of edges and vertices.
GraphAlgorithm<K,VV,EV,T> - Interface in org.apache.flink.graph
 
GraphAlgorithmDelegatingDataSet<K,VV,EV,T> - Class in org.apache.flink.graph.utils.proxy
A GraphAlgorithm transforms an input Graph into an output of type T.
GraphAlgorithmDelegatingDataSet() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
 
GraphAlgorithmDelegatingGraph<IN_K,IN_VV,IN_EV,OUT_K,OUT_VV,OUT_EV> - Class in org.apache.flink.graph.utils.proxy
A GraphAlgorithm transforms an input Graph into an output of type T.
GraphAlgorithmDelegatingGraph() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
 
GraphAnalytic<K,VV,EV,T> - Interface in org.apache.flink.graph
A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators.
GraphCsvReader - Class in org.apache.flink.graph
A class to build a Graph using path(s) provided to CSV file(s) with optional vertex and edge data.
GraphCsvReader(Path, Path, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(Path, MapFunction<K, VV>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(String, String, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(String, MapFunction<K, VV>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphGenerator<K,VV,EV> - Interface in org.apache.flink.graph.generator
Graph generators shall be - parallelizable, in order to create large datasets - scale-free, generating the same graph regardless of parallelism - thrifty, using as few operators as possible Graph generators should prefer to emit edges sorted by the source label.
GraphGeneratorUtils - Class in org.apache.flink.graph.generator
 
GraphGeneratorUtils() - Constructor for class org.apache.flink.graph.generator.GraphGeneratorUtils
 
GraphUtils - Class in org.apache.flink.graph.utils
 
GraphUtils() - Constructor for class org.apache.flink.graph.utils.GraphUtils
 
GraphUtils.AddLongValue - Class in org.apache.flink.graph.utils
Add LongValue elements.
GraphUtils.MapTo<I,O> - Class in org.apache.flink.graph.utils
Map each element to a value.
GraphValidator<K,VV,EV> - Class in org.apache.flink.graph.validation
A utility for defining validation criteria for different types of Graphs.
GraphValidator() - Constructor for class org.apache.flink.graph.validation.GraphValidator
 
GridGraph - Class in org.apache.flink.graph.generator
 
GridGraph(ExecutionEnvironment) - Constructor for class org.apache.flink.graph.generator.GridGraph
An undirected Graph connecting vertices in a regular tiling in one or more dimensions.
GridGraph.LinkVertexToNeighbors - Class in org.apache.flink.graph.generator
 
groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
GSAConfiguration - Class in org.apache.flink.graph.gsa
A GSAConfiguration object can be used to set the iteration name and degree of parallelism, to register aggregators and use broadcast sets in the GatherFunction, SumFunction as well as ApplyFunction.
GSAConfiguration() - Constructor for class org.apache.flink.graph.gsa.GSAConfiguration
 
GSAConnectedComponents<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
A gather-sum-apply implementation of the Weakly Connected Components algorithm.
GSAConnectedComponents(Integer) - Constructor for class org.apache.flink.graph.library.GSAConnectedComponents
Creates an instance of the GSA Connected Components algorithm.
GSAPageRank<K> - Class in org.apache.flink.graph.library
This is an implementation of a simple PageRank algorithm, using a gather-sum-apply iteration.
GSAPageRank(double, int) - Constructor for class org.apache.flink.graph.library.GSAPageRank
Creates an instance of the GSA PageRank algorithm.
GSASingleSourceShortestPaths<K> - Class in org.apache.flink.graph.library
This is an implementation of the Single Source Shortest Paths algorithm, using a gather-sum-apply iteration
GSASingleSourceShortestPaths(K, Integer) - Constructor for class org.apache.flink.graph.library.GSASingleSourceShortestPaths
Creates an instance of the GSA SingleSourceShortestPaths algorithm.
GSASingleSourceShortestPaths.InitVerticesMapper<K> - Class in org.apache.flink.graph.library
 

H

hash(double) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process a double value.
hash(float) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process a float value.
hash(int) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process an integer value.
hash(long) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process a long value.
hash() - Method in class org.apache.flink.graph.utils.Murmur3_32
Finalize and return the MurmurHash output.
HASH_SEED - Static variable in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
hashCode() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
hashCode() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
hashCode() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
hashCode() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
hashCode() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
hashCode() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
 
hashCode() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
 
hasNext() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
hasNext() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
HITS<K,VV,EV> - Class in org.apache.flink.graph.library.link_analysis
http://www.cs.cornell.edu/home/kleinber/auth.pdf Hyperlink-Induced Topic Search computes two interdependent scores for every vertex in a directed graph.
HITS(int) - Constructor for class org.apache.flink.graph.library.link_analysis.HITS
Hyperlink-Induced Topic Search with a fixed number of iterations.
HITS(double) - Constructor for class org.apache.flink.graph.library.link_analysis.HITS
Hyperlink-Induced Topic Search with a convergence threshold.
HITS(int, double) - Constructor for class org.apache.flink.graph.library.link_analysis.HITS
Hyperlink-Induced Topic Search with a convergence threshold and a maximum iteration count.
HITS.Result<T> - Class in org.apache.flink.graph.library.link_analysis
Wraps the vertex type to encapsulate results from the HITS algorithm.
HypercubeGraph - Class in org.apache.flink.graph.generator
 
HypercubeGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.HypercubeGraph
An undirected Graph where edges form an n-dimensional hypercube.

I

ignoreCommentsEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the string that starts comments for the Edge Csv Reader.
ignoreCommentsVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the string that starts comments for the Vertex Csv Reader.
ignoreFirstLineEdges() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader for the Edges file to ignore the first line.
ignoreFirstLineVertices() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader for the Vertices file to ignore the first line.
ignoreInvalidLinesEdges() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader for the Edges file to ignore any invalid lines.
ignoreInvalidLinesVertices() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader Vertices file to ignore any invalid lines.
includeFieldsEdges(boolean...) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
includeFieldsEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
includeFieldsEdges(long) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
includeFieldsVertices(boolean...) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
includeFieldsVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
includeFieldsVertices(long) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
inDegrees() - Method in class org.apache.flink.graph.Graph
Return the in-degree of all vertices in the graph
init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.ApplyFunction
 
init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.GatherFunction
 
init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.SumFunction
 
InitVerticesMapper(K) - Constructor for class org.apache.flink.graph.library.GSASingleSourceShortestPaths.InitVerticesMapper
 
InitVerticesMapper(K) - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.InitVerticesMapper
 
intersect(Graph<K, VV, EV>, boolean) - Method in class org.apache.flink.graph.Graph
Performs intersect on the edge sets of the input graphs.
InvalidVertexIdsValidator<K,VV,EV> - Class in org.apache.flink.graph.validation
 
InvalidVertexIdsValidator() - Constructor for class org.apache.flink.graph.validation.InvalidVertexIdsValidator
 
isOptDegrees() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Gets whether the degrees option is set.
isOptNumVertices() - Method in class org.apache.flink.graph.IterationConfiguration
Gets whether the number of vertices option is set.
isSolutionSetUnmanagedMemory() - Method in class org.apache.flink.graph.IterationConfiguration
Gets whether the solution set is kept in managed memory (Flink's internal way of keeping object in serialized form) or as a simple object map.
iterateEdges(Iterable<Tuple2<K, Edge<K, EV>>>, Collector<O>) - Method in interface org.apache.flink.graph.EdgesFunction
This method is called per vertex and can iterate over all of its neighboring edges with the specified direction.
iterateEdges(Vertex<K, VV>, Iterable<Edge<K, EV>>, Collector<O>) - Method in interface org.apache.flink.graph.EdgesFunctionWithVertexValue
This method is called per vertex and can iterate over all of its neighboring edges with the specified direction.
iterateNeighbors(Iterable<Tuple3<K, Edge<K, EV>, Vertex<K, VV>>>, Collector<O>) - Method in interface org.apache.flink.graph.NeighborsFunction
This method is called per vertex and can iterate over all of its neighbors with the specified direction.
iterateNeighbors(Vertex<K, VV>, Iterable<Tuple2<Edge<K, EV>, Vertex<K, VV>>>, Collector<O>) - Method in interface org.apache.flink.graph.NeighborsFunctionWithVertexValue
This method is called per vertex and can iterate over all of its neighbors with the specified direction.
IterationConfiguration - Class in org.apache.flink.graph
This is used as a base class for vertex-centric iteration or gather-sum-apply iteration configuration.
IterationConfiguration() - Constructor for class org.apache.flink.graph.IterationConfiguration
 
iterator() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
iterator() - Method in class org.apache.flink.graph.spargel.MessageIterator
 

J

JaccardIndex<K extends org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.similarity
The Jaccard Index measures the similarity between vertex neighborhoods and is computed as the number of shared neighbors divided by the number of distinct neighbors.
JaccardIndex() - Constructor for class org.apache.flink.graph.library.similarity.JaccardIndex
 
JaccardIndex.Result<T> - Class in org.apache.flink.graph.library.similarity
Wraps the vertex type to encapsulate results from the jaccard index algorithm.
JDKRandomGeneratorFactory - Class in org.apache.flink.graph.generator.random
Uses a seeded JDKRandomGenerator to generate seeds for the distributed collection of JDKRandomGenerator.
JDKRandomGeneratorFactory() - Constructor for class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
JDKRandomGeneratorFactory(long) - Constructor for class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
join(Edge<K, Tuple2<EV, D>>, Vertex<K, D>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree
 
join(Edge<K, EV>, Vertex<K, D>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeWithVertexDegree
 
join(Vertex<K, VV>, Vertex<K, LongValue>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinVertexWithVertexDegree
 
JoinEdgeDegreeWithVertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree
 
JoinEdgeWithVertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeWithVertexDegree
 
JoinVertexWithVertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinVertexWithVertexDegree
 
joinWithEdges(DataSet<Tuple3<K, K, T>>, EdgeJoinFunction<EV, T>) - Method in class org.apache.flink.graph.Graph
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.
joinWithEdgesOnSource(DataSet<Tuple2<K, T>>, EdgeJoinFunction<EV, T>) - Method in class org.apache.flink.graph.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnTarget(DataSet<Tuple2<K, T>>, EdgeJoinFunction<EV, T>) - Method in class org.apache.flink.graph.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithVertices(DataSet<Tuple2<K, T>>, VertexJoinFunction<VV, T>) - Method in class org.apache.flink.graph.Graph
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.

K

keyType(Class<K>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input without vertex values or edge values.

L

LabelMessenger() - Constructor for class org.apache.flink.graph.library.CommunityDetection.LabelMessenger
 
LabelPropagation<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
An implementation of the label propagation algorithm.
LabelPropagation(int) - Constructor for class org.apache.flink.graph.library.LabelPropagation
Creates a new Label Propagation algorithm instance.
LabelPropagation.SendNewLabelToNeighbors<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Sends the vertex label to all out-neighbors
LabelPropagation.UpdateVertexLabel<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Function that updates the value of a vertex by adopting the most frequent label among its in-neighbors
lineDelimiterEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates rows for the CSV reader used to read the edges ('\n') is used by default.
lineDelimiterVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates rows for the CSV reader used to read the vertices ('\n') is used by default.
LinkVertexToAll(long) - Constructor for class org.apache.flink.graph.generator.CompleteGraph.LinkVertexToAll
 
LinkVertexToCenter() - Constructor for class org.apache.flink.graph.generator.StarGraph.LinkVertexToCenter
 
LinkVertexToNeighbors(long, List<Tuple2<Long, Boolean>>) - Constructor for class org.apache.flink.graph.generator.GridGraph.LinkVertexToNeighbors
 
LocalClusteringCoefficient<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
The local clustering coefficient measures the connectedness of each vertex's neighborhood.
LocalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
LocalClusteringCoefficient<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
The local clustering coefficient measures the connectedness of each vertex's neighborhood.
LocalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
LocalClusteringCoefficient.Result<T> - Class in org.apache.flink.graph.library.clustering.directed
Wraps the vertex type to encapsulate results from the Local Clustering Coefficient algorithm.
LocalClusteringCoefficient.Result<T> - Class in org.apache.flink.graph.library.clustering.undirected
Wraps the vertex type to encapsulate results from the Local Clustering Coefficient algorithm.
LongValueAddOffset - Class in org.apache.flink.graph.asm.translate
Translate LongValue by adding a constant offset value.
LongValueAddOffset(long) - Constructor for class org.apache.flink.graph.asm.translate.LongValueAddOffset
Translate LongValue by adding a constant offset value.
LongValueToIntValue - Class in org.apache.flink.graph.asm.translate
Translate LongValue to IntValue.
LongValueToIntValue() - Constructor for class org.apache.flink.graph.asm.translate.LongValueToIntValue
 
LongValueToStringValue - Class in org.apache.flink.graph.asm.translate
Translate LongValue to StringValue.
LongValueToStringValue() - Constructor for class org.apache.flink.graph.asm.translate.LongValueToStringValue
 

M

map(Edge<K, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToSourceId
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToTargetId
 
map(Vertex<K, Long>) - Method in class org.apache.flink.graph.library.CommunityDetection.AddScoreToVertexValuesMapper
 
map(Vertex<K, Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.RemoveScoreFromVertexValuesMapper
 
map(Vertex<K, Double>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths.InitVerticesMapper
 
map(Vertex<K, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.InitVerticesMapper
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.utils.EdgeToTuple3Map
 
map(I) - Method in class org.apache.flink.graph.utils.GraphUtils.MapTo
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.utils.NullValueEdgeMapper
 
map(Tuple2<K, VV>) - Method in class org.apache.flink.graph.utils.Tuple2ToVertexMap
 
map(Tuple3<K, K, EV>) - Method in class org.apache.flink.graph.utils.Tuple3ToEdgeMap
 
map(Vertex<K, VV>) - Method in class org.apache.flink.graph.utils.VertexToTuple2Map
 
mapEdges(MapFunction<Edge<K, EV>, NV>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each edge in the graph.
mapEdges(MapFunction<Edge<K, EV>, NV>, TypeInformation<Edge<K, NV>>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each edge in the graph.
MapEdgeToSourceId() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToSourceId
 
MapEdgeToTargetId() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToTargetId
 
mapper - Variable in class org.apache.flink.graph.GraphCsvReader
 
MapTo(O) - Constructor for class org.apache.flink.graph.utils.GraphUtils.MapTo
Map each element to the given object.
mapVertices(MapFunction<Vertex<K, VV>, NV>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each vertex in the graph.
mapVertices(MapFunction<Vertex<K, VV>, NV>, TypeInformation<Vertex<K, NV>>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each vertex in the graph.
MAXIMUM_BLOCK_COUNT - Static variable in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
MaximumDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.filter.undirected
Removes vertices from a graph with degree greater than the given maximum.
MaximumDegree(long) - Constructor for class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
Filter out vertices with degree greater than the given maximum.
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
 
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.link_analysis.HITS
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
mergeConfiguration(GraphAlgorithmDelegatingDataSet) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
An algorithm must first test whether the configurations can be merged before merging individual fields.
mergeConfiguration(GraphAlgorithmDelegatingGraph) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
An algorithm must first test whether the configurations can be merged before merging individual fields.
mergeWith(OptionalBoolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
State transitions: if the states are the same then no change if either state is unset then change to the other state if the states are conflicting then set to the conflicting state
MersenneTwisterFactory - Class in org.apache.flink.graph.generator.random
Uses a seeded MersenneTwister to generate seeds for the distributed collection of MersenneTwister.
MersenneTwisterFactory() - Constructor for class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
MersenneTwisterFactory(long) - Constructor for class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
MessageCombiner<K,Message> - Class in org.apache.flink.graph.pregel
The base class for combining messages sent during a VertexCentricteration.
MessageCombiner() - Constructor for class org.apache.flink.graph.pregel.MessageCombiner
 
MessageIterator<Message> - Class in org.apache.flink.graph.pregel
An iterator that returns messages.
MessageIterator() - Constructor for class org.apache.flink.graph.pregel.MessageIterator
 
MessageIterator<Message> - Class in org.apache.flink.graph.spargel
An iterator that returns messages.
MessageIterator() - Constructor for class org.apache.flink.graph.spargel.MessageIterator
 
MinDistanceMessenger() - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.MinDistanceMessenger
 
MINIMUM_CYCLES_PER_BLOCK - Static variable in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
MINIMUM_CYCLES_PER_BLOCK - Static variable in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
Murmur3_32 - Class in org.apache.flink.graph.utils
A resettable implementation of the 32-bit MurmurHash algorithm.
Murmur3_32(int) - Constructor for class org.apache.flink.graph.utils.Murmur3_32
A resettable implementation of the 32-bit MurmurHash algorithm.

N

Neighbor<VV,EV> - Class in org.apache.flink.graph.gsa
This class represents a <sourceVertex, edge> pair This is a wrapper around Tuple2<VV, EV> for convenience in the GatherFunction
Neighbor() - Constructor for class org.apache.flink.graph.gsa.Neighbor
 
Neighbor(VV, EV) - Constructor for class org.apache.flink.graph.gsa.Neighbor
 
NeighborsFunction<K,VV,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnNeighbors(NeighborsFunction, EdgeDirection) method.
NeighborsFunctionWithVertexValue<K,VV,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnNeighbors(NeighborsFunctionWithVertexValue, EdgeDirection) method.
next() - Method in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
next() - Method in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
next() - Method in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
next() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
next() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
NullValueEdgeMapper<K,EV> - Class in org.apache.flink.graph.utils
 
NullValueEdgeMapper() - Constructor for class org.apache.flink.graph.utils.NullValueEdgeMapper
 
numberOfEdges() - Method in class org.apache.flink.graph.Graph
 
numberOfVertices() - Method in class org.apache.flink.graph.Graph
 

O

OptionalBoolean - Class in org.apache.flink.graph.utils.proxy
A multi-state boolean.
OptionalBoolean(boolean, boolean) - Constructor for class org.apache.flink.graph.utils.proxy.OptionalBoolean
An OptionalBoolean has three possible states: true, false, and "unset".
OptionalBoolean.State - Enum in org.apache.flink.graph.utils.proxy
 
org.apache.flink.graph - package org.apache.flink.graph
 
org.apache.flink.graph.asm.degree.annotate - package org.apache.flink.graph.asm.degree.annotate
The degree annotation package provides a collection of edge-centric graph algorithms for counting the vertex degree of directed and undirected graphs.
org.apache.flink.graph.asm.degree.annotate.directed - package org.apache.flink.graph.asm.degree.annotate.directed
 
org.apache.flink.graph.asm.degree.annotate.undirected - package org.apache.flink.graph.asm.degree.annotate.undirected
 
org.apache.flink.graph.asm.degree.filter.undirected - package org.apache.flink.graph.asm.degree.filter.undirected
 
org.apache.flink.graph.asm.simple.directed - package org.apache.flink.graph.asm.simple.directed
 
org.apache.flink.graph.asm.simple.undirected - package org.apache.flink.graph.asm.simple.undirected
 
org.apache.flink.graph.asm.translate - package org.apache.flink.graph.asm.translate
 
org.apache.flink.graph.generator - package org.apache.flink.graph.generator
 
org.apache.flink.graph.generator.random - package org.apache.flink.graph.generator.random
 
org.apache.flink.graph.gsa - package org.apache.flink.graph.gsa
 
org.apache.flink.graph.library - package org.apache.flink.graph.library
 
org.apache.flink.graph.library.clustering.directed - package org.apache.flink.graph.library.clustering.directed
 
org.apache.flink.graph.library.clustering.undirected - package org.apache.flink.graph.library.clustering.undirected
 
org.apache.flink.graph.library.link_analysis - package org.apache.flink.graph.library.link_analysis
 
org.apache.flink.graph.library.metric - package org.apache.flink.graph.library.metric
 
org.apache.flink.graph.library.metric.directed - package org.apache.flink.graph.library.metric.directed
 
org.apache.flink.graph.library.metric.undirected - package org.apache.flink.graph.library.metric.undirected
 
org.apache.flink.graph.library.similarity - package org.apache.flink.graph.library.similarity
 
org.apache.flink.graph.pregel - package org.apache.flink.graph.pregel
 
org.apache.flink.graph.spargel - package org.apache.flink.graph.spargel
 
org.apache.flink.graph.utils - package org.apache.flink.graph.utils
 
org.apache.flink.graph.utils.proxy - package org.apache.flink.graph.utils.proxy
 
org.apache.flink.graph.validation - package org.apache.flink.graph.validation
 
outDegrees() - Method in class org.apache.flink.graph.Graph
Return the out-degree of all vertices in the graph

P

PageRank<K> - Class in org.apache.flink.graph.library
This is an implementation of a simple PageRank algorithm, using a scatter-gather iteration.
PageRank(double, int) - Constructor for class org.apache.flink.graph.library.PageRank
Creates an instance of the PageRank algorithm.
PageRank.RankMessenger<K> - Class in org.apache.flink.graph.library
Distributes the rank of a vertex among all target vertices according to the transition probability, which is associated with an edge as the edge value.
PageRank.VertexRankUpdater<K> - Class in org.apache.flink.graph.library
Function that updates the rank of a vertex by summing up the partial ranks from all incoming messages and then applying the dampening formula.
parallelism - Variable in class org.apache.flink.graph.generator.AbstractGraphGenerator
 
parseQuotedStringsEdges(char) - Method in class org.apache.flink.graph.GraphCsvReader
Enables quoted String parsing for Edge Csv Reader.
parseQuotedStringsVertices(char) - Method in class org.apache.flink.graph.GraphCsvReader
Enables quoted String parsing for Vertex Csv Reader.
PathGraph - Class in org.apache.flink.graph.generator
 
PathGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.PathGraph
An undirected Graph where all edges form a single path.
postSuperstep() - Method in class org.apache.flink.graph.gsa.ApplyFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.gsa.GatherFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.gsa.SumFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.pregel.ComputeFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.spargel.GatherFunction
This method is executed once per superstep after the gather function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.spargel.ScatterFunction
This method is executed once per superstep after the scatter function has been invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.gsa.ApplyFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.gsa.GatherFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.gsa.SumFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.pregel.ComputeFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.spargel.GatherFunction
This method is executed once per superstep before the gather function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.spargel.ScatterFunction
This method is executed once per superstep before the scatter function is invoked for each vertex.

R

RandomGenerable<T extends org.apache.commons.math3.random.RandomGenerator> - Interface in org.apache.flink.graph.generator.random
A RandomGenerable provides deferred instantiation and initialization of a RandomGenerator.
RandomGenerableFactory<T extends org.apache.commons.math3.random.RandomGenerator> - Interface in org.apache.flink.graph.generator.random
A RandomGenerableFactory returns a scale-free collection of sources of pseudorandomness which can be used to perform repeatable parallel computation regardless of parallelism.
RankMessenger() - Constructor for class org.apache.flink.graph.library.PageRank.RankMessenger
 
reduce(Vertex<K, LongValue>, Vertex<K, LongValue>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.DegreeCount
 
reduce(Iterable<Tuple2<K, Either<NullValue, Message>>>, Collector<Tuple2<K, Either<NullValue, Message>>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration.MessageCombinerUdf
 
reduce(LongValue, LongValue) - Method in class org.apache.flink.graph.utils.GraphUtils.AddLongValue
 
reduceEdges(EV, EV) - Method in interface org.apache.flink.graph.ReduceEdgesFunction
It combines two neighboring edge values into one new value of the same type.
ReduceEdgesFunction<EV> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.reduceOnEdges(org.apache.flink.graph.ReduceEdgesFunction, EdgeDirection) method.
reduceNeighbors(VV, VV) - Method in interface org.apache.flink.graph.ReduceNeighborsFunction
It combines two neighboring vertex values into one new value of the same type.
ReduceNeighborsFunction<VV> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.reduceOnNeighbors(ReduceNeighborsFunction, EdgeDirection) method.
reduceOnEdges(ReduceEdgesFunction<EV>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Compute a reduce transformation over the edge values of each vertex.
reduceOnNeighbors(ReduceNeighborsFunction<VV>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Compute a reduce transformation over the neighbors' vertex values of each vertex.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.graph.IterationConfiguration
Registers a new aggregator.
remove() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
remove() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
removeEdge(Edge<K, EV>) - Method in class org.apache.flink.graph.Graph
Removes all edges that match the given edge from the graph.
removeEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Removes all the edges that match the edges in the given data set from the graph.
RemoveScoreFromVertexValuesMapper() - Constructor for class org.apache.flink.graph.library.CommunityDetection.RemoveScoreFromVertexValuesMapper
 
removeVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.Graph
Removes the given vertex and its edges from the graph.
removeVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
Removes the given list of vertices and its edges from the graph.
reset() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
Resets the fields to initial values.
reset() - Method in class org.apache.flink.graph.utils.Murmur3_32
Re-initialize the MurmurHash state.
Result(long, long) - Constructor for class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Instantiate an immutable result.
Result() - Constructor for class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
No-args constructor.
Result() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
No-args constructor.
Result(T, T, T, ByteValue) - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
Populates parent tuple with constructor parameters.
Result(long, long) - Constructor for class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Instantiate an immutable result.
Result() - Constructor for class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
 
Result() - Constructor for class org.apache.flink.graph.library.link_analysis.HITS.Result
 
Result(long, long, long) - Constructor for class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
Result(long, long, long) - Constructor for class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
Result() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar.Result
No-args constructor.
Result() - Constructor for class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
reverse() - Method in class org.apache.flink.graph.Edge
Reverses the direction of this Edge.
reverse() - Method in class org.apache.flink.graph.Graph
Reverse the direction of the edges in the graph
RichTranslateFunction<IN,OUT> - Class in org.apache.flink.graph.asm.translate
Rich variant of the TranslateFunction.
RichTranslateFunction() - Constructor for class org.apache.flink.graph.asm.translate.RichTranslateFunction
 
RMatGraph<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator
 
RMatGraph(ExecutionEnvironment, RandomGenerableFactory<T>, long, long) - Constructor for class org.apache.flink.graph.generator.RMatGraph
Generate a directed or undirected power-law Graph using the Recursive Matrix (R-Mat) model.
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.AbstractGraphAnalytic
 
run(GraphAlgorithm<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
 
run(GraphAnalytic<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators.
run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAlgorithm
 
run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAnalytic
All GraphAnalytic processing must be terminated by an OutputFormat.
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleCount
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleCount
 
run(Graph<K, Long, Double>) - Method in class org.apache.flink.graph.library.CommunityDetection
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.ConnectedComponents
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.GSAConnectedComponents
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.GSAPageRank
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.LabelPropagation
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.ChecksumHashCode
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.PageRank
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.Summarization
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.TriangleEnumerator
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
 
run(Graph<IN_K, IN_VV, IN_EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
 
runGatherSumApplyIteration(GatherFunction, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.Graph
Runs a Gather-Sum-Apply iteration on the graph.
runGatherSumApplyIteration(GatherFunction, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int, GSAConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a Gather-Sum-Apply iteration on the graph with configuration options.
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
runInternal(Graph<K, VV, OLD>) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
runInternal(Graph<OLD, VV, EV>) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
runInternal(Graph<K, OLD, EV>) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.link_analysis.HITS
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingDataSet
The implementation of the algorithm, renamed from GraphAlgorithm.run(Graph).
runInternal(Graph<IN_K, IN_VV, IN_EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmDelegatingGraph
The implementation of the algorithm, renamed from GraphAlgorithm.run(Graph).
runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.Graph
Runs a ScatterGather iteration on the graph.
runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int, ScatterGatherConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a ScatterGather iteration on the graph with configuration options.
runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int) - Method in class org.apache.flink.graph.Graph
Runs a VertexCentricIteration on the graph.
runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int, VertexCentricConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a VertexCentricIteration on the graph with configuration options.

S

ScatterFunction<K,VV,Message,EV> - Class in org.apache.flink.graph.spargel
The base class for functions that produce messages between vertices as a part of a ScatterGatherIteration.
ScatterFunction() - Constructor for class org.apache.flink.graph.spargel.ScatterFunction
 
ScatterGatherConfiguration - Class in org.apache.flink.graph.spargel
A ScatterGatherConfiguration object can be used to set the iteration name and degree of parallelism, to register aggregators and use broadcast sets in the GatherFunction and ScatterFunction The VertexCentricConfiguration object is passed as an argument to ( org.apache.flink.graph.spargel.GatherFunction, org.apache.flink.graph.spargel.ScatterFunction, int, ScatterGatherConfiguration).
ScatterGatherConfiguration() - Constructor for class org.apache.flink.graph.spargel.ScatterGatherConfiguration
 
ScatterGatherIteration<K,VV,Message,EV> - Class in org.apache.flink.graph.spargel
This class represents iterative graph computations, programmed in a scatter-gather perspective.
sendCombinedMessage(Message) - Method in class org.apache.flink.graph.pregel.MessageCombiner
Sends the combined message to the target vertex.
sendMessages(Vertex<K, Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.LabelMessenger
 
sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
sendMessages(Vertex<K, Double>) - Method in class org.apache.flink.graph.library.PageRank.RankMessenger
 
sendMessages(Vertex<K, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.MinDistanceMessenger
 
sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.spargel.ScatterFunction
This method is invoked once per superstep for each vertex that was changed in that superstep.
sendMessageTo(K, Message) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Sends the given message to the vertex identified by the given key.
sendMessageTo(K, Message) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Sends the given message to the vertex identified by the given key.
sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Sends the given message to all vertices that adjacent to the changed vertex.
sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Sends the given message to all vertices that are targets of an edge of the changed vertex.
SendNewLabelToNeighbors(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
set(boolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Set the boolean state.
setBroadcastHighDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
After filtering high-degree vertices this algorithm must perform joins on the original graph's vertex set and on both the source and target IDs of the edge set.
setConstants(float, float, float) - Method in class org.apache.flink.graph.generator.RMatGraph
The parameters for recursively subdividing the adjacency matrix.
setDirection(EdgeDirection) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Sets the direction in which neighbors are to be selected By default the neighbors who are target of the edges are selected
setDirection(EdgeDirection) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Sets the direction in which messages are sent in the ScatterFunction.
setEdgeGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
setEdgeGroupValue(EV) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
setFirstDegree(Integer) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setFirstVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setFirstVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
setGroupRepresentativeId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setGroupRepresentativeId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
setGroupSize(int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Override the default group size for the quadratic expansion of neighbor pairs.
setId(K) - Method in class org.apache.flink.graph.Vertex
 
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
By default only the edge set is processed for the computation of degree.
setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Sets the input data set for this operator.
setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
Sets the input data set for this operator.
setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Sets the input data set for this operator.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleCount
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleCount
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Override the parallelism of operators processing small amounts of data.
setMaximumScore(int, int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Filter out Jaccard Index scores greater than or equal to the given maximum fraction.
setMinimumRatio(float) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
Filter out Adamic-Adar scores less than the given ratio times the average score.
setMinimumScore(float) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
Filter out Adamic-Adar scores less than the given minimum.
setMinimumScore(int, int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Filter out Jaccard Index scores less than the given minimum fraction.
setName(String) - Method in class org.apache.flink.graph.IterationConfiguration
Sets the name for the iteration.
setNewVertexValue(VV) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Sets the new value of this vertex.
setNewVertexValue(VV) - Method in class org.apache.flink.graph.spargel.GatherFunction
Sets the new value of this vertex.
setNoise(boolean, float) - Method in class org.apache.flink.graph.generator.RMatGraph
Enable and configure noise.
setObject(X) - Method in class org.apache.flink.graph.utils.proxy.Delegate
Change the delegated object.
setOptDegrees(boolean) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Sets the degree option.
setOptNumVertices(boolean) - Method in class org.apache.flink.graph.IterationConfiguration
Sets the number of vertices option.
setOutput(Vertex<K, VV>, Collector<Vertex<K, VV>>) - Method in class org.apache.flink.graph.gsa.ApplyFunction
 
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.generator.AbstractGraphGenerator
 
setParallelism(int) - Method in interface org.apache.flink.graph.generator.GraphGenerator
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.IterationConfiguration
Sets the parallelism for the iteration.
setParallelism(int) - Method in class org.apache.flink.graph.library.link_analysis.HITS
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
Override the operator parallelism.
setReduceOnSourceId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
The degree can be counted from either the edge source or target IDs.
setResult(VV) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Sets the result for the apply function
setSecondDegree(Integer) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setSecondVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setSecondVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
setSolutionSetUnmanagedMemory(boolean) - Method in class org.apache.flink.graph.IterationConfiguration
Defines whether the solution set is kept in managed memory (Flink's internal way of keeping object in serialized form) or as a simple object map.
setSortTriangleVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
Normalize the triangle listing such that for each result (K0, K1, K2) the vertex IDs are sorted K0 < K1 < K2.
setSortTriangleVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
Normalize the triangle listing such that for each result (K0, K1, K2) the vertex IDs are sorted K0 < K1 < K2.
setSource(K) - Method in class org.apache.flink.graph.Edge
 
setTarget(K) - Method in class org.apache.flink.graph.Edge
 
setThirdVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
setValue(V) - Method in class org.apache.flink.graph.Edge
 
setValue(V) - Method in class org.apache.flink.graph.Vertex
 
setVertexGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setVertexGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
setVertexGroupValue(VGV) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setVertexGroupValue(VV) - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
setVertexId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setVertexId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
Simplify<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.asm.simple.directed
Remove self-loops and duplicate edges from a directed graph.
Simplify() - Constructor for class org.apache.flink.graph.asm.simple.directed.Simplify
 
Simplify<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.asm.simple.undirected
Add symmetric edges and remove self-loops and duplicate edges from an undirected graph.
Simplify(boolean) - Constructor for class org.apache.flink.graph.asm.simple.undirected.Simplify
Simplifies an undirected graph by adding reverse edges and removing self-loops and duplicate edges.
SingleSourceShortestPaths<K> - Class in org.apache.flink.graph.library
This is an implementation of the Single-Source-Shortest Paths algorithm, using a scatter-gather iteration.
SingleSourceShortestPaths(K, Integer) - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths
Creates an instance of the SingleSourceShortestPaths algorithm.
SingleSourceShortestPaths.InitVerticesMapper<K> - Class in org.apache.flink.graph.library
 
SingleSourceShortestPaths.MinDistanceMessenger<K> - Class in org.apache.flink.graph.library
Distributes the minimum distance associated with a given vertex among all the target vertices summed up with the edge's value.
SingleSourceShortestPaths.VertexDistanceUpdater<K> - Class in org.apache.flink.graph.library
Function that updates the value of a vertex by picking the minimum distance from all incoming messages.
SingletonEdgeGraph - Class in org.apache.flink.graph.generator
A singleton-edge Graph contains one or more isolated two-paths.
SingletonEdgeGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.SingletonEdgeGraph
An undirected Graph containing isolated two-paths.
StarGraph - Class in org.apache.flink.graph.generator
 
StarGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.StarGraph
An undirected Graph containing a single central Vertex connected to all other leaf vertices.
StarGraph.LinkVertexToCenter - Class in org.apache.flink.graph.generator
 
subgraph(FilterFunction<Vertex<K, VV>>, FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.
sum(M, M) - Method in class org.apache.flink.graph.gsa.SumFunction
This method is invoked once per superstep, after the GatherFunction in a GatherSumApplyIteration.
SumFunction<VV,EV,M> - Class in org.apache.flink.graph.gsa
The base class for the second step of a GatherSumApplyIteration.
SumFunction() - Constructor for class org.apache.flink.graph.gsa.SumFunction
 
Summarization<K,VV,EV> - Class in org.apache.flink.graph.library
The summarization algorithm computes a condensed version of the input graph
by grouping vertices and edges based on their values.
Summarization() - Constructor for class org.apache.flink.graph.library.Summarization
 
Summarization.EdgeValue<EV> - Class in org.apache.flink.graph.library
Value that is stored at a summarized edge.
Summarization.VertexGroupItem<K,VGV> - Class in org.apache.flink.graph.library
Represents a single vertex in a vertex group.
Summarization.VertexValue<VV> - Class in org.apache.flink.graph.library
Value that is stored at a summarized vertex.
Summarization.VertexWithRepresentative<K> - Class in org.apache.flink.graph.library
Represents a vertex identifier and its corresponding vertex group identifier.

T

toString() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
 
toString() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
 
toString() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
toString() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
toVerboseString() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Format values into a human-readable string.
toVerboseString() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
Format values into a human-readable string.
toVerboseString() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Format values into a human-readable string.
toVerboseString() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
toVerboseString() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
toVerboseString() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
translate(LongValue, LongValue) - Method in class org.apache.flink.graph.asm.translate.LongValueAddOffset
 
translate(LongValue, IntValue) - Method in class org.apache.flink.graph.asm.translate.LongValueToIntValue
 
translate(LongValue, StringValue) - Method in class org.apache.flink.graph.asm.translate.LongValueToStringValue
 
translate(IN, OUT) - Method in class org.apache.flink.graph.asm.translate.RichTranslateFunction
 
Translate - Class in org.apache.flink.graph.asm.translate
Methods for translation of the type or modification of the data of graph IDs, vertex values, and edge values.
Translate() - Constructor for class org.apache.flink.graph.asm.translate.Translate
 
translate(T, O) - Method in interface org.apache.flink.graph.asm.translate.TranslateFunction
The translating method.
translateEdgeIds(DataSet<Edge<OLD, EV>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge IDs using the given TranslateFunction.
translateEdgeIds(DataSet<Edge<OLD, EV>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge IDs using the given TranslateFunction.
translateEdgeValues(DataSet<Edge<K, OLD>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge values using the given TranslateFunction.
translateEdgeValues(DataSet<Edge<K, OLD>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge values using the given TranslateFunction.
TranslateEdgeValues<K,VV,OLD,NEW> - Class in org.apache.flink.graph.asm.translate
Translate Edge values using the given TranslateFunction.
TranslateEdgeValues(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateEdgeValues
Translate Edge values using the given TranslateFunction.
translateEdgeValues(TranslateFunction<EV, NEW>) - Method in class org.apache.flink.graph.Graph
Translate Edge values using the given MapFunction.
TranslateFunction<T,O> - Interface in org.apache.flink.graph.asm.translate
Base interface for Translate functions.
TranslateGraphIds<OLD,NEW,VV,EV> - Class in org.apache.flink.graph.asm.translate
Translate Vertex and Edge IDs of a Graph using the given TranslateFunction
TranslateGraphIds(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateGraphIds
Translate Vertex and Edge IDs of a Graph using the given TranslateFunction
translateGraphIds(TranslateFunction<K, NEW>) - Method in class org.apache.flink.graph.Graph
Translate Vertex and Edge IDs using the given MapFunction.
translateVertexIds(DataSet<Vertex<OLD, VV>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex IDs using the given TranslateFunction.
translateVertexIds(DataSet<Vertex<OLD, VV>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex IDs using the given TranslateFunction.
translateVertexValues(DataSet<Vertex<K, OLD>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex values using the given TranslateFunction.
translateVertexValues(DataSet<Vertex<K, OLD>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex values using the given TranslateFunction.
TranslateVertexValues<K,OLD,NEW,EV> - Class in org.apache.flink.graph.asm.translate
Translate Vertex values using the given TranslateFunction.
TranslateVertexValues(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateVertexValues
Translate Vertex values using the given TranslateFunction.
translateVertexValues(TranslateFunction<VV, NEW>) - Method in class org.apache.flink.graph.Graph
Translate Vertex values using the given MapFunction.
Triad() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
TriangleCount<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
Count the number of distinct triangles in an undirected graph.
TriangleCount() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleCount
 
TriangleCount<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
Count the number of distinct triangles in an undirected graph.
TriangleCount() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriangleCount
 
TriangleEnumerator<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library
This library method enumerates unique triangles present in the input graph.
TriangleEnumerator() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator
 
TriangleEnumerator.EdgeWithDegrees<K> - Class in org.apache.flink.graph.library
 
TriangleEnumerator.Triad<K> - Class in org.apache.flink.graph.library
 
TriangleListing<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
Generates a listing of distinct triangles from the input graph.
TriangleListing() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
TriangleListing<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
Generates a listing of distinct triangles from the input graph.
TriangleListing() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
TriangleListing.Result<T> - Class in org.apache.flink.graph.library.clustering.directed
Wraps the vertex type to encapsulate results from the Triangle Listing algorithm.
Triplet<K,VV,EV> - Class in org.apache.flink.graph
A Triplet stores and retrieves the edges along with their corresponding source and target vertices.
Triplet() - Constructor for class org.apache.flink.graph.Triplet
 
Triplet(Vertex<K, VV>, Vertex<K, VV>, Edge<K, EV>) - Constructor for class org.apache.flink.graph.Triplet
Constructs a Triplet from a given source vertex, target vertex and edge
Triplet(K, K, VV, VV, EV) - Constructor for class org.apache.flink.graph.Triplet
Constructs a Triplet from its src vertex id, src target id, src vertex value, src target value and edge value respectively.
Tuple2ToVertexMap<K,VV> - Class in org.apache.flink.graph.utils
Create a Vertex DataSet from a Tuple2 DataSet
Tuple2ToVertexMap() - Constructor for class org.apache.flink.graph.utils.Tuple2ToVertexMap
 
Tuple3ToEdgeMap<K,EV> - Class in org.apache.flink.graph.utils
Create an Edge DataSet from a Tuple3 DataSet
Tuple3ToEdgeMap() - Constructor for class org.apache.flink.graph.utils.Tuple3ToEdgeMap
 
types(Class<K>, Class<VV>, Class<EV>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input with vertex values and edge values.

U

union(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
Performs union on the vertices and edges sets of the input graphs removing duplicate vertices but maintaining duplicate edges.
unset() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Reset to the unset state.
updateVertex(Vertex<K, Tuple2<Long, Double>>, MessageIterator<Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.VertexLabelUpdater
 
updateVertex(Vertex<K, VV>, MessageIterator<VV>) - Method in class org.apache.flink.graph.library.ConnectedComponents.CCUpdater
 
updateVertex(Vertex<K, VV>, MessageIterator<VV>) - Method in class org.apache.flink.graph.library.LabelPropagation.UpdateVertexLabel
 
updateVertex(Vertex<K, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.library.PageRank.VertexRankUpdater
 
updateVertex(Vertex<K, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.VertexDistanceUpdater
 
updateVertex(Vertex<K, VV>, MessageIterator<Message>) - Method in class org.apache.flink.graph.spargel.GatherFunction
This method is invoked once per vertex per superstep.
UpdateVertexLabel() - Constructor for class org.apache.flink.graph.library.LabelPropagation.UpdateVertexLabel
 

V

V1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
V1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
V2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
V2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
V3 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
validate(GraphValidator<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
Function that checks whether a Graph is a valid Graph, as defined by the given GraphValidator.
validate(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.validation.GraphValidator
 
validate(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.validation.InvalidVertexIdsValidator
Checks that the edge set input contains valid vertex Ids, i.e.
valueOf(String) - Static method in enum org.apache.flink.graph.EdgeDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.graph.EdgeOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.graph.utils.proxy.OptionalBoolean.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.flink.graph.EdgeDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.graph.EdgeOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.graph.utils.proxy.OptionalBoolean.State
Returns an array containing the constants of this enum type, in the order they are declared.
Vertex<K,V> - Class in org.apache.flink.graph
Represents the graph's nodes.
Vertex() - Constructor for class org.apache.flink.graph.Vertex
 
Vertex(K, V) - Constructor for class org.apache.flink.graph.Vertex
 
VertexCentricConfiguration - Class in org.apache.flink.graph.pregel
A VertexCentricConfiguration object can be used to set the iteration name and degree of parallelism, to register aggregators and use broadcast sets in the ComputeFunction.
VertexCentricConfiguration() - Constructor for class org.apache.flink.graph.pregel.VertexCentricConfiguration
 
VertexCentricIteration<K,VV,EV,Message> - Class in org.apache.flink.graph.pregel
This class represents iterative graph computations, programmed in a vertex-centric perspective.
VertexCentricIteration.MessageCombinerUdf<K,Message> - Class in org.apache.flink.graph.pregel
 
VertexDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates vertices of an undirected graph with the degree.
VertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
VertexDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates vertices of a directed graph with the degree, out-, and in-degree.
VertexDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
VertexDegrees.Degrees - Class in org.apache.flink.graph.asm.degree.annotate.directed
Wraps the vertex degree, out-degree, and in-degree.
VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.VertexDistanceUpdater
 
VertexGroupItem() - Constructor for class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
VertexInDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates vertices of a directed graph with the in-degree.
VertexInDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
vertexJoin(VV, T) - Method in interface org.apache.flink.graph.VertexJoinFunction
Applies a transformation on the current vertex value and the value of the matched tuple of the input DataSet.
VertexJoinFunction<VV,T> - Interface in org.apache.flink.graph
Interface to be implemented by the transformation function applied in Graph.joinWithVertices(DataSet, VertexJoinFunction) method.
vertexKey - Variable in class org.apache.flink.graph.GraphCsvReader
 
VertexLabelUpdater(double) - Constructor for class org.apache.flink.graph.library.CommunityDetection.VertexLabelUpdater
 
VertexMetrics<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.directed
Compute the number of vertices, number of edges, and number of triplets in a directed graph.
VertexMetrics() - Constructor for class org.apache.flink.graph.library.metric.directed.VertexMetrics
 
VertexMetrics<K extends Comparable<K> & org.apache.flink.types.CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.undirected
Compute the number of vertices, number of edges, and number of triplets in an undirected graph.
VertexMetrics() - Constructor for class org.apache.flink.graph.library.metric.undirected.VertexMetrics
 
VertexMetrics.Result - Class in org.apache.flink.graph.library.metric.directed
Wraps vertex metrics.
VertexMetrics.Result - Class in org.apache.flink.graph.library.metric.undirected
Wraps vertex metrics.
VertexOutDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates vertices of a directed graph with the out-degree.
VertexOutDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
VertexRankUpdater(double) - Constructor for class org.apache.flink.graph.library.PageRank.VertexRankUpdater
 
vertexReader - Variable in class org.apache.flink.graph.GraphCsvReader
 
vertexSequence(ExecutionEnvironment, int, long) - Static method in class org.apache.flink.graph.generator.GraphGeneratorUtils
Generates Vertices with sequential, numerical labels.
vertexSet(DataSet<Edge<K, EV>>, int) - Static method in class org.apache.flink.graph.generator.GraphGeneratorUtils
Generates Vertices present in the given set of Edges.
VertexToTuple2Map<K,VV> - Class in org.apache.flink.graph.utils
Create a Tuple2 DataSet from a Vertex DataSet
VertexToTuple2Map() - Constructor for class org.apache.flink.graph.utils.VertexToTuple2Map
 
vertexTypes(Class<K>, Class<VV>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input without edge values.
vertexValue - Variable in class org.apache.flink.graph.GraphCsvReader
 
VertexValue() - Constructor for class org.apache.flink.graph.library.Summarization.VertexValue
 
VertexWithRepresentative() - Constructor for class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 

W

withEdges(DataSet<Edge<K, EV>>, GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int) - Static method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Creates a new gather-sum-apply iteration operator for graphs
withEdges(DataSet<Edge<K, EV>>, ComputeFunction<K, VV, EV, Message>, int) - Static method in class org.apache.flink.graph.pregel.VertexCentricIteration
Creates a new vertex-centric iteration operator.
withEdges(DataSet<Edge<K, EV>>, ComputeFunction<K, VV, EV, Message>, MessageCombiner<K, Message>, int) - Static method in class org.apache.flink.graph.pregel.VertexCentricIteration
Creates a new vertex-centric iteration operator for graphs where the edges are associated with a value (such as a weight or distance).
withEdges(DataSet<Edge<K, EV>>, ScatterFunction<K, VV, Message, EV>, GatherFunction<K, VV, Message>, int) - Static method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Creates a new scatter-gather iteration operator for graphs where the edges are associated with a value (such as a weight or distance).
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links

Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.