- 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
-
- 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
-
- 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
-
- 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
-