Class MiniClusterJobClient

    • 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 terminate,
                                                           @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
      • sendCoordinationRequest

        public CompletableFuture<CoordinationResponse> sendCoordinationRequest​(String operatorUid,
                                                                               CoordinationRequest request)
        Description copied from interface: CoordinationRequestGateway
        Send out a request to a specified coordinator and return the response.

        On the client side, a unique operatorUid must be defined to identify an operator. Otherwise, the query cannot be executed correctly. Note that we use operatorUid instead of operatorID because the latter is an internal runtime concept that cannot be recognized by the client.

        Specified by:
        sendCoordinationRequest in interface CoordinationRequestGateway
        Parameters:
        operatorUid - specifies which coordinator to receive the request
        request - the request to send
        Returns:
        the response from the coordinator
      • reportHeartbeat

        public void reportHeartbeat​(long expiredTimestamp)
        Specified by:
        reportHeartbeat in interface org.apache.flink.core.execution.JobClient