瀏覽代碼

HADOOP-12087. [JDK8] Fix javadoc errors caused by incorrect or illegal tags. (Akira AJISAKA via stevel).

Steve Loughran 9 年之前
父節點
當前提交
7269906254

+ 2 - 1
hadoop-common-project/hadoop-auth/src/main/java/org/apache/hadoop/security/authentication/server/AuthenticationToken.java

@@ -62,7 +62,8 @@ public class AuthenticationToken extends AuthToken {
   /**
    * Sets the max inactive time of the token.
    *
-   * @param max inactive time of the token in milliseconds since the epoch.
+   * @param maxInactives inactive time of the token in milliseconds
+   *                     since the epoch.
    */
   public void setMaxInactives(long maxInactives) {
     if (this != AuthenticationToken.ANONYMOUS) {

+ 3 - 0
hadoop-common-project/hadoop-common/CHANGES.txt

@@ -1060,6 +1060,9 @@ Release 2.8.0 - UNRELEASED
     HADOOP-12348. MetricsSystemImpl creates MetricsSourceAdapter with wrong
     time unit parameter. (zxu via rkanter)
 
+    HADOOP-12087. [JDK8] Fix javadoc errors caused by incorrect or illegal
+    tags. (Akira AJISAKA via stevel).
+
   OPTIMIZATIONS
 
     HADOOP-12051. ProtobufRpcEngine.invoke() should use Exception.toString()

+ 10 - 9
hadoop-tools/hadoop-distcp/src/main/java/org/apache/hadoop/tools/util/ProducerConsumer.java

@@ -32,9 +32,10 @@ import java.util.concurrent.LinkedBlockingQueue;
 
 /**
  * ProducerConsumer class encapsulates input and output queues and a
- * thread-pool of Workers that loop on WorkRequest<T> inputQueue and for each
- * consumed WorkRequest Workers invoke WorkRequestProcessor.processItem()
- * and output resulting WorkReport<R> to the outputQueue.
+ * thread-pool of Workers that loop on WorkRequest{@literal <T>} inputQueue
+ * and for each consumed WorkRequest Workers invoke
+ * WorkRequestProcessor.processItem() and output resulting
+ * WorkReport{@literal <R>} to the outputQueue.
  */
 public class ProducerConsumer<T, R> {
   private Log LOG = LogFactory.getLog(ProducerConsumer.class);
@@ -57,9 +58,9 @@ public class ProducerConsumer<T, R> {
   }
 
   /**
-   *  Add another worker that will consume WorkRequest<T> items from input
-   *  queue, process each item using supplied processor, and for every
-   *  processed item output WorkReport<R> to output queue.
+   *  Add another worker that will consume WorkRequest{@literal <T>} items
+   *  from input queue, process each item using supplied processor, and for
+   *  every processed item output WorkReport{@literal <R>} to output queue.
    *
    *  @param processor  Processor implementing WorkRequestProcessor interface.
    *
@@ -102,7 +103,7 @@ public class ProducerConsumer<T, R> {
   /**
    *  Blocking put workRequest to ProducerConsumer input queue.
    *
-   *  @param  WorkRequest<T> item to be processed.
+   *  @param  workRequest item to be processed.
    */
   public void put(WorkRequest<T> workRequest) {
     boolean isDone = false;
@@ -120,7 +121,7 @@ public class ProducerConsumer<T, R> {
   /**
    *  Blocking take from ProducerConsumer output queue that can be interrupted.
    *
-   *  @return  WorkReport<R> item returned by processor's processItem().
+   *  @return  item returned by processor's processItem().
    */
   public WorkReport<R> take() throws InterruptedException {
     WorkReport<R> report = outputQueue.take();
@@ -132,7 +133,7 @@ public class ProducerConsumer<T, R> {
    *  Blocking take from ProducerConsumer output queue (catches exceptions and
    *  retries forever).
    *
-   *  @return  WorkReport<R> item returned by processor's processItem().
+   *  @return  item returned by processor's processItem().
    */
   public WorkReport<R> blockingTake() {
     while (true) {

+ 1 - 1
hadoop-tools/hadoop-distcp/src/main/java/org/apache/hadoop/tools/util/WorkReport.java

@@ -19,7 +19,7 @@
 package org.apache.hadoop.tools.util;
 
 /**
- *  WorkReport<T> is a simple container for items of class T and its
+ *  WorkReport{@literal <T>} is a simple container for items of class T and its
  *  corresponding retry counter that indicates how many times this item
  *  was previously attempted to be processed.
  */

+ 1 - 1
hadoop-tools/hadoop-distcp/src/main/java/org/apache/hadoop/tools/util/WorkRequest.java

@@ -19,7 +19,7 @@
 package org.apache.hadoop.tools.util;
 
 /**
- *  WorkRequest<T> is a simple container for items of class T and its
+ *  WorkRequest{@literal <T>} is a simple container for items of class T and its
  *  corresponding retry counter that indicates how many times this item
  *  was previously attempted to be processed.
  */

+ 1 - 1
hadoop-yarn-project/hadoop-yarn/hadoop-yarn-api/src/main/java/org/apache/hadoop/yarn/api/records/ApplicationReport.java

@@ -404,7 +404,7 @@ public abstract class ApplicationReport {
   public abstract boolean isUnmanagedApp();
 
   /**
-   * @param value true if RM should not manage the AM
+   * @param unmanagedApplication true if RM should not manage the AM
    */
   @Public
   @Unstable

+ 0 - 1
hadoop-yarn-project/hadoop-yarn/hadoop-yarn-api/src/main/java/org/apache/hadoop/yarn/server/api/ContainerType.java

@@ -27,7 +27,6 @@ package org.apache.hadoop.yarn.server.api;
  * <li>{@link #APPLICATION_MASTER}
  * <li>{@link #TASK}
  * </ul>
- * </p>
  */
 public enum ContainerType {
   APPLICATION_MASTER, TASK

+ 1 - 1
hadoop-yarn-project/hadoop-yarn/hadoop-yarn-common/src/main/java/org/apache/hadoop/yarn/nodelabels/CommonNodeLabelsManager.java

@@ -827,7 +827,7 @@ public class CommonNodeLabelsManager extends AbstractService {
   /**
    * Get mapping of labels info to nodes for specified set of labels.
    *
-   * @param nodelabels
+   * @param labels
    *          set of nodelabels for which labels to nodes mapping will be
    *          returned.
    * @return labels to nodes map

+ 1 - 1
hadoop-yarn-project/hadoop-yarn/hadoop-yarn-server/hadoop-yarn-server-common/src/main/java/org/apache/hadoop/yarn/server/api/records/NodeStatus.java

@@ -46,7 +46,7 @@ public abstract class NodeStatus {
    * @param containerStatuses Status of the containers running in this node.
    * @param keepAliveApplications Applications to keep alive.
    * @param nodeHealthStatus Health status of the node.
-   * @param containersUtilizations Utilization of the containers in this node.
+   * @param containersUtilization Utilization of the containers in this node.
    * @param nodeUtilization Utilization of the node.
    * @return New {@code NodeStatus} with the provided information.
    */

+ 1 - 1
hadoop-yarn-project/hadoop-yarn/hadoop-yarn-server/hadoop-yarn-server-resourcemanager/src/main/java/org/apache/hadoop/yarn/server/resourcemanager/scheduler/policy/OrderingPolicy.java

@@ -107,7 +107,7 @@ public interface OrderingPolicy<S extends SchedulableEntity> {
   void demandUpdated(S schedulableEntity);
 
   /**
-   * Display information regarding configuration & status
+   * Display information regarding configuration and status
    */
   public String getInfo();