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 su...@apache.org on 2012/08/25 03:03:34 UTC

svn commit: r1377168 [2/7] - in /hadoop/common/trunk/hadoop-common-project: hadoop-annotations/src/main/java/org/apache/hadoop/classification/tools/ hadoop-common/src/main/java/org/apache/hadoop/conf/ hadoop-common/src/main/java/org/apache/hadoop/fs/ h...

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFileSystem.java Sat Aug 25 01:03:22 2012
@@ -76,6 +76,7 @@ public class FilterFileSystem extends Fi
    *   for this FileSystem
    * @param conf the configuration
    */
+  @Override
   public void initialize(URI name, Configuration conf) throws IOException {
     super.initialize(name, conf);
     // this is less than ideal, but existing filesystems sometimes neglect
@@ -90,6 +91,7 @@ public class FilterFileSystem extends Fi
   }
 
   /** Returns a URI whose scheme and authority identify this FileSystem.*/
+  @Override
   public URI getUri() {
     return fs.getUri();
   }
@@ -104,6 +106,7 @@ public class FilterFileSystem extends Fi
   }
   
   /** Make sure that a path specifies a FileSystem. */
+  @Override
   public Path makeQualified(Path path) {
     Path fqPath = fs.makeQualified(path);
     // swap in our scheme if the filtered fs is using a different scheme
@@ -125,10 +128,12 @@ public class FilterFileSystem extends Fi
   ///////////////////////////////////////////////////////////////
 
   /** Check that a Path belongs to this FileSystem. */
+  @Override
   protected void checkPath(Path path) {
     fs.checkPath(path);
   }
 
+  @Override
   public BlockLocation[] getFileBlockLocations(FileStatus file, long start,
     long len) throws IOException {
       return fs.getFileBlockLocations(file, start, len);
@@ -143,17 +148,17 @@ public class FilterFileSystem extends Fi
    * @param f the file name to open
    * @param bufferSize the size of the buffer to be used.
    */
+  @Override
   public FSDataInputStream open(Path f, int bufferSize) throws IOException {
     return fs.open(f, bufferSize);
   }
 
-  /** {@inheritDoc} */
+  @Override
   public FSDataOutputStream append(Path f, int bufferSize,
       Progressable progress) throws IOException {
     return fs.append(f, bufferSize, progress);
   }
 
-  /** {@inheritDoc} */
   @Override
   public FSDataOutputStream create(Path f, FsPermission permission,
       boolean overwrite, int bufferSize, short replication, long blockSize,
@@ -171,6 +176,7 @@ public class FilterFileSystem extends Fi
    * @return true if successful;
    *         false if file does not exist or is a directory
    */
+  @Override
   public boolean setReplication(Path src, short replication) throws IOException {
     return fs.setReplication(src, replication);
   }
@@ -179,23 +185,23 @@ public class FilterFileSystem extends Fi
    * Renames Path src to Path dst.  Can take place on local fs
    * or remote DFS.
    */
+  @Override
   public boolean rename(Path src, Path dst) throws IOException {
     return fs.rename(src, dst);
   }
   
   /** Delete a file */
+  @Override
   public boolean delete(Path f, boolean recursive) throws IOException {
     return fs.delete(f, recursive);
   }
   
   /** List files in a directory. */
+  @Override
   public FileStatus[] listStatus(Path f) throws IOException {
     return fs.listStatus(f);
   }
 
-  /**
-   * {@inheritDoc}
-   */
   @Override
   public RemoteIterator<Path> listCorruptFileBlocks(Path path)
     throws IOException {
@@ -203,11 +209,13 @@ public class FilterFileSystem extends Fi
   }
 
   /** List files and its block locations in a directory. */
+  @Override
   public RemoteIterator<LocatedFileStatus> listLocatedStatus(Path f)
   throws IOException {
     return fs.listLocatedStatus(f);
   }
   
+  @Override
   public Path getHomeDirectory() {
     return fs.getHomeDirectory();
   }
@@ -219,6 +227,7 @@ public class FilterFileSystem extends Fi
    * 
    * @param newDir
    */
+  @Override
   public void setWorkingDirectory(Path newDir) {
     fs.setWorkingDirectory(newDir);
   }
@@ -228,21 +237,21 @@ public class FilterFileSystem extends Fi
    * 
    * @return the directory pathname
    */
+  @Override
   public Path getWorkingDirectory() {
     return fs.getWorkingDirectory();
   }
   
+  @Override
   protected Path getInitialWorkingDirectory() {
     return fs.getInitialWorkingDirectory();
   }
   
-  /** {@inheritDoc} */
   @Override
   public FsStatus getStatus(Path p) throws IOException {
     return fs.getStatus(p);
   }
   
-  /** {@inheritDoc} */
   @Override
   public boolean mkdirs(Path f, FsPermission permission) throws IOException {
     return fs.mkdirs(f, permission);
@@ -254,6 +263,7 @@ public class FilterFileSystem extends Fi
    * the given dst name.
    * delSrc indicates if the source should be removed
    */
+  @Override
   public void copyFromLocalFile(boolean delSrc, Path src, Path dst)
     throws IOException {
     fs.copyFromLocalFile(delSrc, src, dst);
@@ -264,6 +274,7 @@ public class FilterFileSystem extends Fi
    * the given dst name.
    * delSrc indicates if the source should be removed
    */
+  @Override
   public void copyFromLocalFile(boolean delSrc, boolean overwrite, 
                                 Path[] srcs, Path dst)
     throws IOException {
@@ -275,6 +286,7 @@ public class FilterFileSystem extends Fi
    * the given dst name.
    * delSrc indicates if the source should be removed
    */
+  @Override
   public void copyFromLocalFile(boolean delSrc, boolean overwrite, 
                                 Path src, Path dst)
     throws IOException {
@@ -286,6 +298,7 @@ public class FilterFileSystem extends Fi
    * Copy it from FS control to the local dst name.
    * delSrc indicates if the src will be removed or not.
    */   
+  @Override
   public void copyToLocalFile(boolean delSrc, Path src, Path dst)
     throws IOException {
     fs.copyToLocalFile(delSrc, src, dst);
@@ -297,6 +310,7 @@ public class FilterFileSystem extends Fi
    * file.  If the FS is local, we write directly into the target.  If
    * the FS is remote, we write into the tmp local area.
    */
+  @Override
   public Path startLocalOutput(Path fsOutputFile, Path tmpLocalFile)
     throws IOException {
     return fs.startLocalOutput(fsOutputFile, tmpLocalFile);
@@ -308,12 +322,14 @@ public class FilterFileSystem extends Fi
    * FS will copy the contents of tmpLocalFile to the correct target at
    * fsOutputFile.
    */
+  @Override
   public void completeLocalOutput(Path fsOutputFile, Path tmpLocalFile)
     throws IOException {
     fs.completeLocalOutput(fsOutputFile, tmpLocalFile);
   }
 
   /** Return the total size of all files in the filesystem.*/
+  @Override
   public long getUsed() throws IOException{
     return fs.getUsed();
   }
@@ -357,16 +373,17 @@ public class FilterFileSystem extends Fi
   /**
    * Get file status.
    */
+  @Override
   public FileStatus getFileStatus(Path f) throws IOException {
     return fs.getFileStatus(f);
   }
 
-  /** {@inheritDoc} */
+  @Override
   public FileChecksum getFileChecksum(Path f) throws IOException {
     return fs.getFileChecksum(f);
   }
   
-  /** {@inheritDoc} */
+  @Override
   public void setVerifyChecksum(boolean verifyChecksum) {
     fs.setVerifyChecksum(verifyChecksum);
   }
@@ -387,21 +404,18 @@ public class FilterFileSystem extends Fi
     fs.close();
   }
 
-  /** {@inheritDoc} */
   @Override
   public void setOwner(Path p, String username, String groupname
       ) throws IOException {
     fs.setOwner(p, username, groupname);
   }
 
-  /** {@inheritDoc} */
   @Override
   public void setTimes(Path p, long mtime, long atime
       ) throws IOException {
     fs.setTimes(p, mtime, atime);
   }
 
-  /** {@inheritDoc} */
   @Override
   public void setPermission(Path p, FsPermission permission
       ) throws IOException {

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFs.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFs.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFs.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FilterFs.java Sat Aug 25 01:03:22 2012
@@ -174,9 +174,6 @@ public abstract class FilterFs extends A
     return myFs.listStatus(f);
   }
 
-  /**
-   * {@inheritDoc}
-   */
   @Override
   public RemoteIterator<Path> listCorruptFileBlocks(Path path)
     throws IOException {

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsServerDefaults.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsServerDefaults.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsServerDefaults.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsServerDefaults.java Sat Aug 25 01:03:22 2012
@@ -39,6 +39,7 @@ public class FsServerDefaults implements
 
   static { // register a ctor
     WritableFactories.setFactory(FsServerDefaults.class, new WritableFactory() {
+      @Override
       public Writable newInstance() {
         return new FsServerDefaults();
       }
@@ -106,6 +107,7 @@ public class FsServerDefaults implements
   // /////////////////////////////////////////
   // Writable
   // /////////////////////////////////////////
+  @Override
   @InterfaceAudience.Private
   public void write(DataOutput out) throws IOException {
     out.writeLong(blockSize);
@@ -116,6 +118,7 @@ public class FsServerDefaults implements
     WritableUtils.writeEnum(out, checksumType);
   }
 
+  @Override
   @InterfaceAudience.Private
   public void readFields(DataInput in) throws IOException {
     blockSize = in.readLong();

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsShell.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsShell.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsShell.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsShell.java Sat Aug 25 01:03:22 2012
@@ -236,6 +236,7 @@ public class FsShell extends Configured 
   /**
    * run
    */
+  @Override
   public int run(String argv[]) throws Exception {
     // initialize FsShell
     init();

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsStatus.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsStatus.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsStatus.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsStatus.java Sat Aug 25 01:03:22 2012
@@ -60,12 +60,14 @@ public class FsStatus implements Writabl
   //////////////////////////////////////////////////
   // Writable
   //////////////////////////////////////////////////
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeLong(capacity);
     out.writeLong(used);
     out.writeLong(remaining);
   }
 
+  @Override
   public void readFields(DataInput in) throws IOException {
     capacity = in.readLong();
     used = in.readLong();

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlConnection.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlConnection.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlConnection.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlConnection.java Sat Aug 25 01:03:22 2012
@@ -53,7 +53,6 @@ class FsUrlConnection extends URLConnect
     }
   }
 
-  /* @inheritDoc */
   @Override
   public InputStream getInputStream() throws IOException {
     if (is == null) {

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlStreamHandlerFactory.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlStreamHandlerFactory.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlStreamHandlerFactory.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/FsUrlStreamHandlerFactory.java Sat Aug 25 01:03:22 2012
@@ -59,6 +59,7 @@ public class FsUrlStreamHandlerFactory i
     this.handler = new FsUrlStreamHandler(this.conf);
   }
 
+  @Override
   public java.net.URLStreamHandler createURLStreamHandler(String protocol) {
     if (!protocols.containsKey(protocol)) {
       boolean known = true;

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/GlobFilter.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/GlobFilter.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/GlobFilter.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/GlobFilter.java Sat Aug 25 01:03:22 2012
@@ -31,6 +31,7 @@ import org.apache.hadoop.classification.
 @InterfaceStability.Evolving
 public class GlobFilter implements PathFilter {
   private final static PathFilter DEFAULT_FILTER = new PathFilter() {
+      @Override
       public boolean accept(Path file) {
         return true;
       }
@@ -75,6 +76,7 @@ public class GlobFilter implements PathF
     return pattern.hasWildcard();
   }
 
+  @Override
   public boolean accept(Path path) {
     return pattern.matches(path.getName()) && userFilter.accept(path);
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/HarFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/HarFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/HarFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/HarFileSystem.java Sat Aug 25 01:03:22 2012
@@ -106,6 +106,7 @@ public class HarFileSystem extends Filte
    * har:///archivepath. This assumes the underlying filesystem
    * to be used in case not specified.
    */
+  @Override
   public void initialize(URI name, Configuration conf) throws IOException {
     // decode the name
     URI underLyingURI = decodeHarURI(name, conf);
@@ -247,6 +248,7 @@ public class HarFileSystem extends Filte
   /**
    * return the top level archive.
    */
+  @Override
   public Path getWorkingDirectory() {
     return new Path(uri.toString());
   }
@@ -636,6 +638,7 @@ public class HarFileSystem extends Filte
   /**
    * @return null since no checksum algorithm is implemented.
    */
+  @Override
   public FileChecksum getFileChecksum(Path f) {
     return null;
   }
@@ -668,6 +671,7 @@ public class HarFileSystem extends Filte
     throw new IOException("Har: Create not allowed");
   }
   
+  @Override
   public FSDataOutputStream create(Path f,
       FsPermission permission,
       boolean overwrite,
@@ -735,10 +739,12 @@ public class HarFileSystem extends Filte
   /**
    * return the top level archive path.
    */
+  @Override
   public Path getHomeDirectory() {
     return new Path(uri.toString());
   }
   
+  @Override
   public void setWorkingDirectory(Path newDir) {
     //does nothing.
   }
@@ -746,6 +752,7 @@ public class HarFileSystem extends Filte
   /**
    * not implemented.
    */
+  @Override
   public boolean mkdirs(Path f, FsPermission permission) throws IOException {
     throw new IOException("Har: mkdirs not allowed");
   }
@@ -753,6 +760,7 @@ public class HarFileSystem extends Filte
   /**
    * not implemented.
    */
+  @Override
   public void copyFromLocalFile(boolean delSrc, Path src, Path dst) throws 
         IOException {
     throw new IOException("Har: copyfromlocalfile not allowed");
@@ -761,6 +769,7 @@ public class HarFileSystem extends Filte
   /**
    * copies the file in the har filesystem to a local file.
    */
+  @Override
   public void copyToLocalFile(boolean delSrc, Path src, Path dst) 
     throws IOException {
     FileUtil.copy(this, src, getLocal(getConf()), dst, false, getConf());
@@ -769,6 +778,7 @@ public class HarFileSystem extends Filte
   /**
    * not implemented.
    */
+  @Override
   public Path startLocalOutput(Path fsOutputFile, Path tmpLocalFile) 
     throws IOException {
     throw new IOException("Har: startLocalOutput not allowed");
@@ -777,6 +787,7 @@ public class HarFileSystem extends Filte
   /**
    * not implemented.
    */
+  @Override
   public void completeLocalOutput(Path fsOutputFile, Path tmpLocalFile) 
     throws IOException {
     throw new IOException("Har: completeLocalOutput not allowed");
@@ -785,6 +796,7 @@ public class HarFileSystem extends Filte
   /**
    * not implemented.
    */
+  @Override
   public void setOwner(Path p, String username, String groupname)
     throws IOException {
     throw new IOException("Har: setowner not allowed");
@@ -793,6 +805,7 @@ public class HarFileSystem extends Filte
   /**
    * Not implemented.
    */
+  @Override
   public void setPermission(Path p, FsPermission permisssion) 
     throws IOException {
     throw new IOException("Har: setPermission not allowed");
@@ -825,6 +838,7 @@ public class HarFileSystem extends Filte
         this.end = start + length;
       }
       
+      @Override
       public synchronized int available() throws IOException {
         long remaining = end - underLyingStream.getPos();
         if (remaining > (long)Integer.MAX_VALUE) {
@@ -833,6 +847,7 @@ public class HarFileSystem extends Filte
         return (int) remaining;
       }
       
+      @Override
       public synchronized  void close() throws IOException {
         underLyingStream.close();
         super.close();
@@ -847,15 +862,18 @@ public class HarFileSystem extends Filte
       /**
        * reset is not implemented
        */
+      @Override
       public void reset() throws IOException {
         throw new IOException("reset not implemented.");
       }
       
+      @Override
       public synchronized int read() throws IOException {
         int ret = read(oneBytebuff, 0, 1);
         return (ret <= 0) ? -1: (oneBytebuff[0] & 0xff);
       }
       
+      @Override
       public synchronized int read(byte[] b) throws IOException {
         int ret = read(b, 0, b.length);
         if (ret != -1) {
@@ -867,6 +885,7 @@ public class HarFileSystem extends Filte
       /**
        * 
        */
+      @Override
       public synchronized int read(byte[] b, int offset, int len) 
         throws IOException {
         int newlen = len;
@@ -882,6 +901,7 @@ public class HarFileSystem extends Filte
         return ret;
       }
       
+      @Override
       public synchronized long skip(long n) throws IOException {
         long tmpN = n;
         if (tmpN > 0) {
@@ -895,10 +915,12 @@ public class HarFileSystem extends Filte
         return (tmpN < 0)? -1 : 0;
       }
       
+      @Override
       public synchronized long getPos() throws IOException {
         return (position - start);
       }
       
+      @Override
       public synchronized void seek(long pos) throws IOException {
         if (pos < 0 || (start + pos > end)) {
           throw new IOException("Failed to seek: EOF");
@@ -907,6 +929,7 @@ public class HarFileSystem extends Filte
         underLyingStream.seek(position);
       }
 
+      @Override
       public boolean seekToNewSource(long targetPos) throws IOException {
         //do not need to implement this
         // hdfs in itself does seektonewsource 
@@ -917,6 +940,7 @@ public class HarFileSystem extends Filte
       /**
        * implementing position readable. 
        */
+      @Override
       public int read(long pos, byte[] b, int offset, int length) 
       throws IOException {
         int nlength = length;
@@ -929,6 +953,7 @@ public class HarFileSystem extends Filte
       /**
        * position readable again.
        */
+      @Override
       public void readFully(long pos, byte[] b, int offset, int length) 
       throws IOException {
         if (start + length + pos > end) {
@@ -937,6 +962,7 @@ public class HarFileSystem extends Filte
         underLyingStream.readFully(pos + start, b, offset, length);
       }
       
+      @Override
       public void readFully(long pos, byte[] b) throws IOException {
           readFully(pos, b, 0, b.length);
       }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocalFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocalFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocalFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocalFileSystem.java Sat Aug 25 01:03:22 2012
@@ -91,6 +91,7 @@ public class LocalFileSystem extends Che
    * Moves files to a bad file directory on the same device, so that their
    * storage will not be reused.
    */
+  @Override
   public boolean reportChecksumFailure(Path p, FSDataInputStream in,
                                        long inPos,
                                        FSDataInputStream sums, long sumsPos) {

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocatedFileStatus.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocatedFileStatus.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocatedFileStatus.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/LocatedFileStatus.java Sat Aug 25 01:03:22 2012
@@ -94,6 +94,7 @@ public class LocatedFileStatus extends F
    * @throws ClassCastException if the specified object's is not of 
    *         type FileStatus
    */
+  @Override
   public int compareTo(Object o) {
     return super.compareTo(o);
   }
@@ -102,6 +103,7 @@ public class LocatedFileStatus extends F
    * @param   o the object to be compared.
    * @return  true if two file status has the same path name; false if not.
    */
+  @Override
   public boolean equals(Object o) {
     return super.equals(o);
   }
@@ -112,6 +114,7 @@ public class LocatedFileStatus extends F
    *
    * @return  a hash code value for the path name.
    */
+  @Override
   public int hashCode() {
     return super.hashCode();
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/MD5MD5CRC32FileChecksum.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/MD5MD5CRC32FileChecksum.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/MD5MD5CRC32FileChecksum.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/MD5MD5CRC32FileChecksum.java Sat Aug 25 01:03:22 2012
@@ -57,7 +57,7 @@ public class MD5MD5CRC32FileChecksum ext
     this.md5 = md5;
   }
   
-  /** {@inheritDoc} */ 
+  @Override
   public String getAlgorithmName() {
     return "MD5-of-" + crcPerBlock + "MD5-of-" + bytesPerCRC +
         getCrcType().name();
@@ -73,11 +73,11 @@ public class MD5MD5CRC32FileChecksum ext
 
     throw new IOException("Unknown checksum type in " + algorithm);
   }
-
-  /** {@inheritDoc} */ 
+ 
+  @Override
   public int getLength() {return LENGTH;}
-
-  /** {@inheritDoc} */ 
+ 
+  @Override
   public byte[] getBytes() {
     return WritableUtils.toByteArray(this);
   }
@@ -92,14 +92,14 @@ public class MD5MD5CRC32FileChecksum ext
     return new ChecksumOpt(getCrcType(), bytesPerCRC);
   }
 
-  /** {@inheritDoc} */ 
+  @Override
   public void readFields(DataInput in) throws IOException {
     bytesPerCRC = in.readInt();
     crcPerBlock = in.readLong();
     md5 = MD5Hash.read(in);
   }
-
-  /** {@inheritDoc} */ 
+ 
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeInt(bytesPerCRC);
     out.writeLong(crcPerBlock);
@@ -161,8 +161,8 @@ public class MD5MD5CRC32FileChecksum ext
           + ", md5=" + md5, e);
     }
   }
-
-  /** {@inheritDoc} */ 
+ 
+  @Override
   public String toString() {
     return getAlgorithmName() + ":" + md5;
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Options.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Options.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Options.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Options.java Sat Aug 25 01:03:22 2012
@@ -22,7 +22,6 @@ import org.apache.hadoop.classification.
 import org.apache.hadoop.fs.permission.FsPermission;
 import org.apache.hadoop.util.DataChecksum;
 import org.apache.hadoop.util.Progressable;
-import org.apache.hadoop.HadoopIllegalArgumentException;
 
 /**
  * This class contains options related to file system operations.

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Path.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Path.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Path.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/Path.java Sat Aug 25 01:03:22 2012
@@ -261,6 +261,7 @@ public class Path implements Comparable 
     return new Path(getParent(), getName()+suffix);
   }
 
+  @Override
   public String toString() {
     // we can't use uri.toString(), which escapes everything, because we want
     // illegal characters unescaped in the string, for glob processing, etc.
@@ -289,6 +290,7 @@ public class Path implements Comparable 
     return buffer.toString();
   }
 
+  @Override
   public boolean equals(Object o) {
     if (!(o instanceof Path)) {
       return false;
@@ -297,10 +299,12 @@ public class Path implements Comparable 
     return this.uri.equals(that.uri);
   }
 
+  @Override
   public int hashCode() {
     return uri.hashCode();
   }
 
+  @Override
   public int compareTo(Object o) {
     Path that = (Path)o;
     return this.uri.compareTo(that.uri);

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/RawLocalFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/RawLocalFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/RawLocalFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/RawLocalFileSystem.java Sat Aug 25 01:03:22 2012
@@ -72,8 +72,10 @@ public class RawLocalFileSystem extends 
     return new File(path.toUri().getPath());
   }
 
+  @Override
   public URI getUri() { return NAME; }
   
+  @Override
   public void initialize(URI uri, Configuration conf) throws IOException {
     super.initialize(uri, conf);
     setConf(conf);
@@ -84,6 +86,7 @@ public class RawLocalFileSystem extends 
       super(f);
     }
     
+    @Override
     public int read() throws IOException {
       int result = super.read();
       if (result != -1) {
@@ -92,6 +95,7 @@ public class RawLocalFileSystem extends 
       return result;
     }
     
+    @Override
     public int read(byte[] data) throws IOException {
       int result = super.read(data);
       if (result != -1) {
@@ -100,6 +104,7 @@ public class RawLocalFileSystem extends 
       return result;
     }
     
+    @Override
     public int read(byte[] data, int offset, int length) throws IOException {
       int result = super.read(data, offset, length);
       if (result != -1) {
@@ -120,15 +125,18 @@ public class RawLocalFileSystem extends 
       this.fis = new TrackingFileInputStream(pathToFile(f));
     }
     
+    @Override
     public void seek(long pos) throws IOException {
       fis.getChannel().position(pos);
       this.position = pos;
     }
     
+    @Override
     public long getPos() throws IOException {
       return this.position;
     }
     
+    @Override
     public boolean seekToNewSource(long targetPos) throws IOException {
       return false;
     }
@@ -136,11 +144,14 @@ public class RawLocalFileSystem extends 
     /*
      * Just forward to the fis
      */
+    @Override
     public int available() throws IOException { return fis.available(); }
+    @Override
     public void close() throws IOException { fis.close(); }
     @Override
     public boolean markSupported() { return false; }
     
+    @Override
     public int read() throws IOException {
       try {
         int value = fis.read();
@@ -153,6 +164,7 @@ public class RawLocalFileSystem extends 
       }
     }
     
+    @Override
     public int read(byte[] b, int off, int len) throws IOException {
       try {
         int value = fis.read(b, off, len);
@@ -165,6 +177,7 @@ public class RawLocalFileSystem extends 
       }
     }
     
+    @Override
     public int read(long position, byte[] b, int off, int len)
       throws IOException {
       ByteBuffer bb = ByteBuffer.wrap(b, off, len);
@@ -175,6 +188,7 @@ public class RawLocalFileSystem extends 
       }
     }
     
+    @Override
     public long skip(long n) throws IOException {
       long value = fis.skip(n);
       if (value > 0) {
@@ -189,6 +203,7 @@ public class RawLocalFileSystem extends 
     }
   }
   
+  @Override
   public FSDataInputStream open(Path f, int bufferSize) throws IOException {
     if (!exists(f)) {
       throw new FileNotFoundException(f.toString());
@@ -210,8 +225,11 @@ public class RawLocalFileSystem extends 
     /*
      * Just forward to the fos
      */
+    @Override
     public void close() throws IOException { fos.close(); }
+    @Override
     public void flush() throws IOException { fos.flush(); }
+    @Override
     public void write(byte[] b, int off, int len) throws IOException {
       try {
         fos.write(b, off, len);
@@ -220,6 +238,7 @@ public class RawLocalFileSystem extends 
       }
     }
     
+    @Override
     public void write(int b) throws IOException {
       try {
         fos.write(b);
@@ -229,7 +248,7 @@ public class RawLocalFileSystem extends 
     }
   }
 
-  /** {@inheritDoc} */
+  @Override
   public FSDataOutputStream append(Path f, int bufferSize,
       Progressable progress) throws IOException {
     if (!exists(f)) {
@@ -242,7 +261,6 @@ public class RawLocalFileSystem extends 
         new LocalFSFileOutputStream(f, true), bufferSize), statistics);
   }
 
-  /** {@inheritDoc} */
   @Override
   public FSDataOutputStream create(Path f, boolean overwrite, int bufferSize,
     short replication, long blockSize, Progressable progress)
@@ -264,7 +282,6 @@ public class RawLocalFileSystem extends 
         new LocalFSFileOutputStream(f, false), bufferSize), statistics);
   }
 
-  /** {@inheritDoc} */
   @Override
   public FSDataOutputStream create(Path f, FsPermission permission,
     boolean overwrite, int bufferSize, short replication, long blockSize,
@@ -276,7 +293,6 @@ public class RawLocalFileSystem extends 
     return out;
   }
 
-  /** {@inheritDoc} */
   @Override
   public FSDataOutputStream createNonRecursive(Path f, FsPermission permission,
       boolean overwrite,
@@ -288,6 +304,7 @@ public class RawLocalFileSystem extends 
     return out;
   }
 
+  @Override
   public boolean rename(Path src, Path dst) throws IOException {
     if (pathToFile(src).renameTo(pathToFile(dst))) {
       return true;
@@ -302,6 +319,7 @@ public class RawLocalFileSystem extends 
    * @return true if the file or directory and all its contents were deleted
    * @throws IOException if p is non-empty and recursive is false 
    */
+  @Override
   public boolean delete(Path p, boolean recursive) throws IOException {
     File f = pathToFile(p);
     if (f.isFile()) {
@@ -319,6 +337,7 @@ public class RawLocalFileSystem extends 
    * (<b>Note</b>: Returned list is not sorted in any given order,
    * due to reliance on Java's {@link File#list()} API.)
    */
+  @Override
   public FileStatus[] listStatus(Path f) throws IOException {
     File localf = pathToFile(f);
     FileStatus[] results;
@@ -356,6 +375,7 @@ public class RawLocalFileSystem extends 
    * Creates the specified directory hierarchy. Does not
    * treat existence as an error.
    */
+  @Override
   public boolean mkdirs(Path f) throws IOException {
     if(f == null) {
       throw new IllegalArgumentException("mkdirs path arg is null");
@@ -373,7 +393,6 @@ public class RawLocalFileSystem extends 
       (p2f.mkdir() || p2f.isDirectory());
   }
 
-  /** {@inheritDoc} */
   @Override
   public boolean mkdirs(Path f, FsPermission permission) throws IOException {
     boolean b = mkdirs(f);
@@ -418,7 +437,6 @@ public class RawLocalFileSystem extends 
     return this.makeQualified(new Path(System.getProperty("user.dir")));
   }
 
-  /** {@inheritDoc} */
   @Override
   public FsStatus getStatus(Path p) throws IOException {
     File partition = pathToFile(p == null ? new Path("/") : p);
@@ -430,29 +448,35 @@ public class RawLocalFileSystem extends 
   }
   
   // In the case of the local filesystem, we can just rename the file.
+  @Override
   public void moveFromLocalFile(Path src, Path dst) throws IOException {
     rename(src, dst);
   }
   
   // We can write output directly to the final location
+  @Override
   public Path startLocalOutput(Path fsOutputFile, Path tmpLocalFile)
     throws IOException {
     return fsOutputFile;
   }
   
   // It's in the right place - nothing to do.
+  @Override
   public void completeLocalOutput(Path fsWorkingFile, Path tmpLocalFile)
     throws IOException {
   }
   
+  @Override
   public void close() throws IOException {
     super.close();
   }
   
+  @Override
   public String toString() {
     return "LocalFS";
   }
   
+  @Override
   public FileStatus getFileStatus(Path f) throws IOException {
     File path = pathToFile(f);
     if (path.exists()) {

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/TrashPolicyDefault.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/TrashPolicyDefault.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/TrashPolicyDefault.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/TrashPolicyDefault.java Sat Aug 25 01:03:22 2012
@@ -263,6 +263,7 @@ public class TrashPolicyDefault extends 
       }
     }
 
+    @Override
     public void run() {
       if (emptierInterval == 0)
         return;                                   // trash disabled

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPFileSystem.java Sat Aug 25 01:03:22 2012
@@ -262,6 +262,7 @@ public class FTPFileSystem extends FileS
   }
 
   /** This optional operation is not yet supported. */
+  @Override
   public FSDataOutputStream append(Path f, int bufferSize,
       Progressable progress) throws IOException {
     throw new IOException("Not supported");

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPInputStream.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPInputStream.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPInputStream.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/ftp/FTPInputStream.java Sat Aug 25 01:03:22 2012
@@ -51,19 +51,23 @@ public class FTPInputStream extends FSIn
     this.closed = false;
   }
 
+  @Override
   public long getPos() throws IOException {
     return pos;
   }
 
   // We don't support seek.
+  @Override
   public void seek(long pos) throws IOException {
     throw new IOException("Seek not supported");
   }
 
+  @Override
   public boolean seekToNewSource(long targetPos) throws IOException {
     throw new IOException("Seek not supported");
   }
 
+  @Override
   public synchronized int read() throws IOException {
     if (closed) {
       throw new IOException("Stream closed");
@@ -79,6 +83,7 @@ public class FTPInputStream extends FSIn
     return byteRead;
   }
 
+  @Override
   public synchronized int read(byte buf[], int off, int len) throws IOException {
     if (closed) {
       throw new IOException("Stream closed");
@@ -95,6 +100,7 @@ public class FTPInputStream extends FSIn
     return result;
   }
 
+  @Override
   public synchronized void close() throws IOException {
     if (closed) {
       throw new IOException("Stream closed");
@@ -116,14 +122,17 @@ public class FTPInputStream extends FSIn
 
   // Not supported.
 
+  @Override
   public boolean markSupported() {
     return false;
   }
 
+  @Override
   public void mark(int readLimit) {
     // Do nothing
   }
 
+  @Override
   public void reset() throws IOException {
     throw new IOException("Mark not supported");
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSImpl.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSImpl.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSImpl.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSImpl.java Sat Aug 25 01:03:22 2012
@@ -50,22 +50,27 @@ class KFSImpl implements IFSImpl {
         statistics = stats;
     }
 
+    @Override
     public boolean exists(String path) throws IOException {
         return kfsAccess.kfs_exists(path);
     }
 
+    @Override
     public boolean isDirectory(String path) throws IOException {
         return kfsAccess.kfs_isDirectory(path);
     }
 
+    @Override
     public boolean isFile(String path) throws IOException {
         return kfsAccess.kfs_isFile(path);
     }
 
+    @Override
     public String[] readdir(String path) throws IOException {
         return kfsAccess.kfs_readdir(path);
     }
 
+    @Override
     public FileStatus[] readdirplus(Path path) throws IOException {
         String srep = path.toUri().getPath();
         KfsFileAttr[] fattr = kfsAccess.kfs_readdirplus(srep);
@@ -100,52 +105,64 @@ class KFSImpl implements IFSImpl {
     }
 
 
+    @Override
     public int mkdirs(String path) throws IOException {
         return kfsAccess.kfs_mkdirs(path);
     }
 
+    @Override
     public int rename(String source, String dest) throws IOException {
         return kfsAccess.kfs_rename(source, dest);
     }
 
+    @Override
     public int rmdir(String path) throws IOException {
         return kfsAccess.kfs_rmdir(path);
     }
 
+    @Override
     public int remove(String path) throws IOException {
         return kfsAccess.kfs_remove(path);
     }
 
+    @Override
     public long filesize(String path) throws IOException {
         return kfsAccess.kfs_filesize(path);
     }
 
+    @Override
     public short getReplication(String path) throws IOException {
         return kfsAccess.kfs_getReplication(path);
     }
 
+    @Override
     public short setReplication(String path, short replication) throws IOException {
         return kfsAccess.kfs_setReplication(path, replication);
     }
 
+    @Override
     public String[][] getDataLocation(String path, long start, long len) throws IOException {
         return kfsAccess.kfs_getDataLocation(path, start, len);
     }
 
+    @Override
     public long getModificationTime(String path) throws IOException {
         return kfsAccess.kfs_getModificationTime(path);
     }
 
+    @Override
     public FSDataInputStream open(String path, int bufferSize) throws IOException {
         return new FSDataInputStream(new KFSInputStream(kfsAccess, path, 
                                                         statistics));
     }
 
+    @Override
     public FSDataOutputStream create(String path, short replication, int bufferSize, Progressable progress) throws IOException {
         return new FSDataOutputStream(new KFSOutputStream(kfsAccess, path, replication, false, progress), 
                                       statistics);
     }
 
+    @Override
     public FSDataOutputStream append(String path, int bufferSize, Progressable progress) throws IOException {
         // when opening for append, # of replicas is ignored
         return new FSDataOutputStream(new KFSOutputStream(kfsAccess, path, (short) 1, true, progress), 

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSInputStream.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSInputStream.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSInputStream.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSInputStream.java Sat Aug 25 01:03:22 2012
@@ -53,6 +53,7 @@ class KFSInputStream extends FSInputStre
             this.fsize = 0;
     }
 
+    @Override
     public long getPos() throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -60,6 +61,7 @@ class KFSInputStream extends FSInputStre
         return kfsChannel.tell();
     }
 
+    @Override
     public synchronized int available() throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -67,6 +69,7 @@ class KFSInputStream extends FSInputStre
         return (int) (this.fsize - getPos());
     }
 
+    @Override
     public synchronized void seek(long targetPos) throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -74,10 +77,12 @@ class KFSInputStream extends FSInputStre
         kfsChannel.seek(targetPos);
     }
 
+    @Override
     public synchronized boolean seekToNewSource(long targetPos) throws IOException {
         return false;
     }
 
+    @Override
     public synchronized int read() throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -93,6 +98,7 @@ class KFSInputStream extends FSInputStre
         return -1;
     }
 
+    @Override
     public synchronized int read(byte b[], int off, int len) throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -109,6 +115,7 @@ class KFSInputStream extends FSInputStre
 	return res;
     }
 
+    @Override
     public synchronized void close() throws IOException {
         if (kfsChannel == null) {
             return;
@@ -118,14 +125,17 @@ class KFSInputStream extends FSInputStre
         kfsChannel = null;
     }
 
+    @Override
     public boolean markSupported() {
         return false;
     }
 
+    @Override
     public void mark(int readLimit) {
         // Do nothing
     }
 
+    @Override
     public void reset() throws IOException {
         throw new IOException("Mark not supported");
     }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSOutputStream.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSOutputStream.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSOutputStream.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/kfs/KFSOutputStream.java Sat Aug 25 01:03:22 2012
@@ -20,15 +20,10 @@
 package org.apache.hadoop.fs.kfs;
 
 import java.io.*;
-import java.net.*;
-import java.util.*;
 import java.nio.ByteBuffer;
 
 import org.apache.hadoop.classification.InterfaceAudience;
 import org.apache.hadoop.classification.InterfaceStability;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.fs.Path;
-import org.apache.hadoop.fs.FSDataOutputStream;
 import org.apache.hadoop.util.Progressable;
 
 import org.kosmix.kosmosfs.access.KfsAccess;
@@ -60,6 +55,7 @@ class KFSOutputStream extends OutputStre
         return kfsChannel.tell();
     }
 
+    @Override
     public void write(int v) throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -70,6 +66,7 @@ class KFSOutputStream extends OutputStre
         write(b, 0, 1);
     }
 
+    @Override
     public void write(byte b[], int off, int len) throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -80,6 +77,7 @@ class KFSOutputStream extends OutputStre
         kfsChannel.write(ByteBuffer.wrap(b, off, len));
     }
 
+    @Override
     public void flush() throws IOException {
         if (kfsChannel == null) {
             throw new IOException("File closed");
@@ -89,6 +87,7 @@ class KFSOutputStream extends OutputStre
         kfsChannel.sync();
     }
 
+    @Override
     public synchronized void close() throws IOException {
         if (kfsChannel == null) {
             return;

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/FsPermission.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/FsPermission.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/FsPermission.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/FsPermission.java Sat Aug 25 01:03:22 2012
@@ -40,6 +40,7 @@ public class FsPermission implements Wri
   private static final Log LOG = LogFactory.getLog(FsPermission.class);
 
   static final WritableFactory FACTORY = new WritableFactory() {
+    @Override
     public Writable newInstance() { return new FsPermission(); }
   };
   static {                                      // register a ctor
@@ -124,12 +125,12 @@ public class FsPermission implements Wri
     set(v[(n >>> 6) & 7], v[(n >>> 3) & 7], v[n & 7], (((n >>> 9) & 1) == 1) );
   }
 
-  /** {@inheritDoc} */
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeShort(toShort());
   }
 
-  /** {@inheritDoc} */
+  @Override
   public void readFields(DataInput in) throws IOException {
     fromShort(in.readShort());
   }
@@ -155,7 +156,7 @@ public class FsPermission implements Wri
     return (short)s;
   }
 
-  /** {@inheritDoc} */
+  @Override
   public boolean equals(Object obj) {
     if (obj instanceof FsPermission) {
       FsPermission that = (FsPermission)obj;
@@ -167,10 +168,10 @@ public class FsPermission implements Wri
     return false;
   }
 
-  /** {@inheritDoc} */
+  @Override
   public int hashCode() {return toShort();}
 
-  /** {@inheritDoc} */
+  @Override
   public String toString() {
     String str = useraction.SYMBOL + groupaction.SYMBOL + otheraction.SYMBOL;
     if(stickyBit) {
@@ -300,9 +301,11 @@ public class FsPermission implements Wri
     public ImmutableFsPermission(short permission) {
       super(permission);
     }
+    @Override
     public FsPermission applyUMask(FsPermission umask) {
       throw new UnsupportedOperationException();
     }
+    @Override
     public void readFields(DataInput in) throws IOException {
       throw new UnsupportedOperationException();
     }    

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/PermissionStatus.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/PermissionStatus.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/PermissionStatus.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/permission/PermissionStatus.java Sat Aug 25 01:03:22 2012
@@ -32,6 +32,7 @@ import java.io.IOException;
 @InterfaceStability.Unstable
 public class PermissionStatus implements Writable {
   static final WritableFactory FACTORY = new WritableFactory() {
+    @Override
     public Writable newInstance() { return new PermissionStatus(); }
   };
   static {                                      // register a ctor
@@ -42,9 +43,11 @@ public class PermissionStatus implements
   public static PermissionStatus createImmutable(
       String user, String group, FsPermission permission) {
     return new PermissionStatus(user, group, permission) {
+      @Override
       public PermissionStatus applyUMask(FsPermission umask) {
         throw new UnsupportedOperationException();
       }
+      @Override
       public void readFields(DataInput in) throws IOException {
         throw new UnsupportedOperationException();
       }
@@ -82,14 +85,14 @@ public class PermissionStatus implements
     return this;
   }
 
-  /** {@inheritDoc} */
+  @Override
   public void readFields(DataInput in) throws IOException {
     username = Text.readString(in, Text.DEFAULT_MAX_LEN);
     groupname = Text.readString(in, Text.DEFAULT_MAX_LEN);
     permission = FsPermission.read(in);
   }
 
-  /** {@inheritDoc} */
+  @Override
   public void write(DataOutput out) throws IOException {
     write(out, username, groupname, permission);
   }
@@ -115,7 +118,7 @@ public class PermissionStatus implements
     permission.write(out);
   }
 
-  /** {@inheritDoc} */
+  @Override
   public String toString() {
     return username + ":" + groupname + ":" + permission;
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/Jets3tFileSystemStore.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/Jets3tFileSystemStore.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/Jets3tFileSystemStore.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/Jets3tFileSystemStore.java Sat Aug 25 01:03:22 2012
@@ -83,6 +83,7 @@ class Jets3tFileSystemStore implements F
   private static final Log LOG = 
     LogFactory.getLog(Jets3tFileSystemStore.class.getName());
   
+  @Override
   public void initialize(URI uri, Configuration conf) throws IOException {
     
     this.conf = conf;
@@ -108,6 +109,7 @@ class Jets3tFileSystemStore implements F
 		      );
   }
 
+  @Override
   public String getVersion() throws IOException {
     return FILE_SYSTEM_VERSION_VALUE;
   }
@@ -123,14 +125,17 @@ class Jets3tFileSystemStore implements F
     }
   }
 
+  @Override
   public void deleteINode(Path path) throws IOException {
     delete(pathToKey(path));
   }
 
+  @Override
   public void deleteBlock(Block block) throws IOException {
     delete(blockToKey(block));
   }
 
+  @Override
   public boolean inodeExists(Path path) throws IOException {
     InputStream in = get(pathToKey(path), true);
     if (in == null) {
@@ -140,6 +145,7 @@ class Jets3tFileSystemStore implements F
     return true;
   }
   
+  @Override
   public boolean blockExists(long blockId) throws IOException {
     InputStream in = get(blockToKey(blockId), false);
     if (in == null) {
@@ -203,10 +209,12 @@ class Jets3tFileSystemStore implements F
     }
   }
 
+  @Override
   public INode retrieveINode(Path path) throws IOException {
     return INode.deserialize(get(pathToKey(path), true));
   }
 
+  @Override
   public File retrieveBlock(Block block, long byteRangeStart)
     throws IOException {
     File fileBlock = null;
@@ -249,6 +257,7 @@ class Jets3tFileSystemStore implements F
     return result;
   }
 
+  @Override
   public Set<Path> listSubPaths(Path path) throws IOException {
     try {
       String prefix = pathToKey(path);
@@ -270,6 +279,7 @@ class Jets3tFileSystemStore implements F
     }
   }
   
+  @Override
   public Set<Path> listDeepSubPaths(Path path) throws IOException {
     try {
       String prefix = pathToKey(path);
@@ -311,10 +321,12 @@ class Jets3tFileSystemStore implements F
     }
   }
 
+  @Override
   public void storeINode(Path path, INode inode) throws IOException {
     put(pathToKey(path), inode.serialize(), inode.getSerializedLength(), true);
   }
 
+  @Override
   public void storeBlock(Block block, File file) throws IOException {
     BufferedInputStream in = null;
     try {
@@ -354,6 +366,7 @@ class Jets3tFileSystemStore implements F
     return blockToKey(block.getId());
   }
 
+  @Override
   public void purge() throws IOException {
     try {
       S3Object[] objects = s3Service.listObjects(bucket);
@@ -368,6 +381,7 @@ class Jets3tFileSystemStore implements F
     }
   }
 
+  @Override
   public void dump() throws IOException {
     StringBuilder sb = new StringBuilder("S3 Filesystem, ");
     sb.append(bucket.getName()).append("\n");

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/MigrationTool.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/MigrationTool.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/MigrationTool.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/MigrationTool.java Sat Aug 25 01:03:22 2012
@@ -61,6 +61,7 @@ public class MigrationTool extends Confi
     System.exit(res);
   }
   
+  @Override
   public int run(String[] args) throws Exception {
     
     if (args.length == 0) {
@@ -195,6 +196,7 @@ public class MigrationTool extends Confi
   
   class UnversionedStore implements Store {
 
+    @Override
     public Set<Path> listAllPaths() throws IOException {
       try {
         String prefix = urlEncode(Path.SEPARATOR);
@@ -212,6 +214,7 @@ public class MigrationTool extends Confi
       }   
     }
 
+    @Override
     public void deleteINode(Path path) throws IOException {
       delete(pathToKey(path));
     }
@@ -227,6 +230,7 @@ public class MigrationTool extends Confi
       }
     }
     
+    @Override
     public INode retrieveINode(Path path) throws IOException {
       return INode.deserialize(get(pathToKey(path)));
     }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/S3FileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/S3FileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/S3FileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3/S3FileSystem.java Sat Aug 25 01:03:22 2012
@@ -206,6 +206,7 @@ public class S3FileSystem extends FileSy
   }
 
   /** This optional operation is not yet supported. */
+  @Override
   public FSDataOutputStream append(Path f, int bufferSize,
       Progressable progress) throws IOException {
     throw new IOException("Not supported");
@@ -298,6 +299,7 @@ public class S3FileSystem extends FileSy
     return true;
   }
 
+  @Override
   public boolean delete(Path path, boolean recursive) throws IOException {
    Path absolutePath = makeAbsolute(path);
    INode inode = store.retrieveINode(absolutePath);

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3native/Jets3tNativeFileSystemStore.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3native/Jets3tNativeFileSystemStore.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3native/Jets3tNativeFileSystemStore.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/s3native/Jets3tNativeFileSystemStore.java Sat Aug 25 01:03:22 2012
@@ -49,6 +49,7 @@ class Jets3tNativeFileSystemStore implem
   private S3Service s3Service;
   private S3Bucket bucket;
   
+  @Override
   public void initialize(URI uri, Configuration conf) throws IOException {
     S3Credentials s3Credentials = new S3Credentials();
     s3Credentials.initialize(uri, conf);
@@ -63,6 +64,7 @@ class Jets3tNativeFileSystemStore implem
     bucket = new S3Bucket(uri.getHost());
   }
   
+  @Override
   public void storeFile(String key, File file, byte[] md5Hash)
     throws IOException {
     
@@ -90,6 +92,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
 
+  @Override
   public void storeEmptyFile(String key) throws IOException {
     try {
       S3Object object = new S3Object(key);
@@ -102,6 +105,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
   
+  @Override
   public FileMetadata retrieveMetadata(String key) throws IOException {
     try {
       S3Object object = s3Service.getObjectDetails(bucket, key);
@@ -117,6 +121,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
   
+  @Override
   public InputStream retrieve(String key) throws IOException {
     try {
       S3Object object = s3Service.getObject(bucket, key);
@@ -127,6 +132,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
   
+  @Override
   public InputStream retrieve(String key, long byteRangeStart)
     throws IOException {
     try {
@@ -139,11 +145,13 @@ class Jets3tNativeFileSystemStore implem
     }
   }
 
+  @Override
   public PartialListing list(String prefix, int maxListingLength)
     throws IOException {
     return list(prefix, maxListingLength, null, false);
   }
   
+  @Override
   public PartialListing list(String prefix, int maxListingLength, String priorLastKey,
       boolean recurse) throws IOException {
 
@@ -175,6 +183,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
 
+  @Override
   public void delete(String key) throws IOException {
     try {
       s3Service.deleteObject(bucket, key);
@@ -183,6 +192,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
   
+  @Override
   public void copy(String srcKey, String dstKey) throws IOException {
     try {
       s3Service.copyObject(bucket.getName(), srcKey, bucket.getName(),
@@ -192,6 +202,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
 
+  @Override
   public void purge(String prefix) throws IOException {
     try {
       S3Object[] objects = s3Service.listObjects(bucket, prefix, null);
@@ -203,6 +214,7 @@ class Jets3tNativeFileSystemStore implem
     }
   }
 
+  @Override
   public void dump() throws IOException {
     StringBuilder sb = new StringBuilder("S3 Native Filesystem, ");
     sb.append(bucket.getName()).append("\n");

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/CommandFormat.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/CommandFormat.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/CommandFormat.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/CommandFormat.java Sat Aug 25 01:03:22 2012
@@ -150,6 +150,7 @@ public class CommandFormat {
       actual = got;
     }
 
+    @Override
     public String getMessage() {
       return "expected " + expected + " but got " + actual;
     }
@@ -165,6 +166,7 @@ public class CommandFormat {
       super(expected, actual);
     }
 
+    @Override
     public String getMessage() {
       return "Too many arguments: " + super.getMessage();
     }
@@ -180,6 +182,7 @@ public class CommandFormat {
       super(expected, actual);
     }
 
+    @Override
     public String getMessage() {
       return "Not enough arguments: " + super.getMessage();
     }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Delete.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Delete.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Delete.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Delete.java Sat Aug 25 01:03:22 2012
@@ -114,6 +114,7 @@ class Delete {
   static class Rmr extends Rm {
     public static final String NAME = "rmr";
     
+    @Override
     protected void processOptions(LinkedList<String> args) throws IOException {
       args.addFirst("-r");
       super.processOptions(args);
@@ -136,6 +137,7 @@ class Delete {
     
     private boolean ignoreNonEmpty = false;
     
+    @Override
     protected void processOptions(LinkedList<String> args) throws IOException {
       CommandFormat cf = new CommandFormat(
           1, Integer.MAX_VALUE, "-ignore-fail-on-non-empty");

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Display.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Display.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Display.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/Display.java Sat Aug 25 01:03:22 2012
@@ -161,6 +161,7 @@ class Display extends FsCommand {
       outbuf = new DataOutputBuffer();
     }
 
+    @Override
     public int read() throws IOException {
       int ret;
       if (null == inbuf || -1 == (ret = inbuf.read())) {
@@ -180,6 +181,7 @@ class Display extends FsCommand {
       return ret;
     }
 
+    @Override
     public void close() throws IOException {
       r.close();
       super.close();

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/FsCommand.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/FsCommand.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/FsCommand.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/FsCommand.java Sat Aug 25 01:03:22 2012
@@ -73,6 +73,7 @@ abstract public class FsCommand extends 
   
   // abstract method that normally is invoked by runall() which is
   // overridden below
+  @Override
   protected void run(Path path) throws IOException {
     throw new RuntimeException("not supposed to get here");
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/PathData.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/PathData.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/PathData.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/shell/PathData.java Sat Aug 25 01:03:22 2012
@@ -380,6 +380,7 @@ public class PathData implements Compara
    * as given on the commandline, or the full path
    * @return String of the path
    */
+  @Override
   public String toString() {
     String scheme = uri.getScheme();
     // No interpretation of symbols. Just decode % escaped chars.

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java Sat Aug 25 01:03:22 2012
@@ -102,6 +102,7 @@ class ChRootedFileSystem extends FilterF
    *   for this FileSystem
    * @param conf the configuration
    */
+  @Override
   public void initialize(final URI name, final Configuration conf)
       throws IOException {
     super.initialize(name, conf);

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/NotInMountpointException.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/NotInMountpointException.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/NotInMountpointException.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/NotInMountpointException.java Sat Aug 25 01:03:22 2012
@@ -20,10 +20,6 @@ package org.apache.hadoop.fs.viewfs;
 
 import org.apache.hadoop.classification.InterfaceAudience;
 import org.apache.hadoop.classification.InterfaceStability;
-import java.io.IOException;
-import java.util.ArrayList;
-import java.util.HashSet;
-
 import org.apache.hadoop.fs.Path;
 
 /**

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java Sat Aug 25 01:03:22 2012
@@ -164,6 +164,7 @@ public class ViewFileSystem extends File
    *          this FileSystem
    * @param conf the configuration
    */
+  @Override
   public void initialize(final URI theUri, final Configuration conf)
       throws IOException {
     super.initialize(theUri, conf);

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFsFileStatus.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFsFileStatus.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFsFileStatus.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFsFileStatus.java Sat Aug 25 01:03:22 2012
@@ -42,7 +42,8 @@ class ViewFsFileStatus extends FileStatu
      return super.equals(o);
    }
    
-   public int hashCode() {
+   @Override
+  public int hashCode() {
      return super.hashCode();
    }
    

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/ActiveStandbyElector.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/ActiveStandbyElector.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/ActiveStandbyElector.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/ActiveStandbyElector.java Sat Aug 25 01:03:22 2012
@@ -892,6 +892,7 @@ public class ActiveStandbyElector implem
       final List<ACL> acl, final CreateMode mode)
       throws InterruptedException, KeeperException {
     return zkDoWithRetries(new ZKAction<String>() {
+      @Override
       public String run() throws KeeperException, InterruptedException {
         return zkClient.create(path, data, acl, mode);
       }
@@ -901,6 +902,7 @@ public class ActiveStandbyElector implem
   private byte[] getDataWithRetries(final String path, final boolean watch,
       final Stat stat) throws InterruptedException, KeeperException {
     return zkDoWithRetries(new ZKAction<byte[]>() {
+      @Override
       public byte[] run() throws KeeperException, InterruptedException {
         return zkClient.getData(path, watch, stat);
       }
@@ -910,6 +912,7 @@ public class ActiveStandbyElector implem
   private Stat setDataWithRetries(final String path, final byte[] data,
       final int version) throws InterruptedException, KeeperException {
     return zkDoWithRetries(new ZKAction<Stat>() {
+      @Override
       public Stat run() throws KeeperException, InterruptedException {
         return zkClient.setData(path, data, version);
       }
@@ -919,6 +922,7 @@ public class ActiveStandbyElector implem
   private void deleteWithRetries(final String path, final int version)
       throws KeeperException, InterruptedException {
     zkDoWithRetries(new ZKAction<Void>() {
+      @Override
       public Void run() throws KeeperException, InterruptedException {
         zkClient.delete(path, version);
         return null;

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/HAServiceProtocol.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/HAServiceProtocol.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/HAServiceProtocol.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/HAServiceProtocol.java Sat Aug 25 01:03:22 2012
@@ -56,6 +56,7 @@ public interface HAServiceProtocol {
       this.name = name;
     }
 
+    @Override
     public String toString() {
       return name;
     }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/NodeFencer.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/NodeFencer.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/NodeFencer.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/NodeFencer.java Sat Aug 25 01:03:22 2012
@@ -184,6 +184,7 @@ public class NodeFencer {
       this.arg = arg;
     }
     
+    @Override
     public String toString() {
       return method.getClass().getCanonicalName() + "(" + arg + ")";
     }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/SshFenceByTcpPort.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/SshFenceByTcpPort.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/SshFenceByTcpPort.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/ha/SshFenceByTcpPort.java Sat Aug 25 01:03:22 2012
@@ -274,6 +274,7 @@ public class SshFenceByTcpPort extends C
     static final Log LOG = LogFactory.getLog(
         SshFenceByTcpPort.class.getName() + ".jsch");
 
+    @Override
     public boolean isEnabled(int level) {
       switch (level) {
       case com.jcraft.jsch.Logger.DEBUG:
@@ -291,6 +292,7 @@ public class SshFenceByTcpPort extends C
       }
     }
       
+    @Override
     public void log(int level, String message) {
       switch (level) {
       case com.jcraft.jsch.Logger.DEBUG:

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/http/HttpServer.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/http/HttpServer.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/http/HttpServer.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/http/HttpServer.java Sat Aug 25 01:03:22 2012
@@ -474,7 +474,7 @@ public class HttpServer implements Filte
     }
   }
 
-  /** {@inheritDoc} */
+  @Override
   public void addFilter(String name, String classname,
       Map<String, String> parameters) {
 
@@ -494,7 +494,7 @@ public class HttpServer implements Filte
     filterNames.add(name);
   }
 
-  /** {@inheritDoc} */
+  @Override
   public void addGlobalFilter(String name, String classname,
       Map<String, String> parameters) {
     final String[] ALL_URLS = { "/*" };

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/AbstractMapWritable.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/AbstractMapWritable.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/AbstractMapWritable.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/AbstractMapWritable.java Sat Aug 25 01:03:22 2012
@@ -164,16 +164,18 @@ public abstract class AbstractMapWritabl
   }
 
   /** @return the conf */
+  @Override
   public Configuration getConf() {
     return conf.get();
   }
 
   /** @param conf the conf to set */
+  @Override
   public void setConf(Configuration conf) {
     this.conf.set(conf);
   }
   
-  /** {@inheritDoc} */
+  @Override
   public void write(DataOutput out) throws IOException {
     
     // First write out the size of the class table and any classes that are
@@ -187,7 +189,7 @@ public abstract class AbstractMapWritabl
     }
   }
   
-  /** {@inheritDoc} */
+  @Override
   public void readFields(DataInput in) throws IOException {
     
     // Get the number of "unknown" classes

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ArrayWritable.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ArrayWritable.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ArrayWritable.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ArrayWritable.java Sat Aug 25 01:03:22 2012
@@ -88,6 +88,7 @@ public class ArrayWritable implements Wr
 
   public Writable[] get() { return values; }
 
+  @Override
   public void readFields(DataInput in) throws IOException {
     values = new Writable[in.readInt()];          // construct values
     for (int i = 0; i < values.length; i++) {
@@ -97,6 +98,7 @@ public class ArrayWritable implements Wr
     }
   }
 
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeInt(values.length);                 // write values
     for (int i = 0; i < values.length; i++) {

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BooleanWritable.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BooleanWritable.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BooleanWritable.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BooleanWritable.java Sat Aug 25 01:03:22 2012
@@ -57,12 +57,14 @@ public class BooleanWritable implements 
 
   /**
    */
+  @Override
   public void readFields(DataInput in) throws IOException {
     value = in.readBoolean();
   }
 
   /**
    */
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeBoolean(value);
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ByteWritable.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ByteWritable.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ByteWritable.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/ByteWritable.java Sat Aug 25 01:03:22 2012
@@ -39,10 +39,12 @@ public class ByteWritable implements Wri
   /** Return the value of this ByteWritable. */
   public byte get() { return value; }
 
+  @Override
   public void readFields(DataInput in) throws IOException {
     value = in.readByte();
   }
 
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeByte(value);
   }

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BytesWritable.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BytesWritable.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BytesWritable.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/BytesWritable.java Sat Aug 25 01:03:22 2012
@@ -81,6 +81,7 @@ public class BytesWritable extends Binar
    * if you need the returned array to be precisely the length of the data.
    * @return The data is only valid between 0 and getLength() - 1.
    */
+  @Override
   public byte[] getBytes() {
     return bytes;
   }
@@ -97,6 +98,7 @@ public class BytesWritable extends Binar
   /**
    * Get the current size of the buffer.
    */
+  @Override
   public int getLength() {
     return size;
   }
@@ -171,6 +173,7 @@ public class BytesWritable extends Binar
   }
 
   // inherit javadoc
+  @Override
   public void readFields(DataInput in) throws IOException {
     setSize(0); // clear the old data
     setSize(in.readInt());
@@ -178,6 +181,7 @@ public class BytesWritable extends Binar
   }
   
   // inherit javadoc
+  @Override
   public void write(DataOutput out) throws IOException {
     out.writeInt(size);
     out.write(bytes, 0, size);

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/CompressedWritable.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/CompressedWritable.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/CompressedWritable.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/CompressedWritable.java Sat Aug 25 01:03:22 2012
@@ -45,6 +45,7 @@ public abstract class CompressedWritable
 
   public CompressedWritable() {}
 
+  @Override
   public final void readFields(DataInput in) throws IOException {
     compressed = new byte[in.readInt()];
     in.readFully(compressed, 0, compressed.length);
@@ -70,6 +71,7 @@ public abstract class CompressedWritable
   protected abstract void readFieldsCompressed(DataInput in)
     throws IOException;
 
+  @Override
   public final void write(DataOutput out) throws IOException {
     if (compressed == null) {
       ByteArrayOutputStream deflated = new ByteArrayOutputStream();

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DataInputByteBuffer.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DataInputByteBuffer.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DataInputByteBuffer.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DataInputByteBuffer.java Sat Aug 25 01:03:22 2012
@@ -21,8 +21,6 @@ package org.apache.hadoop.io;
 import java.io.DataInputStream;
 import java.io.InputStream;
 import java.nio.ByteBuffer;
-import java.util.LinkedList;
-import java.util.List;
 
 public class DataInputByteBuffer extends DataInputStream {
 

Modified: hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DefaultStringifier.java
URL: http://svn.apache.org/viewvc/hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DefaultStringifier.java?rev=1377168&r1=1377167&r2=1377168&view=diff
==============================================================================
--- hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DefaultStringifier.java (original)
+++ hadoop/common/trunk/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/io/DefaultStringifier.java Sat Aug 25 01:03:22 2012
@@ -72,6 +72,7 @@ public class DefaultStringifier<T> imple
     }
   }
 
+  @Override
   public T fromString(String str) throws IOException {
     try {
       byte[] bytes = Base64.decodeBase64(str.getBytes("UTF-8"));
@@ -83,6 +84,7 @@ public class DefaultStringifier<T> imple
     }
   }
 
+  @Override
   public String toString(T obj) throws IOException {
     outBuf.reset();
     serializer.serialize(obj);
@@ -91,6 +93,7 @@ public class DefaultStringifier<T> imple
     return new String(Base64.encodeBase64(buf));
   }
 
+  @Override
   public void close() throws IOException {
     inBuf.close();
     outBuf.close();