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 org.apache.flink.runtime.jobgraph.tasks.TaskInvokable> 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 |
---|---|
org.apache.flink.api.java.tuple.Tuple2<StreamNode,StreamNode> |
StreamGraph.createIterationSourceAndSink(int loopId,
int sourceId,
int sinkId,
long timeout,
int parallelism,
int maxParallelism,
org.apache.flink.api.common.operators.ResourceSpec minResources,
org.apache.flink.api.common.operators.ResourceSpec preferredResources) |
org.apache.flink.api.java.tuple.Tuple2<StreamNode,StreamNode> |
StreamGraph.createIterationSourceAndSink(int loopId,
int sourceId,
int sinkId,
long timeout,
int parallelism,
int maxParallelism,
org.apache.flink.api.common.operators.ResourceSpec minResources,
org.apache.flink.api.common.operators.ResourceSpec preferredResources) |
Set<org.apache.flink.api.java.tuple.Tuple2<StreamNode,StreamNode>> |
StreamGraph.getIterationSourceSinkPairs() |
Set<org.apache.flink.api.java.tuple.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,
long bufferTimeout,
StreamPartitioner<?> outputPartitioner,
org.apache.flink.util.OutputTag outputTag,
StreamExchangeMode exchangeMode,
int uniqueId,
org.apache.flink.runtime.jobgraph.IntermediateDataSetID intermediateDatasetId) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
StreamPartitioner<?> outputPartitioner,
org.apache.flink.util.OutputTag outputTag) |
StreamEdge(StreamNode sourceVertex,
StreamNode targetVertex,
int typeNumber,
StreamPartitioner<?> outputPartitioner,
org.apache.flink.util.OutputTag outputTag,
StreamExchangeMode exchangeMode,
int uniqueId,
org.apache.flink.runtime.jobgraph.IntermediateDataSetID intermediateDatasetId) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.