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 SeekableInputStream.java

public class SeekableInputStream extends FilterInputStream implements Seekable {
    private final Seekable seek;

    public SeekableInputStream(FSDataInputStream in) {
        super(in);
        this.seek = in;

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 co.cask.cdap.common.io.SeekableInputStream.java

/**
 * Abstract base class for {@link InputStream} that implements the {@link Seekable} interface.
 */
public abstract class SeekableInputStream extends FilterInputStream implements Seekable {

    /**

From source file co.cask.tigon.io.SeekableInputStream.java

/**
 * Abstract base class for {@link java.io.InputStream} that implements the
 * {@link org.apache.hadoop.fs.Seekable} interface.
 */
public abstract class SeekableInputStream extends FilterInputStream implements Seekable {

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.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);