public class AsynchronousBulkBlockReader extends AsynchronousFileIOChannel<MemorySegment,org.apache.flink.runtime.io.disk.iomanager.ReadRequest> implements BulkBlockChannelReader
FileIOChannel.Enumerator, FileIOChannel.ID
closed, closeLock, exception, requestQueue, requestsNotReturned, resultHandler
fileChannel, id, LOG
Modifier | Constructor and Description |
---|---|
protected |
AsynchronousBulkBlockReader(FileIOChannel.ID channelID,
RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue,
List<MemorySegment> sourceSegments,
int numBlocks) |
Modifier and Type | Method and Description |
---|---|
List<MemorySegment> |
getFullSegments() |
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 AsynchronousBulkBlockReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, List<MemorySegment> sourceSegments, int numBlocks) throws IOException
IOException
public List<MemorySegment> getFullSegments()
getFullSegments
in interface BulkBlockChannelReader
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.