Uses of Class
org.apache.flink.streaming.api.graph.StreamNode
-
Packages that use StreamNode Package Description org.apache.flink.streaming.api.graph -
-
Uses of StreamNode in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return StreamNode Modifier and Type Method Description protected StreamNode
StreamGraph. addNode(Integer vertexID, String slotSharingGroup, String coLocationGroup, Class<? extends TaskInvokable> vertexClass, StreamOperatorFactory<?> operatorFactory, String operatorName)
StreamNode
StreamGraph. getSourceVertex(StreamEdge edge)
StreamNode
StreamGraph. getStreamNode(Integer vertexID)
StreamNode
StreamGraph. getTargetVertex(StreamEdge edge)
Methods in org.apache.flink.streaming.api.graph that return types with arguments of type StreamNode Modifier and Type Method 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()
Methods in org.apache.flink.streaming.api.graph with parameters of type StreamNode Modifier and Type Method Description boolean
StreamNode. isSameSlotSharingGroup(StreamNode downstreamVertex)
Constructors in org.apache.flink.streaming.api.graph with parameters of type StreamNode Constructor Description StreamEdge(StreamNode sourceVertex, StreamNode targetVertex, int typeNumber, long bufferTimeout, StreamPartitioner<?> outputPartitioner, org.apache.flink.util.OutputTag outputTag, StreamExchangeMode exchangeMode, int uniqueId, 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, IntermediateDataSetID intermediateDatasetId)
-