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 StreamEdge
StreamConfig.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 void
StreamNode. addInEdge(StreamEdge inEdge)
void
StreamNode. addOutEdge(StreamEdge outEdge)
static IntermediateDataSet
StreamingJobGraphGenerator. connect(Integer headOfChain, StreamEdge edge, NonChainedOutput output, Map<Integer,JobVertex> jobVertices, JobVertexBuildContext jobVertexBuildContext)
static ResultPartitionType
StreamingJobGraphGenerator. determineUndefinedResultPartitionType(StreamEdge edge, JobVertexBuildContext jobVertexBuildContext)
StreamNode
StreamGraph. getSourceVertex(StreamEdge edge)
StreamNode
StreamGraph. getTargetVertex(StreamEdge edge)
static boolean
StreamingJobGraphGenerator. isChainable(StreamEdge edge, StreamGraph streamGraph)
static boolean
StreamingJobGraphGenerator. 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.ResourceSpec
StreamingJobGraphGenerator. createChainedMinResources(Integer vertexID, List<StreamEdge> chainedOutputs, OperatorChainInfo operatorChainInfo, JobVertexBuildContext jobVertexBuildContext)
static String
StreamingJobGraphGenerator. createChainedName(Integer vertexID, List<StreamEdge> chainedOutputs, Optional<OperatorChainInfo> operatorChainInfo, Map<Integer,String> chainedNames, JobVertexBuildContext jobVertexBuildContext)
static org.apache.flink.api.common.operators.ResourceSpec
StreamingJobGraphGenerator. createChainedPreferredResources(Integer vertexID, List<StreamEdge> chainedOutputs, OperatorChainInfo operatorChainInfo, JobVertexBuildContext jobVertexBuildContext)
static void
StreamingJobGraphGenerator. setAllOperatorNonChainedOutputsConfigs(Map<Integer,Map<StreamEdge,NonChainedOutput>> opIntermediateOutputs, JobVertexBuildContext jobVertexBuildContext)
void
StreamConfig. setChainedOutputs(List<StreamEdge> chainedOutputs)
void
StreamConfig. setInPhysicalEdges(List<StreamEdge> inEdges)
static void
StreamingJobGraphGenerator. setOperatorChainedOutputsConfig(StreamConfig config, List<StreamEdge> chainableOutputs, JobVertexBuildContext jobVertexBuildContext)
static void
StreamingJobGraphGenerator. 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 void
JobVertexBuildContext. addPhysicalEdgesInOrder(StreamEdge edge)
void
OperatorChainInfo. addTransitiveInEdge(StreamEdge streamEdge)
Method parameters in org.apache.flink.streaming.api.graph.util with type arguments of type StreamEdge Modifier and Type Method Description void
OperatorInfo. addNonChainableOutputs(List<StreamEdge> nonChainableOutEdges)
void
OperatorChainInfo. setTransitiveOutEdges(List<StreamEdge> transitiveOutEdges)
Constructors in org.apache.flink.streaming.api.graph.util with parameters of type StreamEdge Constructor Description ImmutableStreamEdge(StreamEdge streamEdge)
-