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.facebook.presto.hive.ForwardingFileSystem.java

@SuppressWarnings("deprecation")
public abstract class ForwardingFileSystem extends FileSystem {
    private final FileSystem fileSystem;

    protected ForwardingFileSystem(FileSystem fileSystem) {
        this.fileSystem = checkNotNull(fileSystem, "fileSystem is null");

From source file com.facebook.presto.hive.PrestoS3FileSystem.java

public class PrestoS3FileSystem extends FileSystem {
    public static final String S3_SSL_ENABLED = "presto.s3.ssl.enabled";
    public static final String S3_MAX_ERROR_RETRIES = "presto.s3.max-error-retries";
    public static final String S3_MAX_CLIENT_RETRIES = "presto.s3.max-client-retries";
    public static final String S3_CONNECT_TIMEOUT = "presto.s3.connect-timeout";
    public static final String S3_STAGING_DIRECTORY = "presto.s3.staging-directory";

From source file com.facebook.presto.hive.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.google.cloud.hadoop.fs.gcs.GoogleHadoopFileSystemBase.java

/**
 * This class provides a Hadoop compatible File System on top of Google Cloud Storage (GCS).
 *
 * <p>It is implemented as a thin abstraction layer on top of GCS. The layer hides any specific
 * characteristics of the underlying store and exposes FileSystem interface understood by the Hadoop
 * engine.

From source file com.ibm.crail.hdfs.CrailHadoopFileSystem.java

public class CrailHadoopFileSystem extends FileSystem {
    private static final Logger LOG = CrailUtils.getLogger();
    private CrailFS dfs;
    private Path workingDir;
    private URI uri;

From source file com.ibm.stocator.fs.ObjectStoreFileSystem.java

/**
 * Object store driver implementation
 * Based on the Hadoop FileSystem interface
 *
 */
public class ObjectStoreFileSystem extends FileSystem {

From source file com.kenshoo.integrations.plugins.connectors.GCSFileSystem.java

public class GCSFileSystem extends FileSystem {

    protected GCSConnector connect(Path path) {
        Configuration conf = getConf();
        GCSConnector gcsConnector = new GCSConnector();
        gcsConnector.connect(conf, path);

From source file com.mellanox.r4h.DistributedFileSystem.java

/****************************************************************
 * Implementation of the abstract FileSystem for the DFS system.
 * This object is the way end-user code interacts with a Hadoop
 * DistributedFileSystem.
 * 
 *****************************************************************/

From source file com.netflix.bdp.s3.MockS3FileSystem.java

public class MockS3FileSystem extends FileSystem {
    public static final String BUCKET = "bucket-name";
    public static final URI FS_URI = URI.create("s3://" + BUCKET + "/");

    private FileSystem mock = null;

From source file com.pigai.hadoop.HttpFSFileSystem.java

/**
 * HttpFSServer implementation of the FileSystemAccess FileSystem.
 * <p/>
 * This implementation allows a user to access HDFS over HTTP via a HttpFSServer
 * server.
 */