You are viewing a plain text version of this content. The canonical link for it is here.
Posted to common-commits@hadoop.apache.org by sz...@apache.org on 2008/11/26 19:17:25 UTC

svn commit: r720930 - in /hadoop/core/trunk: ./ src/contrib/data_join/src/java/org/apache/hadoop/contrib/utils/join/ src/core/org/apache/hadoop/conf/ src/core/org/apache/hadoop/fs/ src/core/org/apache/hadoop/util/ src/examples/org/apache/hadoop/example...

Author: szetszwo
Date: Wed Nov 26 10:17:24 2008
New Revision: 720930

URL: http://svn.apache.org/viewvc?rev=720930&view=rev
Log:
HADOOP-4704. Fix javadoc typos "the the". (szetszwo)

Modified:
    hadoop/core/trunk/CHANGES.txt
    hadoop/core/trunk/src/contrib/data_join/src/java/org/apache/hadoop/contrib/utils/join/ResetableIterator.java
    hadoop/core/trunk/src/core/org/apache/hadoop/conf/Configuration.java
    hadoop/core/trunk/src/core/org/apache/hadoop/fs/HarFileSystem.java
    hadoop/core/trunk/src/core/org/apache/hadoop/util/NativeCodeLoader.java
    hadoop/core/trunk/src/examples/org/apache/hadoop/examples/dancing/DancingLinks.java
    hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/protocol/QuotaExceededException.java
    hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/FSNamesystem.java
    hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/ReplicationTargetChooser.java
    hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/JobQueueJobInProgressListener.java
    hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/jobcontrol/JobControl.java
    hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/lib/MultipleOutputs.java
    hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/pipes/BinaryProtocol.java
    hadoop/core/trunk/src/test/org/apache/hadoop/fs/loadGenerator/LoadGenerator.java
    hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/MiniDFSCluster.java
    hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/TestDFSPermission.java
    hadoop/core/trunk/src/test/org/apache/hadoop/mapred/MRCaching.java

Modified: hadoop/core/trunk/CHANGES.txt
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/CHANGES.txt?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/CHANGES.txt (original)
+++ hadoop/core/trunk/CHANGES.txt Wed Nov 26 10:17:24 2008
@@ -219,6 +219,8 @@
     name "value", so the counter values can not be seen. (Jason Attributor
     and Brian Bockelman via stack)
 
+    HADOOP-4704. Fix javadoc typos "the the". (szetszwo)
+
 Release 0.19.1 - Unreleased
 
   BUG FIXES

Modified: hadoop/core/trunk/src/contrib/data_join/src/java/org/apache/hadoop/contrib/utils/join/ResetableIterator.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/contrib/data_join/src/java/org/apache/hadoop/contrib/utils/join/ResetableIterator.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/contrib/data_join/src/java/org/apache/hadoop/contrib/utils/join/ResetableIterator.java (original)
+++ hadoop/core/trunk/src/contrib/data_join/src/java/org/apache/hadoop/contrib/utils/join/ResetableIterator.java Wed Nov 26 10:17:24 2008
@@ -22,12 +22,9 @@
 import java.util.Iterator;
 
 /**
- * This interface defines an iterator interface that will help the reducer class
- * for re-grouping the values in the values iterator of the reduce method
- * according the their source tags. Once the value re-grouped, the reducer can
- * perform the cross product over the values in different groups.
- * 
- * 
+ * This defines an iterator interface that will help the reducer class
+ * re-group its input by source tags. Once the values are re-grouped,
+ * the reducer will receive the cross product of values from different groups.
  */
 public interface ResetableIterator extends Iterator {
   public void reset();

Modified: hadoop/core/trunk/src/core/org/apache/hadoop/conf/Configuration.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/core/org/apache/hadoop/conf/Configuration.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/core/org/apache/hadoop/conf/Configuration.java (original)
+++ hadoop/core/trunk/src/core/org/apache/hadoop/conf/Configuration.java Wed Nov 26 10:17:24 2008
@@ -1153,9 +1153,9 @@
   }
 
   /** 
-   * Set the quiteness-mode. 
+   * Set the quietness-mode. 
    * 
-   * In the the quite-mode error and informational messages might not be logged.
+   * In the quiet-mode, error and informational messages might not be logged.
    * 
    * @param quietmode <code>true</code> to set quiet-mode on, <code>false</code>
    *              to turn it off.

Modified: hadoop/core/trunk/src/core/org/apache/hadoop/fs/HarFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/core/org/apache/hadoop/fs/HarFileSystem.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/core/org/apache/hadoop/fs/HarFileSystem.java (original)
+++ hadoop/core/trunk/src/core/org/apache/hadoop/fs/HarFileSystem.java Wed Nov 26 10:17:24 2008
@@ -518,7 +518,7 @@
   @Override
   public FileStatus getFileStatus(Path f) throws IOException {
     FileStatus archiveStatus = fs.getFileStatus(archiveIndex);
-    // get the fs DataInputStream for the the underlying file
+    // get the fs DataInputStream for the underlying file
     // look up the index.
     Path p = makeQualified(f);
     Path harPath = getPathInHar(p);
@@ -547,7 +547,7 @@
    */
   @Override
   public FSDataInputStream open(Path f, int bufferSize) throws IOException {
-    // get the fs DataInputStream for the the underlying file
+    // get the fs DataInputStream for the underlying file
     // look up the index.
     Path p = makeQualified(f);
     Path harPath = getPathInHar(p);

Modified: hadoop/core/trunk/src/core/org/apache/hadoop/util/NativeCodeLoader.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/core/org/apache/hadoop/util/NativeCodeLoader.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/core/org/apache/hadoop/util/NativeCodeLoader.java (original)
+++ hadoop/core/trunk/src/core/org/apache/hadoop/util/NativeCodeLoader.java Wed Nov 26 10:17:24 2008
@@ -25,7 +25,7 @@
 /**
  * A helper to load the native hadoop code i.e. libhadoop.so.
  * This handles the fallback to either the bundled libhadoop-Linux-i386-32.so
- * or the the default java implementations where appropriate.
+ * or the default java implementations where appropriate.
  *  
  */
 public class NativeCodeLoader {

Modified: hadoop/core/trunk/src/examples/org/apache/hadoop/examples/dancing/DancingLinks.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/examples/org/apache/hadoop/examples/dancing/DancingLinks.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/examples/org/apache/hadoop/examples/dancing/DancingLinks.java (original)
+++ hadoop/core/trunk/src/examples/org/apache/hadoop/examples/dancing/DancingLinks.java Wed Nov 26 10:17:24 2008
@@ -275,7 +275,7 @@
   }
   
   /**
-   * Find a solution the the problem.
+   * Find a solution to the problem.
    * @param partial a temporary datastructure to keep the current partial 
    *                answer in
    * @param output the acceptor for the results that are found

Modified: hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/protocol/QuotaExceededException.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/protocol/QuotaExceededException.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/protocol/QuotaExceededException.java (original)
+++ hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/protocol/QuotaExceededException.java Wed Nov 26 10:17:24 2008
@@ -26,7 +26,7 @@
  * on number of files and directories) or a diskspace quota (limit on space 
  * taken by all the file under the directory tree). <br> <br>
  * 
- * The message for the exception specifies the the directory where the quota
+ * The message for the exception specifies the directory where the quota
  * was violated and actual quotas.
  */
 public final class QuotaExceededException extends IOException {

Modified: hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/FSNamesystem.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/FSNamesystem.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/FSNamesystem.java (original)
+++ hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/FSNamesystem.java Wed Nov 26 10:17:24 2008
@@ -2575,7 +2575,7 @@
                                  getReplication(timedOutItems[i]));
         }
       }
-      /* If we know the the target datanodes where the replication timedout,
+      /* If we know the target datanodes where the replication timedout,
        * we could invoke decBlocksScheduled() on it. Its ok for now.
        */
     }

Modified: hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/ReplicationTargetChooser.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/ReplicationTargetChooser.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/ReplicationTargetChooser.java (original)
+++ hadoop/core/trunk/src/hdfs/org/apache/hadoop/hdfs/server/namenode/ReplicationTargetChooser.java Wed Nov 26 10:17:24 2008
@@ -483,7 +483,7 @@
 
   /**
    * Verify that the block is replicated on at least 2 different racks
-   * if there is more than one rack in the the system.
+   * if there is more than one rack in the system.
    * 
    * @param lBlk block with locations
    * @param cluster 
@@ -499,7 +499,7 @@
 
   /**
    * Verify that the block is replicated on at least minRacks different racks
-   * if there is more than minRacks rack in the the system.
+   * if there is more than minRacks rack in the system.
    * 
    * @param lBlk block with locations
    * @param minRacks number of racks the block should be replicated to

Modified: hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/JobQueueJobInProgressListener.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/JobQueueJobInProgressListener.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/JobQueueJobInProgressListener.java (original)
+++ hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/JobQueueJobInProgressListener.java Wed Nov 26 10:17:24 2008
@@ -91,7 +91,7 @@
   }
 
   /**
-   * Returns a synchronized view of the the job queue.
+   * Returns a synchronized view of the job queue.
    */
   public Collection<JobInProgress> getJobQueue() {
     return jobQueue.values();

Modified: hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/jobcontrol/JobControl.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/jobcontrol/JobControl.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/jobcontrol/JobControl.java (original)
+++ hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/jobcontrol/JobControl.java Wed Nov 26 10:17:24 2008
@@ -148,7 +148,7 @@
 
   /**
    * Add a new job.
-   * @param aJob the the new job
+   * @param aJob the new job
    */
   synchronized public String addJob(Job aJob) {
     String id = this.getNextJobID();

Modified: hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/lib/MultipleOutputs.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/lib/MultipleOutputs.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/lib/MultipleOutputs.java (original)
+++ hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/lib/MultipleOutputs.java Wed Nov 26 10:17:24 2008
@@ -127,7 +127,7 @@
   private static final String COUNTERS_ENABLED = "mo.counters";
 
   /**
-   * Counters group used by the the counters of MultipleOutputs.
+   * Counters group used by the counters of MultipleOutputs.
    */
   private static final String COUNTERS_GROUP = MultipleOutputs.class.getName();
 

Modified: hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/pipes/BinaryProtocol.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/pipes/BinaryProtocol.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/pipes/BinaryProtocol.java (original)
+++ hadoop/core/trunk/src/mapred/org/apache/hadoop/mapred/pipes/BinaryProtocol.java Wed Nov 26 10:17:24 2008
@@ -205,7 +205,7 @@
 
   /**
    * Create a proxy object that will speak the binary protocol on a socket.
-   * Upward messages are passed on the the specified handler and downward
+   * Upward messages are passed on the specified handler and downward
    * downward messages are public methods on this object.
    * @param sock The socket to communicate on.
    * @param handler The handler for the received messages.

Modified: hadoop/core/trunk/src/test/org/apache/hadoop/fs/loadGenerator/LoadGenerator.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/test/org/apache/hadoop/fs/loadGenerator/LoadGenerator.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/test/org/apache/hadoop/fs/loadGenerator/LoadGenerator.java (original)
+++ hadoop/core/trunk/src/test/org/apache/hadoop/fs/loadGenerator/LoadGenerator.java Wed Nov 26 10:17:24 2008
@@ -38,7 +38,7 @@
  * different client loads.
  * It allows the user to generate different mixes of read, write,
  * and list requests by specifying the probabilities of read and
- * write. The user controls the the intensity of the load by
+ * write. The user controls the intensity of the load by
  * adjusting parameters for the number of worker threads and the delay
  * between operations. While load generators are running, the user
  * can profile and monitor the running of the NameNode. When a load

Modified: hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/MiniDFSCluster.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/MiniDFSCluster.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/MiniDFSCluster.java (original)
+++ hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/MiniDFSCluster.java Wed Nov 26 10:17:24 2008
@@ -771,7 +771,7 @@
   
   
   /**
-   * This method is valid only if the the data nodes have simulated data
+   * This method is valid only if the data nodes have simulated data
    * @param dataNodeIndex - data node i which to inject - the index is same as for getDataNodes()
    * @param blocksToInject - the blocks
    * @throws IOException
@@ -793,7 +793,7 @@
   }
   
   /**
-   * This method is valid only if the the data nodes have simulated data
+   * This method is valid only if the data nodes have simulated data
    * @param blocksToInject - blocksToInject[] is indexed in the same order as the list 
    *             of datanodes returned by getDataNodes()
    * @throws IOException

Modified: hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/TestDFSPermission.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/TestDFSPermission.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/TestDFSPermission.java (original)
+++ hadoop/core/trunk/src/test/org/apache/hadoop/hdfs/TestDFSPermission.java Wed Nov 26 10:17:24 2008
@@ -496,7 +496,7 @@
       }
     }
 
-    /* Log the the permissions and required permissions */
+    /** Log the permissions and required permissions */
     protected void logPermissions() {
       LOG.info("required ancestor permission:"
           + Integer.toOctalString(requiredAncestorPermission));

Modified: hadoop/core/trunk/src/test/org/apache/hadoop/mapred/MRCaching.java
URL: http://svn.apache.org/viewvc/hadoop/core/trunk/src/test/org/apache/hadoop/mapred/MRCaching.java?rev=720930&r1=720929&r2=720930&view=diff
==============================================================================
--- hadoop/core/trunk/src/test/org/apache/hadoop/mapred/MRCaching.java (original)
+++ hadoop/core/trunk/src/test/org/apache/hadoop/mapred/MRCaching.java Wed Nov 26 10:17:24 2008
@@ -205,7 +205,7 @@
     DistributedCache.addCacheArchive(uri6, conf);
     RunningJob job = JobClient.runJob(conf);
     int count = 0;
-    // after the job ran check to see if the the input from the localized cache
+    // after the job ran check to see if the input from the localized cache
     // match the real string. check if there are 3 instances or not.
     Path result = new Path(TEST_ROOT_DIR + "/test.txt");
     {