public class AsynchronousBufferFileReader extends AsynchronousFileIOChannel<Buffer,org.apache.flink.runtime.io.disk.iomanager.ReadRequest> implements BufferFileReader
FileIOChannel.Enumerator, FileIOChannel.ID
closed, closeLock, exception, requestQueue, requestsNotReturned, resultHandler
fileChannel, id, LOG
Modifier | Constructor and Description |
---|---|
protected |
AsynchronousBufferFileReader(FileIOChannel.ID channelID,
RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue,
RequestDoneCallback<Buffer> callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
hasReachedEndOfFile() |
void |
readInto(Buffer buffer) |
void |
seekToPosition(long position) |
addRequest, checkErroneous, close, closeAndDelete, handleProcessedBuffer, isClosed, registerAllRequestsProcessedListener
deleteChannel, getChannelID, getNioFileChannel, getSize
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close, closeAndDelete, deleteChannel, getChannelID, getNioFileChannel, getSize, isClosed
protected AsynchronousBufferFileReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, RequestDoneCallback<Buffer> callback) throws IOException
IOException
public void readInto(Buffer buffer) throws IOException
readInto
in interface BufferFileReader
IOException
public void seekToPosition(long position) throws IOException
seekToPosition
in interface BufferFileReader
IOException
public boolean hasReachedEndOfFile()
hasReachedEndOfFile
in interface BufferFileReader
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.