Class StreamContextEnvironment

  • All Implemented Interfaces:
    AutoCloseable

    @PublicEvolving
    public class StreamContextEnvironment
    extends org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
    Special StreamExecutionEnvironment that will be used in cases where the CLI client or testing utilities create a StreamExecutionEnvironment that should be used when StreamExecutionEnvironment.getExecutionEnvironment() is called.
    • Field Summary

      • Fields inherited from class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment

        cacheFile, checkpointCfg, config, configuration, transformations
    • Constructor Summary

      Constructors 
      Constructor Description
      StreamContextEnvironment​(org.apache.flink.core.execution.PipelineExecutorServiceLoader executorServiceLoader, org.apache.flink.configuration.Configuration configuration, ClassLoader userCodeClassLoader, boolean enforceSingleJobExecution, boolean suppressSysout)  
      StreamContextEnvironment​(org.apache.flink.core.execution.PipelineExecutorServiceLoader executorServiceLoader, org.apache.flink.configuration.Configuration clusterConfiguration, org.apache.flink.configuration.Configuration configuration, ClassLoader userCodeClassLoader, boolean enforceSingleJobExecution, boolean suppressSysout, boolean programConfigEnabled, Collection<String> programConfigWildcards)  
    • Method Summary

      All Methods Static Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      org.apache.flink.api.common.JobExecutionResult execute​(org.apache.flink.streaming.api.graph.StreamGraph streamGraph)  
      org.apache.flink.core.execution.JobClient executeAsync​(org.apache.flink.streaming.api.graph.StreamGraph streamGraph)  
      static void setAsContext​(org.apache.flink.core.execution.PipelineExecutorServiceLoader executorServiceLoader, org.apache.flink.configuration.Configuration clusterConfiguration, ClassLoader userCodeClassLoader, boolean enforceSingleJobExecution, boolean suppressSysout)  
      static void unsetAsContext()  
      • Methods inherited from class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment

        addOperator, addSource, addSource, addSource, addSource, areExplicitEnvironmentsAllowed, clean, clearJobListeners, close, configure, configure, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableChangelogStateBackend, enableCheckpointing, enableCheckpointing, enableCheckpointing, execute, execute, executeAsync, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromData, fromData, fromData, fromData, fromData, fromElements, fromElements, fromParallelCollection, fromParallelCollection, fromSequence, fromSource, fromSource, generateSequence, generateStreamGraph, getBufferTimeout, getCachedFiles, getCheckpointConfig, getCheckpointingConsistencyMode, getCheckpointingMode, getCheckpointInterval, getConfig, getConfiguration, getDefaultLocalParallelism, getDefaultSavepointDirectory, getExecutionEnvironment, getExecutionEnvironment, getExecutionPlan, getJobListeners, getMaxParallelism, getParallelism, getStreamGraph, getStreamGraph, getTransformations, getUserClassloader, initializeContextEnvironment, invalidateClusterDataset, isChainingEnabled, isChainingOfOperatorsWithDifferentMaxParallelismEnabled, isChangelogStateBackendEnabled, isForceUnalignedCheckpoints, isUnalignedCheckpointsEnabled, listCompletedClusterDatasets, readFile, readFile, readFile, readFile, readFileStream, registerCachedFile, registerCachedFile, registerCacheTransformation, registerCollectIterator, registerJobListener, registerSlotSharingGroup, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setMaxParallelism, setParallelism, setRuntimeMode, socketTextStream, socketTextStream, socketTextStream, socketTextStream, socketTextStream
    • Constructor Detail

      • StreamContextEnvironment

        public StreamContextEnvironment​(org.apache.flink.core.execution.PipelineExecutorServiceLoader executorServiceLoader,
                                        org.apache.flink.configuration.Configuration configuration,
                                        ClassLoader userCodeClassLoader,
                                        boolean enforceSingleJobExecution,
                                        boolean suppressSysout)
      • StreamContextEnvironment

        @Internal
        public StreamContextEnvironment​(org.apache.flink.core.execution.PipelineExecutorServiceLoader executorServiceLoader,
                                        org.apache.flink.configuration.Configuration clusterConfiguration,
                                        org.apache.flink.configuration.Configuration configuration,
                                        ClassLoader userCodeClassLoader,
                                        boolean enforceSingleJobExecution,
                                        boolean suppressSysout,
                                        boolean programConfigEnabled,
                                        Collection<String> programConfigWildcards)
    • Method Detail

      • execute

        public org.apache.flink.api.common.JobExecutionResult execute​(org.apache.flink.streaming.api.graph.StreamGraph streamGraph)
                                                               throws Exception
        Overrides:
        execute in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
        Throws:
        Exception
      • executeAsync

        public org.apache.flink.core.execution.JobClient executeAsync​(org.apache.flink.streaming.api.graph.StreamGraph streamGraph)
                                                               throws Exception
        Overrides:
        executeAsync in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
        Throws:
        Exception
      • setAsContext

        public static void setAsContext​(org.apache.flink.core.execution.PipelineExecutorServiceLoader executorServiceLoader,
                                        org.apache.flink.configuration.Configuration clusterConfiguration,
                                        ClassLoader userCodeClassLoader,
                                        boolean enforceSingleJobExecution,
                                        boolean suppressSysout)
      • unsetAsContext

        public static void unsetAsContext()