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 Z 

A

AdamicAdar - Class in io.kgraph.library.similarity
This class computes the Adamic-Adar similarity or distance for each pair of neighbors in an undirected unweighted graph.
AdamicAdar() - Constructor for class io.kgraph.library.similarity.AdamicAdar
 
AdamicAdar.ComputeLogOfInverseDegree - Class in io.kgraph.library.similarity
Implements the first step in the Adamic-Adar similarity computation.
AdamicAdar.LongIdDoubleValueFriendsList - Class in io.kgraph.library.similarity
This is the message sent in the implementation of the exact Adamic-Adar similarity.
AdamicAdar.ScaleToDistance - Class in io.kgraph.library.similarity
 
AdamicAdar.SendFriendsListAndValue - Class in io.kgraph.library.similarity
Implements the first step in the exact Adamic-Adar similarity algorithm.
addChild(CuratorFramework, String, PregelState, String) - Static method in class io.kgraph.pregel.ZKUtils
 
addChild(CuratorFramework, String, PregelState, String, CreateMode) - Static method in class io.kgraph.pregel.ZKUtils
 
addChild(CuratorFramework, String, String, CreateMode) - Static method in class io.kgraph.pregel.ZKUtils
 
addChild(CuratorFramework, String, String, CreateMode, byte[]) - Static method in class io.kgraph.pregel.ZKUtils
 
addEdge(K, EV) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
addEdge(K, K) - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
Adds the edge to the current adjacency graph
addVertex(VertexWithValue<Long, Set<SemiClustering.SemiCluster>>, Iterable<EdgeWithValue<Long, Double>>, double) - Method in class io.kgraph.library.clustering.SemiClustering.SemiCluster
Adds a vertex to the cluster.
AdjacencyListGraph<K extends Comparable<K>> - Class in io.kgraph.streaming.summaries
A simple, undirected adjacency list graph representation with methods for traversals.
AdjacencyListGraph(int) - Constructor for class io.kgraph.streaming.summaries.AdjacencyListGraph
 
AdjacencyListGraph(AdjacencyListGraph<K>) - Constructor for class io.kgraph.streaming.summaries.AdjacencyListGraph
 
AdjacencyListGraph(AdjacencyListGraph<K>, K, K) - Constructor for class io.kgraph.streaming.summaries.AdjacencyListGraph
 
AdjacencyListGraph.Node - Class in io.kgraph.streaming.summaries
 
adjacencyMap() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
 
aggregate(List<Double>) - Method in class io.kgraph.library.clustering.DoubleListAggregator
 
aggregate(List<List<Double>>) - Method in class io.kgraph.library.clustering.ListOfDoubleListAggregator
Used to randomly select initial points for k-means If the size of the current list is less than k (#centers) then the element is appended in the list else it replaces an element in a random position with probability k/N, where N is the total number of points
aggregate(T) - Method in interface io.kgraph.pregel.aggregators.Aggregator
 
aggregate(Boolean) - Method in class io.kgraph.pregel.aggregators.BooleanAndAggregator
 
aggregate(Boolean) - Method in class io.kgraph.pregel.aggregators.BooleanOrAggregator
 
aggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleMaxAggregator
 
aggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleMinAggregator
 
aggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleProductAggregator
 
aggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleSumAggregator
 
aggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongMaxAggregator
 
aggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongMinAggregator
 
aggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongProductAggregator
 
aggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongSumAggregator
 
aggregate(String, T) - Method in class io.kgraph.pregel.ComputeFunction.Aggregators
 
aggregate(String, T) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
aggregate(String, T) - Method in interface io.kgraph.pregel.ComputeFunction.ReadWriteAggregators
 
aggregate(Map<Integer, Long>) - Method in class io.kgraph.pregel.PregelComputation.MapOfLongMaxAggregator
 
aggregate(KeyValueMapper<Edge<K>, EV, Iterable<KeyValue<K, VV>>>, KeyValueMapper<K, VV, KeyValue<K, VV>>) - Method in class io.kgraph.streaming.EdgeStream
The aggregate function splits the edge stream up into a vertex stream and applies a mapper on the resulting vertices
aggregate(SummaryAggregation<K, EV, S, T>) - Method in class io.kgraph.streaming.EdgeStream
Applies an incremental aggregation on a graphstream and returns a stream of aggregation results
aggregate(KeyValueMapper<Edge<K>, EV, Iterable<KeyValue<K, VV>>>, KeyValueMapper<K, VV, KeyValue<K, VV>>) - Method in interface io.kgraph.streaming.KGraphStream
The aggregate function splits the edge stream up into a vertex stream and applies a mapper on the resulting vertices
aggregate(SummaryAggregation<K, EV, S, T>) - Method in interface io.kgraph.streaming.KGraphStream
Applies an incremental aggregation on a graphstream and returns a stream of aggregation results
aggregatePath(String, int) - Static method in class io.kgraph.pregel.ZKUtils
 
aggregates() - Method in class io.kgraph.GraphAlgorithmState
 
AGGREGATES - Static variable in class io.kgraph.pregel.ZKUtils
 
Aggregator<T> - Interface in io.kgraph.pregel.aggregators
 
aggregator(KStream<Edge<K>, EV>) - Method in class io.kgraph.streaming.SummaryAggregation
 
AGGREGATOR_NUM_TRUSTED - Static variable in class io.kgraph.library.SybilRank
Name of aggregator used to calculate the total number of trusted nodes.
Aggregators(Map<String, ?>, Map<String, Aggregator<?>>) - Constructor for class io.kgraph.pregel.ComputeFunction.Aggregators
 
aggregators - Variable in class io.kgraph.pregel.ComputeFunction.Aggregators
 
aggregators - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
aggregators - Variable in class io.kgraph.pregel.ComputeFunction.InitCallback
 
AggregatorWrapper(Class<? extends Aggregator<T>>, boolean) - Constructor for class io.kgraph.pregel.PregelComputation.AggregatorWrapper
 
ALL_PARTITIONS - Static variable in class io.kgraph.pregel.PregelComputation
 
Als - Class in io.kgraph.library.cf
Alternating Least Squares (ALS) implementation.
Als() - Constructor for class io.kgraph.library.cf.Als
 
Als.InitItemsComputation - Class in io.kgraph.library.cf
This computation class is used to initialize the factors of the item nodes in the second superstep.
Als.InitUsersComputation - Class in io.kgraph.library.cf
This computation class is used to initialize the factors of the user nodes in the very first superstep, and send the first updates to the item nodes.
applicationId - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
apply(VV, Iterable<EdgeWithValue<K, EV>>) - Method in class io.kgraph.KGraph.ApplyEdgeLeftJoinFunction
 
apply(EV, T) - Method in class io.kgraph.KGraph.ApplyLeftJoinToEdgeValues
 
apply(Iterable<EdgeWithValue<K, EV>>, T) - Method in class io.kgraph.KGraph.ApplyLeftJoinToEdgeValuesOnEitherSourceOrTarget
 
apply(VV, T) - Method in class io.kgraph.KGraph.ApplyLeftJoinToVertexValues
 
apply(VV, Map<EdgeWithValue<K, EV>, VV>) - Method in class io.kgraph.KGraph.ApplyNeighborLeftJoinFunction
 
apply(VV, Iterable<EdgeWithValue<K, EV>>) - Method in class io.kgraph.KGraph.CountNeighborsLeftJoin
 
apply(Edge<K>, EV) - Method in class io.kgraph.KGraph.EmitSrcAndTarget
 
apply(Edge<K>, EV) - Method in class io.kgraph.KGraph.UndirectEdges
 
apply(K, EdgeWithValue<K, EV>, T) - Method in class io.kgraph.streaming.KGraphWindowedStream.ApplyEdgesFoldFunction
 
apply(EdgeWithValue<K, EV>, EdgeWithValue<K, EV>) - Method in class io.kgraph.streaming.KGraphWindowedStream.ApplyEdgesReduceFunction
 
apply(Candidates, Candidates) - Method in class io.kgraph.streaming.library.BipartitenessCheck.CombineFunction
Implements reduce method of ReduceFunction interface.
apply(DisjointSet<K>, DisjointSet<K>) - Method in class io.kgraph.streaming.library.ConnectedComponents.CombineCC
Implements reduce method of ReduceFunction interface.
apply(Edge<Long>, Set<Long>) - Method in class io.kgraph.streaming.library.ExactTriangleCount.IntersectNeighborhoods
 
apply(Edge<Long>, Set<Long>) - Method in class io.kgraph.streaming.library.ExactTriangleCount.ProjectCanonicalEdges
 
apply(Long, Long) - Method in class io.kgraph.streaming.library.ExactTriangleCount.SumAndEmitCounters
 
apply(AdjacencyListGraph<K>, AdjacencyListGraph<K>) - Method in class io.kgraph.streaming.library.Spanner.CombineSpanners
 
ApplyEdgeLeftJoinFunction(EdgesFunctionWithVertexValue<K, VV, EV, T>) - Constructor for class io.kgraph.KGraph.ApplyEdgeLeftJoinFunction
 
ApplyEdgesFoldFunction(EdgeFoldFunction<K, EV, T>) - Constructor for class io.kgraph.streaming.KGraphWindowedStream.ApplyEdgesFoldFunction
 
ApplyEdgesReduceFunction(EdgeReduceFunction<EV>) - Constructor for class io.kgraph.streaming.KGraphWindowedStream.ApplyEdgesReduceFunction
 
ApplyLeftJoinToEdgeValues(EdgeJoinFunction<EV, T>) - Constructor for class io.kgraph.KGraph.ApplyLeftJoinToEdgeValues
 
ApplyLeftJoinToEdgeValuesOnEitherSourceOrTarget(EdgeJoinFunction<EV, T>) - Constructor for class io.kgraph.KGraph.ApplyLeftJoinToEdgeValuesOnEitherSourceOrTarget
 
ApplyLeftJoinToVertexValues(VertexJoinFunction<VV, T>) - Constructor for class io.kgraph.KGraph.ApplyLeftJoinToVertexValues
 
ApplyNeighborLeftJoinFunction(NeighborsFunctionWithVertexValue<K, VV, EV, T>) - Constructor for class io.kgraph.KGraph.ApplyNeighborLeftJoinFunction
 
assign(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
ASSIGNED_POINTS_PREFIX - Static variable in class io.kgraph.library.clustering.KMeansClustering
The prefix for the aggregators used to store the number of points assigned to each cluster center
assignment() - Method in class io.kgraph.pregel.PregelConsumer
 

B

barrierPath(String, PregelState) - Static method in class io.kgraph.pregel.ZKUtils
 
BARRIERS - Static variable in class io.kgraph.pregel.ZKUtils
 
beginningOffsets(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
beginningOffsets(Collection<TopicPartition>, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
BIAS_GAMMA - Static variable in class io.kgraph.library.cf.Svdpp
Bias learning rate parameter
BIAS_GAMMA_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default value for bias learning rate
BIAS_LAMBDA - Static variable in class io.kgraph.library.cf.Svdpp
Bias regularization parameter.
BIAS_LAMBDA_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default value for bias regularization parameter
BipartitenessCheck<EV> - Class in io.kgraph.streaming.library
The Bipartiteness check library method checks whether an input graph is bipartite or not.
BipartitenessCheck(long) - Constructor for class io.kgraph.streaming.library.BipartitenessCheck
Creates a BipartitenessCheck object using WindowGraphAggregation class.
BipartitenessCheck.CombineFunction - Class in io.kgraph.streaming.library
Implements the ReduceFunction Interface, applies reduce function to combine group of elements into a single value.
BipartitenessCheck.UpdateFunction<EV> - Class in io.kgraph.streaming.library
Implements the EdgesFold Interface, applies foldEdges function to a vertex neighborhood.
BooleanAndAggregator - Class in io.kgraph.pregel.aggregators
 
BooleanAndAggregator() - Constructor for class io.kgraph.pregel.aggregators.BooleanAndAggregator
 
BooleanOrAggregator - Class in io.kgraph.pregel.aggregators
 
BooleanOrAggregator() - Constructor for class io.kgraph.pregel.aggregators.BooleanOrAggregator
 
bootstrapServers - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
boundedBFS(K, K) - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
Performs a bounded BFS on the adjacency graph to determine whether the current distance between src and trg is greater than k.
BreadthFirstSearch<K,EV> - Class in io.kgraph.library
Adapted from the Graphalytics implementation.
BreadthFirstSearch() - Constructor for class io.kgraph.library.BreadthFirstSearch
 
buildNeighborhood(boolean) - Method in class io.kgraph.streaming.EdgeStream
Builds the neighborhood state by creating adjacency lists.
buildNeighborhood(boolean) - Method in interface io.kgraph.streaming.KGraphStream
Builds the neighborhood state by creating adjacency lists.

C

Callback(ProcessorContext, K, TimestampedKeyValueStore<K, Map<K, EV>>, Map<String, ?>, Map<String, Map<K, ?>>) - Constructor for class io.kgraph.pregel.ComputeFunction.Callback
 
Candidates - Class in io.kgraph.streaming.summaries
 
Candidates(boolean) - Constructor for class io.kgraph.streaming.summaries.Candidates
 
Candidates(boolean, long, long) - Constructor for class io.kgraph.streaming.summaries.Candidates
 
Candidates(Candidates) - Constructor for class io.kgraph.streaming.summaries.Candidates
 
CENTER_AGGR_PREFIX - Static variable in class io.kgraph.library.clustering.KMeansClustering
The prefix for the cluster center aggregators, used to store the cluster centers coordinates.
CfId<T> - Interface in io.kgraph.library.cf
Classes that implement this interface represent the ID of a node in a user-item graph.
CfLongId - Class in io.kgraph.library.cf
This class represents the ID of a node in a CF scenario that has an identifier of type long.
CfLongId(byte, long) - Constructor for class io.kgraph.library.cf.CfLongId
 
CfLongId(String) - Constructor for class io.kgraph.library.cf.CfLongId
 
CfLongIdDeserializer - Class in io.kgraph.library.cf
 
CfLongIdDeserializer() - Constructor for class io.kgraph.library.cf.CfLongIdDeserializer
 
CfLongIdSerde - Class in io.kgraph.library.cf
 
CfLongIdSerde() - Constructor for class io.kgraph.library.cf.CfLongIdSerde
 
CfLongIdSerializer - Class in io.kgraph.library.cf
 
CfLongIdSerializer() - Constructor for class io.kgraph.library.cf.CfLongIdSerializer
 
ClientUtils - Class in io.kgraph.utils
 
ClientUtils() - Constructor for class io.kgraph.utils.ClientUtils
 
close() - Method in class io.kgraph.library.cf.CfLongIdDeserializer
 
close() - Method in class io.kgraph.library.cf.CfLongIdSerde
 
close() - Method in class io.kgraph.library.cf.CfLongIdSerializer
 
close() - Method in class io.kgraph.pregel.PregelComputation
 
close() - Method in class io.kgraph.pregel.PregelConsumer
 
close(long, TimeUnit) - Method in class io.kgraph.pregel.PregelConsumer
 
close(Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
close() - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
close() - Method in class io.kgraph.pregel.PregelStateDeserializer
 
close() - Method in class io.kgraph.pregel.PregelStateSerializer
 
close() - Method in class io.kgraph.utils.KryoDeserializer
 
close() - Method in class io.kgraph.utils.KryoSerde
 
close() - Method in class io.kgraph.utils.KryoSerializer
 
close() - Method in class io.kgraph.utils.TopicPartitionDeserializer
 
close() - Method in class io.kgraph.utils.TopicPartitionSerializer
 
CLUSTER_CAPACITY - Static variable in class io.kgraph.library.clustering.SemiClustering
Maximum number of vertices in a semi-cluster.
CLUSTER_CAPACITY_DEFAULT - Static variable in class io.kgraph.library.clustering.SemiClustering
Default value for cluster capacity.
CLUSTER_CENTERS_COUNT - Static variable in class io.kgraph.library.clustering.KMeansClustering
Number of cluster centers
CLUSTER_CENTERS_COUNT - Static variable in class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
CLUSTER_CENTERS_COUNT_DEFAULT - Static variable in class io.kgraph.library.clustering.KMeansClustering
Default number of cluster centers
code() - Method in enum io.kgraph.GraphAlgorithmState.State
 
code() - Method in enum io.kgraph.pregel.PregelState.Stage
 
CombineCC() - Constructor for class io.kgraph.streaming.library.ConnectedComponents.CombineCC
 
combineFun() - Method in class io.kgraph.streaming.SummaryAggregation
 
CombineFunction() - Constructor for class io.kgraph.streaming.library.BipartitenessCheck.CombineFunction
 
CombineSpanners() - Constructor for class io.kgraph.streaming.library.Spanner.CombineSpanners
 
commitAsync() - Method in class io.kgraph.pregel.PregelConsumer
 
commitAsync(OffsetCommitCallback) - Method in class io.kgraph.pregel.PregelConsumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class io.kgraph.pregel.PregelConsumer
 
commitSync() - Method in class io.kgraph.pregel.PregelConsumer
 
commitSync(Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class io.kgraph.pregel.PregelConsumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
committed(TopicPartition) - Method in class io.kgraph.pregel.PregelConsumer
 
committed(TopicPartition, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
committed(Set<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
committed(Set<TopicPartition>, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
compareTo(CfId<Long>) - Method in class io.kgraph.library.cf.CfLongId
 
compareTo(SemiClustering.SemiCluster) - Method in class io.kgraph.library.clustering.SemiClustering.SemiCluster
Two semi clusters are the same when: (i) they have the same number of vertices, (ii) all their vertices are the same
completeGraph(StreamsBuilder, Properties, int) - Static method in class io.kgraph.utils.GraphGenerators
 
computation - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
compute(int, VertexWithValue<K, VV>, Iterable<Message>, Iterable<EdgeWithValue<K, EV>>, ComputeFunction.Callback<K, VV, EV, Message>) - Method in class io.kgraph.library.basic.EdgeCount
 
compute(int, VertexWithValue<K, VV>, Iterable<EdgeWithValue<K, EV>>, Iterable<EdgeWithValue<K, EV>>, ComputeFunction.Callback<K, VV, EV, EdgeWithValue<K, EV>>) - Method in class io.kgraph.library.basic.ReverseEdges
 
compute(int, VertexWithValue<K, VV>, Iterable<Message>, Iterable<EdgeWithValue<K, EV>>, ComputeFunction.Callback<K, VV, EV, Message>) - Method in class io.kgraph.library.basic.VertexCount
 
compute(int, VertexWithValue<K, Long>, Iterable<Long>, Iterable<EdgeWithValue<K, EV>>, ComputeFunction.Callback<K, Long, EV, Long>) - Method in class io.kgraph.library.BreadthFirstSearch
 
compute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Als
 
compute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Als.InitItemsComputation
 
compute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Als.InitUsersComputation
 
compute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Sgd
 
compute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Sgd.InitItemsComputation
 
compute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Sgd.InitUsersComputation
 
compute(int, VertexWithValue<CfLongId, Svdpp.SvdppValue>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, Svdpp.SvdppValue, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Svdpp
 
compute(int, VertexWithValue<CfLongId, Svdpp.SvdppValue>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, Svdpp.SvdppValue, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Svdpp.InitItemsComputation
 
compute(int, VertexWithValue<CfLongId, Svdpp.SvdppValue>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, Svdpp.SvdppValue, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Svdpp.InitUsersComputation
 
compute(int, VertexWithValue<CfLongId, Svdpp.SvdppValue>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, Svdpp.SvdppValue, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Svdpp.ItemComputation
 
compute(int, VertexWithValue<CfLongId, Svdpp.SvdppValue>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, Svdpp.SvdppValue, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Svdpp.UserComputation
 
compute(int, VertexWithValue<Long, KMeansVertexValue>, Iterable<Message>, Iterable<EdgeWithValue<Long, EV>>, ComputeFunction.Callback<Long, KMeansVertexValue, EV, Message>) - Method in class io.kgraph.library.clustering.KMeansClustering
 
compute(int, VertexWithValue<Long, KMeansVertexValue>, Iterable<Message>, Iterable<EdgeWithValue<Long, EV>>, ComputeFunction.Callback<Long, KMeansVertexValue, EV, Message>) - Method in class io.kgraph.library.clustering.KMeansClustering.RandomCentersInitialization
 
compute(int, VertexWithValue<Long, Set<SemiClustering.SemiCluster>>, Iterable<Set<SemiClustering.SemiCluster>>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Set<SemiClustering.SemiCluster>, Double, Set<SemiClustering.SemiCluster>>) - Method in class io.kgraph.library.clustering.SemiClustering
Compute method.
compute(int, VertexWithValue<Long, Long>, Iterable<Long>, Iterable<EdgeWithValue<Long, EV>>, ComputeFunction.Callback<Long, Long, EV, Long>) - Method in class io.kgraph.library.ConnectedComponents
 
compute(int, VertexWithValue<Long, Long>, Iterable<Map<Long, Long>>, Iterable<EdgeWithValue<Long, EV>>, ComputeFunction.Callback<Long, Long, EV, Map<Long, Long>>) - Method in class io.kgraph.library.LabelPropagation
 
compute(int, VertexWithValue<Long, Double>, Iterable<LocalClusteringCoefficient.LCCMessage>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, LocalClusteringCoefficient.LCCMessage>) - Method in class io.kgraph.library.LocalClusteringCoefficient
 
compute(int, VertexWithValue<Long, Integer>, Iterable<MBMMessage>, Iterable<EdgeWithValue<Long, MBMEdgeValue>>, ComputeFunction.Callback<Long, Integer, MBMEdgeValue, MBMMessage>) - Method in class io.kgraph.library.maxbmatching.MaxBMatching
 
compute(int, VertexWithValue<Long, Map<Long, Double>>, Iterable<Map<Long, Double>>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Map<Long, Double>, Double, Map<Long, Double>>) - Method in class io.kgraph.library.MultipleSourceShortestPaths
 
compute(int, VertexWithValue<K, Tuple2<Double, Double>>, Iterable<Double>, Iterable<EdgeWithValue<K, Double>>, ComputeFunction.Callback<K, Tuple2<Double, Double>, Double, Double>) - Method in class io.kgraph.library.PageRank
 
compute(int, VertexWithValue<Long, Double>, Iterable<AdamicAdar.LongIdDoubleValueFriendsList>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, AdamicAdar.LongIdDoubleValueFriendsList>) - Method in class io.kgraph.library.similarity.AdamicAdar
 
compute(int, VertexWithValue<Long, Double>, Iterable<AdamicAdar.LongIdDoubleValueFriendsList>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, AdamicAdar.LongIdDoubleValueFriendsList>) - Method in class io.kgraph.library.similarity.AdamicAdar.ComputeLogOfInverseDegree
 
compute(int, VertexWithValue<Long, Double>, Iterable<AdamicAdar.LongIdDoubleValueFriendsList>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, AdamicAdar.LongIdDoubleValueFriendsList>) - Method in class io.kgraph.library.similarity.AdamicAdar.ScaleToDistance
 
compute(int, VertexWithValue<Long, Double>, Iterable<AdamicAdar.LongIdDoubleValueFriendsList>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, AdamicAdar.LongIdDoubleValueFriendsList>) - Method in class io.kgraph.library.similarity.AdamicAdar.SendFriendsListAndValue
 
compute(int, VertexWithValue<Long, VV>, Iterable<Jaccard.MessageWrapper<Long, List<Long>>>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, VV, Double, Jaccard.MessageWrapper<Long, List<Long>>>) - Method in class io.kgraph.library.similarity.Jaccard
 
compute(int, VertexWithValue<Long, VV>, Iterable<Jaccard.MessageWrapper<Long, List<Long>>>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, VV, Double, Jaccard.MessageWrapper<Long, List<Long>>>) - Method in class io.kgraph.library.similarity.Jaccard.ScaleToDistance
 
compute(int, VertexWithValue<K, VV>, Iterable<Jaccard.MessageWrapper<K, List<K>>>, Iterable<EdgeWithValue<K, EV>>, ComputeFunction.Callback<K, VV, EV, Jaccard.MessageWrapper<K, List<K>>>) - Method in class io.kgraph.library.similarity.Jaccard.SendFriends
 
compute(int, VertexWithValue<Long, Double>, Iterable<Double>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, Double>) - Method in class io.kgraph.library.SingleSourceShortestPaths
 
compute(int, VertexWithValue<Long, SybilRank.VertexValue>, Iterable<Double>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, SybilRank.VertexValue, Double, Double>) - Method in class io.kgraph.library.SybilRank
 
compute(int, VertexWithValue<Long, SybilRank.VertexValue>, Iterable<Double>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, SybilRank.VertexValue, Double, Double>) - Method in class io.kgraph.library.SybilRank.Initializer
 
compute(int, VertexWithValue<Long, SybilRank.VertexValue>, Iterable<Double>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, SybilRank.VertexValue, Double, Double>) - Method in class io.kgraph.library.SybilRank.SybilRankComputation
 
compute(int, VertexWithValue<Long, SybilRank.VertexValue>, Iterable<Double>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, SybilRank.VertexValue, Double, Double>) - Method in class io.kgraph.library.SybilRank.TrustAggregation
 
compute(int, VertexWithValue<K, VV>, Iterable<Message>, Iterable<EdgeWithValue<K, EV>>, ComputeFunction.Callback<K, VV, EV, Message>) - Method in interface io.kgraph.pregel.ComputeFunction
The function for computing a new vertex value or sending messages to the next superstep.
computeDegree(Iterable<EdgeWithValue<Long, Double>>) - Static method in class io.kgraph.library.SybilRank
This method computes the degree of a vertex as the sum of its edge weights.
computeFunction(GraphAlgorithmType) - Static method in enum io.kgraph.library.GraphAlgorithmType
 
ComputeFunction<K,VV,EV,Message> - Interface in io.kgraph.pregel
The user-defined compute function for a Pregel computation.
ComputeFunction.Aggregators - Class in io.kgraph.pregel
 
ComputeFunction.Callback<K,VV,EV,Message> - Class in io.kgraph.pregel
 
ComputeFunction.InitCallback - Class in io.kgraph.pregel
 
ComputeFunction.MasterCallback - Class in io.kgraph.pregel
 
ComputeFunction.ReadAggregators - Interface in io.kgraph.pregel
 
ComputeFunction.ReadWriteAggregators - Interface in io.kgraph.pregel
 
ComputeLogOfInverseDegree() - Constructor for class io.kgraph.library.similarity.AdamicAdar.ComputeLogOfInverseDegree
 
computePredictedRating(float, float, float, FloatMatrix, FloatMatrix, int, FloatMatrix, float, float) - Static method in class io.kgraph.library.cf.Svdpp
Computes the predicted rating r between a user and an item based on the formula: r = b + q^T * (p + (1/sqrt(N) * sum(y_i)))
computeUpdatedBaseLine(float, float, float, float, float) - Static method in class io.kgraph.library.cf.Svdpp
Computes the updated baseline based on the formula:
configs() - Method in interface io.kgraph.GraphAlgorithm
 
configs() - Method in class io.kgraph.pregel.PregelComputation
 
configs() - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
configure(StreamsBuilder, Properties) - Method in interface io.kgraph.GraphAlgorithm
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.library.cf.CfLongIdDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.library.cf.CfLongIdSerde
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.library.cf.CfLongIdSerializer
 
configure(Map<String, ?>) - Method in class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
configure(StreamsBuilder, Properties) - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.pregel.PregelStateDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.pregel.PregelStateSerializer
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.utils.KryoDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.utils.KryoSerde
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.utils.KryoSerializer
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.utils.TopicPartitionDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.kgraph.utils.TopicPartitionSerializer
 
ConnectedComponents<EV> - Class in io.kgraph.library
 
ConnectedComponents() - Constructor for class io.kgraph.library.ConnectedComponents
 
ConnectedComponents<K,EV> - Class in io.kgraph.streaming.library
The Connected Components library method assigns a component ID to each vertex in the graph.
ConnectedComponents(long) - Constructor for class io.kgraph.streaming.library.ConnectedComponents
Creates a ConnectedComponents object using WindowGraphAggregation class.
ConnectedComponents.CombineCC<K> - Class in io.kgraph.streaming.library
Implements the ReduceFunction Interface, applies reduce function to combine group of elements into a single value.
ConnectedComponents.UpdateCC<K,EV> - Class in io.kgraph.streaming.library
Implements EdgesFold Interface, applies foldEdges function to a vertex neighborhood The Edge stream is divided into different windows, the foldEdges function is applied on each window incrementally and the aggregate state for each window is updated, in this case it checks the connected components in a window.
consumerConfig(String, String, Class, Class, Properties) - Static method in class io.kgraph.utils.ClientUtils
 
context - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
CountNeighborsLeftJoin() - Constructor for class io.kgraph.KGraph.CountNeighborsLeftJoin
 
countTriangles(KGraphStream<Long, Void, Void>) - Static method in class io.kgraph.streaming.library.ExactTriangleCount
 
createCurator(String) - Static method in class io.kgraph.pregel.ZKUtils
 
createTopic(String, int, short, Properties) - Static method in class io.kgraph.utils.ClientUtils
 
curator - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 

D

deepCopy(V) - Static method in class io.kgraph.utils.KryoUtils
 
degrees() - Method in class io.kgraph.streaming.EdgeStream
Get the degree stream
degrees() - Method in interface io.kgraph.streaming.KGraphStream
Get the degree stream
deserialize(String, byte[]) - Method in class io.kgraph.library.cf.CfLongIdDeserializer
 
deserialize(String, byte[]) - Method in class io.kgraph.pregel.PregelStateDeserializer
 
deserialize(String, byte[]) - Method in class io.kgraph.utils.KryoDeserializer
 
deserialize(byte[]) - Static method in class io.kgraph.utils.KryoUtils
 
deserialize(String, byte[]) - Method in class io.kgraph.utils.TopicPartitionDeserializer
 
deserializer() - Method in class io.kgraph.library.cf.CfLongIdSerde
 
deserializer() - Method in class io.kgraph.utils.KryoSerde
 
DIMENSIONS - Static variable in class io.kgraph.library.clustering.KMeansClustering
Dimensions of the input points
DisjointSet<R> - Class in io.kgraph.streaming.summaries
 
DisjointSet() - Constructor for class io.kgraph.streaming.summaries.DisjointSet
 
DisjointSet(Set<R>) - Constructor for class io.kgraph.streaming.summaries.DisjointSet
 
DisjointSet(DisjointSet<R>) - Constructor for class io.kgraph.streaming.summaries.DisjointSet
 
DisjointSet(DisjointSet<R>, R, R) - Constructor for class io.kgraph.streaming.summaries.DisjointSet
 
DISTANCE_CONVERSION - Static variable in class io.kgraph.library.similarity.AdamicAdar
Enables the conversion to distance conversion
DISTANCE_CONVERSION - Static variable in class io.kgraph.library.similarity.Jaccard
Enables the conversion to distance conversion
DISTANCE_CONVERSION_DEFAULT - Static variable in class io.kgraph.library.similarity.AdamicAdar
Default value for distance conversion
DISTANCE_CONVERSION_DEFAULT - Static variable in class io.kgraph.library.similarity.Jaccard
Default value for distance conversion
distinct() - Method in class io.kgraph.streaming.EdgeStream
Removes the duplicate edges by storing a neighborhood set for each vertex
distinct() - Method in interface io.kgraph.streaming.KGraphStream
Removes the duplicate edges by storing a neighborhood set for each vertex
DoubleListAggregator - Class in io.kgraph.library.clustering
 
DoubleListAggregator() - Constructor for class io.kgraph.library.clustering.DoubleListAggregator
 
DoubleMaxAggregator - Class in io.kgraph.pregel.aggregators
 
DoubleMaxAggregator() - Constructor for class io.kgraph.pregel.aggregators.DoubleMaxAggregator
 
DoubleMinAggregator - Class in io.kgraph.pregel.aggregators
 
DoubleMinAggregator() - Constructor for class io.kgraph.pregel.aggregators.DoubleMinAggregator
 
DoubleParser() - Constructor for class io.kgraph.utils.Parsers.DoubleParser
 
DoubleProductAggregator - Class in io.kgraph.pregel.aggregators
 
DoubleProductAggregator() - Constructor for class io.kgraph.pregel.aggregators.DoubleProductAggregator
 
DoubleSumAggregator - Class in io.kgraph.pregel.aggregators
 
DoubleSumAggregator() - Constructor for class io.kgraph.pregel.aggregators.DoubleSumAggregator
 

E

Edge<K> - Class in io.kgraph
 
Edge(K, K) - Constructor for class io.kgraph.Edge
 
EDGE_COUNT_AGGREGATOR - Static variable in class io.kgraph.library.basic.EdgeCount
 
EdgeCfLongIdFloatValueParser - Class in io.kgraph.library.cf
 
EdgeCfLongIdFloatValueParser() - Constructor for class io.kgraph.library.cf.EdgeCfLongIdFloatValueParser
 
EdgeCount<K,VV,EV,Message> - Class in io.kgraph.library.basic
 
EdgeCount() - Constructor for class io.kgraph.library.basic.EdgeCount
 
EdgeDirection - Enum in io.kgraph
 
EdgeFoldFunction<K,EV,T> - Interface in io.kgraph.streaming
Interface to be implemented by the function applied to a vertex neighborhood in the KGraphWindowedStream.foldNeighbors(Object, EdgeFoldFunction) method.
EdgeJoinFunction<EV,T> - Interface in io.kgraph
 
EdgeParser(Parser<K>, Parser<K>, Parser<V>) - Constructor for class io.kgraph.utils.Parsers.EdgeParser
 
EdgeReduceFunction<EV> - Interface in io.kgraph.streaming
Interface to be implemented by the function applied to a vertex neighborhood in the KGraphWindowedStream.reduceOnEdges(EdgeReduceFunction) method.
edges() - Method in class io.kgraph.KGraph
 
edges() - Method in class io.kgraph.streaming.EdgeStream
 
edges() - Method in interface io.kgraph.streaming.KGraphStream
 
edgesBySource() - Method in class io.kgraph.KGraph
 
edgesByTarget() - Method in class io.kgraph.KGraph
 
EdgesFunctionWithVertexValue<K,VV,EV,T> - Interface in io.kgraph
 
edgesGroupedBySource() - Method in class io.kgraph.KGraph
 
edgesGroupedBySource() - Method in class io.kgraph.pregel.PregelComputation
 
edgesGroupedBySourceTopic - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
edgesGroupedByTarget() - Method in class io.kgraph.KGraph
 
edgesStore - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
edgesToTopic(InputStream, Parser<K>, Parser<K>, Parser<V>, Serializer<V>, Properties, String, int, short) - Static method in class io.kgraph.utils.GraphUtils
 
edgesToTopic(InputStream, Parser<EdgeWithValue<K, V>>, Serializer<V>, Properties, String, int, short) - Static method in class io.kgraph.utils.GraphUtils
 
EdgeStream<K,EV> - Class in io.kgraph.streaming
Represents a graph stream where the stream consists solely of edges.
EdgeStream(KStream<Edge<K>, EV>, GraphSerialized<K, Void, EV>) - Constructor for class io.kgraph.streaming.EdgeStream
Creates a graph from an edge stream.
edgeValueSerde() - Method in class io.kgraph.GraphSerialized
 
edgeValueSerde() - Method in class io.kgraph.KGraph
 
EdgeWithValue<K,V> - Class in io.kgraph
 
EdgeWithValue(Edge<K>, V) - Constructor for class io.kgraph.EdgeWithValue
 
EdgeWithValue(K, K, V) - Constructor for class io.kgraph.EdgeWithValue
 
EmitSrcAndTarget(ValueMapper<K, VV>) - Constructor for class io.kgraph.KGraph.EmitSrcAndTarget
 
endOffsets(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
endOffsets(Collection<TopicPartition>, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
endTime() - Method in class io.kgraph.pregel.PregelState
 
equals(Object) - Method in class io.kgraph.Edge
 
equals(Object) - Method in class io.kgraph.EdgeWithValue
 
equals(Object) - Method in class io.kgraph.library.cf.CfLongId
 
equals(Object) - Method in class io.kgraph.library.cf.FloatMatrixMessage
 
equals(Object) - Method in class io.kgraph.library.cf.Svdpp.SvdppValue
 
equals(Object) - Method in class io.kgraph.library.clustering.KMeansVertexValue
 
equals(Object) - Method in class io.kgraph.library.clustering.SemiClustering.SemiCluster
 
equals(Object) - Method in class io.kgraph.library.maxbmatching.MBMEdgeValue
 
equals(Object) - Method in class io.kgraph.library.maxbmatching.MBMMessage
 
equals(Object) - Method in class io.kgraph.library.similarity.Jaccard.MessageWrapper
 
equals(Object) - Method in class io.kgraph.library.SybilRank.VertexValue
 
equals(Object) - Method in class io.kgraph.pregel.PregelState
 
equals(Object) - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
 
equals(Object) - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph.Node
 
equals(Object) - Method in class io.kgraph.streaming.summaries.Candidates
 
equals(Object) - Method in class io.kgraph.streaming.summaries.DisjointSet
 
equals(Object) - Method in class io.kgraph.streaming.utils.SignedVertex
 
equals(Object) - Method in class io.kgraph.VertexWithValue
 
ExactTriangleCount - Class in io.kgraph.streaming.library
Single-pass, insertion-only exact Triangle Local and Global Count algorithm.
ExactTriangleCount() - Constructor for class io.kgraph.streaming.library.ExactTriangleCount
 
ExactTriangleCount.IntersectNeighborhoods - Class in io.kgraph.streaming.library
Receives 2 tuples from the same edge (src + target) and intersects the attached neighborhoods.
ExactTriangleCount.ProjectCanonicalEdges - Class in io.kgraph.streaming.library
 
ExactTriangleCount.SumAndEmitCounters - Class in io.kgraph.streaming.library
Sums up and emits local and global counters.

F

FACTOR_GAMMA - Static variable in class io.kgraph.library.cf.Svdpp
Factor learning rate parameter
FACTOR_GAMMA_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default value for factor learning rate
FACTOR_LAMBDA - Static variable in class io.kgraph.library.cf.Svdpp
Factor regularization parameter.
FACTOR_LAMBDA_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default value for factor regularization parameter
filterEdges(Predicate<Edge<K>, EV>) - Method in class io.kgraph.streaming.EdgeStream
Apply a filter to each edge in the graph stream
filterEdges(Predicate<Edge<K>, EV>) - Method in interface io.kgraph.streaming.KGraphStream
Apply a filter to each edge in the graph stream
filterOnEdges(Predicate<Edge<K>, EV>) - Method in class io.kgraph.KGraph
 
filterOnVertices(Predicate<K, VV>) - Method in class io.kgraph.KGraph
 
filterVertices(Predicate<K, Void>) - Method in class io.kgraph.streaming.EdgeStream
Apply a filter to each vertex in the graph stream Since this is an edge-only stream, the vertex filter can only access the key of vertices
filterVertices(Predicate<K, Void>) - Method in interface io.kgraph.streaming.KGraphStream
Apply a filter to each vertex in the graph stream Since this is an edge-only stream, the vertex filter can only access the key of vertices
find(R) - Method in class io.kgraph.streaming.summaries.DisjointSet
Find returns the root of the disjoint set e belongs in.
FloatMatrixMessage - Class in io.kgraph.library.cf
Messages send in most of the CF algorithm typically must carry the id of the message sender as well as the payload of the message, that is, the latent vector.
FloatMatrixMessage(FloatMatrixMessage) - Constructor for class io.kgraph.library.cf.FloatMatrixMessage
 
FloatMatrixMessage(CfLongId, FloatMatrix, float) - Constructor for class io.kgraph.library.cf.FloatMatrixMessage
 
FloatParser() - Constructor for class io.kgraph.utils.Parsers.FloatParser
 
foldEdges(T, K, K, EV) - Method in interface io.kgraph.streaming.EdgeFoldFunction
Combines two edge values into one value of the same type.
foldEdges(Candidates, Long, Long, EV) - Method in class io.kgraph.streaming.library.BipartitenessCheck.UpdateFunction
Implements foldEdges method of EdgesFold interface for combining two edges values into same type using merge method of the Candidates class.
foldEdges(DisjointSet<K>, K, K, EV) - Method in class io.kgraph.streaming.library.ConnectedComponents.UpdateCC
Implements foldEdges method of EdgesFold interface for combining two edges values into same type using union method of the DisjointSet class.
foldEdges(AdjacencyListGraph<K>, K, K, EV) - Method in class io.kgraph.streaming.library.Spanner.UpdateLocal
 
foldNeighbors(T, EdgeFoldFunction<K, EV, T>) - Method in class io.kgraph.streaming.KGraphWindowedStream
Performs a neighborhood fold on the graph window stream.
fromBytes(byte[]) - Static method in class io.kgraph.pregel.PregelState
 
fromEdges(KTable<Edge<K>, EV>, ValueMapper<K, VV>, GraphSerialized<K, VV, EV>) - Static method in class io.kgraph.KGraph
 
fromValue(byte) - Static method in enum io.kgraph.library.maxbmatching.MBMEdgeValue.State
 
futureResult() - Method in class io.kgraph.pregel.PregelComputation
 

G

GAMMA - Static variable in class io.kgraph.library.cf.Sgd
Keyword for parameter setting the learning rate GAMMA.
GAMMA_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default value for GAMMA.
generateRandomHexString(int) - Static method in class io.kgraph.utils.ClientUtils
 
generateStoreName() - Static method in class io.kgraph.KGraph
 
get(int) - Static method in enum io.kgraph.GraphAlgorithmState.State
 
get(int) - Static method in enum io.kgraph.pregel.PregelState.Stage
 
getAdminClient(Map<String, Object>) - Method in class io.kgraph.pregel.PregelClientSupplier
 
getAggregate() - Method in class io.kgraph.library.clustering.DoubleListAggregator
 
getAggregate() - Method in class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
getAggregate() - Method in interface io.kgraph.pregel.aggregators.Aggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.BooleanAndAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.BooleanOrAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.DoubleMaxAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.DoubleMinAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.DoubleProductAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.DoubleSumAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.LongMaxAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.LongMinAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.LongProductAggregator
 
getAggregate() - Method in class io.kgraph.pregel.aggregators.LongSumAggregator
 
getAggregate() - Method in class io.kgraph.pregel.PregelComputation.MapOfLongMaxAggregator
 
getAggregatedValue(String) - Method in class io.kgraph.pregel.ComputeFunction.Aggregators
 
getAggregatedValue(String) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
getAggregatedValue(String) - Method in class io.kgraph.pregel.ComputeFunction.MasterCallback
 
getAggregatedValue(String) - Method in interface io.kgraph.pregel.ComputeFunction.ReadAggregators
 
getAggregatorClass() - Method in class io.kgraph.pregel.PregelComputation.AggregatorWrapper
 
getBaseline() - Method in class io.kgraph.library.cf.Svdpp.SvdppValue
 
getChildData(CuratorFramework, String, String) - Static method in class io.kgraph.pregel.ZKUtils
 
getClusterId() - Method in class io.kgraph.library.clustering.KMeansVertexValue
 
getConfiguredInstance(Class<T>, Map<String, ?>) - Static method in class io.kgraph.utils.ClientUtils
 
getConsumer(Map<String, Object>) - Method in class io.kgraph.pregel.PregelClientSupplier
 
getFactors() - Method in class io.kgraph.library.cf.FloatMatrixMessage
 
getFactors() - Method in class io.kgraph.library.cf.Svdpp.SvdppValue
 
getGlobalConsumer(Map<String, Object>) - Method in class io.kgraph.pregel.PregelClientSupplier
 
getId() - Method in interface io.kgraph.library.cf.CfId
Returns the identifier of the node.
getId() - Method in class io.kgraph.library.cf.CfLongId
 
getId() - Method in class io.kgraph.library.maxbmatching.MBMMessage
 
getMessage() - Method in class io.kgraph.library.similarity.Jaccard.MessageWrapper
 
getNeighborsList() - Method in class io.kgraph.library.similarity.AdamicAdar.LongIdDoubleValueFriendsList
 
getPointCoordinates() - Method in class io.kgraph.library.clustering.KMeansVertexValue
 
getProducer(Map<String, Object>) - Method in class io.kgraph.pregel.PregelClientSupplier
 
getRank() - Method in class io.kgraph.library.SybilRank.VertexValue
 
getRestoreConsumer(Map<String, Object>) - Method in class io.kgraph.pregel.PregelClientSupplier
 
getScore() - Method in class io.kgraph.library.cf.FloatMatrixMessage
 
getSenderId() - Method in class io.kgraph.library.cf.FloatMatrixMessage
 
getSerde(Class<Serde<T>>, Map<String, ?>) - Static method in class io.kgraph.utils.ClientUtils
 
getSourceId() - Method in class io.kgraph.library.similarity.Jaccard.MessageWrapper
 
getState() - Method in class io.kgraph.library.maxbmatching.MBMEdgeValue
 
getState() - Method in class io.kgraph.library.maxbmatching.MBMMessage
 
getTotalNumEdges(ComputeFunction.ReadAggregators) - Method in class io.kgraph.library.cf.Als
 
getTotalNumEdges(ComputeFunction.ReadAggregators) - Method in class io.kgraph.library.cf.Sgd
 
getTotalNumEdges(ComputeFunction.ReadAggregators) - Method in class io.kgraph.library.cf.Svdpp
 
getTotalNumVertices(ComputeFunction.ReadAggregators) - Method in class io.kgraph.library.SybilRank
 
getType() - Method in interface io.kgraph.library.cf.CfId
Returns the type of the node.
getType() - Method in class io.kgraph.library.cf.CfLongId
 
getVertexValue() - Method in class io.kgraph.library.similarity.AdamicAdar.LongIdDoubleValueFriendsList
 
getWeight() - Method in class io.kgraph.library.cf.Svdpp.SvdppValue
 
getWeight() - Method in class io.kgraph.library.maxbmatching.MBMEdgeValue
 
GLOBAL_KEY - Static variable in interface io.kgraph.streaming.KGraphStream
 
globalAggregate(KeyValueMapper<Edge<K>, EV, Iterable<KeyValue<K, VV>>>, KeyValueMapper<K, VV, Iterable<KeyValue<Short, VV>>>, boolean) - Method in class io.kgraph.streaming.EdgeStream
Returns a global aggregate on the previously split vertex stream
globalAggregate(KeyValueMapper<Edge<K>, EV, Iterable<KeyValue<K, VV>>>, KeyValueMapper<K, VV, Iterable<KeyValue<Short, VV>>>, boolean) - Method in interface io.kgraph.streaming.KGraphStream
Returns a global aggregate on the previously split vertex stream
GraphAlgorithm<K,VV,EV,T> - Interface in io.kgraph
 
GraphAlgorithmState<T> - Class in io.kgraph
 
GraphAlgorithmState(KafkaStreams, GraphAlgorithmState.State, int, long, Map<String, ?>, CompletableFuture<T>) - Constructor for class io.kgraph.GraphAlgorithmState
 
GraphAlgorithmState.State - Enum in io.kgraph
 
GraphAlgorithmType - Enum in io.kgraph.library
 
GraphGenerators - Class in io.kgraph.utils
 
GraphGenerators() - Constructor for class io.kgraph.utils.GraphGenerators
 
graphOffsets - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
GRAPHS_PATH - Static variable in class io.kgraph.pregel.ZKUtils
 
GraphSerialized<K,VV,EV> - Class in io.kgraph
 
GraphSerialized(GraphSerialized<K, VV, EV>) - Constructor for class io.kgraph.GraphSerialized
 
graphSerialized(GraphAlgorithmType, boolean) - Static method in enum io.kgraph.library.GraphAlgorithmType
 
GraphUtils - Class in io.kgraph.utils
 
GraphUtils() - Constructor for class io.kgraph.utils.GraphUtils
 
gridGraph(StreamsBuilder, Properties, int, int) - Static method in class io.kgraph.utils.GraphGenerators
 
GROUP - Static variable in class io.kgraph.pregel.ZKUtils
 
groupEdgesBySourceAndRepartition(StreamsBuilder, Properties, String, String, GraphSerialized<K, VV, EV>, String, String, int, short) - Static method in class io.kgraph.utils.GraphUtils
 
groupEdgesBySourceAndRepartition(StreamsBuilder, Properties, KGraph<K, VV, EV>, String, String, int, short) - Static method in class io.kgraph.utils.GraphUtils
 
groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class io.kgraph.KGraph
 
groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class io.kgraph.KGraph
 

H

haltComputation - Variable in class io.kgraph.pregel.ComputeFunction.MasterCallback
 
haltComputation() - Method in class io.kgraph.pregel.ComputeFunction.MasterCallback
 
hasChild(CuratorFramework, String, PregelState, String) - Static method in class io.kgraph.pregel.ZKUtils
 
hasChild(CuratorFramework, String, String) - Static method in class io.kgraph.pregel.ZKUtils
 
hashCode() - Method in class io.kgraph.Edge
 
hashCode() - Method in class io.kgraph.EdgeWithValue
 
hashCode() - Method in class io.kgraph.library.cf.CfLongId
 
hashCode() - Method in class io.kgraph.library.cf.FloatMatrixMessage
 
hashCode() - Method in class io.kgraph.library.cf.Svdpp.SvdppValue
 
hashCode() - Method in class io.kgraph.library.clustering.KMeansVertexValue
 
hashCode() - Method in class io.kgraph.library.clustering.SemiClustering.SemiCluster
 
hashCode() - Method in class io.kgraph.library.maxbmatching.MBMEdgeValue
 
hashCode() - Method in class io.kgraph.library.maxbmatching.MBMMessage
 
hashCode() - Method in class io.kgraph.library.similarity.Jaccard.MessageWrapper
 
hashCode() - Method in class io.kgraph.library.SybilRank.VertexValue
 
hashCode() - Method in class io.kgraph.pregel.PregelState
 
hashCode() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
 
hashCode() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph.Node
 
hashCode() - Method in class io.kgraph.streaming.summaries.Candidates
 
hashCode() - Method in class io.kgraph.streaming.summaries.DisjointSet
 
hashCode() - Method in class io.kgraph.streaming.utils.SignedVertex
 
hashCode() - Method in class io.kgraph.VertexWithValue
 
hostAndPort - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 

I

id() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph.Node
 
id() - Method in class io.kgraph.VertexWithValue
 
incrementValue(float, float, float, float) - Static method in class io.kgraph.library.cf.Svdpp
Increments a scalar value according to the formula:
incrementValue(FloatMatrix, FloatMatrix, float, float) - Static method in class io.kgraph.library.cf.Svdpp
Increments a vector according to the formula
inDegrees() - Method in class io.kgraph.KGraph
 
inDegrees() - Method in class io.kgraph.streaming.EdgeStream
Get the in-degree stream
inDegrees() - Method in interface io.kgraph.streaming.KGraphStream
Get the in-degree stream
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.basic.EdgeCount
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.basic.VertexCount
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.BreadthFirstSearch
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.cf.Als
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.cf.Sgd
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.cf.Svdpp
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.clustering.KMeansClustering
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.clustering.SemiClustering
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.MultipleSourceShortestPaths
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.PageRank
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.similarity.AdamicAdar
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.similarity.Jaccard
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.SingleSourceShortestPaths
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in class io.kgraph.library.SybilRank
 
init(Map<String, ?>, ComputeFunction.InitCallback) - Method in interface io.kgraph.pregel.ComputeFunction
Initialize the ComputeFunction, this is the place to register aggregators.
InitCallback(Map<String, PregelComputation.AggregatorWrapper<?>>) - Constructor for class io.kgraph.pregel.ComputeFunction.InitCallback
 
INITIAL_CENTERS - Static variable in class io.kgraph.library.clustering.KMeansClustering
The initial centers aggregator
Initializer() - Constructor for class io.kgraph.library.SybilRank.Initializer
 
initialValue() - Method in class io.kgraph.streaming.SummaryAggregation
 
initialVertexValueMapper(GraphAlgorithmType) - Static method in enum io.kgraph.library.GraphAlgorithmType
 
InitItemsComputation() - Constructor for class io.kgraph.library.cf.Als.InitItemsComputation
 
InitItemsComputation() - Constructor for class io.kgraph.library.cf.Sgd.InitItemsComputation
 
InitItemsComputation() - Constructor for class io.kgraph.library.cf.Svdpp.InitItemsComputation
 
InitUsersComputation() - Constructor for class io.kgraph.library.cf.Als.InitUsersComputation
 
InitUsersComputation() - Constructor for class io.kgraph.library.cf.Sgd.InitUsersComputation
 
InitUsersComputation() - Constructor for class io.kgraph.library.cf.Svdpp.InitUsersComputation
 
IntegerParser() - Constructor for class io.kgraph.utils.Parsers.IntegerParser
 
IntersectNeighborhoods() - Constructor for class io.kgraph.streaming.library.ExactTriangleCount.IntersectNeighborhoods
 
io.kgraph - package io.kgraph
 
io.kgraph.library - package io.kgraph.library
 
io.kgraph.library.basic - package io.kgraph.library.basic
 
io.kgraph.library.cf - package io.kgraph.library.cf
 
io.kgraph.library.clustering - package io.kgraph.library.clustering
 
io.kgraph.library.maxbmatching - package io.kgraph.library.maxbmatching
 
io.kgraph.library.similarity - package io.kgraph.library.similarity
 
io.kgraph.pregel - package io.kgraph.pregel
 
io.kgraph.pregel.aggregators - package io.kgraph.pregel.aggregators
 
io.kgraph.streaming - package io.kgraph.streaming
 
io.kgraph.streaming.library - package io.kgraph.streaming.library
 
io.kgraph.streaming.summaries - package io.kgraph.streaming.summaries
 
io.kgraph.streaming.utils - package io.kgraph.streaming.utils
 
io.kgraph.utils - package io.kgraph.utils
 
isItem() - Method in class io.kgraph.library.cf.CfLongId
 
isOutput() - Method in class io.kgraph.library.cf.CfLongId
 
isPersistent() - Method in class io.kgraph.pregel.PregelComputation.AggregatorWrapper
 
isReady(CuratorFramework, String, PregelState) - Static method in class io.kgraph.pregel.ZKUtils
 
isTransientState() - Method in class io.kgraph.streaming.SummaryAggregation
 
isTrusted() - Method in class io.kgraph.library.SybilRank.VertexValue
 
isUser() - Method in class io.kgraph.library.cf.CfLongId
 
ItemComputation() - Constructor for class io.kgraph.library.cf.Svdpp.ItemComputation
 
iterateEdges(VV, Iterable<EdgeWithValue<K, EV>>) - Method in interface io.kgraph.EdgesFunctionWithVertexValue
 
iterateNeighbors(VV, Map<EdgeWithValue<K, EV>, VV>) - Method in interface io.kgraph.NeighborsFunctionWithVertexValue
 
ITERATION_MULTIPLIER - Static variable in class io.kgraph.library.SybilRank
Property name for the iteration multiplier.
ITERATION_MULTIPLIER_DEFAULT - Static variable in class io.kgraph.library.SybilRank
Default multiplier for the iterations.
ITERATIONS - Static variable in class io.kgraph.library.cf.Als
Keyword for parameter setting the number of iterations.
ITERATIONS - Static variable in class io.kgraph.library.cf.Sgd
Keyword for parameter setting the number of iterations.
ITERATIONS - Static variable in class io.kgraph.library.cf.Svdpp
Maximum number of iterations.
ITERATIONS - Static variable in class io.kgraph.library.clustering.SemiClustering
Maximum number of iterations.
ITERATIONS_DEFAULT - Static variable in class io.kgraph.library.cf.Als
Default value for ITERATIONS.
ITERATIONS_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default value for ITERATIONS.
ITERATIONS_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default value for ITERATIONS.
ITERATIONS_DEFAULT - Static variable in class io.kgraph.library.clustering.KMeansClustering
Default value for iterations
ITERATIONS_DEFAULT - Static variable in class io.kgraph.library.clustering.SemiClustering
Default value for ITERATIONS.

J

Jaccard<VV> - Class in io.kgraph.library.similarity
This class computes the Jaccard similarity or distance for each pair of neighbors in an undirected unweighted graph.
Jaccard() - Constructor for class io.kgraph.library.similarity.Jaccard
 
Jaccard.MessageWrapper<K,Message> - Class in io.kgraph.library.similarity
 
Jaccard.ScaleToDistance<VV> - Class in io.kgraph.library.similarity
 
Jaccard.SendFriends<K,VV,EV> - Class in io.kgraph.library.similarity
Implements the first step in the exact jaccard similirity algorithm.
joinEdges(EV, T) - Method in interface io.kgraph.EdgeJoinFunction
 
joinVertices(VV, T) - Method in interface io.kgraph.VertexJoinFunction
 
joinWithEdges(KTable<Edge<K>, T>, EdgeJoinFunction<EV, T>) - Method in class io.kgraph.KGraph
 
joinWithEdgesOnSource(KTable<K, T>, EdgeJoinFunction<EV, T>) - Method in class io.kgraph.KGraph
 
joinWithEdgesOnTarget(KTable<K, T>, EdgeJoinFunction<EV, T>) - Method in class io.kgraph.KGraph
 
joinWithVertices(KTable<K, T>, VertexJoinFunction<VV, T>) - Method in class io.kgraph.KGraph
 

K

key - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
keySerde() - Method in class io.kgraph.GraphSerialized
 
keySerde() - Method in class io.kgraph.KGraph
 
KGraph<K,VV,EV> - Class in io.kgraph
 
KGraph(KTable<K, VV>, KTable<Edge<K>, EV>, GraphSerialized<K, VV, EV>) - Constructor for class io.kgraph.KGraph
 
KGraph.ApplyEdgeLeftJoinFunction<K,VV,EV,T> - Class in io.kgraph
 
KGraph.ApplyLeftJoinToEdgeValues<K,EV,T> - Class in io.kgraph
 
KGraph.ApplyLeftJoinToEdgeValuesOnEitherSourceOrTarget<K,EV,T> - Class in io.kgraph
 
KGraph.ApplyLeftJoinToVertexValues<K,VV,T> - Class in io.kgraph
 
KGraph.ApplyNeighborLeftJoinFunction<K,VV,EV,T> - Class in io.kgraph
 
KGraph.CountNeighborsLeftJoin<K,VV,EV> - Class in io.kgraph
 
KGraph.EmitSrcAndTarget<K,VV,EV> - Class in io.kgraph
 
KGraph.UndirectEdges<K,EV> - Class in io.kgraph
 
KGraphStream<K,VV,EV> - Interface in io.kgraph.streaming
The super-class of all graph stream types.
KGraphWindowedStream<K,EV> - Class in io.kgraph.streaming
A stream of discrete graphs, each maintaining the graph state of the edges contained in the respective window.
KGraphWindowedStream.ApplyEdgesFoldFunction<K,EV,T> - Class in io.kgraph.streaming
 
KGraphWindowedStream.ApplyEdgesReduceFunction<K,EV> - Class in io.kgraph.streaming
 
KMeansClustering<EV,Message> - Class in io.kgraph.library.clustering
The k-means clustering algorithm partitions N data points (observations) into k clusters.
KMeansClustering() - Constructor for class io.kgraph.library.clustering.KMeansClustering
 
KMeansClustering.RandomCentersInitialization - Class in io.kgraph.library.clustering
 
KMeansVertexValue - Class in io.kgraph.library.clustering
The type of the vertex value in K-means It stores the coordinates of the point and the currently assigned cluster id
KMeansVertexValue(List<Double>, int) - Constructor for class io.kgraph.library.clustering.KMeansVertexValue
 
KMeansVertexValue() - Constructor for class io.kgraph.library.clustering.KMeansVertexValue
 
KryoDeserializer<T> - Class in io.kgraph.utils
 
KryoDeserializer() - Constructor for class io.kgraph.utils.KryoDeserializer
 
KryoSerde<T> - Class in io.kgraph.utils
 
KryoSerde() - Constructor for class io.kgraph.utils.KryoSerde
 
KryoSerializer<T> - Class in io.kgraph.utils
 
KryoSerializer() - Constructor for class io.kgraph.utils.KryoSerializer
 
KryoUtils - Class in io.kgraph.utils
 
KryoUtils() - Constructor for class io.kgraph.utils.KryoUtils
 

L

LabelPropagation<EV> - Class in io.kgraph.library
 
LabelPropagation() - Constructor for class io.kgraph.library.LabelPropagation
 
LAMBDA - Static variable in class io.kgraph.library.cf.Als
Keyword for parameter setting the regularization parameter LAMBDA.
LAMBDA - Static variable in class io.kgraph.library.cf.Sgd
Keyword for parameter setting the regularization parameter LAMBDA.
LAMBDA_DEFAULT - Static variable in class io.kgraph.library.cf.Als
Default value for LABDA.
LAMBDA_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default value for LABDA.
LANDMARK_VERTEX_IDS - Static variable in class io.kgraph.library.MultipleSourceShortestPaths
 
LAST_WRITTEN_OFFSETS - Static variable in class io.kgraph.pregel.PregelComputation
 
LCCMessage(long) - Constructor for class io.kgraph.library.LocalClusteringCoefficient.LCCMessage
 
LCCMessage(int) - Constructor for class io.kgraph.library.LocalClusteringCoefficient.LCCMessage
 
LCCMessage(long, long[]) - Constructor for class io.kgraph.library.LocalClusteringCoefficient.LCCMessage
 
LEADER - Static variable in class io.kgraph.pregel.ZKUtils
 
listFromStore(KafkaStreams, String) - Static method in class io.kgraph.utils.StreamUtils
 
listFromTable(KafkaStreams, KTable<K, V>) - Static method in class io.kgraph.utils.StreamUtils
 
ListOfDoubleListAggregator - Class in io.kgraph.library.clustering
 
ListOfDoubleListAggregator() - Constructor for class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
listTopics() - Method in class io.kgraph.pregel.PregelConsumer
 
listTopics(Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
LocalClusteringCoefficient - Class in io.kgraph.library
Adapted from the Graphalytics implementation.
LocalClusteringCoefficient() - Constructor for class io.kgraph.library.LocalClusteringCoefficient
 
LocalClusteringCoefficient.LCCMessage - Class in io.kgraph.library
 
LongIdDoubleValueFriendsList() - Constructor for class io.kgraph.library.similarity.AdamicAdar.LongIdDoubleValueFriendsList
 
LongIdDoubleValueFriendsList(Double, List<Long>) - Constructor for class io.kgraph.library.similarity.AdamicAdar.LongIdDoubleValueFriendsList
 
LongMaxAggregator - Class in io.kgraph.pregel.aggregators
 
LongMaxAggregator() - Constructor for class io.kgraph.pregel.aggregators.LongMaxAggregator
 
LongMinAggregator - Class in io.kgraph.pregel.aggregators
 
LongMinAggregator() - Constructor for class io.kgraph.pregel.aggregators.LongMinAggregator
 
LongParser() - Constructor for class io.kgraph.utils.Parsers.LongParser
 
LongProductAggregator - Class in io.kgraph.pregel.aggregators
 
LongProductAggregator() - Constructor for class io.kgraph.pregel.aggregators.LongProductAggregator
 
LongSumAggregator - Class in io.kgraph.pregel.aggregators
 
LongSumAggregator() - Constructor for class io.kgraph.pregel.aggregators.LongSumAggregator
 

M

mapEdges(ValueMapperWithKey<Edge<K>, EV, NV>, Serde<NV>) - Method in class io.kgraph.KGraph
 
mapEdges(KeyValueMapper<Edge<K>, EV, KeyValue<Edge<K>, NV>>, Serde<NV>) - Method in class io.kgraph.streaming.EdgeStream
Apply a function to the attribute of each edge in the graph stream.
mapEdges(KeyValueMapper<Edge<K>, EV, KeyValue<Edge<K>, NV>>, Serde<NV>) - Method in interface io.kgraph.streaming.KGraphStream
Apply a function to the attribute of each edge in the graph stream.
mapFromStore(KafkaStreams, String) - Static method in class io.kgraph.utils.StreamUtils
 
mapFromTable(KafkaStreams, KTable<K, V>) - Static method in class io.kgraph.utils.StreamUtils
 
MapOfLongMaxAggregator() - Constructor for class io.kgraph.pregel.PregelComputation.MapOfLongMaxAggregator
 
mapVertices(ValueMapperWithKey<K, VV, NV>, Serde<NV>) - Method in class io.kgraph.KGraph
 
MasterCallback(Map<String, Aggregator<?>>) - Constructor for class io.kgraph.pregel.ComputeFunction.MasterCallback
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in class io.kgraph.library.cf.Als
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in class io.kgraph.library.cf.Sgd
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in class io.kgraph.library.cf.Svdpp
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in class io.kgraph.library.clustering.KMeansClustering
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in class io.kgraph.library.PageRank
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in class io.kgraph.library.SybilRank
 
masterCompute(int, ComputeFunction.MasterCallback) - Method in interface io.kgraph.pregel.ComputeFunction
A function for performing sequential computations between supersteps.
matches() - Method in class io.kgraph.streaming.summaries.DisjointSet
 
MAX_CLUSTERS - Static variable in class io.kgraph.library.clustering.SemiClustering
Maximum number of semi-clusters.
MAX_CLUSTERS_DEFAULT - Static variable in class io.kgraph.library.clustering.SemiClustering
Default value for maximum number of semi-clusters.
MAX_ITERATIONS - Static variable in class io.kgraph.library.clustering.KMeansClustering
Maximum number of iterations
MAX_RATING - Static variable in class io.kgraph.library.cf.Sgd
Max rating.
MAX_RATING - Static variable in class io.kgraph.library.cf.Svdpp
Max rating.
MAX_RATING_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default maximum rating
MAX_RATING_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default maximum rating
MaxBMatching - Class in io.kgraph.library.maxbmatching
Greedy algorithm for the Maximum B-Matching problem as described in G.
MaxBMatching() - Constructor for class io.kgraph.library.maxbmatching.MaxBMatching
 
maxRating - Variable in class io.kgraph.library.cf.Sgd
 
maybeCreateReadyToReceiveNode(CuratorFramework, String, PregelState, TreeCache) - Static method in class io.kgraph.pregel.ZKUtils
 
maybeCreateReadyToSendNode(CuratorFramework, String, PregelState, TreeCache, int) - Static method in class io.kgraph.pregel.ZKUtils
 
MBMEdgeValue - Class in io.kgraph.library.maxbmatching
 
MBMEdgeValue() - Constructor for class io.kgraph.library.maxbmatching.MBMEdgeValue
 
MBMEdgeValue(double) - Constructor for class io.kgraph.library.maxbmatching.MBMEdgeValue
 
MBMEdgeValue(double, MBMEdgeValue.State) - Constructor for class io.kgraph.library.maxbmatching.MBMEdgeValue
 
MBMEdgeValue.State - Enum in io.kgraph.library.maxbmatching
 
MBMMessage - Class in io.kgraph.library.maxbmatching
 
MBMMessage() - Constructor for class io.kgraph.library.maxbmatching.MBMMessage
 
MBMMessage(Long, MBMEdgeValue.State) - Constructor for class io.kgraph.library.maxbmatching.MBMMessage
 
merge(AdjacencyListGraph<K>) - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
 
merge(Candidates) - Method in class io.kgraph.streaming.summaries.Candidates
 
merge(DisjointSet<R>) - Method in class io.kgraph.streaming.summaries.DisjointSet
Merge works in a similar fashion to a naive symmetric hash join.
MessageWrapper(K, Message) - Constructor for class io.kgraph.library.similarity.Jaccard.MessageWrapper
 
metrics() - Method in class io.kgraph.pregel.PregelConsumer
 
MIN_RATING - Static variable in class io.kgraph.library.cf.Sgd
Min rating.
MIN_RATING - Static variable in class io.kgraph.library.cf.Svdpp
Min rating.
MIN_RATING_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default minimum rating
MIN_RATING_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default minimum rating
minRating - Variable in class io.kgraph.library.cf.Sgd
 
MultipleSourceShortestPaths - Class in io.kgraph.library
 
MultipleSourceShortestPaths() - Constructor for class io.kgraph.library.MultipleSourceShortestPaths
 

N

NeighborsFunctionWithVertexValue<K,VV,EV,T> - Interface in io.kgraph
 
newVertexValue - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
next() - Method in class io.kgraph.pregel.PregelState
 
numberOfEdges() - Method in class io.kgraph.streaming.EdgeStream
 
numberOfEdges() - Method in interface io.kgraph.streaming.KGraphStream
 
numberOfVertices() - Method in class io.kgraph.streaming.EdgeStream
 
numberOfVertices() - Method in interface io.kgraph.streaming.KGraphStream
 
numPartitions - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 

O

offsetsForTimes(Map<TopicPartition, Long>) - Method in class io.kgraph.pregel.PregelConsumer
 
offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
outDegrees() - Method in class io.kgraph.KGraph
 
outDegrees() - Method in class io.kgraph.streaming.EdgeStream
Get the out-degree stream
outDegrees() - Method in interface io.kgraph.streaming.KGraphStream
Get the out-degree stream
outgoingMessages - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
OVERALL_RATING_AGGREGATOR - Static variable in class io.kgraph.library.cf.Svdpp
Name of aggregator that aggregates all ratings.

P

PageRank<K> - Class in io.kgraph.library
 
PageRank() - Constructor for class io.kgraph.library.PageRank
 
parse(String) - Method in interface io.kgraph.utils.Parser
 
parse(String) - Method in class io.kgraph.utils.Parsers.DoubleParser
 
parse(String) - Method in class io.kgraph.utils.Parsers.EdgeParser
 
parse(String) - Method in class io.kgraph.utils.Parsers.FloatParser
 
parse(String) - Method in class io.kgraph.utils.Parsers.IntegerParser
 
parse(String) - Method in class io.kgraph.utils.Parsers.LongParser
 
parse(String) - Method in class io.kgraph.utils.Parsers.StringParser
 
parse(String) - Method in class io.kgraph.utils.Parsers.VertexParser
 
Parser<T> - Interface in io.kgraph.utils
 
Parsers<T> - Class in io.kgraph.utils
 
Parsers() - Constructor for class io.kgraph.utils.Parsers
 
Parsers.DoubleParser - Class in io.kgraph.utils
 
Parsers.EdgeParser<K,V> - Class in io.kgraph.utils
 
Parsers.FloatParser - Class in io.kgraph.utils
 
Parsers.IntegerParser - Class in io.kgraph.utils
 
Parsers.LongParser - Class in io.kgraph.utils
 
Parsers.StringParser - Class in io.kgraph.utils
 
Parsers.VertexParser<K,V> - Class in io.kgraph.utils
 
partitionsFor(String) - Method in class io.kgraph.pregel.PregelConsumer
 
partitionsFor(String, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
pause(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
paused() - Method in class io.kgraph.pregel.PregelConsumer
 
POINTS_COUNT - Static variable in class io.kgraph.library.clustering.KMeansClustering
Total number of input points
POINTS_COUNT - Static variable in class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
poll(long) - Method in class io.kgraph.pregel.PregelConsumer
 
poll(Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
position(TopicPartition) - Method in class io.kgraph.pregel.PregelConsumer
 
position(TopicPartition, Duration) - Method in class io.kgraph.pregel.PregelConsumer
 
postSuperstep(int, ComputeFunction.Aggregators) - Method in interface io.kgraph.pregel.ComputeFunction
Finish computation.
PREGEL_PATH - Static variable in class io.kgraph.pregel.ZKUtils
 
PregelClientSupplier - Class in io.kgraph.pregel
 
PregelClientSupplier() - Constructor for class io.kgraph.pregel.PregelClientSupplier
 
PregelComputation<K,VV,EV,Message> - Class in io.kgraph.pregel
 
PregelComputation(String, String, String, CuratorFramework, String, String, Map<TopicPartition, Long>, GraphSerialized<K, VV, EV>, String, String, String, int, Map<String, ?>, Optional<Message>, ComputeFunction<K, VV, EV, Message>) - Constructor for class io.kgraph.pregel.PregelComputation
 
PregelComputation.AggregatorWrapper<T> - Class in io.kgraph.pregel
 
PregelComputation.MapOfLongMaxAggregator - Class in io.kgraph.pregel
 
PregelConsumer - Class in io.kgraph.pregel
 
PregelConsumer(Consumer<byte[], byte[]>) - Constructor for class io.kgraph.pregel.PregelConsumer
 
PregelGraphAlgorithm<K,VV,EV,Message> - Class in io.kgraph.pregel
 
PregelGraphAlgorithm(String, String, String, CuratorFramework, String, String, Map<TopicPartition, Long>, GraphSerialized<K, VV, EV>, int, short, Map<String, ?>, Optional<Message>, ComputeFunction<K, VV, EV, Message>) - Constructor for class io.kgraph.pregel.PregelGraphAlgorithm
 
PregelGraphAlgorithm(String, String, String, String, String, String, Map<TopicPartition, Long>, GraphSerialized<K, VV, EV>, String, String, String, int, short, Map<String, ?>, Optional<Message>, ComputeFunction<K, VV, EV, Message>) - Constructor for class io.kgraph.pregel.PregelGraphAlgorithm
 
PregelGraphAlgorithm(String, String, String, CuratorFramework, String, String, Map<TopicPartition, Long>, GraphSerialized<K, VV, EV>, String, String, String, int, short, Map<String, ?>, Optional<Message>, ComputeFunction<K, VV, EV, Message>) - Constructor for class io.kgraph.pregel.PregelGraphAlgorithm
 
PregelState - Class in io.kgraph.pregel
 
PregelState(GraphAlgorithmState.State, int, PregelState.Stage) - Constructor for class io.kgraph.pregel.PregelState
 
PregelState(GraphAlgorithmState.State, int, PregelState.Stage, long, long) - Constructor for class io.kgraph.pregel.PregelState
 
PregelState.Stage - Enum in io.kgraph.pregel
 
PregelStateDeserializer - Class in io.kgraph.pregel
 
PregelStateDeserializer() - Constructor for class io.kgraph.pregel.PregelStateDeserializer
 
PregelStateSerializer - Class in io.kgraph.pregel
 
PregelStateSerializer() - Constructor for class io.kgraph.pregel.PregelStateSerializer
 
prepare(StreamsBuilder, Properties) - Method in class io.kgraph.pregel.PregelComputation
 
preSuperstep(int, ComputeFunction.Aggregators) - Method in class io.kgraph.library.cf.Als
 
preSuperstep(int, ComputeFunction.Aggregators) - Method in class io.kgraph.library.cf.Sgd
 
preSuperstep(int, ComputeFunction.Aggregators) - Method in class io.kgraph.library.cf.Svdpp.ItemComputation
 
preSuperstep(int, ComputeFunction.Aggregators) - Method in class io.kgraph.library.cf.Svdpp
 
preSuperstep(int, ComputeFunction.Aggregators) - Method in class io.kgraph.library.cf.Svdpp.UserComputation
 
preSuperstep(int, ComputeFunction.Aggregators) - Method in interface io.kgraph.pregel.ComputeFunction
Prepare for computation.
previousAggregates - Variable in class io.kgraph.pregel.ComputeFunction.Aggregators
 
previousAggregates - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
previousAggregates(int) - Method in class io.kgraph.pregel.PregelComputation
 
previousAggregators - Variable in class io.kgraph.pregel.ComputeFunction.MasterCallback
 
PRINT_FINAL_CENTERS - Static variable in class io.kgraph.library.clustering.KMeansClustering
Parameter that enables printing the final centers coordinates
PRINT_FINAL_CENTERS_DEFAULT - Static variable in class io.kgraph.library.clustering.KMeansClustering
False by default
producerConfig(String, Class, Class, Properties) - Static method in class io.kgraph.utils.ClientUtils
 
ProjectCanonicalEdges() - Constructor for class io.kgraph.streaming.library.ExactTriangleCount.ProjectCanonicalEdges
 

R

RANDOM_SEED - Static variable in class io.kgraph.library.cf.Als
Random seed.
RANDOM_SEED - Static variable in class io.kgraph.library.cf.Sgd
Random seed.
RANDOM_SEED - Static variable in class io.kgraph.library.cf.Svdpp
Random seed.
RANDOM_SEED_DEFAULT - Static variable in class io.kgraph.library.cf.Als
Default random seed
RANDOM_SEED_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default random seed
RANDOM_SEED_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default random seed
RandomCentersInitialization() - Constructor for class io.kgraph.library.clustering.KMeansClustering.RandomCentersInitialization
 
READY - Static variable in class io.kgraph.pregel.ZKUtils
 
reduceEdges(EV, EV) - Method in interface io.kgraph.streaming.EdgeReduceFunction
Combines two edge values into one value of the same type.
reduceOnEdges(Reducer<EV>, EdgeDirection) - Method in class io.kgraph.KGraph
 
reduceOnEdges(EdgeReduceFunction<EV>) - Method in class io.kgraph.streaming.KGraphWindowedStream
Performs an aggregation on the neighboring edges of each vertex on the graph window stream.
reduceOnNeighbors(Reducer<VV>, EdgeDirection) - Method in class io.kgraph.KGraph
 
registerAggregator(String, Class<? extends Aggregator<T>>) - Method in class io.kgraph.pregel.ComputeFunction.InitCallback
 
registerAggregator(String, Class<? extends Aggregator<T>>, boolean) - Method in class io.kgraph.pregel.ComputeFunction.InitCallback
 
removeChild(CuratorFramework, String, PregelState, String) - Static method in class io.kgraph.pregel.ZKUtils
 
removeChild(CuratorFramework, String, String) - Static method in class io.kgraph.pregel.ZKUtils
 
removeEdge(K) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
removeRoot(CuratorFramework, String) - Static method in class io.kgraph.pregel.ZKUtils
 
replicationFactor - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
reset() - Method in class io.kgraph.library.clustering.DoubleListAggregator
 
reset() - Method in class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
reset() - Method in interface io.kgraph.pregel.aggregators.Aggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.BooleanAndAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.BooleanOrAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.DoubleMaxAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.DoubleMinAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.DoubleProductAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.DoubleSumAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.LongMaxAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.LongMinAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.LongProductAggregator
 
reset() - Method in class io.kgraph.pregel.aggregators.LongSumAggregator
 
reset() - Method in class io.kgraph.pregel.PregelComputation.MapOfLongMaxAggregator
 
RESET_PROBABILITY - Static variable in class io.kgraph.library.PageRank
 
result() - Method in interface io.kgraph.GraphAlgorithm
 
result() - Method in class io.kgraph.GraphAlgorithmState
 
result() - Method in class io.kgraph.pregel.PregelComputation
 
result() - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
resume(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
reverse() - Method in class io.kgraph.Edge
 
reverse() - Method in class io.kgraph.EdgeWithValue
 
reverse() - Method in class io.kgraph.streaming.EdgeStream
 
reverse() - Method in interface io.kgraph.streaming.KGraphStream
 
reverse() - Method in class io.kgraph.streaming.utils.SignedVertex
 
ReverseEdges<K,VV,EV> - Class in io.kgraph.library.basic
 
ReverseEdges() - Constructor for class io.kgraph.library.basic.ReverseEdges
 
RMSE_AGGREGATOR - Static variable in class io.kgraph.library.cf.Als
Aggregator used to compute the RMSE
RMSE_AGGREGATOR - Static variable in class io.kgraph.library.cf.Sgd
Aggregator used to compute the RMSE
RMSE_AGGREGATOR - Static variable in class io.kgraph.library.cf.Svdpp
Aggregator for the computation of RMSE
RMSE_TARGET - Static variable in class io.kgraph.library.cf.Als
RMSE target to reach.
RMSE_TARGET - Static variable in class io.kgraph.library.cf.Sgd
Keyword for RMSE aggregator tolerance.
RMSE_TARGET - Static variable in class io.kgraph.library.cf.Svdpp
RMSE target
RMSE_TARGET_DEFAULT - Static variable in class io.kgraph.library.cf.Als
Default value of RMSE target.
RMSE_TARGET_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default value for parameter enabling the RMSE aggregator.
RMSE_TARGET_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default value for parameter enabling the RMSE aggregator.
run() - Method in interface io.kgraph.GraphAlgorithm
 
run(int) - Method in interface io.kgraph.GraphAlgorithm
 
run(int, CompletableFuture<KTable<K, VV>>) - Method in class io.kgraph.pregel.PregelComputation
 
run(int) - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
run(KStream<Edge<K>, EV>) - Method in class io.kgraph.streaming.SummaryAggregation
 
run(KStream<Edge<K>, EV>) - Method in class io.kgraph.streaming.SummaryBulkAggregation
 
RUNNING_SUM - Static variable in class io.kgraph.library.PageRank
 
runningTime() - Method in class io.kgraph.GraphAlgorithmState
 
runningTime() - Method in class io.kgraph.pregel.PregelState
 

S

ScaleToDistance() - Constructor for class io.kgraph.library.similarity.AdamicAdar.ScaleToDistance
 
ScaleToDistance() - Constructor for class io.kgraph.library.similarity.Jaccard.ScaleToDistance
 
SCORE_FACTOR - Static variable in class io.kgraph.library.clustering.SemiClustering
Boundary edge score factor.
SCORE_FACTOR_DEFAULT - Static variable in class io.kgraph.library.clustering.SemiClustering
Default value for Boundary Edge Score Factor.
seek(TopicPartition, long) - Method in class io.kgraph.pregel.PregelConsumer
 
seek(TopicPartition, OffsetAndMetadata) - Method in class io.kgraph.pregel.PregelConsumer
 
seekToBeginning(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
seekToEnd(Collection<TopicPartition>) - Method in class io.kgraph.pregel.PregelConsumer
 
SemiCluster() - Constructor for class io.kgraph.library.clustering.SemiClustering.SemiCluster
Constructor: Create a new empty Cluster.
SemiCluster(SemiClustering.SemiCluster) - Constructor for class io.kgraph.library.clustering.SemiClustering.SemiCluster
Constructor: Initialize a new Cluster.
SemiClustering - Class in io.kgraph.library.clustering
Implements the Semi-Clustering algorithm as presented in the Pregel paper from SIGMOD'10.
SemiClustering() - Constructor for class io.kgraph.library.clustering.SemiClustering
 
SemiClustering.SemiCluster - Class in io.kgraph.library.clustering
This class represents a semi-cluster.
SendFriends() - Constructor for class io.kgraph.library.similarity.Jaccard.SendFriends
 
SendFriendsListAndValue() - Constructor for class io.kgraph.library.similarity.AdamicAdar.SendFriendsListAndValue
 
sendMessageTo(K, Message) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
serialize(String, CfLongId) - Method in class io.kgraph.library.cf.CfLongIdSerializer
 
serialize(String, PregelState) - Method in class io.kgraph.pregel.PregelStateSerializer
 
serialize(String, T) - Method in class io.kgraph.utils.KryoSerializer
 
serialize(Object) - Static method in class io.kgraph.utils.KryoUtils
 
serialize(String, TopicPartition) - Method in class io.kgraph.utils.TopicPartitionSerializer
 
serialized() - Method in class io.kgraph.KGraph
 
serialized - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
serialized() - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
serializer() - Method in class io.kgraph.library.cf.CfLongIdSerde
 
serializer() - Method in class io.kgraph.utils.KryoSerde
 
setAggregate(List<Double>) - Method in class io.kgraph.library.clustering.DoubleListAggregator
 
setAggregate(List<List<Double>>) - Method in class io.kgraph.library.clustering.ListOfDoubleListAggregator
 
setAggregate(T) - Method in interface io.kgraph.pregel.aggregators.Aggregator
 
setAggregate(Boolean) - Method in class io.kgraph.pregel.aggregators.BooleanAndAggregator
 
setAggregate(Boolean) - Method in class io.kgraph.pregel.aggregators.BooleanOrAggregator
 
setAggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleMaxAggregator
 
setAggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleMinAggregator
 
setAggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleProductAggregator
 
setAggregate(Double) - Method in class io.kgraph.pregel.aggregators.DoubleSumAggregator
 
setAggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongMaxAggregator
 
setAggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongMinAggregator
 
setAggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongProductAggregator
 
setAggregate(Long) - Method in class io.kgraph.pregel.aggregators.LongSumAggregator
 
setAggregate(Map<Integer, Long>) - Method in class io.kgraph.pregel.PregelComputation.MapOfLongMaxAggregator
 
setAggregatedValue(String, T) - Method in class io.kgraph.pregel.ComputeFunction.MasterCallback
 
setNewEdgeValue(K, EV) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
setNewVertexValue(VV) - Method in class io.kgraph.pregel.ComputeFunction.Callback
 
setRank(double) - Method in class io.kgraph.library.SybilRank.VertexValue
 
Sgd - Class in io.kgraph.library.cf
Stochastic Gradient Descent (SGD) implementation.
Sgd() - Constructor for class io.kgraph.library.cf.Sgd
 
Sgd.InitItemsComputation - Class in io.kgraph.library.cf
This computation class is used to initialize the factors of the item nodes in the second superstep.
Sgd.InitUsersComputation - Class in io.kgraph.library.cf
This computation class is used to initialize the factors of the user nodes in the very first superstep, and send the first updates to the item nodes.
sign() - Method in class io.kgraph.streaming.utils.SignedVertex
 
SignedVertex - Class in io.kgraph.streaming.utils
 
SignedVertex(long, boolean) - Constructor for class io.kgraph.streaming.utils.SignedVertex
 
SingleSourceShortestPaths - Class in io.kgraph.library
 
SingleSourceShortestPaths() - Constructor for class io.kgraph.library.SingleSourceShortestPaths
 
size() - Method in class io.kgraph.library.clustering.SemiClustering.SemiCluster
Returns size of semi cluster list.
size() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
 
size() - Method in class io.kgraph.streaming.summaries.DisjointSet
 
slice(Windows<? extends Window>) - Method in class io.kgraph.streaming.EdgeStream
Discretizes the edge stream into tumbling windows of the specified size.
slice(Windows<? extends Window>, EdgeDirection) - Method in class io.kgraph.streaming.EdgeStream
Discretizes the edge stream into tumbling windows of the specified size.
slice(Windows<? extends Window>) - Method in interface io.kgraph.streaming.KGraphStream
Discretizes the edge stream into tumbling windows of the specified size.
slice(Windows<? extends Window>, EdgeDirection) - Method in interface io.kgraph.streaming.KGraphStream
Discretizes the edge stream into tumbling windows of the specified size.
solutionSetStore - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
solutionSetTopic - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
source() - Method in class io.kgraph.Edge
 
source() - Method in class io.kgraph.EdgeWithValue
 
Spanner<K extends Comparable<K>,EV> - Class in io.kgraph.streaming.library
The Spanner library method continuously computes a k-Spanner of an insertion-only edge stream.
Spanner(long, int) - Constructor for class io.kgraph.streaming.library.Spanner
Creates a Spanner instance.
Spanner.CombineSpanners<K extends Comparable<K>> - Class in io.kgraph.streaming.library
Merge the local spanners of each partition into the global spanner.
Spanner.UpdateLocal<K extends Comparable<K>,EV> - Class in io.kgraph.streaming.library
Decide to add or remove an edge to the local spanner in the current window.
SRC_VERTEX_ID - Static variable in class io.kgraph.library.BreadthFirstSearch
 
SRC_VERTEX_ID - Static variable in class io.kgraph.library.PageRank
 
SRC_VERTEX_ID - Static variable in class io.kgraph.library.SingleSourceShortestPaths
 
stage() - Method in class io.kgraph.pregel.PregelState
 
starGraph(StreamsBuilder, Properties, int) - Static method in class io.kgraph.utils.GraphGenerators
 
startTime() - Method in class io.kgraph.pregel.PregelState
 
state() - Method in interface io.kgraph.GraphAlgorithm
 
state() - Method in class io.kgraph.GraphAlgorithmState
 
state() - Method in class io.kgraph.pregel.PregelComputation
 
state() - Method in class io.kgraph.pregel.PregelGraphAlgorithm
 
state(GraphAlgorithmState.State) - Method in class io.kgraph.pregel.PregelState
 
state() - Method in class io.kgraph.pregel.PregelState
 
streamFromCollection(StreamsBuilder, Properties, Serde<K>, Serde<V>, Collection<KeyValue<K, V>>) - Static method in class io.kgraph.utils.StreamUtils
 
streamFromCollection(StreamsBuilder, Properties, String, int, short, Serde<K>, Serde<V>, Collection<KeyValue<K, V>>) - Static method in class io.kgraph.utils.StreamUtils
 
streams() - Method in class io.kgraph.GraphAlgorithmState
 
streams - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
streamsConfig(String, String, String, Class, Class) - Static method in class io.kgraph.utils.ClientUtils
 
streamsConfig(String, String, String, Class, Class, Properties) - Static method in class io.kgraph.utils.ClientUtils
 
StreamUtils - Class in io.kgraph.utils
 
StreamUtils() - Constructor for class io.kgraph.utils.StreamUtils
 
StringParser() - Constructor for class io.kgraph.utils.Parsers.StringParser
 
subgraph(Predicate<K, VV>, Predicate<Edge<K>, EV>) - Method in class io.kgraph.KGraph
 
subscribe(Collection<String>) - Method in class io.kgraph.pregel.PregelConsumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class io.kgraph.pregel.PregelConsumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in class io.kgraph.pregel.PregelConsumer
 
subscribe(Pattern) - Method in class io.kgraph.pregel.PregelConsumer
 
subscription() - Method in class io.kgraph.pregel.PregelConsumer
 
success() - Method in class io.kgraph.streaming.summaries.Candidates
 
SumAndEmitCounters() - Constructor for class io.kgraph.streaming.library.ExactTriangleCount.SumAndEmitCounters
 
SummaryAggregation<K,EV,S,T> - Class in io.kgraph.streaming
 
SummaryAggregation(EdgeFoldFunction<K, EV, S>, Reducer<S>, ValueMapper<S, T>, S, boolean) - Constructor for class io.kgraph.streaming.SummaryAggregation
 
SummaryBulkAggregation<K,EV,S,T> - Class in io.kgraph.streaming
Graph Aggregation on Parallel Time Window
SummaryBulkAggregation(EdgeFoldFunction<K, EV, S>, Reducer<S>, ValueMapper<S, T>, S, long, boolean) - Constructor for class io.kgraph.streaming.SummaryBulkAggregation
 
SummaryBulkAggregation(EdgeFoldFunction<K, EV, S>, Reducer<S>, S, long, boolean) - Constructor for class io.kgraph.streaming.SummaryBulkAggregation
 
superstep() - Method in class io.kgraph.GraphAlgorithmState
 
superstep() - Method in class io.kgraph.pregel.PregelState
 
SUPERSTEP - Static variable in class io.kgraph.pregel.ZKUtils
 
superstepCompute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Als
Main ALS compute method.
superstepCompute(int, VertexWithValue<CfLongId, FloatMatrix>, Iterable<FloatMatrixMessage>, Iterable<EdgeWithValue<CfLongId, Float>>, ComputeFunction.Callback<CfLongId, FloatMatrix, Float, FloatMatrixMessage>) - Method in class io.kgraph.library.cf.Sgd
Main SGD compute method.
superstepCompute(int, VertexWithValue<Long, KMeansVertexValue>, Iterable<Message>, Iterable<EdgeWithValue<Long, EV>>, ComputeFunction.Callback<Long, KMeansVertexValue, EV, Message>) - Method in class io.kgraph.library.clustering.KMeansClustering
Main K-means clustering compute method.
superstepCompute(int, VertexWithValue<Long, Double>, Iterable<AdamicAdar.LongIdDoubleValueFriendsList>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, Double, Double, AdamicAdar.LongIdDoubleValueFriendsList>) - Method in class io.kgraph.library.similarity.AdamicAdar
Implements the computation of the exact AdamicAdar vertex similarity.
superstepCompute(int, VertexWithValue<Long, VV>, Iterable<Jaccard.MessageWrapper<Long, List<Long>>>, Iterable<EdgeWithValue<Long, Double>>, ComputeFunction.Callback<Long, VV, Double, Jaccard.MessageWrapper<Long, List<Long>>>) - Method in class io.kgraph.library.similarity.Jaccard
Implements the computation of the exact Jaccard vertex similarity.
Svdpp - Class in io.kgraph.library.cf
 
Svdpp() - Constructor for class io.kgraph.library.cf.Svdpp
 
Svdpp.InitItemsComputation - Class in io.kgraph.library.cf
 
Svdpp.InitUsersComputation - Class in io.kgraph.library.cf
This computation class is used to initialize the factors of the user nodes in the very first superstep, and send the first updates to the item nodes.
Svdpp.ItemComputation - Class in io.kgraph.library.cf
 
Svdpp.SvdppValue - Class in io.kgraph.library.cf
A value in the Svdpp algorithm consists of (i) the baseline estimate, (ii) the latent vector, and (iii) the weight vector.
Svdpp.UserComputation - Class in io.kgraph.library.cf
 
SvdppValue(float, FloatMatrix, FloatMatrix) - Constructor for class io.kgraph.library.cf.Svdpp.SvdppValue
 
SybilRank - Class in io.kgraph.library
This is an implementation of the SybilRank algorithm.
SybilRank() - Constructor for class io.kgraph.library.SybilRank
 
SybilRank.Initializer - Class in io.kgraph.library
This class is used only to initialize the rank of the vertices.
SybilRank.SybilRankComputation - Class in io.kgraph.library
This class implements the main part of the SybilRank algorithms, that is, the power iterations.
SybilRank.TrustAggregation - Class in io.kgraph.library
This computation class is used to calculate the aggregate number of trusted nodes.
SybilRank.VertexValue - Class in io.kgraph.library
Represents the state of a vertex for this algorithm.
SybilRankComputation() - Constructor for class io.kgraph.library.SybilRank.SybilRankComputation
 

T

tableFromCollection(StreamsBuilder, Properties, Serde<K>, Serde<V>, Collection<KeyValue<K, V>>) - Static method in class io.kgraph.utils.StreamUtils
 
tableFromCollection(StreamsBuilder, Properties, String, int, short, Serde<K>, Serde<V>, Collection<KeyValue<K, V>>) - Static method in class io.kgraph.utils.StreamUtils
 
target() - Method in class io.kgraph.Edge
 
target() - Method in class io.kgraph.EdgeWithValue
 
tempDirectory(String) - Static method in class io.kgraph.utils.ClientUtils
Create a temporary relative directory in the default temporary-file directory with the given prefix.
tempDirectory() - Static method in class io.kgraph.utils.ClientUtils
Create a temporary relative directory in the default temporary-file directory with a prefix of "kafka-"
tempDirectory(Path, String) - Static method in class io.kgraph.utils.ClientUtils
Create a temporary relative directory in the specified parent directory with the given prefix.
TEST_INITIAL_CENTERS - Static variable in class io.kgraph.library.clustering.KMeansClustering
False by default
toBytes() - Method in class io.kgraph.pregel.PregelState
 
TOLERANCE - Static variable in class io.kgraph.library.cf.Sgd
Keyword for parameter setting the convergence tolerance
TOLERANCE - Static variable in class io.kgraph.library.PageRank
 
TOLERANCE_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default value for TOLERANCE.
TopicPartitionDeserializer - Class in io.kgraph.utils
 
TopicPartitionDeserializer() - Constructor for class io.kgraph.utils.TopicPartitionDeserializer
 
TopicPartitionSerializer - Class in io.kgraph.utils
 
TopicPartitionSerializer() - Constructor for class io.kgraph.utils.TopicPartitionSerializer
 
toString() - Method in class io.kgraph.Edge
 
toString() - Method in class io.kgraph.EdgeWithValue
 
toString() - Method in class io.kgraph.library.cf.CfLongId
 
toString() - Method in class io.kgraph.library.cf.FloatMatrixMessage
 
toString() - Method in class io.kgraph.library.cf.Svdpp.SvdppValue
 
toString() - Method in class io.kgraph.library.clustering.KMeansVertexValue
 
toString() - Method in class io.kgraph.library.clustering.SemiClustering.SemiCluster
 
toString() - Method in class io.kgraph.library.maxbmatching.MBMEdgeValue
 
toString() - Method in class io.kgraph.library.maxbmatching.MBMMessage
 
toString() - Method in class io.kgraph.library.similarity.Jaccard.MessageWrapper
 
toString() - Method in class io.kgraph.library.SybilRank.VertexValue
 
toString() - Method in class io.kgraph.pregel.PregelState
 
toString() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph.Node
 
toString() - Method in class io.kgraph.streaming.summaries.AdjacencyListGraph
 
toString() - Method in class io.kgraph.streaming.summaries.Candidates
 
toString() - Method in class io.kgraph.streaming.summaries.DisjointSet
 
toString() - Method in class io.kgraph.streaming.utils.SignedVertex
 
toString() - Method in class io.kgraph.VertexWithValue
 
TOTAL_TRUST - Static variable in class io.kgraph.library.SybilRank
Property name for the total trust.
transform() - Method in class io.kgraph.streaming.SummaryAggregation
 
TrustAggregation() - Constructor for class io.kgraph.library.SybilRank.TrustAggregation
 

U

undirected() - Method in class io.kgraph.KGraph
 
undirected() - Method in class io.kgraph.streaming.EdgeStream
 
undirected() - Method in interface io.kgraph.streaming.KGraphStream
 
UndirectEdges() - Constructor for class io.kgraph.KGraph.UndirectEdges
 
union(KGraphStream<K, Void, EV>) - Method in class io.kgraph.streaming.EdgeStream
 
union(KGraphStream<K, VV, EV>) - Method in interface io.kgraph.streaming.KGraphStream
 
union(R, R) - Method in class io.kgraph.streaming.summaries.DisjointSet
Union combines the two possibly disjoint sets where e1 and e2 belong in.
unsubscribe() - Method in class io.kgraph.pregel.PregelConsumer
 
UNVISITED - Static variable in class io.kgraph.library.BreadthFirstSearch
 
UpdateCC() - Constructor for class io.kgraph.streaming.library.ConnectedComponents.UpdateCC
 
updateChild(CuratorFramework, String, String, byte[]) - Static method in class io.kgraph.pregel.ZKUtils
 
updateFun() - Method in class io.kgraph.streaming.SummaryAggregation
 
UpdateFunction() - Constructor for class io.kgraph.streaming.library.BipartitenessCheck.UpdateFunction
 
UpdateLocal() - Constructor for class io.kgraph.streaming.library.Spanner.UpdateLocal
 
updateValue(FloatMatrix, FloatMatrix, FloatMatrix, float) - Method in class io.kgraph.library.cf.Als
 
updateValue(FloatMatrix, FloatMatrix, float, float, float, float, float) - Method in class io.kgraph.library.cf.Sgd
Applies the SGD update logic in the provided vector.
updateValue(FloatMatrix, FloatMatrix, float, float, float) - Method in class io.kgraph.library.cf.Svdpp.UserComputation
 
UserComputation() - Constructor for class io.kgraph.library.cf.Svdpp.UserComputation
 

V

value() - Method in class io.kgraph.EdgeWithValue
 
value() - Method in enum io.kgraph.library.maxbmatching.MBMEdgeValue.State
 
value() - Method in class io.kgraph.VertexWithValue
 
valueOf(String) - Static method in enum io.kgraph.EdgeDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.kgraph.GraphAlgorithmState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.kgraph.library.GraphAlgorithmType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.kgraph.library.maxbmatching.MBMEdgeValue.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.kgraph.pregel.PregelState.Stage
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.kgraph.EdgeDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.kgraph.GraphAlgorithmState.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.kgraph.library.GraphAlgorithmType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.kgraph.library.maxbmatching.MBMEdgeValue.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.kgraph.pregel.PregelState.Stage
Returns an array containing the constants of this enum type, in the order they are declared.
VECTOR_SIZE - Static variable in class io.kgraph.library.cf.Als
Keyword for parameter setting the Latent Vector Size.
VECTOR_SIZE - Static variable in class io.kgraph.library.cf.Sgd
Keyword for parameter setting the Latent Vector Size.
VECTOR_SIZE - Static variable in class io.kgraph.library.cf.Svdpp
Latent vector size.
VECTOR_SIZE_DEFAULT - Static variable in class io.kgraph.library.cf.Als
Default value for vector size.
VECTOR_SIZE_DEFAULT - Static variable in class io.kgraph.library.cf.Sgd
Default value for GAMMA.
VECTOR_SIZE_DEFAULT - Static variable in class io.kgraph.library.cf.Svdpp
Default latent vector size
vertex() - Method in class io.kgraph.streaming.utils.SignedVertex
 
VERTEX_COUNT_AGGREGATOR - Static variable in class io.kgraph.library.basic.VertexCount
 
VertexCount<K,VV,EV,Message> - Class in io.kgraph.library.basic
 
VertexCount() - Constructor for class io.kgraph.library.basic.VertexCount
 
VertexJoinFunction<VV,T> - Interface in io.kgraph
 
VertexParser(Parser<K>, Parser<V>) - Constructor for class io.kgraph.utils.Parsers.VertexParser
 
VertexValue(double, boolean) - Constructor for class io.kgraph.library.SybilRank.VertexValue
 
vertexValueSerde() - Method in class io.kgraph.GraphSerialized
 
vertexValueSerde() - Method in class io.kgraph.KGraph
 
VertexWithValue<K,V> - Class in io.kgraph
 
VertexWithValue(K, V) - Constructor for class io.kgraph.VertexWithValue
 
vertices() - Method in class io.kgraph.KGraph
 
vertices() - Method in class io.kgraph.pregel.PregelComputation
 
vertices() - Method in class io.kgraph.streaming.EdgeStream
 
vertices() - Method in interface io.kgraph.streaming.KGraphStream
 
verticesToFile(KTable<Long, V>, String) - Static method in class io.kgraph.utils.GraphUtils
 
verticesTopic - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
verticesToTopic(InputStream, Parser<K>, Parser<V>, Serializer<K>, Serializer<V>, Properties, String, int, short) - Static method in class io.kgraph.utils.GraphUtils
 
verticesToTopic(InputStream, Parser<VertexWithValue<K, V>>, Serializer<K>, Serializer<V>, Properties, String, int, short) - Static method in class io.kgraph.utils.GraphUtils
 
voteToHalt - Variable in class io.kgraph.pregel.ComputeFunction.Callback
 
voteToHalt() - Method in class io.kgraph.pregel.ComputeFunction.Callback
 

W

wakeup() - Method in class io.kgraph.pregel.PregelConsumer
 
with(Serde<K>, Serde<VV>, Serde<EV>) - Static method in class io.kgraph.GraphSerialized
 
workSetTopic - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 

Z

ZKUtils - Class in io.kgraph.pregel
 
ZKUtils() - Constructor for class io.kgraph.pregel.ZKUtils
 
zookeeperConnect - Variable in class io.kgraph.pregel.PregelGraphAlgorithm
 
A B C D E F G H I J K L M N O P R S T U V W Z 
Skip navigation links

Copyright © 2020. All rights reserved.