Class WebSubmissionJobClient

  • All Implemented Interfaces:
    org.apache.flink.core.execution.JobClient

    @PublicEvolving
    public class WebSubmissionJobClient
    extends Object
    implements org.apache.flink.core.execution.JobClient
    A JobClient that only allows asking for the job id of the job it is attached to.

    This is used in web submission, where we do not want the Web UI to have jobs blocking threads while waiting for their completion.

    • Constructor Detail

      • WebSubmissionJobClient

        public WebSubmissionJobClient​(org.apache.flink.api.common.JobID jobId)
    • Method Detail

      • getJobID

        public org.apache.flink.api.common.JobID getJobID()
        Specified by:
        getJobID in interface org.apache.flink.core.execution.JobClient
      • getJobStatus

        public CompletableFuture<org.apache.flink.api.common.JobStatus> getJobStatus()
        Specified by:
        getJobStatus in interface org.apache.flink.core.execution.JobClient
      • cancel

        public CompletableFuture<Void> cancel()
        Specified by:
        cancel in interface org.apache.flink.core.execution.JobClient
      • stopWithSavepoint

        public CompletableFuture<String> stopWithSavepoint​(boolean advanceToEndOfEventTime,
                                                           @Nullable
                                                           String savepointDirectory,
                                                           org.apache.flink.core.execution.SavepointFormatType formatType)
        Specified by:
        stopWithSavepoint in interface org.apache.flink.core.execution.JobClient
      • triggerSavepoint

        public CompletableFuture<String> triggerSavepoint​(@Nullable
                                                          String savepointDirectory,
                                                          org.apache.flink.core.execution.SavepointFormatType formatType)
        Specified by:
        triggerSavepoint in interface org.apache.flink.core.execution.JobClient
      • getAccumulators

        public CompletableFuture<Map<String,​Object>> getAccumulators()
        Specified by:
        getAccumulators in interface org.apache.flink.core.execution.JobClient
      • getJobExecutionResult

        public CompletableFuture<org.apache.flink.api.common.JobExecutionResult> getJobExecutionResult()
        Specified by:
        getJobExecutionResult in interface org.apache.flink.core.execution.JobClient