All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.hadoop.fs.viewfs.InodeTree Maven / Gradle / Ivy

There is a newer version: 3.4.0
Show newest version
/**
 * 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
 * 

* http://www.apache.org/licenses/LICENSE-2.0 *

* 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 com.google.common.base.Preconditions; import java.io.FileNotFoundException; import java.io.IOException; import java.net.URI; import java.net.URISyntaxException; import java.util.ArrayList; import java.util.Collections; import java.util.HashMap; import java.util.LinkedList; import java.util.List; import java.util.Map; import java.util.Map.Entry; import org.apache.hadoop.classification.InterfaceAudience; import org.apache.hadoop.classification.InterfaceStability; import org.apache.hadoop.conf.Configuration; import org.apache.hadoop.fs.FileAlreadyExistsException; import org.apache.hadoop.fs.Path; import org.apache.hadoop.fs.UnsupportedFileSystemException; import org.apache.hadoop.security.UserGroupInformation; import org.apache.hadoop.util.StringUtils; /** * InodeTree implements a mount-table as a tree of inodes. * It is used to implement ViewFs and ViewFileSystem. * In order to use it the caller must subclass it and implement * the abstract methods {@link #getTargetFileSystem(INodeDir)}, etc. * * The mountable is initialized from the config variables as * specified in {@link ViewFs} * * @param is AbstractFileSystem or FileSystem * * The two main methods are * {@link #InodeTree(Configuration, String)} // constructor * {@link #resolve(String, boolean)} */ @InterfaceAudience.Private @InterfaceStability.Unstable abstract class InodeTree { enum ResultKind { INTERNAL_DIR, EXTERNAL_DIR } static final Path SlashPath = new Path("/"); // the root of the mount table private final INode root; // the fallback filesystem private final INodeLink rootFallbackLink; // the homedir for this mount table private final String homedirPrefix; private List> mountPoints = new ArrayList>(); static class MountPoint { String src; INodeLink target; MountPoint(String srcPath, INodeLink mountLink) { src = srcPath; target = mountLink; } } /** * Breaks file path into component names. * @param path * @return array of names component names */ static String[] breakIntoPathComponents(final String path) { return path == null ? null : path.split(Path.SEPARATOR); } /** * Internal class for INode tree. * @param */ abstract static class INode { final String fullPath; // the full path to the root public INode(String pathToNode, UserGroupInformation aUgi) { fullPath = pathToNode; } // INode forming the internal mount table directory tree // for ViewFileSystem. This internal directory tree is // constructed based on the mount table config entries // and is read only. abstract boolean isInternalDir(); // INode linking to another filesystem. Represented // via mount table link config entries. boolean isLink() { return !isInternalDir(); } } /** * Internal class to represent an internal dir of the mount table. * @param */ static class INodeDir extends INode { private final Map> children = new HashMap<>(); private T internalDirFs = null; //filesystem of this internal directory private boolean isRoot = false; INodeDir(final String pathToNode, final UserGroupInformation aUgi) { super(pathToNode, aUgi); } @Override boolean isInternalDir() { return true; } T getInternalDirFs() { return internalDirFs; } void setInternalDirFs(T internalDirFs) { this.internalDirFs = internalDirFs; } void setRoot(boolean root) { isRoot = root; } boolean isRoot() { return isRoot; } Map> getChildren() { return Collections.unmodifiableMap(children); } INode resolveInternal(final String pathComponent) { return children.get(pathComponent); } INodeDir addDir(final String pathComponent, final UserGroupInformation aUgi) throws FileAlreadyExistsException { if (children.containsKey(pathComponent)) { throw new FileAlreadyExistsException(); } final INodeDir newDir = new INodeDir(fullPath + (isRoot() ? "" : "/") + pathComponent, aUgi); children.put(pathComponent, newDir); return newDir; } void addLink(final String pathComponent, final INodeLink link) throws FileAlreadyExistsException { if (children.containsKey(pathComponent)) { throw new FileAlreadyExistsException(); } children.put(pathComponent, link); } } /** * Mount table link type. */ enum LinkType { /** * Link entry pointing to a single filesystem uri. * Config prefix: fs.viewfs.mounttable..link. * Refer: {@link Constants#CONFIG_VIEWFS_LINK} */ SINGLE, /** * Fallback filesystem for the paths not mounted by * any single link entries. * Config prefix: fs.viewfs.mounttable..linkFallback * Refer: {@link Constants#CONFIG_VIEWFS_LINK_FALLBACK} */ SINGLE_FALLBACK, /** * Link entry pointing to an union of two or more filesystem uris. * Config prefix: fs.viewfs.mounttable..linkMerge. * Refer: {@link Constants#CONFIG_VIEWFS_LINK_MERGE} */ MERGE, /** * Link entry for merging mount table's root with the * root of another filesystem. * Config prefix: fs.viewfs.mounttable..linkMergeSlash * Refer: {@link Constants#CONFIG_VIEWFS_LINK_MERGE_SLASH} */ MERGE_SLASH, /** * Link entry to write to multiple filesystems and read * from the closest filesystem. * Config prefix: fs.viewfs.mounttable..linkNfly * Refer: {@link Constants#CONFIG_VIEWFS_LINK_NFLY} */ NFLY; } /** * An internal class to represent a mount link. * A mount link can be single dir link or a merge dir link. * A merge dir link is a merge (junction) of links to dirs: * example : merge of 2 dirs * /users -> hdfs:nn1//users * /users -> hdfs:nn2//users * * For a merge, each target is checked to be dir when created but if target * is changed later it is then ignored (a dir with null entries) */ static class INodeLink extends INode { final URI[] targetDirLinkList; final T targetFileSystem; // file system object created from the link. /** * Construct a mergeLink or nfly. */ INodeLink(final String pathToNode, final UserGroupInformation aUgi, final T targetMergeFs, final URI[] aTargetDirLinkList) { super(pathToNode, aUgi); targetFileSystem = targetMergeFs; targetDirLinkList = aTargetDirLinkList; } /** * Construct a simple link (i.e. not a mergeLink). */ INodeLink(final String pathToNode, final UserGroupInformation aUgi, final T targetFs, final URI aTargetDirLink) { super(pathToNode, aUgi); targetFileSystem = targetFs; targetDirLinkList = new URI[1]; targetDirLinkList[0] = aTargetDirLink; } /** * Get the target of the link. If a merge link then it returned * as "," separated URI list. */ Path getTargetLink() { StringBuilder result = new StringBuilder(targetDirLinkList[0].toString()); // If merge link, use "," as separator between the merged URIs for (int i = 1; i < targetDirLinkList.length; ++i) { result.append(',').append(targetDirLinkList[i].toString()); } return new Path(result.toString()); } @Override boolean isInternalDir() { return false; } public T getTargetFileSystem() { return targetFileSystem; } } private void createLink(final String src, final String target, final LinkType linkType, final String settings, final UserGroupInformation aUgi, final Configuration config) throws URISyntaxException, IOException, FileAlreadyExistsException, UnsupportedFileSystemException { // Validate that src is valid absolute path final Path srcPath = new Path(src); if (!srcPath.isAbsoluteAndSchemeAuthorityNull()) { throw new IOException("ViewFs: Non absolute mount name in config:" + src); } final String[] srcPaths = breakIntoPathComponents(src); // Make sure root is of INodeDir type before // adding any regular links to it. Preconditions.checkState(root.isInternalDir()); INodeDir curInode = getRootDir(); int i; // Ignore first initial slash, process all except last component for (i = 1; i < srcPaths.length - 1; i++) { final String iPath = srcPaths[i]; INode nextInode = curInode.resolveInternal(iPath); if (nextInode == null) { INodeDir newDir = curInode.addDir(iPath, aUgi); newDir.setInternalDirFs(getTargetFileSystem(newDir)); nextInode = newDir; } if (nextInode.isLink()) { // Error - expected a dir but got a link throw new FileAlreadyExistsException("Path " + nextInode.fullPath + " already exists as link"); } else { assert(nextInode.isInternalDir()); curInode = (INodeDir) nextInode; } } // Now process the last component // Add the link in 2 cases: does not exist or a link exists String iPath = srcPaths[i];// last component if (curInode.resolveInternal(iPath) != null) { // directory/link already exists StringBuilder strB = new StringBuilder(srcPaths[0]); for (int j = 1; j <= i; ++j) { strB.append('/').append(srcPaths[j]); } throw new FileAlreadyExistsException("Path " + strB + " already exists as dir; cannot create link here"); } final INodeLink newLink; final String fullPath = curInode.fullPath + (curInode == root ? "" : "/") + iPath; switch (linkType) { case SINGLE: newLink = new INodeLink(fullPath, aUgi, getTargetFileSystem(new URI(target)), new URI(target)); break; case SINGLE_FALLBACK: case MERGE_SLASH: // Link fallback and link merge slash configuration // are handled specially at InodeTree. throw new IllegalArgumentException("Unexpected linkType: " + linkType); case MERGE: case NFLY: final URI[] targetUris = StringUtils.stringToURI( StringUtils.getStrings(target)); newLink = new INodeLink(fullPath, aUgi, getTargetFileSystem(settings, targetUris), targetUris); break; default: throw new IllegalArgumentException(linkType + ": Infeasible linkType"); } curInode.addLink(iPath, newLink); mountPoints.add(new MountPoint(src, newLink)); } /** * The user of this class must subclass and implement the following * 3 abstract methods. * @throws IOException */ protected abstract T getTargetFileSystem(URI uri) throws UnsupportedFileSystemException, URISyntaxException, IOException; protected abstract T getTargetFileSystem(INodeDir dir) throws URISyntaxException; protected abstract T getTargetFileSystem(String settings, URI[] mergeFsURIs) throws UnsupportedFileSystemException, URISyntaxException, IOException; private INodeDir getRootDir() { Preconditions.checkState(root.isInternalDir()); return (INodeDir)root; } private INodeLink getRootLink() { Preconditions.checkState(root.isLink()); return (INodeLink)root; } private boolean hasFallbackLink() { return rootFallbackLink != null; } private INodeLink getRootFallbackLink() { Preconditions.checkState(root.isInternalDir()); return rootFallbackLink; } /** * An internal class representing the ViewFileSystem mount table * link entries and their attributes. * @see LinkType */ private static class LinkEntry { private final String src; private final String target; private final LinkType linkType; private final String settings; private final UserGroupInformation ugi; private final Configuration config; LinkEntry(String src, String target, LinkType linkType, String settings, UserGroupInformation ugi, Configuration config) { this.src = src; this.target = target; this.linkType = linkType; this.settings = settings; this.ugi = ugi; this.config = config; } String getSrc() { return src; } String getTarget() { return target; } LinkType getLinkType() { return linkType; } boolean isLinkType(LinkType type) { return this.linkType == type; } String getSettings() { return settings; } UserGroupInformation getUgi() { return ugi; } Configuration getConfig() { return config; } } /** * Create Inode Tree from the specified mount-table specified in Config * @param config - the mount table keys are prefixed with * FsConstants.CONFIG_VIEWFS_PREFIX * @param viewName - the name of the mount table - if null use defaultMT name * @throws UnsupportedFileSystemException * @throws URISyntaxException * @throws FileAlreadyExistsException * @throws IOException */ protected InodeTree(final Configuration config, final String viewName) throws UnsupportedFileSystemException, URISyntaxException, FileAlreadyExistsException, IOException { String mountTableName = viewName; if (mountTableName == null) { mountTableName = Constants.CONFIG_VIEWFS_DEFAULT_MOUNT_TABLE; } homedirPrefix = ConfigUtil.getHomeDirValue(config, mountTableName); boolean isMergeSlashConfigured = false; String mergeSlashTarget = null; List linkEntries = new LinkedList<>(); final String mountTablePrefix = Constants.CONFIG_VIEWFS_PREFIX + "." + mountTableName + "."; final String linkPrefix = Constants.CONFIG_VIEWFS_LINK + "."; final String linkFallbackPrefix = Constants.CONFIG_VIEWFS_LINK_FALLBACK; final String linkMergePrefix = Constants.CONFIG_VIEWFS_LINK_MERGE + "."; final String linkMergeSlashPrefix = Constants.CONFIG_VIEWFS_LINK_MERGE_SLASH; boolean gotMountTableEntry = false; final UserGroupInformation ugi = UserGroupInformation.getCurrentUser(); for (Entry si : config) { final String key = si.getKey(); if (key.startsWith(mountTablePrefix)) { gotMountTableEntry = true; LinkType linkType; String src = key.substring(mountTablePrefix.length()); String settings = null; if (src.startsWith(linkPrefix)) { src = src.substring(linkPrefix.length()); if (src.equals(SlashPath.toString())) { throw new UnsupportedFileSystemException("Unexpected mount table " + "link entry '" + key + "'. Use " + Constants.CONFIG_VIEWFS_LINK_MERGE_SLASH + " instead!"); } linkType = LinkType.SINGLE; } else if (src.startsWith(linkFallbackPrefix)) { if (src.length() != linkFallbackPrefix.length()) { throw new IOException("ViewFs: Mount points initialization error." + " Invalid " + Constants.CONFIG_VIEWFS_LINK_FALLBACK + " entry in config: " + src); } linkType = LinkType.SINGLE_FALLBACK; } else if (src.startsWith(linkMergePrefix)) { // A merge link src = src.substring(linkMergePrefix.length()); linkType = LinkType.MERGE; } else if (src.startsWith(linkMergeSlashPrefix)) { // This is a LinkMergeSlash entry. This entry should // not have any additional source path. if (src.length() != linkMergeSlashPrefix.length()) { throw new IOException("ViewFs: Mount points initialization error." + " Invalid " + Constants.CONFIG_VIEWFS_LINK_MERGE_SLASH + " entry in config: " + src); } linkType = LinkType.MERGE_SLASH; } else if (src.startsWith(Constants.CONFIG_VIEWFS_LINK_NFLY)) { // prefix.settings.src src = src.substring(Constants.CONFIG_VIEWFS_LINK_NFLY.length() + 1); // settings.src settings = src.substring(0, src.indexOf('.')); // settings // settings.src src = src.substring(settings.length() + 1); // src linkType = LinkType.NFLY; } else if (src.startsWith(Constants.CONFIG_VIEWFS_HOMEDIR)) { // ignore - we set home dir from config continue; } else { throw new IOException("ViewFs: Cannot initialize: Invalid entry in " + "Mount table in config: " + src); } final String target = si.getValue(); if (linkType != LinkType.MERGE_SLASH) { if (isMergeSlashConfigured) { throw new IOException("Mount table " + mountTableName + " has already been configured with a merge slash link. " + "A regular link should not be added."); } linkEntries.add( new LinkEntry(src, target, linkType, settings, ugi, config)); } else { if (!linkEntries.isEmpty()) { throw new IOException("Mount table " + mountTableName + " has already been configured with regular links. " + "A merge slash link should not be configured."); } if (isMergeSlashConfigured) { throw new IOException("Mount table " + mountTableName + " has already been configured with a merge slash link. " + "Multiple merge slash links for the same mount table is " + "not allowed."); } isMergeSlashConfigured = true; mergeSlashTarget = target; } } } if (isMergeSlashConfigured) { Preconditions.checkNotNull(mergeSlashTarget); root = new INodeLink(mountTableName, ugi, getTargetFileSystem(new URI(mergeSlashTarget)), new URI(mergeSlashTarget)); mountPoints.add(new MountPoint("/", (INodeLink) root)); rootFallbackLink = null; } else { root = new INodeDir("/", UserGroupInformation.getCurrentUser()); getRootDir().setInternalDirFs(getTargetFileSystem(getRootDir())); getRootDir().setRoot(true); INodeLink fallbackLink = null; for (LinkEntry le : linkEntries) { if (le.isLinkType(LinkType.SINGLE_FALLBACK)) { if (fallbackLink != null) { throw new IOException("Mount table " + mountTableName + " has already been configured with a link fallback. " + "Multiple fallback links for the same mount table is " + "not allowed."); } fallbackLink = new INodeLink(mountTableName, ugi, getTargetFileSystem(new URI(le.getTarget())), new URI(le.getTarget())); } else { createLink(le.getSrc(), le.getTarget(), le.getLinkType(), le.getSettings(), le.getUgi(), le.getConfig()); } } rootFallbackLink = fallbackLink; } if (!gotMountTableEntry) { throw new IOException( "ViewFs: Cannot initialize: Empty Mount table in config for " + "viewfs://" + mountTableName + "/"); } } /** * Resolve returns ResolveResult. * The caller can continue the resolution of the remainingPath * in the targetFileSystem. * * If the input pathname leads to link to another file system then * the targetFileSystem is the one denoted by the link (except it is * file system chrooted to link target. * If the input pathname leads to an internal mount-table entry then * the target file system is one that represents the internal inode. */ static class ResolveResult { final ResultKind kind; final T targetFileSystem; final String resolvedPath; final Path remainingPath; // to resolve in the target FileSystem ResolveResult(final ResultKind k, final T targetFs, final String resolveP, final Path remainingP) { kind = k; targetFileSystem = targetFs; resolvedPath = resolveP; remainingPath = remainingP; } // Internal dir path resolution completed within the mount table boolean isInternalDir() { return (kind == ResultKind.INTERNAL_DIR); } } /** * Resolve the pathname p relative to root InodeDir * @param p - input path * @param resolveLastComponent * @return ResolveResult which allows further resolution of the remaining path * @throws FileNotFoundException */ ResolveResult resolve(final String p, final boolean resolveLastComponent) throws FileNotFoundException { String[] path = breakIntoPathComponents(p); if (path.length <= 1) { // special case for when path is "/" T targetFs = root.isInternalDir() ? getRootDir().getInternalDirFs() : getRootLink().getTargetFileSystem(); ResolveResult res = new ResolveResult(ResultKind.INTERNAL_DIR, targetFs, root.fullPath, SlashPath); return res; } /** * linkMergeSlash has been configured. The root of this mount table has * been linked to the root directory of a file system. * The first non-slash path component should be name of the mount table. */ if (root.isLink()) { Path remainingPath; StringBuilder remainingPathStr = new StringBuilder(); // ignore first slash for (int i = 1; i < path.length; i++) { remainingPathStr.append("/").append(path[i]); } remainingPath = new Path(remainingPathStr.toString()); ResolveResult res = new ResolveResult(ResultKind.EXTERNAL_DIR, getRootLink().getTargetFileSystem(), root.fullPath, remainingPath); return res; } Preconditions.checkState(root.isInternalDir()); INodeDir curInode = getRootDir(); int i; // ignore first slash for (i = 1; i < path.length - (resolveLastComponent ? 0 : 1); i++) { INode nextInode = curInode.resolveInternal(path[i]); if (nextInode == null) { if (hasFallbackLink()) { return new ResolveResult(ResultKind.EXTERNAL_DIR, getRootFallbackLink().getTargetFileSystem(), root.fullPath, new Path(p)); } else { StringBuilder failedAt = new StringBuilder(path[0]); for (int j = 1; j <= i; ++j) { failedAt.append('/').append(path[j]); } throw (new FileNotFoundException( "File/Directory does not exist: " + failedAt.toString())); } } if (nextInode.isLink()) { final INodeLink link = (INodeLink) nextInode; final Path remainingPath; if (i >= path.length - 1) { remainingPath = SlashPath; } else { StringBuilder remainingPathStr = new StringBuilder("/" + path[i + 1]); for (int j = i + 2; j < path.length; ++j) { remainingPathStr.append('/').append(path[j]); } remainingPath = new Path(remainingPathStr.toString()); } final ResolveResult res = new ResolveResult(ResultKind.EXTERNAL_DIR, link.getTargetFileSystem(), nextInode.fullPath, remainingPath); return res; } else if (nextInode.isInternalDir()) { curInode = (INodeDir) nextInode; } } // We have resolved to an internal dir in mount table. Path remainingPath; if (resolveLastComponent) { remainingPath = SlashPath; } else { // note we have taken care of when path is "/" above // for internal dirs rem-path does not start with / since the lookup // that follows will do a children.get(remaningPath) and will have to // strip-out the initial / StringBuilder remainingPathStr = new StringBuilder("/" + path[i]); for (int j = i + 1; j < path.length; ++j) { remainingPathStr.append('/').append(path[j]); } remainingPath = new Path(remainingPathStr.toString()); } final ResolveResult res = new ResolveResult(ResultKind.INTERNAL_DIR, curInode.getInternalDirFs(), curInode.fullPath, remainingPath); return res; } List> getMountPoints() { return mountPoints; } /** * * @return home dir value from mount table; null if no config value * was found. */ String getHomeDirPrefixValue() { return homedirPrefix; } }





© 2015 - 2024 Weber Informatics LLC | Privacy Policy