Uses of Class
org.apache.flink.streaming.api.graph.StreamEdge
-
Packages that use StreamEdge Package Description org.apache.flink.streaming.api.graph org.apache.flink.streaming.api.graph.util -
-
Uses of StreamEdge in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return StreamEdge Modifier and Type Method Description StreamEdgeStreamConfig.SourceInputConfig. getInputEdge()Methods in org.apache.flink.streaming.api.graph that return types with arguments of type StreamEdge Modifier and Type Method Description static List<StreamEdge>StreamingJobGraphGenerator. createChain(Integer currentNodeId, int chainIndex, OperatorChainInfo chainInfo, Map<Integer,OperatorChainInfo> chainEntryPoints, boolean canCreateNewChain, Executor serializationExecutor, JobVertexBuildContext jobVertexBuildContext, Consumer<Integer> visitedStreamNodeConsumer)List<StreamEdge>StreamConfig. getChainedOutputs(ClassLoader cl)List<StreamEdge>StreamNode. getInEdges()List<StreamEdge>StreamConfig. getInPhysicalEdges(ClassLoader cl)List<StreamEdge>StreamNode. getOutEdges()List<StreamEdge>AdaptiveGraphManager. getOutputStreamEdges(IntermediateDataSetID intermediateDataSetId)Retrieves the stream edges that subscribe to the IntermediateDataSet.List<StreamEdge>StreamGraph. getStreamEdges(int sourceId)List<StreamEdge>StreamGraph. getStreamEdges(int sourceId, int targetId)List<StreamEdge>StreamGraph. getStreamEdgesOrThrow(int sourceId, int targetId)Deprecated.Methods in org.apache.flink.streaming.api.graph with parameters of type StreamEdge Modifier and Type Method Description voidStreamNode. addInEdge(StreamEdge inEdge)voidStreamNode. addOutEdge(StreamEdge outEdge)static IntermediateDataSetStreamingJobGraphGenerator. connect(Integer headOfChain, StreamEdge edge, NonChainedOutput output, Map<Integer,JobVertex> jobVertices, JobVertexBuildContext jobVertexBuildContext)static ResultPartitionTypeStreamingJobGraphGenerator. determineUndefinedResultPartitionType(StreamEdge edge, JobVertexBuildContext jobVertexBuildContext)StreamNodeStreamGraph. getSourceVertex(StreamEdge edge)StreamNodeStreamGraph. getTargetVertex(StreamEdge edge)static booleanStreamingJobGraphGenerator. isChainable(StreamEdge edge, StreamGraph streamGraph)static booleanStreamingJobGraphGenerator. isChainable(StreamEdge edge, StreamGraph streamGraph, boolean allowChainWithDefaultParallelism)Method parameters in org.apache.flink.streaming.api.graph with type arguments of type StreamEdge Modifier and Type Method Description static org.apache.flink.api.common.operators.ResourceSpecStreamingJobGraphGenerator. createChainedMinResources(Integer vertexID, List<StreamEdge> chainedOutputs, OperatorChainInfo operatorChainInfo, JobVertexBuildContext jobVertexBuildContext)static StringStreamingJobGraphGenerator. createChainedName(Integer vertexID, List<StreamEdge> chainedOutputs, Optional<OperatorChainInfo> operatorChainInfo, Map<Integer,String> chainedNames, JobVertexBuildContext jobVertexBuildContext)static org.apache.flink.api.common.operators.ResourceSpecStreamingJobGraphGenerator. createChainedPreferredResources(Integer vertexID, List<StreamEdge> chainedOutputs, OperatorChainInfo operatorChainInfo, JobVertexBuildContext jobVertexBuildContext)static voidStreamingJobGraphGenerator. setAllOperatorNonChainedOutputsConfigs(Map<Integer,Map<StreamEdge,NonChainedOutput>> opIntermediateOutputs, JobVertexBuildContext jobVertexBuildContext)voidStreamConfig. setChainedOutputs(List<StreamEdge> chainedOutputs)voidStreamConfig. setInPhysicalEdges(List<StreamEdge> inEdges)static voidStreamingJobGraphGenerator. setOperatorChainedOutputsConfig(StreamConfig config, List<StreamEdge> chainableOutputs, JobVertexBuildContext jobVertexBuildContext)static voidStreamingJobGraphGenerator. tryConvertPartitionerForDynamicGraph(List<StreamEdge> chainableOutputs, List<StreamEdge> nonChainableOutputs, JobVertexBuildContext jobVertexBuildContext)Constructors in org.apache.flink.streaming.api.graph with parameters of type StreamEdge Constructor Description SourceInputConfig(StreamEdge inputEdge) -
Uses of StreamEdge in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return types with arguments of type StreamEdge Modifier and Type Method Description List<StreamEdge>OperatorInfo. getNonChainableOutputs()List<StreamEdge>JobVertexBuildContext. getPhysicalEdgesInOrder()List<StreamEdge>OperatorChainInfo. getTransitiveInEdges()List<StreamEdge>OperatorChainInfo. getTransitiveOutEdges()Methods in org.apache.flink.streaming.api.graph.util with parameters of type StreamEdge Modifier and Type Method Description voidJobVertexBuildContext. addPhysicalEdgesInOrder(StreamEdge edge)voidOperatorChainInfo. addTransitiveInEdge(StreamEdge streamEdge)Method parameters in org.apache.flink.streaming.api.graph.util with type arguments of type StreamEdge Modifier and Type Method Description voidOperatorInfo. addNonChainableOutputs(List<StreamEdge> nonChainableOutEdges)voidOperatorChainInfo. setTransitiveOutEdges(List<StreamEdge> transitiveOutEdges)Constructors in org.apache.flink.streaming.api.graph.util with parameters of type StreamEdge Constructor Description ImmutableStreamEdge(StreamEdge streamEdge)
-