Uses of Class
org.apache.flink.streaming.api.graph.StreamNode
-
Packages that use StreamNode Package Description org.apache.flink.runtime.jobgraph.forwardgroup org.apache.flink.streaming.api.graph org.apache.flink.streaming.api.graph.util -
-
Uses of StreamNode in org.apache.flink.runtime.jobgraph.forwardgroup
Method parameters in org.apache.flink.runtime.jobgraph.forwardgroup with type arguments of type StreamNode Modifier and Type Method Description static Map<Integer,StreamNodeForwardGroup>
ForwardGroupComputeUtil. computeStreamNodeForwardGroup(Iterable<StreamNode> topologicallySortedStreamNodes, Function<StreamNode,Set<StreamNode>> forwardProducersRetriever)
We calculate forward group by a set of stream nodes.static Map<Integer,StreamNodeForwardGroup>
ForwardGroupComputeUtil. computeStreamNodeForwardGroup(Iterable<StreamNode> topologicallySortedStreamNodes, Function<StreamNode,Set<StreamNode>> forwardProducersRetriever)
We calculate forward group by a set of stream nodes.static Map<Integer,StreamNodeForwardGroup>
ForwardGroupComputeUtil. computeStreamNodeForwardGroup(Iterable<StreamNode> topologicallySortedStreamNodes, Function<StreamNode,Set<StreamNode>> forwardProducersRetriever)
We calculate forward group by a set of stream nodes.Constructor parameters in org.apache.flink.runtime.jobgraph.forwardgroup with type arguments of type StreamNode Constructor Description StreamNodeForwardGroup(Set<StreamNode> streamNodes)
-
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 Collection<StreamNode>
StreamGraph. getStreamNodes()
List<StreamNode>
StreamGraph. getStreamNodesSortedTopologicallyFromSources()
Methods in org.apache.flink.streaming.api.graph with parameters of type StreamNode Modifier and Type Method Description static void
StreamingJobGraphGenerator. createSourceChainInfo(StreamNode sourceNode, Map<Integer,OperatorChainInfo> chainEntryPoints, JobVertexBuildContext jobVertexBuildContext)
static boolean
StreamingJobGraphGenerator. isChainableSource(StreamNode streamNode, StreamGraph streamGraph)
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)
-
Uses of StreamNode in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return StreamNode Modifier and Type Method Description StreamNode
ChainedOperatorHashInfo. getStreamNode()
Methods in org.apache.flink.streaming.api.graph.util that return types with arguments of type StreamNode Modifier and Type Method Description List<StreamNode>
OperatorChainInfo. getAllChainedNodes()
Methods in org.apache.flink.streaming.api.graph.util with parameters of type StreamNode Modifier and Type Method Description void
OperatorChainInfo. addChainedSource(StreamNode sourceNode, ChainedSourceInfo chainedSourceInfo)
void
OperatorChainInfo. recordChainedNode(StreamNode streamNode)
Constructors in org.apache.flink.streaming.api.graph.util with parameters of type StreamNode Constructor Description ImmutableStreamNode(StreamNode streamNode)
-