/* * 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.swift.snative; import org.apache.commons.httpclient.Header; import org.apache.commons.httpclient.HttpStatus; import org.apache.commons.logging.Log; import org.apache.commons.logging.LogFactory; import org.apache.hadoop.conf.Configuration; import org.apache.hadoop.fs.FileStatus; import org.apache.hadoop.fs.Path; import org.apache.hadoop.fs.swift.exceptions.SwiftConfigurationException; import org.apache.hadoop.fs.swift.exceptions.SwiftException; import org.apache.hadoop.fs.swift.exceptions.SwiftInvalidResponseException; import org.apache.hadoop.fs.swift.exceptions.SwiftOperationFailedException; import org.apache.hadoop.fs.swift.http.HttpBodyContent; import org.apache.hadoop.fs.swift.http.SwiftProtocolConstants; import org.apache.hadoop.fs.swift.http.SwiftRestClient; import org.apache.hadoop.fs.swift.util.DurationStats; import org.apache.hadoop.fs.swift.util.JSONUtil; import org.apache.hadoop.fs.swift.util.SwiftObjectPath; import org.apache.hadoop.fs.swift.util.SwiftUtils; import org.codehaus.jackson.map.type.CollectionType; import java.io.ByteArrayInputStream; import java.io.FileNotFoundException; import java.io.IOException; import java.io.InputStream; import java.io.InterruptedIOException; import java.net.URI; import java.net.URISyntaxException; import java.text.ParseException; import java.text.SimpleDateFormat; import java.util.ArrayList; import java.util.Collection; import java.util.Collections; import java.util.LinkedList; import java.util.List; import java.util.regex.Matcher; import java.util.regex.Pattern; /** * File system store implementation. * Makes REST requests, parses data from responses */ public class SwiftNativeFileSystemStore { private static final Pattern URI_PATTERN = Pattern.compile("\"\\S+?\""); private static final String PATTERN = "EEE, d MMM yyyy hh:mm:ss zzz"; private static final Log LOG = LogFactory.getLog(SwiftNativeFileSystemStore.class); private URI uri; private SwiftRestClient swiftRestClient; /** * Initalize the filesystem store -this creates the REST client binding. * * @param fsURI URI of the filesystem, which is used to map to the filesystem-specific * options in the configuration file * @param configuration configuration * @throws IOException on any failure. */ public void initialize(URI fsURI, Configuration configuration) throws IOException { this.uri = fsURI; this.swiftRestClient = SwiftRestClient.getInstance(fsURI, configuration); } @Override public String toString() { return "SwiftNativeFileSystemStore with " + swiftRestClient; } /** * Get the default blocksize of this (bound) filesystem * @return the blocksize returned for all FileStatus queries, * which is used by the MapReduce splitter. */ public long getBlocksize() { return 1024L * swiftRestClient.getBlocksizeKB(); } public long getPartsizeKB() { return swiftRestClient.getPartSizeKB(); } public int getBufferSizeKB() { return swiftRestClient.getBufferSizeKB(); } public int getThrottleDelay() { return swiftRestClient.getThrottleDelay(); } /** * Upload a file/input stream of a specific length. * * @param path destination path in the swift filesystem * @param inputStream input data. This is closed afterwards, always * @param length length of the data * @throws IOException on a problem */ public void uploadFile(Path path, InputStream inputStream, long length) throws IOException { swiftRestClient.upload(toObjectPath(path), inputStream, length); } /** * Upload part of a larger file. * * @param path destination path * @param partNumber item number in the path * @param inputStream input data * @param length length of the data * @throws IOException on a problem */ public void uploadFilePart(Path path, int partNumber, InputStream inputStream, long length) throws IOException { String stringPath = path.toUri().toString(); String partitionFilename = SwiftUtils.partitionFilenameFromNumber( partNumber); if (stringPath.endsWith("/")) { stringPath = stringPath.concat(partitionFilename); } else { stringPath = stringPath.concat("/").concat(partitionFilename); } swiftRestClient.upload( new SwiftObjectPath(toDirPath(path).getContainer(), stringPath), inputStream, length); } /** * Tell the Swift server to expect a multi-part upload by submitting * a 0-byte file with the X-Object-Manifest header * * @param path path of final final * @throws IOException */ public void createManifestForPartUpload(Path path) throws IOException { String pathString = toObjectPath(path).toString(); if (!pathString.endsWith("/")) { pathString = pathString.concat("/"); } if (pathString.startsWith("/")) { pathString = pathString.substring(1); } swiftRestClient.upload(toObjectPath(path), new ByteArrayInputStream(new byte[0]), 0, new Header(SwiftProtocolConstants.X_OBJECT_MANIFEST, pathString)); } /** * Get the metadata of an object * * @param path path * @return file metadata. -or null if no headers were received back from the server. * @throws IOException on a problem * @throws FileNotFoundException if there is nothing at the end */ public SwiftFileStatus getObjectMetadata(Path path) throws IOException { return getObjectMetadata(path, true); } /** * Get the HTTP headers, in case you really need the low-level * metadata * @param path path to probe * @param newest newest or oldest? * @return the header list * @throws IOException IO problem * @throws FileNotFoundException if there is nothing at the end */ public Header[] getObjectHeaders(Path path, boolean newest) throws IOException, FileNotFoundException { SwiftObjectPath objectPath = toObjectPath(path); return stat(objectPath, newest); } /** * Get the metadata of an object * * @param path path * @param newest flag to say "set the newest header", otherwise take any entry * @return file metadata. -or null if no headers were received back from the server. * @throws IOException on a problem * @throws FileNotFoundException if there is nothing at the end */ public SwiftFileStatus getObjectMetadata(Path path, boolean newest) throws IOException, FileNotFoundException { SwiftObjectPath objectPath = toObjectPath(path); final Header[] headers = stat(objectPath, newest); //no headers is treated as a missing file if (headers.length == 0) { throw new FileNotFoundException("Not Found " + path.toUri()); } boolean isDir = false; long length = 0; long lastModified = 0 ; for (Header header : headers) { String headerName = header.getName(); if (headerName.equals(SwiftProtocolConstants.X_CONTAINER_OBJECT_COUNT) || headerName.equals(SwiftProtocolConstants.X_CONTAINER_BYTES_USED)) { length = 0; isDir = true; } if (SwiftProtocolConstants.HEADER_CONTENT_LENGTH.equals(headerName)) { length = Long.parseLong(header.getValue()); } if (SwiftProtocolConstants.HEADER_LAST_MODIFIED.equals(headerName)) { final SimpleDateFormat simpleDateFormat = new SimpleDateFormat(PATTERN); try { lastModified = simpleDateFormat.parse(header.getValue()).getTime(); } catch (ParseException e) { throw new SwiftException("Failed to parse " + header.toString(), e); } } } if (lastModified == 0) { lastModified = System.currentTimeMillis(); } Path correctSwiftPath = getCorrectSwiftPath(path); return new SwiftFileStatus(length, isDir, 1, getBlocksize(), lastModified, correctSwiftPath); } private Header[] stat(SwiftObjectPath objectPath, boolean newest) throws IOException { Header[] headers; if (newest) { headers = swiftRestClient.headRequest("getObjectMetadata-newest", objectPath, SwiftRestClient.NEWEST); } else { headers = swiftRestClient.headRequest("getObjectMetadata", objectPath); } return headers; } /** * Get the object as an input stream * * @param path object path * @return the input stream -this must be closed to terminate the connection * @throws IOException IO problems * @throws FileNotFoundException path doesn't resolve to an object */ public HttpBodyContent getObject(Path path) throws IOException { return swiftRestClient.getData(toObjectPath(path), SwiftRestClient.NEWEST); } /** * Get the input stream starting from a specific point. * * @param path path to object * @param byteRangeStart starting point * @param length no. of bytes * @return an input stream that must be closed * @throws IOException IO problems */ public HttpBodyContent getObject(Path path, long byteRangeStart, long length) throws IOException { return swiftRestClient.getData( toObjectPath(path), byteRangeStart, length); } /** * List a directory. * This is O(n) for the number of objects in this path. * * * * @param path working path * @param listDeep ask for all the data * @param newest ask for the newest data * @return Collection of file statuses * @throws IOException IO problems * @throws FileNotFoundException if the path does not exist */ private List<FileStatus> listDirectory(SwiftObjectPath path, boolean listDeep, boolean newest) throws IOException { final byte[] bytes; final ArrayList<FileStatus> files = new ArrayList<FileStatus>(); final Path correctSwiftPath = getCorrectSwiftPath(path); try { bytes = swiftRestClient.listDeepObjectsInDirectory(path, listDeep); } catch (FileNotFoundException e) { if (LOG.isDebugEnabled()) { LOG.debug("" + "File/Directory not found " + path); } if (SwiftUtils.isRootDir(path)) { return Collections.emptyList(); } else { throw e; } } catch (SwiftInvalidResponseException e) { //bad HTTP error code if (e.getStatusCode() == HttpStatus.SC_NO_CONTENT) { //this can come back on a root list if the container is empty if (SwiftUtils.isRootDir(path)) { return Collections.emptyList(); } else { //NO_CONTENT returned on something other than the root directory; //see if it is there, and convert to empty list or not found //depending on whether the entry exists. FileStatus stat = getObjectMetadata(correctSwiftPath, newest); if (stat.isDirectory()) { //it's an empty directory. state that return Collections.emptyList(); } else { //it's a file -return that as the status files.add(stat); return files; } } } else { //a different status code: rethrow immediately throw e; } } final CollectionType collectionType = JSONUtil.getJsonMapper().getTypeFactory(). constructCollectionType(List.class, SwiftObjectFileStatus.class); final List<SwiftObjectFileStatus> fileStatusList = JSONUtil.toObject(new String(bytes), collectionType); //this can happen if user lists file /data/files/file //in this case swift will return empty array if (fileStatusList.isEmpty()) { SwiftFileStatus objectMetadata = getObjectMetadata(correctSwiftPath, newest); if (objectMetadata.isFile()) { files.add(objectMetadata); } return files; } for (SwiftObjectFileStatus status : fileStatusList) { if (status.getName() != null) { files.add(new SwiftFileStatus(status.getBytes(), status.getBytes() == 0, 1, getBlocksize(), status.getLast_modified().getTime(), getCorrectSwiftPath(new Path(status.getName())))); } } return files; } /** * List all elements in this directory * * * * @param path path to work with * @param recursive do a recursive get * @param newest ask for the newest, or can some out of date data work? * @return the file statuses, or an empty array if there are no children * @throws IOException on IO problems * @throws FileNotFoundException if the path is nonexistent */ public FileStatus[] listSubPaths(Path path, boolean recursive, boolean newest) throws IOException { final Collection<FileStatus> fileStatuses; fileStatuses = listDirectory(toDirPath(path), recursive, newest); return fileStatuses.toArray(new FileStatus[fileStatuses.size()]); } /** * Create a directory * * @param path path * @throws IOException */ public void createDirectory(Path path) throws IOException { innerCreateDirectory(toDirPath(path)); } /** * The inner directory creation option. This only creates * the dir at the given path, not any parent dirs. * @param swiftObjectPath swift object path at which a 0-byte blob should be * put * @throws IOException IO problems */ private void innerCreateDirectory(SwiftObjectPath swiftObjectPath) throws IOException { swiftRestClient.putRequest(swiftObjectPath); } private SwiftObjectPath toDirPath(Path path) throws SwiftConfigurationException { return SwiftObjectPath.fromPath(uri, path, false); } private SwiftObjectPath toObjectPath(Path path) throws SwiftConfigurationException { return SwiftObjectPath.fromPath(uri, path); } /** * Try to find the specific server(s) on which the data lives * @param path path to probe * @return a possibly empty list of locations * @throws IOException on problems determining the locations */ public List<URI> getObjectLocation(Path path) throws IOException { final byte[] objectLocation; objectLocation = swiftRestClient.getObjectLocation(toObjectPath(path)); if (objectLocation == null || objectLocation.length == 0) { //no object location, return an empty list return new LinkedList<URI>(); } return extractUris(new String(objectLocation), path); } /** * deletes object from Swift * * @param path path to delete * @return true if the path was deleted by this specific operation. * @throws IOException on a failure */ public boolean deleteObject(Path path) throws IOException { SwiftObjectPath swiftObjectPath = toObjectPath(path); if (!SwiftUtils.isRootDir(swiftObjectPath)) { return swiftRestClient.delete(swiftObjectPath); } else { if (LOG.isDebugEnabled()) { LOG.debug("Not deleting root directory entry"); } return true; } } /** * deletes a directory from Swift. This is not recursive * * @param path path to delete * @return true if the path was deleted by this specific operation -or * the path was root and not acted on. * @throws IOException on a failure */ public boolean rmdir(Path path) throws IOException { return deleteObject(path); } /** * Does the object exist * * @param path object path * @return true if the metadata of an object could be retrieved * @throws IOException IO problems other than FileNotFound, which * is downgraded to an object does not exist return code */ public boolean objectExists(Path path) throws IOException { return objectExists(toObjectPath(path)); } /** * Does the object exist * * @param path swift object path * @return true if the metadata of an object could be retrieved * @throws IOException IO problems other than FileNotFound, which * is downgraded to an object does not exist return code */ public boolean objectExists(SwiftObjectPath path) throws IOException { try { Header[] headers = swiftRestClient.headRequest("objectExists", path, SwiftRestClient.NEWEST); //no headers is treated as a missing file return headers.length != 0; } catch (FileNotFoundException e) { return false; } } /** * Rename through copy-and-delete. this is a consequence of the * Swift filesystem using the path as the hash * into the Distributed Hash Table, "the ring" of filenames. * <p/> * Because of the nature of the operation, it is not atomic. * * @param src source file/dir * @param dst destination * @throws IOException IO failure * @throws SwiftOperationFailedException if the rename failed * @throws FileNotFoundException if the source directory is missing, or * the parent directory of the destination */ public void rename(Path src, Path dst) throws FileNotFoundException, SwiftOperationFailedException, IOException { if (LOG.isDebugEnabled()) { LOG.debug("mv " + src + " " + dst); } boolean renamingOnToSelf = src.equals(dst); SwiftObjectPath srcObject = toObjectPath(src); SwiftObjectPath destObject = toObjectPath(dst); if (SwiftUtils.isRootDir(srcObject)) { throw new SwiftOperationFailedException("cannot rename root dir"); } final SwiftFileStatus srcMetadata; srcMetadata = getObjectMetadata(src); SwiftFileStatus dstMetadata; try { dstMetadata = getObjectMetadata(dst); } catch (FileNotFoundException e) { //destination does not exist. LOG.debug("Destination does not exist"); dstMetadata = null; } //check to see if the destination parent directory exists Path srcParent = src.getParent(); Path dstParent = dst.getParent(); //skip the overhead of a HEAD call if the src and dest share the same //parent dir (in which case the dest dir exists), or the destination //directory is root, in which case it must also exist if (dstParent != null && !dstParent.equals(srcParent)) { try { getObjectMetadata(dstParent); } catch (FileNotFoundException e) { //destination parent doesn't exist; bail out LOG.debug("destination parent directory " + dstParent + " doesn't exist"); throw e; } } boolean destExists = dstMetadata != null; boolean destIsDir = destExists && SwiftUtils.isDirectory(dstMetadata); //calculate the destination SwiftObjectPath destPath; //enum the child entries and everything underneath List<FileStatus> childStats = listDirectory(srcObject, true, true); boolean srcIsFile = !srcMetadata.isDir(); if (srcIsFile) { //source is a simple file OR a partitioned file // outcomes: // #1 dest exists and is file: fail // #2 dest exists and is dir: destination path becomes under dest dir // #3 dest does not exist: use dest as name if (destExists) { if (destIsDir) { //outcome #2 -move to subdir of dest destPath = toObjectPath(new Path(dst, src.getName())); } else { //outcome #1 dest it's a file: fail if differeent if (!renamingOnToSelf) { throw new SwiftOperationFailedException( "cannot rename a file over one that already exists"); } else { //is mv self self where self is a file. this becomes a no-op LOG.debug("Renaming file onto self: no-op => success"); return; } } } else { //outcome #3 -new entry destPath = toObjectPath(dst); } int childCount = childStats.size(); //here there is one of: // - a single object ==> standard file // -> if (childCount == 0) { copyThenDeleteObject(srcObject, destPath); } else { //do the copy SwiftUtils.debug(LOG, "Source file appears to be partitioned." + " copying file and deleting children"); copyObject(srcObject, destPath); for (FileStatus stat : childStats) { SwiftUtils.debug(LOG, "Deleting partitioned file %s ", stat); deleteObject(stat.getPath()); } swiftRestClient.delete(srcObject); } } else { //here the source exists and is a directory // outcomes (given we know the parent dir exists if we get this far) // #1 destination is a file: fail // #2 destination is a directory: create a new dir under that one // #3 destination doesn't exist: create a new dir with that name // #3 and #4 are only allowed if the dest path is not == or under src if (destExists && !destIsDir) { // #1 destination is a file: fail throw new SwiftOperationFailedException( "the source is a directory, but not the destination"); } Path targetPath; if (destExists) { // #2 destination is a directory: create a new dir under that one targetPath = new Path(dst, src.getName()); } else { // #3 destination doesn't exist: create a new dir with that name targetPath = dst; } SwiftObjectPath targetObjectPath = toObjectPath(targetPath); //final check for any recursive operations if (srcObject.isEqualToOrParentOf(targetObjectPath)) { //you can't rename a directory onto itself throw new SwiftOperationFailedException( "cannot move a directory under itself"); } LOG.info("mv " + srcObject + " " + targetPath); logDirectory("Directory to copy ", srcObject, childStats); // iterative copy of everything under the directory. // by listing all children this can be done iteratively // rather than recursively -everything in this list is either a file // or a 0-byte-len file pretending to be a directory. String srcURI = src.toUri().toString(); int prefixStripCount = srcURI.length() + 1; for (FileStatus fileStatus : childStats) { Path copySourcePath = fileStatus.getPath(); String copySourceURI = copySourcePath.toUri().toString(); String copyDestSubPath = copySourceURI.substring(prefixStripCount); Path copyDestPath = new Path(targetPath, copyDestSubPath); if (LOG.isTraceEnabled()) { //trace to debug some low-level rename path problems; retained //in case they ever come back. LOG.trace("srcURI=" + srcURI + "; copySourceURI=" + copySourceURI + "; copyDestSubPath=" + copyDestSubPath + "; copyDestPath=" + copyDestPath); } SwiftObjectPath copyDestination = toObjectPath(copyDestPath); try { copyThenDeleteObject(toObjectPath(copySourcePath), copyDestination); } catch (FileNotFoundException e) { LOG.info("Skipping rename of " + copySourcePath); } //add a throttle delay throttle(); } //now rename self. If missing, create the dest directory and warn if (!SwiftUtils.isRootDir(srcObject)) { try { copyThenDeleteObject(srcObject, targetObjectPath); } catch (FileNotFoundException e) { //create the destination directory LOG.warn("Source directory deleted during rename", e); innerCreateDirectory(destObject); } } } } /** * Debug action to dump directory statuses to the debug log * * @param message explanation * @param objectPath object path (can be null) * @param statuses listing output */ private void logDirectory(String message, SwiftObjectPath objectPath, Iterable<FileStatus> statuses) { if (LOG.isDebugEnabled()) { LOG.debug(message + ": listing of " + objectPath); for (FileStatus fileStatus : statuses) { LOG.debug(fileStatus.getPath()); } } } public void copy(Path srcKey, Path dstKey) throws IOException { SwiftObjectPath srcObject = toObjectPath(srcKey); SwiftObjectPath destObject = toObjectPath(dstKey); swiftRestClient.copyObject(srcObject, destObject); } /** * Copy an object then, if the copy worked, delete it. * If the copy failed, the source object is not deleted. * * @param srcObject source object path * @param destObject destination object path * @throws IOException IO problems */ private void copyThenDeleteObject(SwiftObjectPath srcObject, SwiftObjectPath destObject) throws IOException { //do the copy copyObject(srcObject, destObject); //getting here means the copy worked swiftRestClient.delete(srcObject); } /** * Copy an object * @param srcObject source object path * @param destObject destination object path * @throws IOException IO problems */ private void copyObject(SwiftObjectPath srcObject, SwiftObjectPath destObject) throws IOException { if (srcObject.isEqualToOrParentOf(destObject)) { throw new SwiftException( "Can't copy " + srcObject + " onto " + destObject); } //do the copy boolean copySucceeded = swiftRestClient.copyObject(srcObject, destObject); if (!copySucceeded) { throw new SwiftException("Copy of " + srcObject + " to " + destObject + "failed"); } } /** * Take a Hadoop path and return one which uses the URI prefix and authority * of this FS. It doesn't make a relative path absolute * @param path path in * @return path with a URI bound to this FS * @throws SwiftException URI cannot be created. */ public Path getCorrectSwiftPath(Path path) throws SwiftException { try { final URI fullUri = new URI(uri.getScheme(), uri.getAuthority(), path.toUri().getPath(), null, null); return new Path(fullUri); } catch (URISyntaxException e) { throw new SwiftException("Specified path " + path + " is incorrect", e); } } /** * Builds a hadoop-Path from a swift path, inserting the URI authority * of this FS instance * @param path swift object path * @return Hadoop path * @throws SwiftException if the URI couldn't be created. */ private Path getCorrectSwiftPath(SwiftObjectPath path) throws SwiftException { try { final URI fullUri = new URI(uri.getScheme(), uri.getAuthority(), path.getObject(), null, null); return new Path(fullUri); } catch (URISyntaxException e) { throw new SwiftException("Specified path " + path + " is incorrect", e); } } /** * extracts URIs from json * @param json json to parse * @param path path (used in exceptions) * @return URIs * @throws SwiftOperationFailedException on any problem parsing the JSON */ public static List<URI> extractUris(String json, Path path) throws SwiftOperationFailedException { final Matcher matcher = URI_PATTERN.matcher(json); final List<URI> result = new ArrayList<URI>(); while (matcher.find()) { final String s = matcher.group(); final String uri = s.substring(1, s.length() - 1); try { URI createdUri = URI.create(uri); result.add(createdUri); } catch (IllegalArgumentException e) { //failure to create the URI, which means this is bad JSON. Convert //to an exception with useful text throw new SwiftOperationFailedException( String.format( "could not convert \"%s\" into a URI." + " source: %s " + " first JSON: %s", uri, path, json.substring(0, 256))); } } return result; } /** * Insert a throttled wait if the throttle delay >0 * @throws InterruptedIOException if interrupted during sleep */ public void throttle() throws InterruptedIOException { int throttleDelay = getThrottleDelay(); if (throttleDelay > 0) { try { Thread.sleep(throttleDelay); } catch (InterruptedException e) { //convert to an IOE throw (InterruptedIOException) new InterruptedIOException(e.toString()) .initCause(e); } } } /** * Get the current operation statistics * @return a snapshot of the statistics */ public List<DurationStats> getOperationStatistics() { return swiftRestClient.getOperationStatistics(); } /** * Delete the entire tree. This is an internal one with slightly different * behavior: if an entry is missing, a {@link FileNotFoundException} is * raised. This lets the caller distinguish a file not found with * other reasons for failure, so handles race conditions in recursive * directory deletes better. * <p/> * The problem being addressed is: caller A requests a recursive directory * of directory /dir ; caller B requests a delete of a file /dir/file, * between caller A enumerating the files contents, and requesting a delete * of /dir/file. We want to recognise the special case * "directed file is no longer there" and not convert that into a failure * * @param absolutePath the path to delete. * @param recursive if path is a directory and set to * true, the directory is deleted else throws an exception if the * directory is not empty * case of a file the recursive can be set to either true or false. * @return true if the object was deleted * @throws IOException IO problems * @throws FileNotFoundException if a file/dir being deleted is not there - * this includes entries below the specified path, (if the path is a dir * and recursive is true) */ public boolean delete(Path absolutePath, boolean recursive) throws IOException { Path swiftPath = getCorrectSwiftPath(absolutePath); SwiftUtils.debug(LOG, "Deleting path '%s' recursive=%b", absolutePath, recursive); boolean askForNewest = true; SwiftFileStatus fileStatus = getObjectMetadata(swiftPath, askForNewest); //ask for the file/dir status, but don't demand the newest, as we //don't mind if the directory has changed //list all entries under this directory. //this will throw FileNotFoundException if the file isn't there FileStatus[] statuses = listSubPaths(absolutePath, true, askForNewest); if (statuses == null) { //the directory went away during the non-atomic stages of the operation. // Return false as it was not this thread doing the deletion. SwiftUtils.debug(LOG, "Path '%s' has no status -it has 'gone away'", absolutePath, recursive); return false; } int filecount = statuses.length; SwiftUtils.debug(LOG, "Path '%s' %d status entries'", absolutePath, filecount); if (filecount == 0) { //it's an empty directory or a path rmdir(absolutePath); return true; } if (LOG.isDebugEnabled()) { SwiftUtils.debug(LOG, SwiftUtils.fileStatsToString(statuses, "\n")); } if (filecount == 1 && swiftPath.equals(statuses[0].getPath())) { // 1 entry => simple file and it is the target //simple file: delete it SwiftUtils.debug(LOG, "Deleting simple file %s", absolutePath); deleteObject(absolutePath); return true; } //>1 entry implies directory with children. Run through them, // but first check for the recursive flag and reject it *unless it looks // like a partitioned file (len > 0 && has children) if (!fileStatus.isDir()) { LOG.debug("Multiple child entries but entry has data: assume partitioned"); } else if (!recursive) { //if there are children, unless this is a recursive operation, fail immediately throw new SwiftOperationFailedException("Directory " + fileStatus + " is not empty: " + SwiftUtils.fileStatsToString( statuses, "; ")); } //delete the entries. including ourself. for (FileStatus entryStatus : statuses) { Path entryPath = entryStatus.getPath(); try { boolean deleted = deleteObject(entryPath); if (!deleted) { SwiftUtils.debug(LOG, "Failed to delete entry '%s'; continuing", entryPath); } } catch (FileNotFoundException e) { //the path went away -race conditions. //do not fail, as the outcome is still OK. SwiftUtils.debug(LOG, "Path '%s' is no longer present; continuing", entryPath); } throttle(); } //now delete self SwiftUtils.debug(LOG, "Deleting base entry %s", absolutePath); deleteObject(absolutePath); return true; } }