Uses of Class
org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
-
Uses of FileIOChannel.ID in org.apache.flink.runtime.io.disk
Methods in org.apache.flink.runtime.io.disk that return FileIOChannel.ID Modifier and Type Method Description FileIOChannel.ID
FileChannelManager. createChannel()
Creates an ID identifying an underlying file channel and returns it.FileIOChannel.ID
FileChannelManagerImpl. createChannel()
Constructors in org.apache.flink.runtime.io.disk with parameters of type FileIOChannel.ID Constructor Description ChannelReaderInputViewIterator(IOManager ioAccess, FileIOChannel.ID channel, LinkedBlockingQueue<MemorySegment> returnQueue, List<MemorySegment> segments, List<MemorySegment> freeMemTarget, TypeSerializer<E> accessors, int numBlocks)
ChannelReaderInputViewIterator(IOManager ioAccess, FileIOChannel.ID channel, List<MemorySegment> segments, List<MemorySegment> freeMemTarget, TypeSerializer<E> accessors, int numBlocks)
SeekableFileChannelInputView(IOManager ioManager, FileIOChannel.ID channelId, MemoryManager memManager, List<MemorySegment> memory, int sizeOfLastBlock)
-
Uses of FileIOChannel.ID in org.apache.flink.runtime.io.disk.iomanager
Fields in org.apache.flink.runtime.io.disk.iomanager declared as FileIOChannel.ID Modifier and Type Field Description protected FileIOChannel.ID
AbstractFileIOChannel. id
The ID of the underlying channel.Methods in org.apache.flink.runtime.io.disk.iomanager that return FileIOChannel.ID Modifier and Type Method Description FileIOChannel.ID
IOManager. createChannel()
Creates a newFileIOChannel.ID
in one of the temp directories.FileIOChannel.ID
AbstractFileIOChannel. getChannelID()
FileIOChannel.ID
FileIOChannel. getChannelID()
Gets the channel ID of this I/O channel.FileIOChannel.ID
FileIOChannel.Enumerator. next()
Constructors in org.apache.flink.runtime.io.disk.iomanager with parameters of type FileIOChannel.ID Constructor Description AbstractFileIOChannel(FileIOChannel.ID channelID, boolean writeEnabled)
Creates a new channel to the path indicated by the given ID.AsynchronousBlockReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, LinkedBlockingQueue<MemorySegment> returnSegments)
Creates a new block channel reader for the given channel.AsynchronousBlockWriter(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.WriteRequest> requestQueue, LinkedBlockingQueue<MemorySegment> returnSegments)
Creates a new block channel writer for the given channel.AsynchronousBlockWriterWithCallback(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.WriteRequest> requestQueue, RequestDoneCallback<MemorySegment> callback)
Creates a new asynchronous block writer for the given channel.AsynchronousBufferFileReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, RequestDoneCallback<Buffer> callback)
AsynchronousBufferFileSegmentReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, RequestDoneCallback<FileSegment> callback)
AsynchronousBufferFileWriter(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.WriteRequest> requestQueue)
AsynchronousBulkBlockReader(FileIOChannel.ID channelID, RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue, List<MemorySegment> sourceSegments, int numBlocks)
AsynchronousFileIOChannel(FileIOChannel.ID channelID, RequestQueue<R> requestQueue, RequestDoneCallback<T> callback, boolean writeEnabled)
Creates a new channel access to the path indicated by the given ID.SynchronousBufferFileReader(FileIOChannel.ID channelID, boolean writeEnabled)
SynchronousFileIOChannel(FileIOChannel.ID channelID, boolean writeEnabled)
-
Uses of FileIOChannel.ID in org.apache.flink.runtime.operators.hash
Methods in org.apache.flink.runtime.operators.hash with parameters of type FileIOChannel.ID Modifier and Type Method Description int
HashPartition. spillPartition(List<MemorySegment> target, IOManager ioAccess, FileIOChannel.ID targetChannel, LinkedBlockingQueue<MemorySegment> bufferReturnQueue)
Spills this partition to disk and sets it up such that it continues spilling records that are added to it. -
Uses of FileIOChannel.ID in org.apache.flink.table.runtime.hashtable
Methods in org.apache.flink.table.runtime.hashtable with parameters of type FileIOChannel.ID Modifier and Type Method Description protected HeaderlessChannelReaderInputView
BaseHybridHashTable. createInputView(FileIOChannel.ID id, int blockCount, int lastSegmentLimit)
protected List<MemorySegment>
BaseHybridHashTable. readAllBuffers(FileIOChannel.ID id, int blockCount)
-
Uses of FileIOChannel.ID in org.apache.flink.table.runtime.io
Methods in org.apache.flink.table.runtime.io that return FileIOChannel.ID Modifier and Type Method Description FileIOChannel.ID
ChannelWithMeta. getChannel()
FileIOChannel.ID
CompressedBlockChannelReader. getChannelID()
FileIOChannel.ID
CompressedBlockChannelWriter. getChannelID()
Constructors in org.apache.flink.table.runtime.io with parameters of type FileIOChannel.ID Constructor Description ChannelWithMeta(FileIOChannel.ID channel, int blockCount, int numBytesInLastBlock)
CompressedBlockChannelReader(IOManager ioManager, FileIOChannel.ID channel, LinkedBlockingQueue<MemorySegment> blockQueue, BlockCompressionFactory codecFactory, int preferBlockSize, int segmentSize)
CompressedBlockChannelWriter(IOManager ioManager, FileIOChannel.ID channel, LinkedBlockingQueue<MemorySegment> blockQueue, BlockCompressionFactory codecFactory, int preferBlockSize, int segmentSize)
CompressedHeaderlessChannelReaderInputView(FileIOChannel.ID id, IOManager ioManager, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize, int numBlocks)
-
Uses of FileIOChannel.ID in org.apache.flink.table.runtime.operators.sort
Methods in org.apache.flink.table.runtime.operators.sort with parameters of type FileIOChannel.ID Modifier and Type Method Description void
SpillChannelManager. addChannel(FileIOChannel.ID id)
Add a new File channel.void
SpillChannelManager. removeChannel(FileIOChannel.ID id)
-
Uses of FileIOChannel.ID in org.apache.flink.table.runtime.util
Methods in org.apache.flink.table.runtime.util with parameters of type FileIOChannel.ID Modifier and Type Method Description static BlockChannelReader<MemorySegment>
FileChannelUtil. createBlockChannelReader(IOManager ioManager, FileIOChannel.ID channel, LinkedBlockingQueue<MemorySegment> bufferReturnQueue, boolean compressionEnable, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize, int segmentSize)
static BlockChannelWriter<MemorySegment>
FileChannelUtil. createBlockChannelWriter(IOManager ioManager, FileIOChannel.ID channel, LinkedBlockingQueue<MemorySegment> bufferReturnQueue, boolean compressionEnable, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize, int segmentSize)
static AbstractChannelWriterOutputView
FileChannelUtil. createOutputView(IOManager ioManager, FileIOChannel.ID channel, boolean compressionEnabled, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize, int segmentSize)
-