Uses of Class
org.apache.flink.streaming.api.graph.StreamGraph
-
Packages that use StreamGraph Package Description org.apache.flink.streaming.api.environment org.apache.flink.streaming.api.graph org.apache.flink.streaming.util.graph -
-
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. createJobGraph(ClassLoader userClassLoader, StreamGraph streamGraph, org.apache.flink.api.common.JobID jobID)static JobGraphStreamingJobGraphGenerator. createJobGraph(StreamGraph streamGraph)static booleanStreamingJobGraphGenerator. isChainable(StreamEdge edge, StreamGraph streamGraph)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 JSONGenerator(StreamGraph streamGraph) -
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.
-