Uses of Interface
org.apache.flink.runtime.io.compression.BlockCompressionFactory
-
-
Uses of BlockCompressionFactory in org.apache.flink.runtime.io.compression
Classes in org.apache.flink.runtime.io.compression that implement BlockCompressionFactory Modifier and Type Class Description class
AirCompressorFactory
class
Lz4BlockCompressionFactory
Implementation ofBlockCompressionFactory
for Lz4 codec.Methods in org.apache.flink.runtime.io.compression that return BlockCompressionFactory Modifier and Type Method Description static BlockCompressionFactory
BlockCompressionFactory. createBlockCompressionFactory(NettyShuffleEnvironmentOptions.CompressionCodec compressionName)
CreatesBlockCompressionFactory
according to the configuration. -
Uses of BlockCompressionFactory in org.apache.flink.table.runtime.hashtable
Fields in org.apache.flink.table.runtime.hashtable declared as BlockCompressionFactory Modifier and Type Field Description protected BlockCompressionFactory
BaseHybridHashTable. compressionCodecFactory
Methods in org.apache.flink.table.runtime.hashtable that return BlockCompressionFactory Modifier and Type Method Description BlockCompressionFactory
LongHybridHashTable. compressionCodecFactory()
-
Uses of BlockCompressionFactory in org.apache.flink.table.runtime.io
Constructors in org.apache.flink.table.runtime.io with parameters of type BlockCompressionFactory Constructor Description 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)
CompressedHeaderlessChannelWriterOutputView(BufferFileWriter writer, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize)
-
Uses of BlockCompressionFactory in org.apache.flink.table.runtime.operators.sort
Constructors in org.apache.flink.table.runtime.operators.sort with parameters of type BlockCompressionFactory Constructor Description AbstractBinaryExternalMerger(IOManager ioManager, int pageSize, int maxFanIn, SpillChannelManager channelManager, boolean compressionEnabled, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize)
BinaryExternalMerger(IOManager ioManager, int pageSize, int maxFanIn, SpillChannelManager channelManager, BinaryRowDataSerializer serializer, RecordComparator comparator, boolean compressionEnabled, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize)
BinaryKVExternalMerger(IOManager ioManager, int pageSize, int maxFanIn, SpillChannelManager channelManager, BinaryRowDataSerializer keySerializer, BinaryRowDataSerializer valueSerializer, RecordComparator comparator, boolean compressionEnabled, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize)
-
Uses of BlockCompressionFactory in org.apache.flink.table.runtime.util
Methods in org.apache.flink.table.runtime.util with parameters of type BlockCompressionFactory 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 AbstractChannelReaderInputView
FileChannelUtil. createInputView(IOManager ioManager, ChannelWithMeta channel, List<FileIOChannel> channels, boolean compressionEnabled, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize, int segmentSize)
static AbstractChannelWriterOutputView
FileChannelUtil. createOutputView(IOManager ioManager, FileIOChannel.ID channel, boolean compressionEnabled, BlockCompressionFactory compressionCodecFactory, int compressionBlockSize, int segmentSize)
-