@org.apache.hadoop.classification.InterfaceStability.Unstable - java examples

Here are the examples of the java api @org.apache.hadoop.classification.InterfaceStability.Unstable taken from open source projects. By voting up you can indicate which examples are most useful and appropriate.

155 Examples 7

19 View Complete Implementation : SCMUploaderCanUploadRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The request from the NodeManager to the <code>SharedCacheManager</code> that
 * requests whether it can upload a resource in the shared cache.
 * </p>
 */
@Private
@Unstable
public abstract clreplaced SCMUploaderCanUploadRequest {

    /**
     * Get the <code>key</code> of the resource that would be uploaded to the
     * shared cache.
     *
     * @return <code>key</code>
     */
    public abstract String getResourceKey();

    /**
     * Set the <code>key</code> of the resource that would be uploaded to the
     * shared cache.
     *
     * @param key unique identifier for the resource
     */
    public abstract void setResourceKey(String key);
}

19 View Complete Implementation : GetApplicationsRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the range of finish times to filter applications on
 *
 * @param begin beginning of the range
 * @param end end of the range
 * @throws IllegalArgumentException
 */
@Private
@Unstable
public abstract void setFinishRange(long begin, long end);

19 View Complete Implementation : GetContainersRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The request from clients to get a list of container reports, which belong to
 * an application attempt from the <code>ResourceManager</code>.
 * </p>
 *
 * @see ApplicationHistoryProtocol#getContainers(GetContainersRequest)
 */
@Public
@Unstable
public abstract clreplaced GetContainersRequest {

    @Public
    @Unstable
    public static GetContainersRequest newInstance(ApplicationAttemptId applicationAttemptId) {
        GetContainersRequest request = Records.newRecord(GetContainersRequest.clreplaced);
        request.setApplicationAttemptId(applicationAttemptId);
        return request;
    }

    /**
     * Get the <code>ApplicationAttemptId</code> of an application attempt.
     *
     * @return <code>ApplicationAttemptId</code> of an application attempt
     */
    @Public
    @Unstable
    public abstract ApplicationAttemptId getApplicationAttemptId();

    /**
     * Set the <code>ApplicationAttemptId</code> of an application attempt
     *
     * @param applicationAttemptId
     *          <code>ApplicationAttemptId</code> of an application attempt
     */
    @Public
    @Unstable
    public abstract void setApplicationAttemptId(ApplicationAttemptId applicationAttemptId);
}

19 View Complete Implementation : YarnClient.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The interface used by client to get node to labels mappings in existing cluster
 * </p>
 *
 * @return node to labels mappings
 * @throws YarnException
 * @throws IOException
 */
@Public
@Unstable
public abstract Map<NodeId, Set<NodeLabel>> getNodeToLabels() throws YarnException, IOException;

19 View Complete Implementation : UseSharedCacheResourceResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The response from the SharedCacheManager to the client that indicates whether
 * a requested resource exists in the cache.
 * </p>
 */
@Public
@Unstable
public abstract clreplaced UseSharedCacheResourceResponse {

    /**
     * Get the <code>Path</code> corresponding to the requested resource in the
     * shared cache.
     *
     * @return String A <code>Path</code> if the resource exists in the shared
     *         cache, <code>null</code> otherwise
     */
    @Public
    @Unstable
    public abstract String getPath();

    /**
     * Set the <code>Path</code> corresponding to a resource in the shared cache.
     *
     * @param p A <code>Path</code> corresponding to a resource in the shared
     *          cache
     */
    @Public
    @Unstable
    public abstract void setPath(String p);
}

19 View Complete Implementation : ResourceUtilization.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Add utilization to the current one.
 * @param pmem Physical memory used to add.
 * @param vmem Virtual memory used to add.
 * @param cpu CPU utilization to add.
 */
@Public
@Unstable
public void addTo(int pmem, int vmem, float cpu) {
    this.setPhysicalMemory(this.getPhysicalMemory() + pmem);
    this.setVirtualMemory(this.getVirtualMemory() + vmem);
    this.setCPU(this.getCPU() + cpu);
}

19 View Complete Implementation : RenewDelegationTokenRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * The request issued by the client to renew a delegation token from
 * the {@code ResourceManager}.
 */
@Private
@Unstable
public abstract clreplaced RenewDelegationTokenRequest {

    @Private
    @Unstable
    public static RenewDelegationTokenRequest newInstance(Token dToken) {
        RenewDelegationTokenRequest request = Records.newRecord(RenewDelegationTokenRequest.clreplaced);
        request.setDelegationToken(dToken);
        return request;
    }

    /**
     * Get the delegation token requested to be renewed by the client.
     * @return the delegation token requested to be renewed by the client.
     */
    @Private
    @Unstable
    public abstract Token getDelegationToken();

    @Private
    @Unstable
    public abstract void setDelegationToken(Token dToken);
}

19 View Complete Implementation : ServerProxy.java
Copyright Apache License 2.0
Author : aliyun-beta
@Public
@Unstable
public clreplaced ServerProxy {

    protected static RetryPolicy createRetryPolicy(Configuration conf, String maxWaitTimeStr, long defMaxWaitTime, String connectRetryIntervalStr, long defRetryInterval) {
        long maxWaitTime = conf.getLong(maxWaitTimeStr, defMaxWaitTime);
        long retryIntervalMS = conf.getLong(connectRetryIntervalStr, defRetryInterval);
        Preconditions.checkArgument((maxWaitTime == -1 || maxWaitTime > 0), "Invalid Configuration. " + maxWaitTimeStr + " should be either" + " positive value or -1.");
        Preconditions.checkArgument(retryIntervalMS > 0, "Invalid Configuration. " + connectRetryIntervalStr + "should be a positive value.");
        RetryPolicy retryPolicy = null;
        if (maxWaitTime == -1) {
            // wait forever.
            retryPolicy = RetryPolicies.retryForeverWithFixedSleep(retryIntervalMS, TimeUnit.MILLISECONDS);
        } else {
            retryPolicy = RetryPolicies.retryUpToMaximumTimeWithFixedSleep(maxWaitTime, retryIntervalMS, TimeUnit.MILLISECONDS);
        }
        Map<Clreplaced<? extends Exception>, RetryPolicy> exceptionToPolicyMap = new HashMap<Clreplaced<? extends Exception>, RetryPolicy>();
        exceptionToPolicyMap.put(EOFException.clreplaced, retryPolicy);
        exceptionToPolicyMap.put(ConnectException.clreplaced, retryPolicy);
        exceptionToPolicyMap.put(NoRouteToHostException.clreplaced, retryPolicy);
        exceptionToPolicyMap.put(UnknownHostException.clreplaced, retryPolicy);
        exceptionToPolicyMap.put(RetriableException.clreplaced, retryPolicy);
        exceptionToPolicyMap.put(SocketException.clreplaced, retryPolicy);
        exceptionToPolicyMap.put(NMNotYetReadyException.clreplaced, retryPolicy);
        return RetryPolicies.retryByException(RetryPolicies.TRY_ONCE_THEN_FAIL, exceptionToPolicyMap);
    }

    @SuppressWarnings("unchecked")
    protected static <T> T createRetriableProxy(final Configuration conf, final Clreplaced<T> protocol, final UserGroupInformation user, final YarnRPC rpc, final InetSocketAddress serverAddress, RetryPolicy retryPolicy) {
        T proxy = user.doAs(new PrivilegedAction<T>() {

            @Override
            public T run() {
                return (T) rpc.getProxy(protocol, serverAddress, conf);
            }
        });
        return (T) RetryProxy.create(protocol, proxy, retryPolicy);
    }
}

19 View Complete Implementation : HostUtil.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public clreplaced HostUtil {

    /**
     * Construct the taskLogUrl
     * @param taskTrackerHostName
     * @param httpPort
     * @param taskAttemptID
     * @return the taskLogUrl
     */
    public static String getTaskLogUrl(String scheme, String taskTrackerHostName, String httpPort, String taskAttemptID) {
        return (scheme + taskTrackerHostName + ":" + httpPort + "/tasklog?attemptid=" + taskAttemptID);
    }

    /**
     * Always throws {@link RuntimeException} because this method is not
     * supposed to be called at runtime. This method is only for keeping
     * binary compatibility with Hive 0.13. MAPREDUCE-5830 for the details.
     * @deprecated Use {@link #getTaskLogUrl(String, String, String, String)}
     * to construct the taskLogUrl.
     */
    @Deprecated
    public static String getTaskLogUrl(String taskTrackerHostName, String httpPort, String taskAttemptID) {
        throw new RuntimeException("This method is not supposed to be called at runtime. " + "Use HostUtil.getTaskLogUrl(String, String, String, String) instead.");
    }

    public static String convertTrackerNameToHostName(String trackerName) {
        // Ugly!
        // Convert the trackerName to its host name
        int indexOfColon = trackerName.indexOf(":");
        String trackerHostName = (indexOfColon == -1) ? trackerName : trackerName.substring(0, indexOfColon);
        return trackerHostName.substring("tracker_".length());
    }
}

19 View Complete Implementation : CheckForDecommissioningNodesResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public abstract clreplaced CheckForDecommissioningNodesResponse {

    @Private
    @Unstable
    public static CheckForDecommissioningNodesResponse newInstance(Set<NodeId> decommissioningNodes) {
        CheckForDecommissioningNodesResponse response = Records.newRecord(CheckForDecommissioningNodesResponse.clreplaced);
        response.setDecommissioningNodes(decommissioningNodes);
        return response;
    }

    public abstract void setDecommissioningNodes(Set<NodeId> decommissioningNodes);

    public abstract Set<NodeId> getDecommissioningNodes();
}

19 View Complete Implementation : IncreaseContainersResourceRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set container tokens to be used during container resource increase.
 * The token is acquired from
 * <code>AllocateResponse.getIncreasedContainers</code>.
 * The token contains the container id and resource capability required for
 * container resource increase.
 * @param containersToIncrease the list of container tokens to be used
 *                             for container resource increase.
 */
@Public
@Unstable
public abstract void setContainersToIncrease(List<Token> containersToIncrease);

19 View Complete Implementation : ReservationSubmissionResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the {@link ReservationId}, that corresponds to a valid resource
 * allocation in the scheduler (between start and end time of this
 * reservation)
 *
 * @return the {@link ReservationId} representing the unique id of the
 *         corresponding reserved resource allocation in the scheduler
 */
@Public
@Unstable
public abstract ReservationId getReservationId();

19 View Complete Implementation : RenewDelegationTokenResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * The response to a renewDelegationToken call to the {@code ResourceManager}.
 */
@Private
@Unstable
public abstract clreplaced RenewDelegationTokenResponse {

    @Private
    @Unstable
    public static RenewDelegationTokenResponse newInstance(long expTime) {
        RenewDelegationTokenResponse response = Records.newRecord(RenewDelegationTokenResponse.clreplaced);
        response.setNextExpirationTime(expTime);
        return response;
    }

    @Private
    @Unstable
    public abstract long getNextExpirationTime();

    @Private
    @Unstable
    public abstract void setNextExpirationTime(long expTime);
}

19 View Complete Implementation : ReservationDeleteRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the {@link ReservationId}, that corresponds to a valid resource
 * allocation in the scheduler (between start and end time of this
 * reservation)
 *
 * @return the {@link ReservationId} representing the unique id of the
 *         corresponding reserved resource allocation in the scheduler
 */
@Public
@Unstable
public abstract ReservationId getReservationId();

19 View Complete Implementation : ConfigurationProvider.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public abstract clreplaced ConfigurationProvider {

    public void init(Configuration bootstrapConf) throws Exception {
        initInternal(bootstrapConf);
    }

    public void close() throws Exception {
        closeInternal();
    }

    /**
     * Opens an InputStream at the indicated file
     * @param bootstrapConf Configuration
     * @param name The configuration file name
     * @return configuration
     * @throws YarnException
     * @throws IOException
     */
    public abstract InputStream getConfigurationInputStream(Configuration bootstrapConf, String name) throws YarnException, IOException;

    /**
     * Derived clreplacedes initialize themselves using this method.
     */
    public abstract void initInternal(Configuration bootstrapConf) throws Exception;

    /**
     * Derived clreplacedes close themselves using this method.
     */
    public abstract void closeInternal() throws Exception;
}

19 View Complete Implementation : RefreshClusterMaxPriorityRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public abstract clreplaced RefreshClusterMaxPriorityRequest {

    @Private
    @Unstable
    public static RefreshClusterMaxPriorityRequest newInstance() {
        RefreshClusterMaxPriorityRequest request = Records.newRecord(RefreshClusterMaxPriorityRequest.clreplaced);
        return request;
    }
}

19 View Complete Implementation : GetContainerReportRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The request sent by a client to the <code>ResourceManager</code> to get an
 * {@link ContainerReport} for a container.
 * </p>
 */
@Public
@Unstable
public abstract clreplaced GetContainerReportRequest {

    @Public
    @Unstable
    public static GetContainerReportRequest newInstance(ContainerId containerId) {
        GetContainerReportRequest request = Records.newRecord(GetContainerReportRequest.clreplaced);
        request.setContainerId(containerId);
        return request;
    }

    /**
     * Get the <code>ContainerId</code> of the Container.
     *
     * @return <code>ContainerId</code> of the Container
     */
    @Public
    @Unstable
    public abstract ContainerId getContainerId();

    /**
     * Set the <code>ContainerId</code> of the container
     *
     * @param containerId
     *          <code>ContainerId</code> of the container
     */
    @Public
    @Unstable
    public abstract void setContainerId(ContainerId containerId);
}

19 View Complete Implementation : RegisterApplicationMasterResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the list of NMTokens for communicating with the NMs where the the
 * containers of previous application attempts are running.
 *
 * @param nmTokens
 *          the list of NMTokens for communicating with the NMs where the
 *          containers of previous application attempts are running.
 */
@Private
@Unstable
public abstract void setNMTokensFromPreviousAttempts(List<NMToken> nmTokens);

19 View Complete Implementation : ReservationDeleteResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * {@link ReservationDeleteResponse} contains the answer of the admission
 * control system in the {@code ResourceManager} to a reservation delete
 * operation. Currently response is empty if the operation was successful, if
 * not an exception reporting reason for a failure.
 *
 * @see ReservationDefinition
 */
@Public
@Unstable
public abstract clreplaced ReservationDeleteResponse {

    @Private
    @Unstable
    public static ReservationDeleteResponse newInstance() {
        ReservationDeleteResponse response = Records.newRecord(ReservationDeleteResponse.clreplaced);
        return response;
    }
}

19 View Complete Implementation : ReservationSubmissionRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the name of the {@code Plan} that corresponds to the name of the
 * {@link QueueInfo} in the scheduler to which the reservation will be
 * submitted to
 *
 * @param queueName the name of the parent {@code Plan} that corresponds to
 *          the name of the {@link QueueInfo} in the scheduler to which the
 *          reservation will be submitted to
 */
@Public
@Unstable
public abstract void setQueue(String queueName);

19 View Complete Implementation : GetApplicationsRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the range of start times to filter applications on
 *
 * @param begin beginning of the range
 * @param end end of the range
 * @throws IllegalArgumentException
 */
@Private
@Unstable
public abstract void setStartRange(long begin, long end) throws IllegalArgumentException;

19 View Complete Implementation : ApplicationAttemptReport.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the <em>diagnositic information</em> of the application attempt in case
 * of errors.
 *
 * @return <em>diagnositic information</em> of the application attempt in case
 *         of errors
 */
@Public
@Unstable
public abstract String getDiagnostics();

19 View Complete Implementation : RegisterApplicationMasterResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the list of running containers as viewed by
 * <code>ResourceManager</code> from previous application attempts.
 *
 * @param containersFromPreviousAttempt
 *          the list of running containers as viewed by
 *          <code>ResourceManager</code> from previous application attempts.
 */
@Private
@Unstable
public abstract void setContainersFromPreviousAttempts(List<Container> containersFromPreviousAttempt);

19 View Complete Implementation : GetContainersResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get a list of <code>ContainerReport</code> for all the containers of an
 * application attempt.
 *
 * @return a list of <code>ContainerReport</code> for all the containers of an
 *         application attempt
 */
@Public
@Unstable
public abstract List<ContainerReport> getContainerList();

19 View Complete Implementation : RegisterApplicationMasterResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * Get the list of running containers as viewed by
 * <code>ResourceManager</code> from previous application attempts.
 * </p>
 *
 * @return the list of running containers as viewed by
 *         <code>ResourceManager</code> from previous application attempts
 * @see RegisterApplicationMasterResponse#getNMTokensFromPreviousAttempts()
 */
@Public
@Unstable
public abstract List<Container> getContainersFromPreviousAttempts();

19 View Complete Implementation : GetContainerReportResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The response sent by the <code>ResourceManager</code> to a client requesting
 * a container report.
 * </p>
 *
 * <p>
 * The response includes a {@link ContainerReport} which has details of a
 * container.
 * </p>
 */
@Public
@Unstable
public abstract clreplaced GetContainerReportResponse {

    @Public
    @Unstable
    public static GetContainerReportResponse newInstance(ContainerReport containerReport) {
        GetContainerReportResponse response = Records.newRecord(GetContainerReportResponse.clreplaced);
        response.setContainerReport(containerReport);
        return response;
    }

    /**
     * Get the <code>ContainerReport</code> for the container.
     *
     * @return <code>ContainerReport</code> for the container
     */
    @Public
    @Unstable
    public abstract ContainerReport getContainerReport();

    @Public
    @Unstable
    public abstract void setContainerReport(ContainerReport containerReport);
}

19 View Complete Implementation : ApplicationSubmissionContext.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the reservation id, that corresponds to a valid resource allocation in
 * the scheduler (between start and end time of the corresponding reservation)
 *
 * @return the reservation id representing the unique id of the corresponding
 *         reserved resource allocation in the scheduler
 */
@Public
@Unstable
public abstract ReservationId getReservationID();

19 View Complete Implementation : ReservationUpdateRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the {@link ReservationId}, that corresponds to a valid resource
 * allocation in the scheduler (between start and end time of this
 * reservation)
 *
 * @return the {@link ReservationId} representing the unique id of the
 *         corresponding reserved resource allocation in the scheduler
 */
@Public
@Unstable
public abstract ReservationId getReservationId();

19 View Complete Implementation : IncreaseContainersResourceResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the list of containerIds of containers whose resource
 * have been successfully increased.
 *
 * @return the list of containerIds of containers whose resource have
 * been successfully increased.
 */
@Public
@Unstable
public abstract List<ContainerId> getSuccessfullyIncreasedContainers();

19 View Complete Implementation : ReservationId.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Parse the string argument as a {@link ReservationId}
 *
 * @param reservationId the string representation of the {@link ReservationId}
 * @return the {@link ReservationId} corresponding to the input string if
 *         valid, null if input is null
 * @throws IOException if unable to parse the input string
 */
@Public
@Unstable
public static ReservationId parseReservationId(String reservationId) throws IOException {
    if (reservationId == null) {
        return null;
    }
    if (!reservationId.startsWith(reserveIdStrPrefix)) {
        throw new IOException("The specified reservation id is invalid: " + reservationId);
    }
    String[] resFields = reservationId.split("_");
    if (resFields.length != 3) {
        throw new IOException("The specified reservation id is not parseable: " + reservationId);
    }
    return newInstance(Long.parseLong(resFields[1]), Long.parseLong(resFields[2]));
}

19 View Complete Implementation : Records.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Convenient API record utils
 */
@LimitedPrivate({ "MapReduce", "YARN" })
@Unstable
public clreplaced Records {

    // The default record factory
    private static final RecordFactory factory = RecordFactoryProvider.getRecordFactory(null);

    public static <T> T newRecord(Clreplaced<T> cls) {
        return factory.newRecordInstance(cls);
    }
}

19 View Complete Implementation : YarnClient.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The interface used by client to get node labels in the cluster
 * </p>
 *
 * @return cluster node labels collection
 * @throws YarnException
 * @throws IOException
 */
@Public
@Unstable
public abstract List<NodeLabel> getClusterNodeLabels() throws YarnException, IOException;

19 View Complete Implementation : YarnClient.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The interface used by client to get labels to nodes mapping
 * for specified labels in existing cluster
 * </p>
 *
 * @param labels labels for which labels to nodes mapping has to be retrieved
 * @return labels to nodes mappings for specific labels
 * @throws YarnException
 * @throws IOException
 */
@Public
@Unstable
public abstract Map<NodeLabel, Set<NodeId>> getLabelsToNodes(Set<String> labels) throws YarnException, IOException;

19 View Complete Implementation : RunSharedCacheCleanerTaskRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The request from admin to ask the <code>SharedCacheManager</code> to run
 * cleaner service right away.
 * </p>
 *
 * <p>
 * Currently, this is empty.
 * </p>
 */
@Public
@Unstable
public abstract clreplaced RunSharedCacheCleanerTaskRequest {
}

19 View Complete Implementation : IncreaseContainersResourceRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get a list of container tokens to be used for authorization during
 * container resource increase.
 * <p>
 * Note: {@link NMToken} will be used for authenticating communication with
 * {@code NodeManager}.
 * @return the list of container tokens to be used for authorization during
 * container resource increase.
 * @see NMToken
 */
@Public
@Unstable
public abstract List<Token> getContainersToIncrease();

19 View Complete Implementation : DirectTimelineWriter.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * A simple writer clreplaced for storing Timeline data into Leveldb store.
 */
@Private
@Unstable
public clreplaced DirectTimelineWriter extends TimelineWriter {

    private static final Log LOG = LogFactory.getLog(DirectTimelineWriter.clreplaced);

    public DirectTimelineWriter(UserGroupInformation authUgi, Client client, URI resURI) {
        super(authUgi, client, resURI);
    }

    @Override
    public TimelinePutResponse putEnreplacedies(ApplicationAttemptId appAttemptId, TimelineEnreplacedyGroupId groupId, TimelineEnreplacedy... enreplacedies) throws IOException, YarnException {
        throw new IOException("Not supported");
    }

    @Override
    public void putDomain(ApplicationAttemptId appAttemptId, TimelineDomain domain) throws IOException, YarnException {
        throw new IOException("Not supported");
    }
}

19 View Complete Implementation : GetApplicationsRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the application states to filter applications on
 *
 * @param applicationStates
 * A Set of Application states to filter on.
 * If not defined, match all running applications
 */
@Private
@Unstable
public abstract void setApplicationStates(EnumSet<YarnApplicationState> applicationStates);

19 View Complete Implementation : YarnRuntimeException.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Base Yarn Exception.
 *
 * NOTE: All derivatives of this exception, which may be thrown by a remote
 * service, must include a String only constructor for the exception to be
 * unwrapped on the client.
 */
@LimitedPrivate({ "MapReduce", "YARN" })
@Unstable
public clreplaced YarnRuntimeException extends RuntimeException {

    private static final long serialVersionUID = -7153142425412203936L;

    public YarnRuntimeException(Throwable cause) {
        super(cause);
    }

    public YarnRuntimeException(String message) {
        super(message);
    }

    public YarnRuntimeException(String message, Throwable cause) {
        super(message, cause);
    }
}

19 View Complete Implementation : ReservationRequests.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the {@link ReservationRequestInterpreter}, representing how the list of
 * resources should be allocated, this captures temporal ordering and other
 * constraints.
 *
 * @return the list of {@link ReservationRequestInterpreter}
 */
@Public
@Unstable
public abstract ReservationRequestInterpreter getInterpreter();

19 View Complete Implementation : CheckForDecommissioningNodesRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public abstract clreplaced CheckForDecommissioningNodesRequest {

    @Private
    @Unstable
    public static CheckForDecommissioningNodesRequest newInstance() {
        CheckForDecommissioningNodesRequest request = Records.newRecord(CheckForDecommissioningNodesRequest.clreplaced);
        return request;
    }
}

19 View Complete Implementation : UseSharedCacheResourceResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the <code>Path</code> corresponding to the requested resource in the
 * shared cache.
 *
 * @return String A <code>Path</code> if the resource exists in the shared
 *         cache, <code>null</code> otherwise
 */
@Public
@Unstable
public abstract String getPath();

19 View Complete Implementation : FifoSchedulerMetrics.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public clreplaced FifoSchedulerMetrics extends SchedulerMetrics {

    public FifoSchedulerMetrics() {
        super();
    }

    @Override
    public void trackQueue(String queueName) {
        trackedQueues.add(queueName);
        FifoScheduler fifo = (FifoScheduler) scheduler;
        // for FifoScheduler, only DEFAULT_QUEUE
        // here the three parameters doesn't affect results
        final QueueInfo queue = fifo.getQueueInfo(queueName, false, false);
        // track currentCapacity, maximumCapacity (always 1.0f)
        metrics.register("variable.queue." + queueName + ".currentcapacity", new Gauge<Float>() {

            @Override
            public Float getValue() {
                return queue.getCurrentCapacity();
            }
        });
        metrics.register("variable.queue." + queueName + ".", new Gauge<Float>() {

            @Override
            public Float getValue() {
                return queue.getCurrentCapacity();
            }
        });
    }
}

19 View Complete Implementation : ReservationDefinition.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Set the deadline or the latest time by when the resource(s) must be
 * allocated. Time expressed as UTC.
 *
 * @param latestEndTime the deadline or the latest time by when the
 *          resource(s) should be allocated
 */
@Public
@Unstable
public abstract void setDeadline(long latestEndTime);

19 View Complete Implementation : LocalConfigurationProvider.java
Copyright Apache License 2.0
Author : aliyun-beta
@Private
@Unstable
public clreplaced LocalConfigurationProvider extends ConfigurationProvider {

    @Override
    public InputStream getConfigurationInputStream(Configuration bootstrapConf, String name) throws IOException, YarnException {
        if (name == null || name.isEmpty()) {
            throw new YarnException("Illegal argument! The parameter should not be null or empty");
        } else if (YarnConfiguration.RM_CONFIGURATION_FILES.contains(name)) {
            return bootstrapConf.getConfResourceAsInputStream(name);
        }
        return new FileInputStream(name);
    }

    @Override
    public void initInternal(Configuration bootstrapConf) throws Exception {
    // Do nothing
    }

    @Override
    public void closeInternal() throws Exception {
    // Do nothing
    }
}

19 View Complete Implementation : ReservationRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the duration in milliseconds for which the resource is required. A
 * default value of -1, indicates an unspecified lease duration, and fallback
 * to current behavior.
 *
 * @return the duration in milliseconds for which the resource is required
 */
@Public
@Unstable
public abstract long getDuration();

19 View Complete Implementation : ReleaseSharedCacheResourceResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The response to clients from the <code>SharedCacheManager</code> when
 * releasing a resource in the shared cache.
 * </p>
 *
 * <p>
 * Currently, this is empty.
 * </p>
 */
@Public
@Unstable
public abstract clreplaced ReleaseSharedCacheResourceResponse {
}

19 View Complete Implementation : Apps.java
Copyright Apache License 2.0
Author : aliyun-beta
@Public
@Unstable
public static void addToEnvironment(Map<String, String> environment, String variable, String value, String clreplacedPathSeparator) {
    String val = environment.get(variable);
    if (val == null) {
        val = value;
    } else {
        val = val + clreplacedPathSeparator + value;
    }
    environment.put(StringInterner.weakIntern(variable), StringInterner.weakIntern(val));
}

19 View Complete Implementation : ReservationDefinition.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * Get the deadline or the latest time by when the resource(s) must be
 * allocated. Time expressed as UTC.
 *
 * @return the deadline or the latest time by when the resource(s) must be
 *         allocated
 */
@Public
@Unstable
public abstract long getDeadline();

19 View Complete Implementation : AddToClusterNodeLabelsRequest.java
Copyright Apache License 2.0
Author : aliyun-beta
@Public
@Unstable
public abstract clreplaced AddToClusterNodeLabelsRequest {

    @Public
    @Unstable
    public static AddToClusterNodeLabelsRequest newInstance(List<NodeLabel> NodeLabels) {
        AddToClusterNodeLabelsRequest request = Records.newRecord(AddToClusterNodeLabelsRequest.clreplaced);
        request.setNodeLabels(NodeLabels);
        return request;
    }

    @Public
    @Unstable
    public abstract void setNodeLabels(List<NodeLabel> NodeLabels);

    @Public
    @Unstable
    public abstract List<NodeLabel> getNodeLabels();
}

19 View Complete Implementation : UpdateApplicationPriorityResponse.java
Copyright Apache License 2.0
Author : aliyun-beta
/**
 * <p>
 * The response sent by the <code>ResourceManager</code> to the client on update
 * the application priority.
 * </p>
 * <p>
 * A response without exception means that the move has completed successfully.
 * </p>
 *
 * @see ApplicationClientProtocol#updateApplicationPriority(UpdateApplicationPriorityRequest)
 */
@Public
@Unstable
public abstract clreplaced UpdateApplicationPriorityResponse {

    public static UpdateApplicationPriorityResponse newInstance(Priority priority) {
        UpdateApplicationPriorityResponse response = Records.newRecord(UpdateApplicationPriorityResponse.clreplaced);
        response.setApplicationPriority(priority);
        return response;
    }

    /**
     * Get the <code>Priority</code> of the application to be set.
     * @return Updated <code>Priority</code> of the application.
     */
    public abstract Priority getApplicationPriority();

    /**
     * Set the <code>Priority</code> of the application.
     *
     * @param priority <code>Priority</code> of the application
     */
    public abstract void setApplicationPriority(Priority priority);
}