Example usage for org.apache.hadoop.fs FileSystem subclass-usage

List of usage examples for org.apache.hadoop.fs FileSystem subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.fs FileSystem subclass-usage.

Usage

From source file com.quantcast.qfs.hadoop.QuantcastFileSystem.java

public class QuantcastFileSystem extends FileSystem {

    protected FileSystem localFs = null;
    protected IFSImpl qfsImpl = null;
    protected URI uri = null;
    protected Path workingDir = null;

From source file com.qubole.rubix.core.CachingFileSystem.java

/**
 * Created by stagra on 29/12/15.
 */
public abstract class CachingFileSystem<T extends FileSystem> extends FileSystem {
    private static final Log log = LogFactory.getLog(CachingFileSystem.class);
    private T fs = null;

From source file com.quixey.hadoop.fs.oss.OSSFileSystem.java

/**
 * <p>
 * A {@link org.apache.hadoop.fs.FileSystem} for reading and writing files stored on
 * <a href="http://www.aliyun.com/product/oss/">Aliyun OSS</a>.
 * </p>
 *

From source file com.rapleaf.ramhdfs.RamFileSystem.java

public class RamFileSystem extends FileSystem {

    private static DefaultFileSystemManager fsManager = new DefaultFileSystemManager();
    private static URI NAME;
    private static Path workingDir;

From source file com.splicemachine.fs.s3.PrestoS3FileSystem.java

public class PrestoS3FileSystem extends FileSystem {
    private static final Logger log = Logger.get(PrestoS3FileSystem.class);

    private static final PrestoS3FileSystemStats STATS = new PrestoS3FileSystemStats();
    private static final PrestoS3FileSystemMetricCollector METRIC_COLLECTOR = new PrestoS3FileSystemMetricCollector(
            STATS);

From source file com.uber.hoodie.common.io.storage.HoodieWrapperFileSystem.java

/**
 * HoodieWrapperFileSystem wraps the default file system. It holds state about the open streams in
 * the file system to support getting the written size to each of the open streams.
 */
public class HoodieWrapperFileSystem extends FileSystem {

From source file com.uber.hoodie.io.storage.HoodieWrapperFileSystem.java

/**
 * HoodieWrapperFileSystem wraps the default file system.
 * It holds state about the open streams in the file system to support getting the
 * written size to each of the open streams.
 */
public class HoodieWrapperFileSystem extends FileSystem {

From source file de.zib.sfs.StatisticsFileSystem.java

/**
 * Implements the Hadoop {@link org.apache.hadoop.fs.FileSystem} interface as it
 * is used in Hadoop and Flink.
 * 
 * @author robert
 *

From source file edu.umn.cs.spatialHadoop.nasa.HTTPFileSystem.java

/**
 * A {@link FileSystem} that is able to open HTTP files. Note that certain
 * features are not supported by the HTTP scheme by design. First, it is
 * read-only which makes all write functionality not supported. Second, it
 * cannot list contents of a directory. For listing, some web browsers provide a
 * default behavior that lists contents of a directory as HTTP links. We try to

From source file gobblin.source.extractor.extract.google.GoogleDriveFileSystem.java

/**
 * A {@link FileSystem} implementation that provides the {@link FileSystem} interface for an Google Drive server.
 * <ul>
 * <li>Note that {@link GoogleDriveFileSystem} currently only supports list, get, delete use cases.
 * <li>Google drive has two different identifier. File ID and File name -- where folder is just different mime-type of File.
 * As File name can be duplicate under same folder, all path that GoogleDriveFileSystem takes assumes that it's a File ID.