public class PregelComputation<K,VV,EV,Message> extends Object implements Closeable
Modifier and Type | Class and Description |
---|---|
protected static class |
PregelComputation.AggregatorWrapper<T> |
static class |
PregelComputation.MapOfLongMaxAggregator |
Modifier and Type | Field and Description |
---|---|
static String |
ALL_PARTITIONS |
static String |
LAST_WRITTEN_OFFSETS |
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) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
Map<String,?> |
configs() |
org.apache.kafka.streams.kstream.KTable<K,Map<K,EV>> |
edgesGroupedBySource() |
CompletableFuture<org.apache.kafka.streams.kstream.KTable<K,VV>> |
futureResult() |
void |
prepare(org.apache.kafka.streams.StreamsBuilder builder,
Properties streamsConfig) |
protected Map<String,?> |
previousAggregates(int superstep) |
org.apache.kafka.streams.kstream.KTable<K,VV> |
result() |
PregelState |
run(int maxIterations,
CompletableFuture<org.apache.kafka.streams.kstream.KTable<K,VV>> futureResult) |
PregelState |
state() |
org.apache.kafka.streams.kstream.KTable<K,VV> |
vertices() |
public static final String ALL_PARTITIONS
public static final String LAST_WRITTEN_OFFSETS
public 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)
public org.apache.kafka.streams.kstream.KTable<K,Map<K,EV>> edgesGroupedBySource()
public CompletableFuture<org.apache.kafka.streams.kstream.KTable<K,VV>> futureResult()
public void prepare(org.apache.kafka.streams.StreamsBuilder builder, Properties streamsConfig)
public PregelState run(int maxIterations, CompletableFuture<org.apache.kafka.streams.kstream.KTable<K,VV>> futureResult)
public PregelState state()
public void close()
close
in interface Closeable
close
in interface AutoCloseable
Copyright © 2020. All rights reserved.