You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by tr...@apache.org on 2021/02/23 16:29:19 UTC

[flink] 01/03: [FLINK-11678][runtime] Removes unnecessary obsolete method overwriting

This is an automated email from the ASF dual-hosted git repository.

trohrmann pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit deddfa256af2f1a879eb8bea19a9f8645b96a4e3
Author: Matthias Pohl <ma...@ververica.com>
AuthorDate: Thu Feb 4 10:31:05 2021 +0100

    [FLINK-11678][runtime] Removes unnecessary obsolete method overwriting
    
    RestfulGateway provides the exact same method signature.
    DispatcherGateway.requestJob became obsolete with the changes made in ce49a904.
---
 .../flink/runtime/dispatcher/DispatcherGateway.java     | 17 -----------------
 1 file changed, 17 deletions(-)

diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/dispatcher/DispatcherGateway.java b/flink-runtime/src/main/java/org/apache/flink/runtime/dispatcher/DispatcherGateway.java
index eb7d9e3..31a42fd 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/dispatcher/DispatcherGateway.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/dispatcher/DispatcherGateway.java
@@ -21,10 +21,8 @@ package org.apache.flink.runtime.dispatcher;
 import org.apache.flink.api.common.JobID;
 import org.apache.flink.api.common.time.Time;
 import org.apache.flink.runtime.clusterframework.ApplicationStatus;
-import org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph;
 import org.apache.flink.runtime.jobgraph.JobGraph;
 import org.apache.flink.runtime.messages.Acknowledge;
-import org.apache.flink.runtime.messages.FlinkJobNotFoundException;
 import org.apache.flink.runtime.rpc.FencedRpcGateway;
 import org.apache.flink.runtime.rpc.RpcTimeout;
 import org.apache.flink.runtime.webmonitor.RestfulGateway;
@@ -60,21 +58,6 @@ public interface DispatcherGateway extends FencedRpcGateway<DispatcherId>, Restf
      */
     CompletableFuture<Integer> getBlobServerPort(@RpcTimeout Time timeout);
 
-    /**
-     * Requests the {@link ArchivedExecutionGraph} for the given jobId. If there is no such graph,
-     * then the future is completed with a {@link FlinkJobNotFoundException}.
-     *
-     * <p>Note: We enforce that the returned future contains a {@link ArchivedExecutionGraph} unlike
-     * the super interface.
-     *
-     * @param jobId identifying the job whose AccessExecutionGraph is requested
-     * @param timeout for the asynchronous operation
-     * @return Future containing the AccessExecutionGraph for the given jobId, otherwise {@link
-     *     FlinkJobNotFoundException}
-     */
-    @Override
-    CompletableFuture<ArchivedExecutionGraph> requestJob(JobID jobId, @RpcTimeout Time timeout);
-
     default CompletableFuture<Acknowledge> shutDownCluster(ApplicationStatus applicationStatus) {
         return shutDownCluster();
     }