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 st...@apache.org on 2016/10/20 18:34:54 UTC

hadoop git commit: Revert "HADOOP-13236. truncate will fail when we use viewfilesystem. Contributed by Brahma Reddy Battula"

Repository: hadoop
Updated Branches:
  refs/heads/branch-2 bf6379fdd -> ab36519b6


Revert "HADOOP-13236. truncate will fail when we use viewfilesystem. Contributed by Brahma Reddy Battula"

This reverts commit bf6379fdd2eef2fed30414559190afa8ccd963d5.


Project: http://git-wip-us.apache.org/repos/asf/hadoop/repo
Commit: http://git-wip-us.apache.org/repos/asf/hadoop/commit/ab36519b
Tree: http://git-wip-us.apache.org/repos/asf/hadoop/tree/ab36519b
Diff: http://git-wip-us.apache.org/repos/asf/hadoop/diff/ab36519b

Branch: refs/heads/branch-2
Commit: ab36519b6ff1adb109c2de0d57e242a53e99b256
Parents: bf6379f
Author: Steve Loughran <st...@apache.org>
Authored: Thu Oct 20 19:32:10 2016 +0100
Committer: Steve Loughran <st...@apache.org>
Committed: Thu Oct 20 19:32:10 2016 +0100

----------------------------------------------------------------------
 .../hadoop/fs/viewfs/ChRootedFileSystem.java    |   5 -
 .../apache/hadoop/fs/viewfs/ViewFileSystem.java |   2 +-
 .../viewfs/TestViewFileSystemWithTruncate.java  | 123 -------------------
 3 files changed, 1 insertion(+), 129 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hadoop/blob/ab36519b/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java b/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java
index 943846d..46e8f2d 100644
--- a/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java
+++ b/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ChRootedFileSystem.java
@@ -354,11 +354,6 @@ class ChRootedFileSystem extends FilterFileSystem {
   }
 
   @Override
-  public boolean truncate(Path path, long newLength) throws IOException {
-    return super.truncate(fullPath(path), newLength);
-  }
-
-  @Override
   public List<String> listXAttrs(Path path) throws IOException {
     return super.listXAttrs(fullPath(path));
   }

http://git-wip-us.apache.org/repos/asf/hadoop/blob/ab36519b/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java b/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java
index 0f090a5..37893d7 100644
--- a/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java
+++ b/hadoop-common-project/hadoop-common/src/main/java/org/apache/hadoop/fs/viewfs/ViewFileSystem.java
@@ -505,7 +505,7 @@ public class ViewFileSystem extends FileSystem {
       throws IOException {
     InodeTree.ResolveResult<FileSystem> res =
         fsState.resolve(getUriPath(f), true);
-    return res.targetFileSystem.truncate(res.remainingPath, newLength);
+    return res.targetFileSystem.truncate(f, newLength);
   }
   
   @Override

http://git-wip-us.apache.org/repos/asf/hadoop/blob/ab36519b/hadoop-hdfs-project/hadoop-hdfs/src/test/java/org/apache/hadoop/fs/viewfs/TestViewFileSystemWithTruncate.java
----------------------------------------------------------------------
diff --git a/hadoop-hdfs-project/hadoop-hdfs/src/test/java/org/apache/hadoop/fs/viewfs/TestViewFileSystemWithTruncate.java b/hadoop-hdfs-project/hadoop-hdfs/src/test/java/org/apache/hadoop/fs/viewfs/TestViewFileSystemWithTruncate.java
deleted file mode 100644
index 0b99cfe..0000000
--- a/hadoop-hdfs-project/hadoop-hdfs/src/test/java/org/apache/hadoop/fs/viewfs/TestViewFileSystemWithTruncate.java
+++ /dev/null
@@ -1,123 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * <p>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.hadoop.fs.viewfs;
-
-import java.io.IOException;
-
-import com.google.common.base.Supplier;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.fs.FSDataOutputStream;
-import org.apache.hadoop.fs.FileSystem;
-import org.apache.hadoop.fs.FileSystemTestHelper;
-import org.apache.hadoop.fs.FsConstants;
-import org.apache.hadoop.fs.Path;
-import org.apache.hadoop.hdfs.MiniDFSCluster;
-import org.apache.hadoop.hdfs.MiniDFSNNTopology;
-import org.apache.hadoop.test.GenericTestUtils;
-import org.junit.After;
-import org.junit.AfterClass;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Test;
-
-import static org.junit.Assert.*;
-
-/**
- * Verify truncate through ViewFileSystem functionality.
- *
- */
-public class TestViewFileSystemWithTruncate {
-  private static MiniDFSCluster cluster;
-  private static Configuration clusterConf = new Configuration();
-  private static FileSystem fHdfs;
-  private FileSystem fsView;
-  private Configuration fsViewConf;
-  private FileSystem fsTarget;
-  private Path targetTestRoot, mountOnNn1;
-  private FileSystemTestHelper fileSystemTestHelper =
-      new FileSystemTestHelper("/tmp/TestViewFileSystemWithXAttrs");
-
-  @BeforeClass
-  public static void clusterSetupAtBeginning() throws IOException {
-    cluster = new MiniDFSCluster.Builder(clusterConf)
-        .nnTopology(MiniDFSNNTopology.simpleFederatedTopology(2))
-        .numDataNodes(2).build();
-    cluster.waitClusterUp();
-
-    fHdfs = cluster.getFileSystem(0);
-  }
-
-  @AfterClass
-  public static void clusterShutdownAtEnd() throws Exception {
-    if (cluster != null) {
-      cluster.shutdown();
-    }
-  }
-
-  @Before
-  public void setUp() throws Exception {
-    fsTarget = fHdfs;
-    targetTestRoot = fileSystemTestHelper.getAbsoluteTestRootPath(fsTarget);
-
-    fsTarget.delete(targetTestRoot, true);
-    fsTarget.mkdirs(targetTestRoot);
-
-    fsViewConf = ViewFileSystemTestSetup.createConfig();
-    setupMountPoints();
-    fsView = FileSystem.get(FsConstants.VIEWFS_URI, fsViewConf);
-  }
-
-  private void setupMountPoints() {
-    mountOnNn1 = new Path("/mountOnNn1");
-    ConfigUtil
-        .addLink(fsViewConf, mountOnNn1.toString(), targetTestRoot.toUri());
-  }
-
-  @After
-  public void tearDown() throws Exception {
-    fsTarget.delete(fileSystemTestHelper.getTestRootPath(fsTarget), true);
-  }
-
-  @Test(timeout = 30000)
-  public void testTruncateWithViewFileSystem()
-      throws Exception {
-    Path filePath = new Path(mountOnNn1 + "/ttest");
-    Path hdfFilepath = new Path("/tmp/TestViewFileSystemWithXAttrs/ttest");
-    FSDataOutputStream out = fsView.create(filePath);
-    out.writeBytes("drtatedasfdasfgdfas");
-    out.close();
-    int newLength = 10;
-    boolean isReady = fsView.truncate(filePath, newLength);
-    if (!isReady) {
-      GenericTestUtils.waitFor(new Supplier<Boolean>() {
-        @Override
-        public Boolean get() {
-          try {
-            return cluster.getFileSystem(0).isFileClosed(hdfFilepath);
-          } catch (IOException e) {
-            return false;
-          }
-        }
-      }, 100, 60 * 1000);
-    }
-    // file length should be 10 after truncate
-    assertEquals(newLength, fsView.getFileStatus(filePath).getLen());
-  }
-
-}


---------------------------------------------------------------------
To unsubscribe, e-mail: common-commits-unsubscribe@hadoop.apache.org
For additional commands, e-mail: common-commits-help@hadoop.apache.org