Modifier and Type | Method and Description |
---|---|
static CoreOptions |
CoreOptions.fromMap(Map<String,String> options) |
CoreOptions |
FileStore.options() |
Constructor and Description |
---|
AppendOnlyFileStore(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
CoreOptions options,
RowType partitionType,
RowType bucketKeyType,
RowType rowType,
String tableName,
CatalogEnvironment catalogEnvironment) |
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) |
Constructor and Description |
---|
FileIndexOptions(CoreOptions coreOptions) |
Constructor and Description |
---|
LookupDataTableScan(CoreOptions options,
SnapshotReader snapshotReader,
SnapshotManager snapshotManager,
boolean supportStreamingReadOverwrite,
DefaultValueAssigner defaultValueAssigner,
LookupFileStoreTable.LookupStreamScanMode lookupScanMode) |
Modifier and Type | Method and Description |
---|---|
static PartitionMarkDoneTrigger |
PartitionMarkDoneTrigger.create(CoreOptions coreOptions,
boolean isRestored,
org.apache.flink.api.common.state.OperatorStateStore stateStore) |
Modifier and Type | Method and Description |
---|---|
static FileFormatDiscover |
FileFormatDiscover.of(CoreOptions options) |
Modifier and Type | Method and Description |
---|---|
KeyValueFileWriterFactory |
KeyValueFileWriterFactory.Builder.build(BinaryRow partition,
int bucket,
CoreOptions options) |
static KeyValueFileReaderFactory.Builder |
KeyValueFileReaderFactory.builder(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
RowType keyType,
RowType valueType,
FileFormatDiscover formatDiscover,
FileStorePathFactory pathFactory,
KeyValueFieldsExtractor extractor,
CoreOptions options) |
static RecordLevelExpire |
RecordLevelExpire.create(CoreOptions options,
RowType rowType) |
Constructor and Description |
---|
KeyValueDataFileWriter(FileIO fileIO,
FormatWriterFactory factory,
Path path,
java.util.function.Function<KeyValue,InternalRow> converter,
RowType keyType,
RowType valueType,
RowType writeRowType,
SimpleStatsExtractor simpleStatsExtractor,
long schemaId,
int level,
String compression,
CoreOptions options,
FileSource fileSource,
FileIndexOptions fileIndexOptions) |
KeyValueDataFileWriterImpl(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) |
KeyValueThinDataFileWriterImpl(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)
Constructs a KeyValueThinDataFileWriterImpl.
|
Modifier and Type | Method and Description |
---|---|
static LookupStoreFactory |
LookupStoreFactory.create(CoreOptions options,
CacheManager cacheManager,
Comparator<MemorySlice> keyComparator) |
static BinaryExternalSortBuffer |
RocksDBState.createBulkLoadSorter(IOManager ioManager,
CoreOptions options) |
Constructor and Description |
---|
MergeSorter(CoreOptions options,
RowType keyType,
RowType valueType,
IOManager ioManager) |
Constructor and Description |
---|
LookupMergeTreeCompactRewriter(int maxLevel,
CoreOptions.MergeEngine mergeEngine,
LookupLevels<T> lookupLevels,
FileReaderFactory<KeyValue> readerFactory,
KeyValueFileWriterFactory writerFactory,
Comparator<InternalRow> keyComparator,
FieldsComparator userDefinedSeqComparator,
MergeFunctionFactory<KeyValue> mfFactory,
MergeSorter mergeSorter,
LookupMergeTreeCompactRewriter.MergeFunctionWrapperFactory<T> wrapperFactory,
boolean produceChangelog,
DeletionVectorsMaintainer dvMaintainer,
CoreOptions options) |
Constructor and Description |
---|
FieldListaggAgg(String name,
VarCharType dataType,
CoreOptions options,
String field) |
Modifier and Type | Method and Description |
---|---|
FieldFirstNonNullValueAgg |
FieldFirstNonNullValueAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldMinAgg |
FieldMinAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldAggregator |
FieldAggregatorFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldCollectAgg |
FieldCollectAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldFirstValueAgg |
FieldFirstValueAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldMaxAgg |
FieldMaxAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldRoaringBitmap32Agg |
FieldRoaringBitmap32AggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldBoolOrAgg |
FieldBoolOrAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldProductAgg |
FieldProductAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldLastNonNullValueAgg |
FieldLastNonNullValueAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldSumAgg |
FieldSumAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldHllSketchAgg |
FieldHllSketchAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldBoolAndAgg |
FieldBoolAndAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldLastValueAgg |
FieldLastValueAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldAggregator |
FieldFirstNonNullValueAggLegacyFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldListaggAgg |
FieldListaggAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldAggregator |
FieldNestedUpdateAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldRoaringBitmap64Agg |
FieldRoaringBitmap64AggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldAggregator |
FieldPrimaryKeyAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldThetaSketchAgg |
FieldThetaSketchAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
FieldMergeMapAgg |
FieldMergeMapAggFactory.create(DataType fieldType,
CoreOptions options,
String field) |
static FieldAggregator |
FieldAggregatorFactory.create(DataType fieldType,
String strAgg,
boolean ignoreRetract,
boolean isPrimaryKey,
CoreOptions options,
String field) |
Modifier and Type | Field and Description |
---|---|
protected CoreOptions |
MemoryFileStoreWrite.options |
Constructor and Description |
---|
AbstractFileStoreWrite(SnapshotManager snapshotManager,
FileStoreScan scan,
IndexMaintainer.Factory<T> indexFactory,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName,
CoreOptions options,
int totalBuckets,
RowType partitionType,
int writerNumberMax,
boolean legacyPartitionName) |
AppendOnlyFileStoreWrite(FileIO fileIO,
RawFileSplitRead read,
long schemaId,
RowType rowType,
RowType partitionType,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
AppendOnlyFixedBucketFileStoreWrite(FileIO fileIO,
RawFileSplitRead read,
long schemaId,
String commitUser,
RowType rowType,
RowType partitionType,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
AppendOnlyUnawareBucketFileStoreWrite(FileIO fileIO,
RawFileSplitRead read,
long schemaId,
RowType rowType,
RowType partitionType,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
FileStoreCommitImpl(FileIO fileIO,
SchemaManager schemaManager,
String tableName,
String commitUser,
RowType partitionType,
CoreOptions options,
String partitionDefaultName,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
ManifestFile.Factory manifestFileFactory,
ManifestList.Factory manifestListFactory,
IndexManifestFile.Factory indexManifestFileFactory,
FileStoreScan scan,
int numBucket,
MemorySize manifestTargetSize,
MemorySize manifestFullCompactionSize,
int manifestMergeMinCount,
boolean dynamicPartitionOverwrite,
Comparator<InternalRow> keyComparator,
String branchName,
StatsFileHandler statsFileHandler,
BucketMode bucketMode,
Integer manifestReadParallelism,
List<CommitCallback> commitCallbacks,
int commitMaxRetries,
long commitTimeout) |
KeyValueFileStoreWrite(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
String commitUser,
RowType partitionType,
RowType keyType,
RowType valueType,
java.util.function.Supplier<Comparator<InternalRow>> keyComparatorSupplier,
java.util.function.Supplier<FieldsComparator> udsComparatorSupplier,
java.util.function.Supplier<RecordEqualiser> logDedupEqualSupplier,
MergeFunctionFactory<KeyValue> mfFactory,
FileStorePathFactory pathFactory,
Map<String,FileStorePathFactory> format2PathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
IndexMaintainer.Factory<KeyValue> indexFactory,
DeletionVectorsMaintainer.Factory deletionVectorsMaintainerFactory,
CoreOptions options,
KeyValueFieldsExtractor extractor,
String tableName) |
MemoryFileStoreWrite(SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
RowType partitionType,
IndexMaintainer.Factory<T> indexFactory,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
MergeFileSplitRead(CoreOptions options,
TableSchema schema,
RowType keyType,
RowType valueType,
Comparator<InternalRow> keyComparator,
MergeFunctionFactory<KeyValue> mfFactory,
KeyValueFileReaderFactory.Builder readerFactoryBuilder) |
Modifier and Type | Method and Description |
---|---|
static PartitionExpireStrategy |
PartitionExpireStrategy.createPartitionExpireStrategy(CoreOptions options,
RowType partitionType) |
Constructor and Description |
---|
PartitionValuesTimeExpireStrategy(CoreOptions options,
RowType partitionType) |
Modifier and Type | Method and Description |
---|---|
static List<PartitionMarkDoneAction> |
PartitionMarkDoneAction.createActions(FileStoreTable fileStoreTable,
CoreOptions options) |
static MetastoreClient |
PartitionMarkDoneAction.createMetastoreClient(FileStoreTable table,
CoreOptions options) |
Modifier and Type | Method and Description |
---|---|
CoreOptions |
PrivilegedFileStore.options() |
Modifier and Type | Method and Description |
---|---|
CoreOptions |
DataTable.coreOptions() |
CoreOptions |
DelegatedFileStoreTable.coreOptions() |
Modifier and Type | Method and Description |
---|---|
static RowKindGenerator |
RowKindGenerator.create(TableSchema schema,
CoreOptions options) |
static List<CommitCallback> |
CallbackUtils.loadCommitCallbacks(CoreOptions coreOptions) |
static List<TagCallback> |
CallbackUtils.loadTagCallbacks(CoreOptions coreOptions) |
Modifier and Type | Method and Description |
---|---|
CoreOptions |
AbstractDataTableScan.options() |
Constructor and Description |
---|
AbstractDataTableScan(CoreOptions options,
SnapshotReader snapshotReader) |
DataTableBatchScan(boolean pkTable,
CoreOptions options,
SnapshotReader snapshotReader,
DefaultValueAssigner defaultValueAssigner) |
DataTableStreamScan(CoreOptions options,
SnapshotReader snapshotReader,
SnapshotManager snapshotManager,
boolean supportStreamingReadOverwrite,
DefaultValueAssigner defaultValueAssigner) |
Modifier and Type | Method and Description |
---|---|
static Snapshot |
TimeTravelUtil.resolveSnapshotFromOptions(CoreOptions options,
SnapshotManager snapshotManager) |
Constructor and Description |
---|
SnapshotReaderImpl(FileStoreScan scan,
TableSchema tableSchema,
CoreOptions options,
SnapshotManager snapshotManager,
SplitGenerator splitGenerator,
java.util.function.BiConsumer<FileStoreScan,Predicate> nonPartitionFilterConsumer,
DefaultValueAssigner defaultValueAssigner,
FileStorePathFactory pathFactory,
String tableName,
IndexFileHandler indexFileHandler) |
Modifier and Type | Method and Description |
---|---|
CoreOptions |
ReadOptimizedTable.coreOptions() |
CoreOptions |
FileMonitorTable.coreOptions() |
CoreOptions |
CompactBucketsTable.coreOptions() |
CoreOptions |
AuditLogTable.coreOptions() |
Modifier and Type | Method and Description |
---|---|
static TagTimeExtractor |
TagTimeExtractor.create(CoreOptions.TagCreationMode mode,
CoreOptions options) |
static TagPreview |
TagPreview.create(CoreOptions options) |
static TagPeriodHandler |
TagPeriodHandler.create(CoreOptions options) |
static TagAutoManager |
TagAutoManager.create(CoreOptions options,
SnapshotManager snapshotManager,
TagManager tagManager,
TagDeletion tagDeletion,
List<TagCallback> callbacks) |
static TagAutoCreation |
TagAutoCreation.create(CoreOptions options,
SnapshotManager snapshotManager,
TagManager tagManager,
TagDeletion tagDeletion,
List<TagCallback> callbacks) |
static TagTimeExtractor |
TagTimeExtractor.createForAutoTag(CoreOptions options) |
static TagTimeExtractor |
TagTimeExtractor.createForTagPreview(CoreOptions options) |
Modifier and Type | Method and Description |
---|---|
static UserDefinedSeqComparator |
UserDefinedSeqComparator.create(RowType rowType,
CoreOptions options) |
static SimpleColStatsCollector.Factory[] |
StatsCollectorFactories.createStatsFactories(CoreOptions options,
List<String> fields) |
static SimpleColStatsCollector.Factory[] |
StatsCollectorFactories.createStatsFactories(CoreOptions options,
List<String> fields,
List<String> keyNames) |
Copyright © 2023–2025 The Apache Software Foundation. All rights reserved.