Package | Description |
---|---|
org.apache.flink.runtime.io.disk.iomanager | |
org.apache.flink.runtime.operators.sort |
Modifier and Type | Interface and Description |
---|---|
interface |
BlockChannelReader<T>
A reader that reads data in blocks from a file channel.
|
interface |
BlockChannelWriter<T>
A writer that writes data in blocks to a file channel.
|
interface |
BlockChannelWriterWithCallback<T> |
interface |
BufferFileReader |
interface |
BufferFileSegmentReader |
interface |
BufferFileWriter |
interface |
BulkBlockChannelReader |
Modifier and Type | Class and Description |
---|---|
class |
AbstractFileIOChannel |
class |
AsynchronousBlockReader
A reader that reads data in blocks from a file channel.
|
class |
AsynchronousBlockWriter |
class |
AsynchronousBlockWriterWithCallback
An asynchronous implementation of the
BlockChannelWriterWithCallback that queues I/O requests
and calls a callback once they have been handled. |
class |
AsynchronousBufferFileReader |
class |
AsynchronousBufferFileSegmentReader |
class |
AsynchronousBufferFileWriter |
class |
AsynchronousBulkBlockReader |
class |
AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest>
A base class for readers and writers that accept read or write requests for whole blocks.
|
class |
SynchronousBufferFileReader
A synchronous
BufferFileReader implementation. |
class |
SynchronousFileIOChannel
A base class for synchronous readers and writers.
|
Modifier and Type | Method and Description |
---|---|
protected void |
UnilateralSortMerger.SpillingThread.registerOpenChannelToBeRemovedAtShudown(FileIOChannel channel)
Adds a channel reader/writer to the list of channels that are to be removed at shutdown.
|
protected void |
UnilateralSortMerger.SpillingThread.unregisterOpenChannelToBeRemovedAtShudown(FileIOChannel channel)
Removes a channel reader/writer from the list of channels that are to be removed at shutdown.
|
Modifier and Type | Method and Description |
---|---|
protected MergeIterator<E> |
UnilateralSortMerger.SpillingThread.getMergingIterator(List<UnilateralSortMerger.ChannelWithBlockCount> channelIDs,
List<List<MemorySegment>> inputSegments,
List<FileIOChannel> readerList,
MutableObjectIterator<E> largeRecords)
Returns an iterator that iterates over the merged result from all given channels.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.