Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValue.copy(InternalRowSerializer keySerializer,
InternalRowSerializer valueSerializer) |
KeyValue |
KeyValueSerializer.fromRow(InternalRow row) |
KeyValue |
KeyValueSerializer.getReusedKv() |
KeyValue |
KeyValue.replace(InternalRow key,
long sequenceNumber,
RowKind valueKind,
InternalRow value) |
KeyValue |
KeyValue.replace(InternalRow key,
RowKind valueKind,
InternalRow value) |
KeyValue |
KeyValue.replaceKey(InternalRow key) |
KeyValue |
KeyValue.replaceValue(InternalRow value) |
KeyValue |
KeyValue.replaceValueKind(RowKind valueKind) |
KeyValue |
KeyValue.setLevel(int level) |
Modifier and Type | Method and Description |
---|---|
InternalRow |
KeyValueSerializer.toRow(KeyValue record) |
Constructor and Description |
---|
KeyValueFileStore(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
boolean crossPartitionUpdate,
CoreOptions options,
RowType partitionType,
RowType bucketKeyType,
RowType keyType,
RowType valueType,
KeyValueFieldsExtractor keyValueFieldsExtractor,
MergeFunctionFactory<KeyValue> mfFactory,
String tableName,
CatalogEnvironment catalogEnvironment) |
Modifier and Type | Method and Description |
---|---|
IndexMaintainer<KeyValue> |
HashIndexMaintainer.Factory.createOrRestore(Long snapshotId,
BinaryRow partition,
int bucket) |
Modifier and Type | Method and Description |
---|---|
void |
HashIndexMaintainer.notifyNewRecord(KeyValue record) |
Modifier and Type | Method and Description |
---|---|
RecordReader<KeyValue> |
KeyValueFileReaderFactory.createRecordReader(DataFileMeta file) |
RecordReader<KeyValue> |
KeyValueFileReaderFactory.createRecordReader(long schemaId,
String fileName,
long fileSize,
int level) |
RollingFileWriter<KeyValue,DataFileMeta> |
KeyValueFileWriterFactory.createRollingChangelogFileWriter(int level) |
RollingFileWriter<KeyValue,DataFileMeta> |
KeyValueFileWriterFactory.createRollingMergeTreeFileWriter(int level,
FileSource fileSource) |
RecordReader.RecordIterator<KeyValue> |
KeyValueDataFileRecordReader.readBatch() |
FileReaderFactory<KeyValue> |
RecordLevelExpire.wrap(FileReaderFactory<KeyValue> readerFactory) |
Modifier and Type | Method and Description |
---|---|
void |
KeyValueDataFileWriter.write(KeyValue kv) |
Modifier and Type | Method and Description |
---|---|
FileReaderFactory<KeyValue> |
RecordLevelExpire.wrap(FileReaderFactory<KeyValue> readerFactory) |
Constructor and Description |
---|
KeyValueDataFileWriter(FileIO fileIO,
FormatWriterFactory factory,
Path path,
java.util.function.Function<KeyValue,InternalRow> converter,
RowType keyType,
RowType valueType,
SimpleStatsExtractor simpleStatsExtractor,
long schemaId,
int level,
String compression,
CoreOptions options,
FileSource fileSource,
FileIndexOptions fileIndexOptions) |
Modifier and Type | Method and Description |
---|---|
KeyValue |
LookupLevels.PositionedKeyValue.keyValue() |
KeyValue |
LookupLevels.KeyValueProcessor.readFromDisk(InternalRow key,
int level,
byte[] bytes,
String fileName) |
Modifier and Type | Method and Description |
---|---|
RecordReader.RecordIterator<KeyValue> |
DropDeleteReader.readBatch() |
Modifier and Type | Method and Description |
---|---|
void |
WriteBuffer.KvConsumer.accept(KeyValue kv) |
byte[] |
LookupLevels.ValueProcessor.persistToDisk(KeyValue kv) |
byte[] |
LookupLevels.KeyValueProcessor.persistToDisk(KeyValue kv) |
byte[] |
LookupLevels.ContainsValueProcessor.persistToDisk(KeyValue kv) |
byte[] |
LookupLevels.PositionedKeyValueProcessor.persistToDisk(KeyValue kv) |
default byte[] |
LookupLevels.ValueProcessor.persistToDisk(KeyValue kv,
long rowPosition) |
byte[] |
LookupLevels.PositionedKeyValueProcessor.persistToDisk(KeyValue kv,
long rowPosition) |
void |
MergeTreeWriter.write(KeyValue kv) |
Modifier and Type | Method and Description |
---|---|
void |
SortBufferWriteBuffer.forEach(Comparator<InternalRow> keyComparator,
MergeFunction<KeyValue> mergeFunction,
WriteBuffer.KvConsumer rawConsumer,
WriteBuffer.KvConsumer mergedConsumer) |
void |
WriteBuffer.forEach(Comparator<InternalRow> keyComparator,
MergeFunction<KeyValue> mergeFunction,
WriteBuffer.KvConsumer rawConsumer,
WriteBuffer.KvConsumer mergedConsumer)
Performs the given action for each remaining element in this buffer until all elements have
been processed or the action throws an exception.
|
<T> RecordReader<T> |
MergeSorter.mergeSort(List<SizedReaderSupplier<KeyValue>> lazyReaders,
Comparator<InternalRow> keyComparator,
FieldsComparator userDefinedSeqComparator,
MergeFunctionWrapper<T> mergeFunction) |
<T> RecordReader<T> |
MergeSorter.mergeSortNoSpill(List<? extends ReaderSupplier<KeyValue>> lazyReaders,
Comparator<InternalRow> keyComparator,
FieldsComparator userDefinedSeqComparator,
MergeFunctionWrapper<T> mergeFunction) |
static <T> RecordReader<T> |
MergeTreeReaders.readerForMergeTree(List<List<SortedRun>> sections,
FileReaderFactory<KeyValue> readerFactory,
Comparator<InternalRow> userKeyComparator,
FieldsComparator userDefinedSeqComparator,
MergeFunctionWrapper<T> mergeFunctionWrapper,
MergeSorter mergeSorter) |
static <T> RecordReader<T> |
MergeTreeReaders.readerForSection(List<SortedRun> section,
FileReaderFactory<KeyValue> readerFactory,
Comparator<InternalRow> userKeyComparator,
FieldsComparator userDefinedSeqComparator,
MergeFunctionWrapper<T> mergeFunctionWrapper,
MergeSorter mergeSorter) |
Constructor and Description |
---|
PositionedKeyValue(KeyValue keyValue,
String fileName,
long rowPosition) |
Constructor and Description |
---|
DropDeleteReader(RecordReader<KeyValue> reader) |
LookupLevels(Levels levels,
Comparator<InternalRow> keyComparator,
RowType keyType,
LookupLevels.ValueProcessor<T> valueProcessor,
IOFunction<DataFileMeta,RecordReader<KeyValue>> fileReaderFactory,
java.util.function.Function<String,File> localFileFactory,
LookupStoreFactory lookupStoreFactory,
java.util.function.Function<Long,BloomFilter.Builder> bfGenerator,
org.apache.paimon.shade.caffeine2.com.github.benmanes.caffeine.cache.Cache<String,LookupFile> lookupFileCache) |
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) |
Modifier and Type | Field and Description |
---|---|
protected MergeFunctionFactory<KeyValue> |
MergeTreeCompactRewriter.mfFactory |
protected FileReaderFactory<KeyValue> |
MergeTreeCompactRewriter.readerFactory |
Modifier and Type | Method and Description |
---|---|
KeyValue |
FirstRowMergeFunction.getResult() |
KeyValue |
LookupMergeFunction.getResult() |
KeyValue |
DeduplicateMergeFunction.getResult() |
KeyValue |
ReducerMergeFunctionWrapper.getResult()
Get current value of the
MergeFunction helper. |
KeyValue |
PartialUpdateMergeFunction.getResult() |
KeyValue |
ChangelogResult.result()
Latest result (result of merge function) for this key.
|
Modifier and Type | Method and Description |
---|---|
List<KeyValue> |
ChangelogResult.changelogs() |
static MergeFunctionFactory<KeyValue> |
DeduplicateMergeFunction.factory() |
static MergeFunctionFactory<KeyValue> |
DeduplicateMergeFunction.factory(Options options) |
static MergeFunctionFactory<KeyValue> |
PartialUpdateMergeFunction.factory(Options options,
RowType rowType,
List<String> primaryKeys) |
static MergeFunctionFactory<KeyValue> |
FirstRowMergeFunction.factory(Options options,
RowType keyType,
RowType valueType) |
static MergeFunctionFactory<KeyValue> |
LookupMergeFunction.wrap(MergeFunctionFactory<KeyValue> wrapped,
RowType keyType,
RowType valueType) |
Modifier and Type | Method and Description |
---|---|
void |
FirstRowMergeFunctionWrapper.add(KeyValue kv) |
void |
LookupChangelogMergeFunctionWrapper.add(KeyValue kv) |
void |
FirstRowMergeFunction.add(KeyValue kv) |
void |
FullChangelogMergeFunctionWrapper.add(KeyValue kv) |
void |
MergeFunction.add(KeyValue kv)
Add the given
KeyValue to the merge function. |
void |
LookupMergeFunction.add(KeyValue kv) |
void |
DeduplicateMergeFunction.add(KeyValue kv) |
void |
ReducerMergeFunctionWrapper.add(KeyValue kv)
Adds the given
KeyValue to the MergeFunction helper. |
void |
MergeFunctionWrapper.add(KeyValue kv) |
void |
PartialUpdateMergeFunction.add(KeyValue kv) |
ChangelogResult |
ChangelogResult.addChangelog(KeyValue record) |
ChangelogResult |
ChangelogResult.setResult(KeyValue result) |
ChangelogResult |
ChangelogResult.setResultIfNotRetract(KeyValue result) |
Modifier and Type | Method and Description |
---|---|
MergeFunctionWrapper<ChangelogResult> |
LookupMergeTreeCompactRewriter.FirstRowMergeFunctionWrapperFactory.create(MergeFunctionFactory<KeyValue> mfFactory,
int outputLevel,
LookupLevels<Boolean> lookupLevels,
DeletionVectorsMaintainer deletionVectorsMaintainer) |
MergeFunctionWrapper<ChangelogResult> |
LookupMergeTreeCompactRewriter.MergeFunctionWrapperFactory.create(MergeFunctionFactory<KeyValue> mfFactory,
int outputLevel,
LookupLevels<T> lookupLevels,
DeletionVectorsMaintainer deletionVectorsMaintainer) |
MergeFunctionWrapper<ChangelogResult> |
LookupMergeTreeCompactRewriter.LookupMergeFunctionWrapperFactory.create(MergeFunctionFactory<KeyValue> mfFactory,
int outputLevel,
LookupLevels<T> lookupLevels,
DeletionVectorsMaintainer deletionVectorsMaintainer) |
static <T> SortMergeReader<T> |
SortMergeReader.createSortMergeReader(List<RecordReader<KeyValue>> readers,
Comparator<InternalRow> userKeyComparator,
FieldsComparator userDefinedSeqComparator,
MergeFunctionWrapper<T> mergeFunctionWrapper,
CoreOptions.SortEngine sortEngine) |
static MergeFunctionFactory<KeyValue> |
LookupMergeFunction.wrap(MergeFunctionFactory<KeyValue> wrapped,
RowType keyType,
RowType valueType) |
Modifier and Type | Method and Description |
---|---|
KeyValue |
AggregateMergeFunction.getResult() |
Modifier and Type | Method and Description |
---|---|
static MergeFunctionFactory<KeyValue> |
AggregateMergeFunction.factory(Options conf,
List<String> tableNames,
List<DataType> tableTypes,
List<String> primaryKeys) |
Modifier and Type | Method and Description |
---|---|
void |
AggregateMergeFunction.add(KeyValue kv) |
Modifier and Type | Method and Description |
---|---|
RecordReader<KeyValue> |
MergeFileSplitRead.createMergeReader(BinaryRow partition,
int bucket,
List<DataFileMeta> files,
List<DeletionFile> deletionFiles,
boolean keepDelete) |
RecordReader<KeyValue> |
MergeFileSplitRead.createNoMergeReader(BinaryRow partition,
int bucket,
List<DataFileMeta> files,
List<DeletionFile> deletionFiles,
boolean onlyFilterKey) |
RecordReader<KeyValue> |
MergeFileSplitRead.createReader(DataSplit split) |
protected java.util.function.Function<AbstractFileStoreWrite.WriterContainer<KeyValue>,Boolean> |
KeyValueFileStoreWrite.createWriterCleanChecker() |
RecordReader.RecordIterator<KeyValue> |
ReverseReader.readBatch() |
Modifier and Type | Method and Description |
---|---|
static MergeFunctionFactory<KeyValue> |
PrimaryKeyTableUtils.createMergeFunctionFactory(TableSchema tableSchema,
KeyValueFieldsExtractor extractor) |
Modifier and Type | Method and Description |
---|---|
KeyValue |
ResetRowKindRecordIterator.nextKeyValue() |
Modifier and Type | Method and Description |
---|---|
static RecordReader<InternalRow> |
KeyValueTableRead.unwrap(RecordReader<KeyValue> reader) |
Constructor and Description |
---|
ResetRowKindRecordIterator(RecordReader.RecordIterator<KeyValue> kvIterator) |
ValueContentRowDataRecordIterator(RecordReader.RecordIterator<KeyValue> kvIterator) |
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValueWithLevelNoReusingSerializer.fromRow(InternalRow row) |
Modifier and Type | Method and Description |
---|---|
InternalRow |
KeyValueWithLevelNoReusingSerializer.toRow(KeyValue kv) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.