Interface Executor

    • Method Summary

      All Methods Instance Methods Abstract Methods 
      Modifier and Type Method Description
      org.apache.flink.api.dag.Pipeline createPipeline​(List<org.apache.flink.api.dag.Transformation<?>> transformations, org.apache.flink.configuration.ReadableConfig tableConfiguration, String defaultJobName)
      Translates the given transformations to a Pipeline.
      org.apache.flink.api.dag.Pipeline createPipeline​(List<org.apache.flink.api.dag.Transformation<?>> transformations, org.apache.flink.configuration.ReadableConfig tableConfiguration, String defaultJobName, List<org.apache.flink.core.execution.JobStatusHook> jobStatusHookList)
      Translates the given transformations with a list of JobStatusHooks to a Pipeline.
      org.apache.flink.api.common.JobExecutionResult execute​(org.apache.flink.api.dag.Pipeline pipeline)
      Executes the given pipeline.
      org.apache.flink.core.execution.JobClient executeAsync​(org.apache.flink.api.dag.Pipeline pipeline)
      Executes the given pipeline asynchronously.
      org.apache.flink.configuration.ReadableConfig getConfiguration()
      Gives read-only access to the configuration of the executor.
      boolean isCheckpointingEnabled()
      Checks whether checkpointing is enabled.
    • Method Detail

      • getConfiguration

        org.apache.flink.configuration.ReadableConfig getConfiguration()
        Gives read-only access to the configuration of the executor.
      • createPipeline

        org.apache.flink.api.dag.Pipeline createPipeline​(List<org.apache.flink.api.dag.Transformation<?>> transformations,
                                                         org.apache.flink.configuration.ReadableConfig tableConfiguration,
                                                         @Nullable
                                                         String defaultJobName)
        Translates the given transformations to a Pipeline.
        Parameters:
        transformations - list of transformations
        tableConfiguration - table-specific configuration options
        defaultJobName - default job name if not specified via PipelineOptions.NAME
        Returns:
        The pipeline representing the transformations.
      • createPipeline

        org.apache.flink.api.dag.Pipeline createPipeline​(List<org.apache.flink.api.dag.Transformation<?>> transformations,
                                                         org.apache.flink.configuration.ReadableConfig tableConfiguration,
                                                         @Nullable
                                                         String defaultJobName,
                                                         List<org.apache.flink.core.execution.JobStatusHook> jobStatusHookList)
        Translates the given transformations with a list of JobStatusHooks to a Pipeline.
        Parameters:
        transformations - list of transformations
        tableConfiguration - table-specific configuration options
        defaultJobName - default job name if not specified via PipelineOptions.NAME
        jobStatusHookList - list of JobStatusHooks
        Returns:
        The pipeline representing the transformations.
      • execute

        org.apache.flink.api.common.JobExecutionResult execute​(org.apache.flink.api.dag.Pipeline pipeline)
                                                        throws Exception
        Executes the given pipeline.
        Parameters:
        pipeline - the pipeline to execute
        Returns:
        The result of the job execution, containing elapsed time and accumulators.
        Throws:
        Exception - which occurs during job execution.
      • executeAsync

        org.apache.flink.core.execution.JobClient executeAsync​(org.apache.flink.api.dag.Pipeline pipeline)
                                                        throws Exception
        Executes the given pipeline asynchronously.
        Parameters:
        pipeline - the pipeline to execute
        Returns:
        A JobClient that can be used to communicate with the submitted job, completed on submission succeeded.
        Throws:
        Exception - which occurs during job execution.
      • isCheckpointingEnabled

        boolean isCheckpointingEnabled()
        Checks whether checkpointing is enabled.
        Returns:
        True if checkpointing is enables, false otherwise.