Package | Description |
---|---|
io.kgraph | |
io.kgraph.library | |
io.kgraph.pregel | |
io.kgraph.streaming | |
io.kgraph.utils |
Modifier and Type | Method and Description |
---|---|
GraphSerialized<K,VV,EV> |
KGraph.serialized() |
static <K,VV,EV> GraphSerialized<K,VV,EV> |
GraphSerialized.with(org.apache.kafka.common.serialization.Serde<K> keySerde,
org.apache.kafka.common.serialization.Serde<VV> vertexValueSerde,
org.apache.kafka.common.serialization.Serde<EV> edgeValueSerde) |
Modifier and Type | Method and Description |
---|---|
static <K,VV,EV> KGraph<K,VV,EV> |
KGraph.fromEdges(org.apache.kafka.streams.kstream.KTable<Edge<K>,EV> edges,
org.apache.kafka.streams.kstream.ValueMapper<K,VV> vertexValueInitializer,
GraphSerialized<K,VV,EV> serialized) |
Constructor and Description |
---|
GraphSerialized(GraphSerialized<K,VV,EV> serialized) |
KGraph(org.apache.kafka.streams.kstream.KTable<K,VV> vertices,
org.apache.kafka.streams.kstream.KTable<Edge<K>,EV> edges,
GraphSerialized<K,VV,EV> serialized) |
Modifier and Type | Method and Description |
---|---|
static GraphSerialized |
GraphAlgorithmType.graphSerialized(GraphAlgorithmType type,
boolean useDouble) |
Modifier and Type | Field and Description |
---|---|
protected GraphSerialized<K,VV,EV> |
PregelGraphAlgorithm.serialized |
Modifier and Type | Method and Description |
---|---|
GraphSerialized<K,VV,EV> |
PregelGraphAlgorithm.serialized() |
Constructor and Description |
---|
PregelComputation(String hostAndPort,
String applicationId,
String bootstrapServers,
org.apache.curator.framework.CuratorFramework curator,
String verticesTopic,
String edgesGroupedBySourceTopic,
Map<org.apache.kafka.common.TopicPartition,Long> graphOffsets,
GraphSerialized<K,VV,EV> serialized,
String solutionSetTopic,
String solutionSetStore,
String workSetTopic,
int numPartitions,
Map<String,?> configs,
Optional<Message> initialMessage,
ComputeFunction<K,VV,EV,Message> cf) |
PregelGraphAlgorithm(String hostAndPort,
String applicationId,
String bootstrapServers,
org.apache.curator.framework.CuratorFramework curator,
String verticesTopic,
String edgesGroupedBySourceTopic,
Map<org.apache.kafka.common.TopicPartition,Long> graphOffsets,
GraphSerialized<K,VV,EV> serialized,
int numPartitions,
short replicationFactor,
Map<String,?> configs,
Optional<Message> initialMessage,
ComputeFunction<K,VV,EV,Message> cf) |
PregelGraphAlgorithm(String hostAndPort,
String applicationId,
String bootstrapServers,
org.apache.curator.framework.CuratorFramework curator,
String verticesTopic,
String edgesGroupedBySourceTopic,
Map<org.apache.kafka.common.TopicPartition,Long> graphOffsets,
GraphSerialized<K,VV,EV> serialized,
String solutionSetTopic,
String solutionSetStore,
String workSetTopic,
int numPartitions,
short replicationFactor,
Map<String,?> configs,
Optional<Message> initialMessage,
ComputeFunction<K,VV,EV,Message> cf) |
PregelGraphAlgorithm(String hostAndPort,
String applicationId,
String bootstrapServers,
String zookeeperConnect,
String verticesTopic,
String edgesGroupedBySourceTopic,
Map<org.apache.kafka.common.TopicPartition,Long> graphOffsets,
GraphSerialized<K,VV,EV> serialized,
String solutionSetTopic,
String solutionSetStore,
String workSetTopic,
int numPartitions,
short replicationFactor,
Map<String,?> configs,
Optional<Message> initialMessage,
ComputeFunction<K,VV,EV,Message> cf) |
Constructor and Description |
---|
EdgeStream(org.apache.kafka.streams.kstream.KStream<Edge<K>,EV> edges,
GraphSerialized<K,Void,EV> serialized)
Creates a graph from an edge stream.
|
Modifier and Type | Method and Description |
---|---|
static <K,VV,EV> CompletableFuture<Map<org.apache.kafka.common.TopicPartition,Long>> |
GraphUtils.groupEdgesBySourceAndRepartition(org.apache.kafka.streams.StreamsBuilder builder,
Properties streamsConfig,
String initialVerticesTopic,
String initialEdgesTopic,
GraphSerialized<K,VV,EV> serialized,
String verticesTopic,
String edgesGroupedBySourceTopic,
int numPartitions,
short replicationFactor) |
Copyright © 2020. All rights reserved.