Constructor and Description |
---|
AppendOnlyWriter(FileIO fileIO,
IOManager ioManager,
long schemaId,
FileFormat fileFormat,
long targetFileSize,
RowType writeSchema,
long maxSequenceNumber,
CompactManager compactManager,
IOFunction<List<DataFileMeta>,RecordReaderIterator<InternalRow>> bucketFileRead,
boolean forceCompact,
DataFilePathFactory pathFactory,
CommitIncrement increment,
boolean useWriteBuffer,
boolean spillable,
String fileCompression,
CompressOptions spillCompression,
SimpleColStatsCollector.Factory[] statsCollectors,
MemorySize maxDiskSize,
FileIndexOptions fileIndexOptions,
boolean asyncFileWrite,
boolean statsDenseStore) |
Modifier and Type | Method and Description |
---|---|
void |
GlobalIndexAssigner.open(long offHeapMemory,
IOManager ioManager,
int numAssigners,
int assignId,
java.util.function.BiConsumer<InternalRow,Integer> collector) |
Modifier and Type | Class and Description |
---|---|
class |
IOManagerImpl
The facade for the provided I/O manager services.
|
Modifier and Type | Method and Description |
---|---|
static IOManager |
IOManager.create(String tempDir) |
static IOManager |
IOManager.create(String[] tempDirs) |
Modifier and Type | Method and Description |
---|---|
static ChannelReaderInputView |
FileChannelUtil.createInputView(IOManager ioManager,
ChannelWithMeta channel,
List<FileIOChannel> channels,
BlockCompressionFactory compressionCodecFactory,
int compressionBlockSize) |
static ChannelWriterOutputView |
FileChannelUtil.createOutputView(IOManager ioManager,
FileIOChannel.ID channel,
BlockCompressionFactory compressionCodecFactory,
int compressionBlockSize) |
static RowBuffer |
RowBuffer.getBuffer(IOManager ioManager,
MemorySegmentPool memoryPool,
AbstractRowDataSerializer<InternalRow> serializer,
boolean spillable,
MemorySize maxDiskSize,
CompressOptions compression) |
Constructor and Description |
---|
ChannelReaderInputView(FileIOChannel.ID id,
IOManager ioManager,
BlockCompressionFactory compressionCodecFactory,
int compressionBlockSize,
int numBlocks) |
Modifier and Type | Method and Description |
---|---|
TableRead |
LookupCompactDiffRead.withIOManager(IOManager ioManager) |
Constructor and Description |
---|
FileStoreSourceReader(org.apache.flink.api.connector.source.SourceReaderContext readerContext,
TableRead tableRead,
FileStoreSourceReaderMetrics metrics,
IOManager ioManager,
Long limit) |
FileStoreSourceReader(org.apache.flink.api.connector.source.SourceReaderContext readerContext,
TableRead tableRead,
FileStoreSourceReaderMetrics metrics,
IOManager ioManager,
Long limit,
org.apache.flink.connector.base.source.reader.synchronization.FutureCompletingBlockingQueue<org.apache.flink.connector.base.source.reader.RecordsWithSplitIds<org.apache.flink.connector.file.src.reader.BulkFormat.RecordIterator<org.apache.flink.table.data.RowData>>> elementsQueue) |
Constructor and Description |
---|
AlignedSourceReader(org.apache.flink.api.connector.source.SourceReaderContext readerContext,
TableRead tableRead,
FileStoreSourceReaderMetrics metrics,
IOManager ioManager,
Long limit,
org.apache.flink.connector.base.source.reader.synchronization.FutureCompletingBlockingQueue<org.apache.flink.connector.base.source.reader.RecordsWithSplitIds<org.apache.flink.connector.file.src.reader.BulkFormat.RecordIterator<org.apache.flink.table.data.RowData>>> elementsQueue) |
Modifier and Type | Method and Description |
---|---|
static BinaryExternalSortBuffer |
RocksDBState.createBulkLoadSorter(IOManager ioManager,
CoreOptions options) |
Modifier and Type | Method and Description |
---|---|
void |
MergeSorter.setIOManager(IOManager ioManager) |
Constructor and Description |
---|
MergeSorter(CoreOptions options,
RowType keyType,
RowType valueType,
IOManager ioManager) |
MergeTreeWriter(boolean writeBufferSpillable,
MemorySize maxDiskSize,
int sortMaxFan,
CompressOptions sortCompression,
IOManager ioManager,
CompactManager compactManager,
long maxSequenceNumber,
Comparator<InternalRow> keyComparator,
MergeFunction<KeyValue> mergeFunction,
KeyValueFileWriterFactory writerFactory,
boolean commitForceCompact,
CoreOptions.ChangelogProducer changelogProducer,
CommitIncrement increment,
FieldsComparator userDefinedSeqComparator) |
SortBufferWriteBuffer(RowType keyType,
RowType valueType,
FieldsComparator userDefinedSeqComparator,
MemorySegmentPool memoryPool,
boolean spillable,
MemorySize maxDiskSize,
int sortMaxFan,
CompressOptions compression,
IOManager ioManager) |
Modifier and Type | Field and Description |
---|---|
protected IOManager |
AbstractFileStoreWrite.ioManager |
Modifier and Type | Method and Description |
---|---|
FileStoreWrite<T> |
FileStoreWrite.withIOManager(IOManager ioManager) |
FileStoreWrite<T> |
AbstractFileStoreWrite.withIOManager(IOManager ioManager) |
SplitRead<InternalRow> |
RawFileSplitRead.withIOManager(IOManager ioManager) |
MergeFileSplitRead |
MergeFileSplitRead.withIOManager(IOManager ioManager) |
SplitRead<T> |
SplitRead.withIOManager(IOManager ioManager) |
Modifier and Type | Field and Description |
---|---|
protected IOManager |
AbstractBinaryExternalMerger.ioManager |
Modifier and Type | Method and Description |
---|---|
static BinaryExternalSortBuffer |
BinaryExternalSortBuffer.create(IOManager ioManager,
RowType rowType,
int[] keyFields,
long bufferSize,
int pageSize,
int maxNumFileHandles,
CompressOptions compression,
MemorySize maxDiskSize,
boolean sequenceOrder) |
static BinaryExternalSortBuffer |
BinaryExternalSortBuffer.create(IOManager ioManager,
RowType rowType,
int[] keyFields,
MemorySegmentPool pool,
int maxNumFileHandles,
CompressOptions compression,
MemorySize maxDiskSize,
boolean sequenceOrder) |
Constructor and Description |
---|
AbstractBinaryExternalMerger(IOManager ioManager,
int pageSize,
int maxFanIn,
SpillChannelManager channelManager,
BlockCompressionFactory compressionCodecFactory,
int compressionBlockSize) |
BinaryExternalMerger(IOManager ioManager,
int pageSize,
int maxFanIn,
SpillChannelManager channelManager,
BinaryRowSerializer serializer,
RecordComparator comparator,
BlockCompressionFactory compressionCodecFactory,
int compressionBlockSize) |
BinaryExternalSortBuffer(BinaryRowSerializer serializer,
RecordComparator comparator,
int pageSize,
BinaryInMemorySortBuffer inMemorySortBuffer,
IOManager ioManager,
int maxNumFileHandles,
CompressOptions compression,
MemorySize maxDiskSize) |
Modifier and Type | Method and Description |
---|---|
static IOManager |
SparkUtils.createIOManager() |
Modifier and Type | Method and Description |
---|---|
LocalTableQuery |
LocalTableQuery.withIOManager(IOManager ioManager) |
Modifier and Type | Method and Description |
---|---|
TableWrite |
TableWrite.withIOManager(IOManager ioManager)
With
IOManager , this is needed if 'write-buffer-spillable' is set to true. |
TableWriteImpl<T> |
TableWriteImpl.withIOManager(IOManager ioManager) |
Modifier and Type | Method and Description |
---|---|
TableRead |
TableRead.withIOManager(IOManager ioManager) |
TableRead |
KeyValueTableRead.withIOManager(IOManager ioManager) |
TableRead |
AbstractDataTableRead.withIOManager(IOManager ioManager) |
Modifier and Type | Method and Description |
---|---|
SplitRead<InternalRow> |
IncrementalDiffSplitRead.withIOManager(IOManager ioManager) |
Modifier and Type | Method and Description |
---|---|
TableRead |
TableLineageTable.TableLineageRead.withIOManager(IOManager ioManager) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.