Package | Description |
---|---|
org.apache.flink.streaming.api.graph |
Modifier and Type | Method and Description |
---|---|
protected StreamNode |
StreamGraph.addNode(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
Class<? extends AbstractInvokable> vertexClass,
StreamOperatorFactory<?> operatorFactory,
String operatorName) |
StreamNode |
StreamGraph.getSourceVertex(StreamEdge edge) |
StreamNode |
StreamGraph.getStreamNode(Integer vertexID) |
StreamNode |
StreamGraph.getTargetVertex(StreamEdge edge) |
Modifier and Type | Method and Description |
---|---|
Tuple2<StreamNode,StreamNode> |
StreamGraph.createIterationSourceAndSink(int loopId,
int sourceId,
int sinkId,
long timeout,
int parallelism,
int maxParallelism,
ResourceSpec minResources,
ResourceSpec preferredResources) |
Tuple2<StreamNode,StreamNode> |
StreamGraph.createIterationSourceAndSink(int loopId,
int sourceId,
int sinkId,
long timeout,
int parallelism,
int maxParallelism,
ResourceSpec minResources,
ResourceSpec preferredResources) |
Set<Tuple2<StreamNode,StreamNode>> |
StreamGraph.getIterationSourceSinkPairs() |
Set<Tuple2<StreamNode,StreamNode>> |
StreamGraph.getIterationSourceSinkPairs() |
Collection<StreamNode> |
StreamGraph.getStreamNodes() |
Modifier and Type | Method and Description |
---|---|
boolean |
StreamNode.isSameSlotSharingGroup(StreamNode downstreamVertex) |
Constructor and Description |
---|
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
List<String> selectedNames,
StreamPartitioner<?> outputPartitioner,
OutputTag outputTag) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
List<String> selectedNames,
StreamPartitioner<?> outputPartitioner,
OutputTag outputTag,
ShuffleMode shuffleMode) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
long bufferTimeout,
List<String> selectedNames,
StreamPartitioner<?> outputPartitioner,
OutputTag outputTag,
ShuffleMode shuffleMode) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.