Example usage for org.apache.hadoop.fs Seekable interface-usage

List of usage examples for org.apache.hadoop.fs Seekable interface-usage

Introduction

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

Usage

From source file edu.umn.cs.spatialHadoop.io.RandomCompressedInputStream.java

/**
 * Provides random access to a file that was previously written using
 * {@link RandomCompressedOutputStream}. The underlying stream should be
 * seekable and the total size of it should be known because the lookup table
 * that helps doing the random access is stored at the very end.
 * 

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

/**
 * A wrapper around a stream obtained from {@link URL#openStream()} that
 * makes it {@link Seekable} and {@link PositionedReadable} to be used
 * with {@link FSDataInputStream}, hence {@link HTTPFileSystem}.
 * 
 * All methods are delegated to the underlying (wrapped) input stream.

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

public class HSyndicateInputStream extends FSInputStream implements Seekable, PositionedReadable {

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

    private SyndicateFSPath path;
    private SyndicateFileSystem fs;

From source file net.sf.katta.util.ThrottledInputStream.java

/**
 * An {@link InputStream} which throttles the amount of bytes which is read from
 * the underlying {@link InputStream} in a given time frame.
 * 
 * <p>
 * Usage Example: <br>

From source file org.apache.accumulo.core.file.streams.RateLimitedInputStream.java

/**
 * A decorator for an {@code InputStream} which limits the rate at which reads are performed.
 */
public class RateLimitedInputStream extends FilterInputStream implements Seekable {
    private final RateLimiter rateLimiter;

From source file org.apache.accumulo.core.file.streams.SeekableDataInputStream.java

/**
 * A wrapper converting a {@link Seekable} {@code InputStream} into a {@code Seekable} {@link DataInputStream}
 */
public class SeekableDataInputStream extends DataInputStream implements Seekable {
    public <StreamType extends InputStream & Seekable> SeekableDataInputStream(StreamType stream) {
        super(stream);

From source file org.apache.ambari.view.hive.utils.SeekableByteArrayInputStream.java

/**
* Created by roma on 2/6/15.
*/
public class SeekableByteArrayInputStream extends ByteArrayInputStream implements Seekable, PositionedReadable {
    public SeekableByteArrayInputStream(byte[] buf) {
        super(buf);

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

public class ResourceInputStream extends ByteArrayInputStream implements Seekable, PositionedReadable {
    static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(ResourceInputStream.class);

    public ResourceInputStream(byte[] bytes) {
        super(bytes);
    }

From source file org.apache.drill.exec.vector.complex.fn.DrillBufInputStream.java

/**
 * An InputStream that wraps a DrillBuf and implements the seekable interface.
 */
public class DrillBufInputStream extends ByteBufInputStream implements Seekable {
    //private static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(DrillBufInputStream.class);

From source file org.apache.drill.exec.vector.complex.fn.SeekableBAIS.java

/**
 * A ByteArrayInputStream that supports the HDFS Seekable API.
 */
public class SeekableBAIS extends ByteArrayInputStream implements Seekable {

    static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(SeekableBAIS.class);