类 DraftExecutionEnvironment


  • public class DraftExecutionEnvironment
    extends org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
    A specialized stream execution environment that allows users to first construct a subgraph and later copy the transformations into the actual environment. During the copying it could apply some kinds of OperatorWrapper to change the operators in each transformation.
    • 字段概要

      • 从类继承的字段 org.apache.flink.streaming.api.environment.StreamExecutionEnvironment

        cacheFile, checkpointCfg, config, configuration, DEFAULT_JOB_NAME, isChainingEnabled, transformations
    • 方法概要

      所有方法 实例方法 具体方法 
      修饰符和类型 方法 说明
      <T> org.apache.flink.streaming.api.datastream.DataStream<T> addDraftSource​(org.apache.flink.streaming.api.datastream.DataStream<?> actualStream, org.apache.flink.api.common.typeinfo.TypeInformation<T> draftOutputType)  
      void addOperator​(org.apache.flink.api.dag.Transformation<?> transformation)  
      void addOperatorIfNotExists​(org.apache.flink.api.dag.Transformation<?> transformation)  
      void copyToActualEnvironment()  
      org.apache.flink.api.common.JobExecutionResult execute​(org.apache.flink.streaming.api.graph.StreamGraph streamGraph)  
      <T> org.apache.flink.streaming.api.datastream.DataStream<T> getActualStream​(int draftTransformationId)  
      OperatorWrapper<?,​?> setCurrentWrapper​(OperatorWrapper<?,​?> newWrapper)  
      • 从类继承的方法 org.apache.flink.streaming.api.environment.StreamExecutionEnvironment

        addDefaultKryoSerializer, addDefaultKryoSerializer, addSource, addSource, addSource, addSource, areExplicitEnvironmentsAllowed, clean, clearJobListeners, configure, configure, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableChangelogStateBackend, enableCheckpointing, enableCheckpointing, enableCheckpointing, enableCheckpointing, execute, execute, executeAsync, executeAsync, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, fromSequence, fromSource, fromSource, generateSequence, generateStreamGraph, getBufferTimeout, getCachedFiles, getCheckpointConfig, getCheckpointingMode, getCheckpointInterval, getConfig, getConfiguration, getDefaultLocalParallelism, getDefaultSavepointDirectory, getExecutionEnvironment, getExecutionEnvironment, getExecutionPlan, getJobListeners, getMaxParallelism, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getStateBackend, getStreamGraph, getStreamGraph, getStreamTimeCharacteristic, getTransformations, getUserClassloader, initializeContextEnvironment, isChainingEnabled, isChangelogStateBackendEnabled, isForceCheckpointing, isForceUnalignedCheckpoints, isUnalignedCheckpointsEnabled, readFile, readFile, readFile, readFile, readFileStream, readTextFile, readTextFile, registerCachedFile, registerCachedFile, registerJobListener, registerSlotSharingGroup, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setMaxParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setRuntimeMode, setStateBackend, setStreamTimeCharacteristic, socketTextStream, socketTextStream, socketTextStream, socketTextStream, socketTextStream
    • 构造器详细资料

      • DraftExecutionEnvironment

        public DraftExecutionEnvironment​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment actualEnv,
                                         OperatorWrapper<?,​?> initialWrapper)
    • 方法详细资料

      • addOperator

        public void addOperator​(org.apache.flink.api.dag.Transformation<?> transformation)
        覆盖:
        addOperator 在类中 org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
      • addOperatorIfNotExists

        public void addOperatorIfNotExists​(org.apache.flink.api.dag.Transformation<?> transformation)
      • addDraftSource

        public <T> org.apache.flink.streaming.api.datastream.DataStream<T> addDraftSource​(org.apache.flink.streaming.api.datastream.DataStream<?> actualStream,
                                                                                          org.apache.flink.api.common.typeinfo.TypeInformation<T> draftOutputType)
      • copyToActualEnvironment

        public void copyToActualEnvironment()
      • getActualStream

        public <T> org.apache.flink.streaming.api.datastream.DataStream<T> getActualStream​(int draftTransformationId)
      • execute

        public org.apache.flink.api.common.JobExecutionResult execute​(org.apache.flink.streaming.api.graph.StreamGraph streamGraph)
                                                               throws Exception
        覆盖:
        execute 在类中 org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
        抛出:
        Exception