Package | Description |
---|---|
org.apache.flink.runtime.io.disk | |
org.apache.flink.runtime.io.disk.iomanager | |
org.apache.flink.table.runtime.io | |
org.apache.flink.table.runtime.util |
Constructor and Description |
---|
ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment> reader,
LinkedBlockingQueue<MemorySegment> returnQueue,
List<MemorySegment> segments,
List<MemorySegment> freeMemTarget,
TypeSerializer<E> accessors,
int numBlocks) |
FileChannelInputView(BlockChannelReader<MemorySegment> reader,
MemoryManager memManager,
List<MemorySegment> memory,
int sizeOfLastBlock) |
Modifier and Type | Class and Description |
---|---|
class |
AsynchronousBlockReader
A reader that reads data in blocks from a file channel.
|
Modifier and Type | Field and Description |
---|---|
protected BlockChannelReader<MemorySegment> |
ChannelReaderInputView.reader |
Modifier and Type | Method and Description |
---|---|
BlockChannelReader<MemorySegment> |
IOManager.createBlockChannelReader(FileIOChannel.ID channelID)
Creates a block channel reader that reads blocks from the given channel.
|
abstract BlockChannelReader<MemorySegment> |
IOManager.createBlockChannelReader(FileIOChannel.ID channelID,
LinkedBlockingQueue<MemorySegment> returnQueue)
Creates a block channel reader that reads blocks from the given channel.
|
BlockChannelReader<MemorySegment> |
IOManagerAsync.createBlockChannelReader(FileIOChannel.ID channelID,
LinkedBlockingQueue<MemorySegment> returnQueue)
Creates a block channel reader that reads blocks from the given channel.
|
Constructor and Description |
---|
ChannelReaderInputView(BlockChannelReader<MemorySegment> reader,
List<MemorySegment> memory,
boolean waitForFirstBlock)
Creates a new channel reader that reads from the given channel until the last block (as
marked by a
ChannelWriterOutputView ) is found. |
ChannelReaderInputView(BlockChannelReader<MemorySegment> reader,
List<MemorySegment> memory,
int numBlocks,
boolean waitForFirstBlock)
Creates a new channel reader that reads from the given channel, expecting a specified number
of blocks in the channel.
|
HeaderlessChannelReaderInputView(BlockChannelReader<MemorySegment> reader,
List<MemorySegment> memory,
int numBlocks,
int numBytesInLastBlock,
boolean waitForFirstBlock)
Creates a new channel reader that reads from the given channel, expecting a specified number
of blocks in the channel, and returns only a specified number of bytes from the last block.
|
HeaderlessChannelReaderInputView(BlockChannelReader<MemorySegment> reader,
List<MemorySegment> memory,
int numBlocks,
int numBytesInLastBlock,
boolean waitForFirstBlock,
long offset) |
Modifier and Type | Class and Description |
---|---|
class |
CompressedBlockChannelReader
Compressed block channel reader provides a scenario where MemorySegment must be maintained.
|
Modifier and Type | Method and Description |
---|---|
static BlockChannelReader<MemorySegment> |
FileChannelUtil.createBlockChannelReader(IOManager ioManager,
FileIOChannel.ID channel,
LinkedBlockingQueue<MemorySegment> bufferReturnQueue,
boolean compressionEnable,
BlockCompressionFactory compressionCodecFactory,
int compressionBlockSize,
int segmentSize) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.