Interface InternalExecutionGraphAccessor

  • All Known Implementing Classes:
    DefaultExecutionGraph

    public interface InternalExecutionGraphAccessor
    This interface encapsulates all methods needed by ExecutionJobVertex / ExecutionVertices / Execution from the DefaultExecutionGraph.
    • Method Detail

      • getJobID

        org.apache.flink.api.common.JobID getJobID()
      • getFutureExecutor

        Executor getFutureExecutor()
        Returns the ExecutionContext associated with this ExecutionGraph.
        Returns:
        ExecutionContext associated with this ExecutionGraph
      • getJobMasterMainThreadExecutor

        @Nonnull
        org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor getJobMasterMainThreadExecutor()
      • registerExecution

        void registerExecution​(Execution exec)
      • deregisterExecution

        void deregisterExecution​(Execution exec)
      • jobVertexFinished

        void jobVertexFinished()
      • jobVertexUnFinished

        void jobVertexUnFinished()
      • failGlobal

        void failGlobal​(Throwable t)
        Fails the execution graph globally.

        This global failure is meant to be triggered in cases where the consistency of the execution graph' state cannot be guaranteed any more (for example when catching unexpected exceptions that indicate a bug or an unexpected call race), and where a full restart is the safe way to get consistency back.

        Parameters:
        t - The exception that caused the failure.
      • notifySchedulerNgAboutInternalTaskFailure

        void notifySchedulerNgAboutInternalTaskFailure​(ExecutionAttemptID attemptId,
                                                       Throwable t,
                                                       boolean cancelTask,
                                                       boolean releasePartitions)
      • isDynamic

        boolean isDynamic()
      • getClusterPartitionShuffleDescriptors

        List<ShuffleDescriptor> getClusterPartitionShuffleDescriptors​(IntermediateDataSetID intermediateResultPartition)
        Get the shuffle descriptors of the cluster partitions ordered by partition number.
      • getJobVertexInputInfo

        JobVertexInputInfo getJobVertexInputInfo​(JobVertexID jobVertexId,
                                                 IntermediateDataSetID resultId)
        Get the input info of a certain input of a certain job vertex.
        Parameters:
        jobVertexId - the job vertex id
        resultId - the input(intermediate result) id
        Returns:
        the input info