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

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

Introduction

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

Usage

From source file alluxio.hadoop.HdfsFileInputStream.java

/**
 * An input stream for reading a file from HDFS.
 */
@NotThreadSafe
public class HdfsFileInputStream extends InputStream implements Seekable, PositionedReadable {
    private static final Logger LOG = LoggerFactory.getLogger(Constants.LOGGER_TYPE);

From source file com.dasasian.chok.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.
 * <br>
 * Usage Example: <br>
 * <i>//creates an throttled input stream which reads 1024 bytes/sec from the

From source file com.knewton.mrtool.io.SeekableByteArrayInputStream.java

/**
 * Helper input stream which composes a {@link ByteArrayInputStream} and implements {@link Seekable}
 * and {@link PositionedReadable} for testing the {@link JsonRecordReader}
 * 
 */
public class SeekableByteArrayInputStream extends InputStream implements Seekable, PositionedReadable {

From source file com.netflix.bdp.inviso.fs.WrappedCompressionInputStream.java

/**
 * Wrapping CompressionInputStream so the job history loader can read a compressed stream.
 *
 * @author dweeks
 */
public class WrappedCompressionInputStream extends CompressionInputStream implements PositionedReadable {

From source file com.ricemap.spateDB.io.MemoryInputStream.java

public class MemoryInputStream extends ByteArrayInputStream implements Seekable, PositionedReadable {

    int originalOffset;

    public MemoryInputStream(byte[] buf, int offset, int length) {
        super(buf, offset, length);

From source file com.twitter.hraven.util.ByteArrayWrapper.java

/**
 * An input stream class backed by a byte array that also implements
 * <code>PositionedReadable</code>, <code>Seekable</code>, and <code>Closeable</code>. It can be
 * used as an input to the <code>FSDataInputStream</code>.
 *
 * @see org.apache.hadoop.fs.FSDataInputStream

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

public class WrappedFSDataInputStream extends InputStream implements PositionedReadable, Seekable {

    private final FSDataInputStream in;
    private final int fd;

    private final String hostname;

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

public class MemoryInputStream extends ByteArrayInputStream implements Seekable, PositionedReadable {

    int originalOffset;

    public MemoryInputStream(byte[] buf, int offset, int length) {
        super(buf, offset, length);

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.