public class AsynchronousBufferFileSegmentReader extends AsynchronousFileIOChannel<FileSegment,org.apache.flink.runtime.io.disk.iomanager.ReadRequest> implements BufferFileSegmentReader
FileIOChannel.Enumerator, FileIOChannel.ID
closed, closeLock, exception, requestQueue, requestsNotReturned, resultHandler
fileChannel, id, LOG
Modifier | Constructor and Description |
---|---|
protected |
AsynchronousBufferFileSegmentReader(FileIOChannel.ID channelID,
RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue,
RequestDoneCallback<FileSegment> callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
hasReachedEndOfFile() |
void |
read() |
void |
seekTo(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 AsynchronousBufferFileSegmentReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, RequestDoneCallback<FileSegment> callback) throws IOException
IOException
public void read() throws IOException
read
in interface BufferFileSegmentReader
IOException
public void seekTo(long position) throws IOException
seekTo
in interface BufferFileSegmentReader
IOException
public boolean hasReachedEndOfFile()
hasReachedEndOfFile
in interface BufferFileSegmentReader
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.