Uses of Class
org.apache.flink.streaming.api.graph.StreamGraph
-
-
Uses of StreamGraph in org.apache.flink.runtime.jobgraph.jsonplan
Methods in org.apache.flink.runtime.jobgraph.jsonplan with parameters of type StreamGraph Modifier and Type Method Description static StringJsonPlanGenerator. generateStreamGraphJson(StreamGraph sg, Map<Integer,JobVertexID> jobVertexIdMap) -
Uses of StreamGraph in org.apache.flink.runtime.scheduler.adaptivebatch
Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type StreamGraph Constructor Description DefaultAdaptiveExecutionHandler(ClassLoader userClassloader, StreamGraph streamGraph, Executor serializationExecutor) -
Uses of StreamGraph in org.apache.flink.streaming.api.environment
Methods in org.apache.flink.streaming.api.environment that return StreamGraph Modifier and Type Method Description StreamGraphStreamExecutionEnvironment. generateStreamGraph(List<org.apache.flink.api.dag.Transformation<?>> transformations)Generates aStreamGraphthat consists of the giventransformationsand is configured with the configuration of this environment.StreamGraphStreamExecutionEnvironment. getStreamGraph()Getter of theStreamGraphof the streaming job.StreamGraphStreamExecutionEnvironment. getStreamGraph(boolean clearTransformations)Getter of theStreamGraphof the streaming job with the option to clear previously registeredtransformations.Methods in org.apache.flink.streaming.api.environment with parameters of type StreamGraph Modifier and Type Method Description org.apache.flink.api.common.JobExecutionResultLocalStreamEnvironment. execute(StreamGraph streamGraph)org.apache.flink.api.common.JobExecutionResultRemoteStreamEnvironment. execute(StreamGraph streamGraph)org.apache.flink.api.common.JobExecutionResultStreamExecutionEnvironment. execute(StreamGraph streamGraph)Triggers the program execution.org.apache.flink.core.execution.JobClientStreamExecutionEnvironment. executeAsync(StreamGraph streamGraph)Triggers the program execution asynchronously. -
Uses of StreamGraph in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return StreamGraph Modifier and Type Method Description StreamGraphStreamGraphGenerator. generate()StreamGraphTransformationTranslator.Context. getStreamGraph()Returns theStreamGraphbeing created as the transformations of a pipeline are translated to their runtime implementations.Methods in org.apache.flink.streaming.api.graph with parameters of type StreamGraph Modifier and Type Method Description static JobGraphStreamingJobGraphGenerator. createAndInitializeJobGraph(StreamGraph streamGraph, org.apache.flink.api.common.JobID jobId)static JobGraphStreamingJobGraphGenerator. createJobGraph(ClassLoader userClassLoader, StreamGraph streamGraph, org.apache.flink.api.common.JobID jobID)static JobGraphStreamingJobGraphGenerator. createJobGraph(StreamGraph streamGraph)booleanStreamGraphHasher. generateHashesByStreamNodeId(int streamNodeId, StreamGraph streamGraph, Map<Integer,byte[]> hashes)Generates a hash forStreamNodewith the specified stream node id in theStreamGraph.booleanStreamGraphHasherV2. generateHashesByStreamNodeId(int streamNodeId, StreamGraph streamGraph, Map<Integer,byte[]> hashes)booleanStreamGraphUserHashHasher. generateHashesByStreamNodeId(int streamNodeId, StreamGraph streamGraph, Map<Integer,byte[]> hashes)static booleanStreamingJobGraphGenerator. isChainable(StreamEdge edge, StreamGraph streamGraph)static booleanStreamingJobGraphGenerator. isChainable(StreamEdge edge, StreamGraph streamGraph, boolean allowChainWithDefaultParallelism)static booleanStreamingJobGraphGenerator. isChainableSource(StreamNode streamNode, StreamGraph streamGraph)static voidStreamingJobGraphGenerator. preValidate(StreamGraph streamGraph, ClassLoader userClassloader)Map<Integer,byte[]>StreamGraphHasher. traverseStreamGraphAndGenerateHashes(StreamGraph streamGraph)Returns a map with a hash for eachStreamNodeof theStreamGraph.Map<Integer,byte[]>StreamGraphHasherV2. traverseStreamGraphAndGenerateHashes(StreamGraph streamGraph)Returns a map with a hash for eachStreamNodeof theStreamGraph.Map<Integer,byte[]>StreamGraphUserHashHasher. traverseStreamGraphAndGenerateHashes(StreamGraph streamGraph)Constructors in org.apache.flink.streaming.api.graph with parameters of type StreamGraph Constructor Description AdaptiveGraphManager(ClassLoader userClassloader, StreamGraph streamGraph, Executor serializationExecutor)DefaultStreamGraphContext(StreamGraph streamGraph, Map<Integer,StreamNodeForwardGroup> steamNodeIdToForwardGroupMap, Map<Integer,Integer> frozenNodeToStartNodeMap, Map<Integer,Map<StreamEdge,NonChainedOutput>> opIntermediateOutputsCaches, Map<String,IntermediateDataSet> consumerEdgeIdToIntermediateDataSetMap, Set<Integer> finishedStreamNodeIds, ClassLoader userClassloader)DefaultStreamGraphContext(StreamGraph streamGraph, Map<Integer,StreamNodeForwardGroup> steamNodeIdToForwardGroupMap, Map<Integer,Integer> frozenNodeToStartNodeMap, Map<Integer,Map<StreamEdge,NonChainedOutput>> opIntermediateOutputsCaches, Map<String,IntermediateDataSet> consumerEdgeIdToIntermediateDataSetMap, Set<Integer> finishedStreamNodeIds, ClassLoader userClassloader, StreamGraphContext.StreamGraphUpdateListener streamGraphUpdateListener)JSONGenerator(StreamGraph streamGraph) -
Uses of StreamGraph in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return StreamGraph Modifier and Type Method Description StreamGraphJobVertexBuildContext. getStreamGraph()Constructors in org.apache.flink.streaming.api.graph.util with parameters of type StreamGraph Constructor Description ImmutableStreamGraph(StreamGraph streamGraph, ClassLoader userClassloader)JobVertexBuildContext(JobGraph jobGraph, StreamGraph streamGraph, AtomicBoolean hasHybridResultPartition, Map<Integer,byte[]> hashes, List<Map<Integer,byte[]>> legacyHashes, SlotSharingGroup defaultSlotSharingGroup) -
Uses of StreamGraph in org.apache.flink.streaming.util.graph
Methods in org.apache.flink.streaming.util.graph with parameters of type StreamGraph Modifier and Type Method Description static <T> voidStreamGraphUtils. configureBufferTimeout(StreamGraph streamGraph, int nodeId, org.apache.flink.api.dag.Transformation<T> transformation, long defaultBufferTimeout)Configure a stream node's buffer timeout according to the given transformation.static voidStreamGraphUtils. validateTransformationUid(StreamGraph streamGraph, org.apache.flink.api.dag.Transformation<?> transformation)ThrowIllegalStateExceptionif thePhysicalTransformation's uid or hash is not set when auto generate uid is disabled. -
Uses of StreamGraph in org.apache.flink.streaming.util.watermark
Methods in org.apache.flink.streaming.util.watermark with parameters of type StreamGraph Modifier and Type Method Description static Set<AbstractInternalWatermarkDeclaration<?>>WatermarkUtils. getInternalWatermarkDeclarationsFromStreamGraph(StreamGraph streamGraph)Retrieve the declared watermarks from StreamGraph and convert them intoInternalWatermarkDeclaration.
-