Modifier and Type | Method and Description |
---|---|
void |
AppendOnlyWriter.setMemoryPool(MemorySegmentPool memoryPool) |
Modifier and Type | Method and Description |
---|---|
static RowBuffer |
RowBuffer.getBuffer(IOManager ioManager,
MemorySegmentPool memoryPool,
AbstractRowDataSerializer<InternalRow> serializer,
boolean spillable,
MemorySize maxDiskSize,
CompressOptions compression) |
Modifier and Type | Class and Description |
---|---|
class |
FlinkMemorySegmentPool
Flink memory segment pool allocates segment from flink managed memory for paimon writer buffer.
|
Modifier and Type | Field and Description |
---|---|
protected MemorySegmentPool |
PrepareCommitOperator.memoryPool |
Modifier and Type | Method and Description |
---|---|
StoreSinkWrite |
StoreSinkWrite.Provider.provide(FileStoreTable table,
String commitUser,
StoreSinkWriteState state,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
MemorySegmentPool memoryPool,
org.apache.flink.metrics.MetricGroup metricGroup)
TODO: The argument list has become too complicated.
|
Constructor and Description |
---|
AsyncLookupSinkWrite(FileStoreTable table,
String commitUser,
StoreSinkWriteState state,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
boolean ignorePreviousFiles,
boolean waitCompaction,
boolean isStreaming,
MemorySegmentPool memoryPool,
org.apache.flink.metrics.MetricGroup metricGroup) |
GlobalFullCompactionSinkWrite(FileStoreTable table,
String commitUser,
StoreSinkWriteState state,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
boolean ignorePreviousFiles,
boolean waitCompaction,
int deltaCommits,
boolean isStreaming,
MemorySegmentPool memoryPool,
org.apache.flink.metrics.MetricGroup metricGroup) |
StoreSinkWriteImpl(FileStoreTable table,
String commitUser,
StoreSinkWriteState state,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
boolean ignorePreviousFiles,
boolean waitCompaction,
boolean isStreamingMode,
MemorySegmentPool memoryPool,
org.apache.flink.metrics.MetricGroup metricGroup) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMemorySegmentPool
Abstract memory segment pool.
|
class |
ArraySegmentPool
A
MemorySegmentPool for allocated segments. |
class |
CachelessSegmentPool
A
MemorySegmentPool without cache. |
class |
HeapMemorySegmentPool
MemorySegment pool from heap.
|
Modifier and Type | Method and Description |
---|---|
static MemorySegmentPool |
MemorySegmentPool.createHeapPool(MemorySize maxMemory,
MemorySize pageSize) |
Modifier and Type | Method and Description |
---|---|
void |
MemoryOwner.setMemoryPool(MemorySegmentPool memoryPool)
Set
MemorySegmentPool for the owner. |
Constructor and Description |
---|
MemoryPoolFactory(MemorySegmentPool innerPool) |
Modifier and Type | Method and Description |
---|---|
MemorySegmentPool |
MergeSorter.memoryPool() |
Modifier and Type | Method and Description |
---|---|
void |
MergeTreeWriter.setMemoryPool(MemorySegmentPool memoryPool) |
Constructor and Description |
---|
SortBufferWriteBuffer(RowType keyType,
RowType valueType,
FieldsComparator userDefinedSeqComparator,
MemorySegmentPool memoryPool,
boolean spillable,
MemorySize maxDiskSize,
int sortMaxFan,
CompressOptions compression,
IOManager ioManager) |
Modifier and Type | Method and Description |
---|---|
default FileStoreWrite<T> |
FileStoreWrite.withMemoryPool(MemorySegmentPool memoryPool)
With memory pool for the current file store write.
|
Modifier and Type | Field and Description |
---|---|
protected MemorySegmentPool |
BinaryIndexedSortable.memorySegmentPool |
Modifier and Type | Method and Description |
---|---|
static BinaryExternalSortBuffer |
BinaryExternalSortBuffer.create(IOManager ioManager,
RowType rowType,
int[] keyFields,
MemorySegmentPool pool,
int maxNumFileHandles,
CompressOptions compression,
MemorySize maxDiskSize,
boolean sequenceOrder) |
static BinaryInMemorySortBuffer |
BinaryInMemorySortBuffer.createBuffer(NormalizedKeyComputer normalizedKeyComputer,
AbstractRowDataSerializer<InternalRow> serializer,
RecordComparator comparator,
MemorySegmentPool memoryPool)
Create a memory sorter in `insert` way.
|
Constructor and Description |
---|
BinaryIndexedSortable(NormalizedKeyComputer normalizedKeyComputer,
BinaryRowSerializer serializer,
RecordComparator comparator,
ArrayList<MemorySegment> recordBufferSegments,
MemorySegmentPool memorySegmentPool) |
Modifier and Type | Method and Description |
---|---|
TableWrite |
TableWrite.withMemoryPool(MemorySegmentPool memoryPool)
With
MemorySegmentPool for the current table write. |
TableWriteImpl<T> |
TableWriteImpl.withMemoryPool(MemorySegmentPool memoryPool) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.