public class PregelGraphAlgorithm<K,VV,EV,Message> extends Object implements GraphAlgorithm<K,VV,EV,org.apache.kafka.streams.kstream.KTable<K,VV>>
Modifier and Type | Field and Description |
---|---|
protected String |
applicationId |
protected String |
bootstrapServers |
protected PregelComputation<K,VV,EV,Message> |
computation |
protected org.apache.curator.framework.CuratorFramework |
curator |
protected String |
edgesGroupedBySourceTopic |
protected Map<org.apache.kafka.common.TopicPartition,Long> |
graphOffsets |
protected String |
hostAndPort |
protected int |
numPartitions |
protected short |
replicationFactor |
protected GraphSerialized<K,VV,EV> |
serialized |
protected String |
solutionSetStore |
protected String |
solutionSetTopic |
protected org.apache.kafka.streams.KafkaStreams |
streams |
protected String |
verticesTopic |
protected String |
workSetTopic |
protected String |
zookeeperConnect |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
Map<String,?> |
configs() |
GraphAlgorithmState<Void> |
configure(org.apache.kafka.streams.StreamsBuilder builder,
Properties streamsConfig) |
Iterable<org.apache.kafka.streams.KeyValue<K,VV>> |
result() |
GraphAlgorithmState<org.apache.kafka.streams.kstream.KTable<K,VV>> |
run(int maxIterations) |
GraphSerialized<K,VV,EV> |
serialized() |
GraphAlgorithmState<org.apache.kafka.streams.kstream.KTable<K,VV>> |
state() |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
run
protected final String hostAndPort
protected final String applicationId
protected final String bootstrapServers
protected final String zookeeperConnect
protected final org.apache.curator.framework.CuratorFramework curator
protected final String verticesTopic
protected final String edgesGroupedBySourceTopic
protected final GraphSerialized<K,VV,EV> serialized
protected final String solutionSetTopic
protected final String solutionSetStore
protected final String workSetTopic
protected final int numPartitions
protected final short replicationFactor
protected final PregelComputation<K,VV,EV,Message> computation
protected org.apache.kafka.streams.KafkaStreams streams
public 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)
public 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)
public 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)
public GraphSerialized<K,VV,EV> serialized()
public GraphAlgorithmState<Void> configure(org.apache.kafka.streams.StreamsBuilder builder, Properties streamsConfig)
public GraphAlgorithmState<org.apache.kafka.streams.kstream.KTable<K,VV>> run(int maxIterations)
public GraphAlgorithmState<org.apache.kafka.streams.kstream.KTable<K,VV>> state()
public void close()
close
in interface Closeable
close
in interface AutoCloseable
Copyright © 2020. All rights reserved.