All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.hadoop.yarn.api.ApplicationClientProtocol Maven / Gradle / Ivy

There is a newer version: 3.4.0
Show newest version
/**
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you under the Apache License, Version 2.0 (the
 * "License"); you may not use this file except in compliance
 * with the License.  You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

package org.apache.hadoop.yarn.api;

import java.io.IOException;

import org.apache.hadoop.classification.InterfaceAudience.Private;
import org.apache.hadoop.classification.InterfaceAudience.Public;
import org.apache.hadoop.classification.InterfaceStability.Stable;
import org.apache.hadoop.classification.InterfaceStability.Unstable;
import org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenRequest;
import org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse;
import org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoRequest;
import org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse;
import org.apache.hadoop.yarn.api.protocolrecords.KillApplicationRequest;
import org.apache.hadoop.yarn.api.protocolrecords.KillApplicationResponse;
import org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenRequest;
import org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenResponse;
import org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationRequest;
import org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationResponse;
import org.apache.hadoop.yarn.api.records.ApplicationId;
import org.apache.hadoop.yarn.api.records.ApplicationReport;
import org.apache.hadoop.yarn.api.records.ContainerLaunchContext;
import org.apache.hadoop.yarn.api.records.NodeReport;
import org.apache.hadoop.yarn.api.records.Resource;
import org.apache.hadoop.yarn.api.records.ResourceRequest;
import org.apache.hadoop.yarn.api.records.Token;
import org.apache.hadoop.yarn.api.records.YarnClusterMetrics;
import org.apache.hadoop.yarn.exceptions.YarnException;

/**
 * 

The protocol between clients and the ResourceManager * to submit/abort jobs and to get information on applications, cluster metrics, * nodes, queues and ACLs.

*/ @Public @Stable public interface ApplicationClientProtocol { /** *

The interface used by clients to obtain a new {@link ApplicationId} for * submitting new applications.

* *

The ResourceManager responds with a new, monotonically * increasing, {@link ApplicationId} which is used by the client to submit * a new application.

* *

The ResourceManager also responds with details such * as maximum resource capabilities in the cluster as specified in * {@link GetNewApplicationResponse}.

* * @param request request to get a new ApplicationId * @return response containing the new ApplicationId to be used * to submit an application * @throws YarnException * @throws IOException * @see #submitApplication(SubmitApplicationRequest) */ @Public @Stable public GetNewApplicationResponse getNewApplication( GetNewApplicationRequest request) throws YarnException, IOException; /** *

The interface used by clients to submit a new application to the * ResourceManager.

* *

The client is required to provide details such as queue, * {@link Resource} required to run the ApplicationMaster, * the equivalent of {@link ContainerLaunchContext} for launching * the ApplicationMaster etc. via the * {@link SubmitApplicationRequest}.

* *

Currently the ResourceManager sends an immediate (empty) * {@link SubmitApplicationResponse} on accepting the submission and throws * an exception if it rejects the submission. However, this call needs to be * followed by {@link #getApplicationReport(GetApplicationReportRequest)} * to make sure that the application gets properly submitted.

* *

In secure mode,the ResourceManager verifies access to * queues etc. before accepting the application submission.

* * @param request request to submit a new application * @return (empty) response on accepting the submission * @throws YarnException * @throws IOException * @throws InvalidResourceRequestException * The exception is thrown when a {@link ResourceRequest} is out of * the range of the configured lower and upper resource boundaries. * @see #getNewApplication(GetNewApplicationRequest) */ @Public @Stable public SubmitApplicationResponse submitApplication( SubmitApplicationRequest request) throws YarnException, IOException; /** *

The interface used by clients to request the * ResourceManager to abort submitted application.

* *

The client, via {@link KillApplicationRequest} provides the * {@link ApplicationId} of the application to be aborted.

* *

In secure mode,the ResourceManager verifies access to the * application, queue etc. before terminating the application.

* *

Currently, the ResourceManager returns an empty response * on success and throws an exception on rejecting the request.

* * @param request request to abort a submitted application * @return ResourceManager returns an empty response * on success and throws an exception on rejecting the request * @throws YarnException * @throws IOException * @see #getQueueUserAcls(GetQueueUserAclsInfoRequest) */ @Public @Stable public KillApplicationResponse forceKillApplication( KillApplicationRequest request) throws YarnException, IOException; /** *

The interface used by clients to get a report of an Application from * the ResourceManager.

* *

The client, via {@link GetApplicationReportRequest} provides the * {@link ApplicationId} of the application.

* *

In secure mode,the ResourceManager verifies access to the * application, queue etc. before accepting the request.

* *

The ResourceManager responds with a * {@link GetApplicationReportResponse} which includes the * {@link ApplicationReport} for the application.

* *

If the user does not have VIEW_APP access then the * following fields in the report will be set to stubbed values: *

    *
  • host - set to "N/A"
  • *
  • RPC port - set to -1
  • *
  • client token - set to "N/A"
  • *
  • diagnostics - set to "N/A"
  • *
  • tracking URL - set to "N/A"
  • *
  • original tracking URL - set to "N/A"
  • *
  • resource usage report - all values are -1
  • *

* * @param request request for an application report * @return application report * @throws YarnException * @throws IOException */ @Public @Stable public GetApplicationReportResponse getApplicationReport( GetApplicationReportRequest request) throws YarnException, IOException; /** *

The interface used by clients to get metrics about the cluster from * the ResourceManager.

* *

The ResourceManager responds with a * {@link GetClusterMetricsResponse} which includes the * {@link YarnClusterMetrics} with details such as number of current * nodes in the cluster.

* * @param request request for cluster metrics * @return cluster metrics * @throws YarnException * @throws IOException */ @Public @Stable public GetClusterMetricsResponse getClusterMetrics( GetClusterMetricsRequest request) throws YarnException, IOException; /** *

The interface used by clients to get a report of Applications * matching the filters defined by {@link GetApplicationsRequest} * in the cluster from the ResourceManager.

* *

The ResourceManager responds with a * {@link GetApplicationsResponse} which includes the * {@link ApplicationReport} for the applications.

* *

If the user does not have VIEW_APP access for an * application then the corresponding report will be filtered as * described in {@link #getApplicationReport(GetApplicationReportRequest)}. *

* * @param request request for report on applications * @return report on applications matching the given application types * defined in the request * @throws YarnException * @throws IOException * @see GetApplicationsRequest */ @Public @Stable public GetApplicationsResponse getApplications( GetApplicationsRequest request) throws YarnException, IOException; /** *

The interface used by clients to get a report of all nodes * in the cluster from the ResourceManager.

* *

The ResourceManager responds with a * {@link GetClusterNodesResponse} which includes the * {@link NodeReport} for all the nodes in the cluster.

* * @param request request for report on all nodes * @return report on all nodes * @throws YarnException * @throws IOException */ @Public @Stable public GetClusterNodesResponse getClusterNodes( GetClusterNodesRequest request) throws YarnException, IOException; /** *

The interface used by clients to get information about queues * from the ResourceManager.

* *

The client, via {@link GetQueueInfoRequest}, can ask for details such * as used/total resources, child queues, running applications etc.

* *

In secure mode,the ResourceManager verifies access before * providing the information.

* * @param request request to get queue information * @return queue information * @throws YarnException * @throws IOException */ @Public @Stable public GetQueueInfoResponse getQueueInfo( GetQueueInfoRequest request) throws YarnException, IOException; /** *

The interface used by clients to get information about queue * acls for current user from the ResourceManager. *

* *

The ResourceManager responds with queue acls for all * existing queues.

* * @param request request to get queue acls for current user * @return queue acls for current user * @throws YarnException * @throws IOException */ @Public @Stable public GetQueueUserAclsInfoResponse getQueueUserAcls( GetQueueUserAclsInfoRequest request) throws YarnException, IOException; /** *

The interface used by clients to get delegation token, enabling the * containers to be able to talk to the service using those tokens. * *

The ResourceManager responds with the delegation * {@link Token} that can be used by the client to speak to this * service. * @param request request to get a delegation token for the client. * @return delegation token that can be used to talk to this service * @throws YarnException * @throws IOException */ @Public @Stable public GetDelegationTokenResponse getDelegationToken( GetDelegationTokenRequest request) throws YarnException, IOException; /** * Renew an existing delegation {@link Token}. * * @param request the delegation token to be renewed. * @return the new expiry time for the delegation token. * @throws YarnException * @throws IOException */ @Private @Unstable public RenewDelegationTokenResponse renewDelegationToken( RenewDelegationTokenRequest request) throws YarnException, IOException; /** * Cancel an existing delegation {@link Token}. * * @param request the delegation token to be cancelled. * @return an empty response. * @throws YarnException * @throws IOException */ @Private @Unstable public CancelDelegationTokenResponse cancelDelegationToken( CancelDelegationTokenRequest request) throws YarnException, IOException; }





© 2015 - 2024 Weber Informatics LLC | Privacy Policy