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 gobblin.source.extractor.extract.sftp.SftpLightWeightFileSystem.java

/**
 * A {@link FileSystem} implementation that provides the {@link FileSystem} interface for an SFTP server. Uses
 * {@link SftpFsHelper} internally to connect to the SFPT server. {@link HadoopUtils#newConfiguration()}
 * <ul>
 * <li>It is the caller's responsibility to call {@link #close()} on this {@link FileSystem} to disconnect the session.
 * <li>Use {@link HadoopUtils#newConfiguration()} when creating a {@link FileSystem} with

From source file gobblin.util.filesystem.FileSystemDecorator.java

/**
 * This is a decorator for {@link FileSystem} that allows optionally changing scheme.
 *
 * Note subclasses must set the underlying {@link FileSystem} at {@link #underlyingFs} as necessary.
 */
class FileSystemDecorator extends FileSystem implements Decorator {

From source file hsyndicate.hadoop.dfs.HSyndicateDFS.java

public class HSyndicateDFS extends FileSystem {

    private static final Log LOG = LogFactory.getLog(HSyndicateDFS.class);

    private URI uri;
    private SyndicateFileSystem syndicateFS;

From source file io.pravega.segmentstore.storage.impl.hdfs.MockFileSystem.java

/**
 * Mock FileSystem for use in unit tests.
 */
@ThreadSafe
class MockFileSystem extends FileSystem {
    //region Members

From source file io.pravega.service.storage.impl.hdfs.MockFileSystem.java

/**
 * Mock FileSystem for use in unit tests.
 */
@ThreadSafe
class MockFileSystem extends FileSystem {
    //region Members

From source file io.prestosql.plugin.hive.s3.PrestoS3FileSystem.java

public class PrestoS3FileSystem extends FileSystem {
    static final String S3_DIRECTORY_OBJECT_CONTENT_TYPE = "application/x-directory";

    private static final Logger log = Logger.get(PrestoS3FileSystem.class);
    private static final PrestoS3FileSystemStats STATS = new PrestoS3FileSystemStats();
    private static final PrestoS3FileSystemMetricCollector METRIC_COLLECTOR = new PrestoS3FileSystemMetricCollector(

From source file org.apache.accumulo.server.trace.TraceFileSystem.java

public class TraceFileSystem extends FileSystem {

    @Override
    public void setConf(Configuration conf) {
        Span span = Trace.start("setConf");
        try {

From source file org.apache.cassandra.hadoop.fs.CassandraFileSystem.java

public class CassandraFileSystem extends FileSystem {
    private static final Logger logger = Logger.getLogger(CassandraFileSystem.class);

    private URI uri;

    public final CassandraFileSystemStore store;

From source file org.apache.distributedlog.fs.DLFileSystem.java

/**
 * A FileSystem Implementation powered by replicated logs.
 */
@Slf4j
public class DLFileSystem extends FileSystem {

From source file org.apache.drill.exec.store.CachedSingleFileSystem.java

public class CachedSingleFileSystem extends FileSystem {

    private ByteBuf file;
    private String path;

    public CachedSingleFileSystem(String path) throws IOException {