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) |
Modifier and Type | Method and Description |
---|---|
TableSchema |
FileSystemCatalog.getDataTableSchema(Identifier identifier) |
protected abstract TableSchema |
AbstractCatalog.getDataTableSchema(Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
Optional<TableSchema> |
AbstractCatalog.tableSchemaInFileSystem(Path tablePath,
String branchName) |
Modifier and Type | Method and Description |
---|---|
Optional<MetastoreClient.Factory> |
AbstractCatalog.metastoreClientFactory(Identifier identifier,
TableSchema schema)
Get metastore client factory for the table specified by
identifier . |
Modifier and Type | Method and Description |
---|---|
static RowType |
IndexBootstrap.bootstrapType(TableSchema schema) |
Constructor and Description |
---|
KeyPartPartitionKeyExtractor(TableSchema schema) |
Modifier and Type | Method and Description |
---|---|
static void |
CdcActionCommonUtils.assertSchemaCompatible(TableSchema paimonSchema,
List<DataField> sourceTableFields) |
static boolean |
CdcActionCommonUtils.schemaCompatible(TableSchema paimonSchema,
List<DataField> sourceTableFields) |
Modifier and Type | Method and Description |
---|---|
FileStoreTable |
LookupFileStoreTable.copy(TableSchema newTableSchema) |
Constructor and Description |
---|
FixedBucketFromPkExtractor(TableSchema schema) |
LookupCompactDiffRead(MergeFileSplitRead mergeRead,
TableSchema schema) |
Modifier and Type | Method and Description |
---|---|
protected abstract SerializableFunction<TableSchema,PartitionKeyExtractor<T>> |
DynamicBucketSink.extractorFunction() |
protected SerializableFunction<TableSchema,PartitionKeyExtractor<InternalRow>> |
RowDynamicBucketSink.extractorFunction() |
Modifier and Type | Method and Description |
---|---|
protected HashBucketAssignerOperator<T> |
DynamicBucketSink.createHashBucketAssignerOperator(String commitUser,
Table table,
Integer numAssigners,
SerializableFunction<TableSchema,PartitionKeyExtractor<T>> extractorFunction,
boolean overwrite) |
Constructor and Description |
---|
LocalMergeOperator(TableSchema schema) |
RowAssignerChannelComputer(TableSchema schema,
Integer numAssigners) |
RowDataChannelComputer(TableSchema schema,
boolean hasLogSink) |
RowDataKeyAndBucketExtractor(TableSchema schema) |
RowWithBucketChannelComputer(TableSchema schema) |
Constructor and Description |
---|
HashBucketAssignerOperator(String commitUser,
Table table,
Integer numAssigners,
SerializableFunction<TableSchema,PartitionKeyExtractor<T>> extractorFunction,
boolean overwrite) |
Modifier and Type | Field and Description |
---|---|
protected TableSchema |
CdcFixedBucketChannelComputerBase.schema |
Modifier and Type | Method and Description |
---|---|
protected SerializableFunction<TableSchema,PartitionKeyExtractor<T>> |
CdcDynamicBucketSinkBase.extractorFunction() |
Modifier and Type | Method and Description |
---|---|
protected abstract KeyAndBucketExtractor<T> |
CdcDynamicBucketSinkBase.createExtractor(TableSchema schema) |
protected KeyAndBucketExtractor<CdcRecord> |
CdcDynamicBucketSink.createExtractor(TableSchema schema) |
Constructor and Description |
---|
CdcFixedBucketChannelComputerBase(TableSchema schema) |
CdcRecordChannelComputer(TableSchema schema) |
CdcRecordKeyAndBucketExtractor(TableSchema schema) |
CdcRecordPartitionKeyExtractor(TableSchema schema) |
Modifier and Type | Method and Description |
---|---|
TableSchema |
HiveCatalog.getDataTableSchema(Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
Optional<MetastoreClient.Factory> |
HiveCatalog.metastoreClientFactory(Identifier identifier,
TableSchema schema) |
Constructor and Description |
---|
Factory(Identifier identifier,
TableSchema schema,
org.apache.hadoop.hive.conf.HiveConf hiveConf,
String clientClassName,
Options options) |
Modifier and Type | Method and Description |
---|---|
static Optional<Predicate> |
HiveUtils.createPredicate(TableSchema tableSchema,
org.apache.hadoop.mapred.JobConf jobConf,
boolean limitToReadColumnNames) |
Modifier and Type | Method and Description |
---|---|
static IcebergSchema |
IcebergSchema.create(TableSchema tableSchema) |
Modifier and Type | Method and Description |
---|---|
static KeyValueFileReaderFactory.Builder |
KeyValueFileReaderFactory.builder(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
RowType keyType,
RowType valueType,
FileFormatDiscover formatDiscover,
FileStorePathFactory pathFactory,
KeyValueFieldsExtractor extractor,
CoreOptions options) |
static boolean |
FileIndexSkipper.skip(FileIO fileIO,
TableSchema dataSchema,
List<Predicate> dataFilter,
DataFilePathFactory dataFilePathFactory,
DataFileMeta file) |
Modifier and Type | Method and Description |
---|---|
protected TableSchema |
JdbcCatalog.getDataTableSchema(Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
protected TableSchema |
AbstractFileStoreScan.scanTableSchema(long id)
Note: Keep this thread-safe.
|
TableSchema |
MergeFileSplitRead.tableSchema() |
Modifier and Type | Method and Description |
---|---|
static DefaultValueAssigner |
DefaultValueAssigner.create(TableSchema schema) |
Constructor and Description |
---|
AbstractFileStoreScan(ManifestsReader manifestsReader,
SnapshotManager snapshotManager,
SchemaManager schemaManager,
TableSchema schema,
ManifestFile.Factory manifestFileFactory,
Integer parallelism) |
AppendOnlyFileStoreScan(ManifestsReader manifestsReader,
BucketSelectConverter bucketSelectConverter,
SnapshotManager snapshotManager,
SchemaManager schemaManager,
TableSchema schema,
ManifestFile.Factory manifestFileFactory,
Integer scanManifestParallelism,
boolean fileIndexReadEnabled) |
KeyValueFileStoreScan(ManifestsReader manifestsReader,
BucketSelectConverter bucketSelectConverter,
SnapshotManager snapshotManager,
SchemaManager schemaManager,
TableSchema schema,
KeyValueFieldsExtractor keyValueFieldsExtractor,
ManifestFile.Factory manifestFileFactory,
Integer scanManifestParallelism,
boolean deletionVectorsEnabled,
CoreOptions.MergeEngine mergeEngine,
CoreOptions.ChangelogProducer changelogProducer,
boolean fileIndexReadEnabled) |
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) |
MergeFileSplitRead(CoreOptions options,
TableSchema schema,
RowType keyType,
RowType valueType,
Comparator<InternalRow> keyComparator,
MergeFunctionFactory<KeyValue> mfFactory,
KeyValueFileReaderFactory.Builder readerFactoryBuilder) |
RawFileSplitRead(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
RowType rowType,
FileFormatDiscover formatDiscover,
FileStorePathFactory pathFactory,
boolean fileIndexReadEnabled) |
Modifier and Type | Method and Description |
---|---|
static Pair<Pair<int[],RowType>,List<DataField>> |
PartitionUtils.constructPartitionMapping(TableSchema dataSchema,
List<DataField> dataFields) |
Modifier and Type | Method and Description |
---|---|
FileStoreTable |
PrivilegedFileStoreTable.copy(TableSchema newTableSchema) |
Modifier and Type | Method and Description |
---|---|
TableSchema |
SchemaManager.commitChanges(List<SchemaChange> changes)
Update
SchemaChange s. |
TableSchema |
SchemaManager.commitChanges(SchemaChange... changes)
Update
SchemaChange s. |
TableSchema |
TableSchema.copy(Map<String,String> newOptions) |
TableSchema |
SchemaManager.createTable(Schema schema) |
TableSchema |
SchemaManager.createTable(Schema schema,
boolean ignoreIfExistsSame) |
TableSchema |
SchemaSerializer.deserialize(org.apache.paimon.shade.jackson2.com.fasterxml.jackson.databind.JsonNode node) |
static TableSchema |
TableSchema.fromJson(String json) |
static TableSchema |
SchemaManager.fromPath(FileIO fileIO,
Path path) |
static TableSchema |
TableSchema.fromPath(FileIO fileIO,
Path path) |
static TableSchema |
SchemaMergingUtils.mergeSchemas(TableSchema currentTableSchema,
RowType targetType,
boolean allowExplicitCast) |
TableSchema |
SchemaManager.schema(long id)
Read schema for schema id.
|
Modifier and Type | Method and Description |
---|---|
Optional<TableSchema> |
SchemaManager.latest() |
List<TableSchema> |
SchemaManager.listAll() |
List<TableSchema> |
SchemaManager.listWithRange(Optional<Long> optionalMaxSchemaId,
Optional<Long> optionalMinSchemaId) |
List<TableSchema> |
SchemaManager.schemasWithId(List<Long> schemaIds) |
Modifier and Type | Method and Description |
---|---|
static Schema |
Schema.fromTableSchema(TableSchema tableSchema) |
List<DataField> |
KeyValueFieldsExtractor.keyFields(TableSchema schema)
Extract key fields from table schema.
|
static TableSchema |
SchemaMergingUtils.mergeSchemas(TableSchema currentTableSchema,
RowType targetType,
boolean allowExplicitCast) |
void |
SchemaSerializer.serialize(TableSchema tableSchema,
org.apache.paimon.shade.jackson2.com.fasterxml.jackson.core.JsonGenerator generator) |
static void |
SchemaValidation.validateFallbackBranch(SchemaManager schemaManager,
TableSchema schema) |
static void |
SchemaValidation.validateTableSchema(TableSchema schema)
Validate the
TableSchema and CoreOptions . |
List<DataField> |
KeyValueFieldsExtractor.valueFields(TableSchema schema)
Extract value fields from table schema.
|
Modifier and Type | Method and Description |
---|---|
void |
Statistics.deserializeFieldsFromString(TableSchema schema) |
void |
Statistics.serializeFieldsToString(TableSchema schema) |
Modifier and Type | Method and Description |
---|---|
TableSchema |
FileStoreTable.schema() |
TableSchema |
DelegatedFileStoreTable.schema() |
Modifier and Type | Method and Description |
---|---|
FileStoreTable |
FileStoreTable.copy(TableSchema newTableSchema) |
FileStoreTable |
FallbackReadFileStoreTable.copy(TableSchema newTableSchema) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
CatalogEnvironment catalogEnvironment) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
Options dynamicOptions,
CatalogEnvironment catalogEnvironment) |
static MergeFunctionFactory<KeyValue> |
PrimaryKeyTableUtils.createMergeFunctionFactory(TableSchema tableSchema,
KeyValueFieldsExtractor extractor) |
static FileStoreTable |
FileStoreTableFactory.createWithoutFallbackBranch(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
Options dynamicOptions,
CatalogEnvironment catalogEnvironment) |
List<DataField> |
PrimaryKeyTableUtils.PrimaryKeyFieldsExtractor.keyFields(TableSchema schema) |
List<DataField> |
PrimaryKeyTableUtils.PrimaryKeyFieldsExtractor.valueFields(TableSchema schema) |
Modifier and Type | Method and Description |
---|---|
static RowKindGenerator |
RowKindGenerator.create(TableSchema schema,
CoreOptions options) |
Constructor and Description |
---|
DynamicBucketRowKeyExtractor(TableSchema schema) |
FixedBucketRowKeyExtractor(TableSchema schema) |
FixedBucketWriteSelector(TableSchema schema) |
RowKeyExtractor(TableSchema schema) |
RowPartitionKeyExtractor(TableSchema schema) |
UnawareBucketRowKeyExtractor(TableSchema schema) |
Constructor and Description |
---|
AbstractDataTableRead(TableSchema schema) |
KeyValueTableRead(java.util.function.Supplier<MergeFileSplitRead> mergeReadSupplier,
java.util.function.Supplier<RawFileSplitRead> batchRawReadSupplier,
TableSchema schema) |
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 |
---|---|
TableSchema |
BulkFormatMapping.getDataSchema() |
Modifier and Type | Method and Description |
---|---|
BulkFormatMapping |
BulkFormatMapping.BulkFormatMappingBuilder.build(String formatIdentifier,
TableSchema tableSchema,
TableSchema dataSchema) |
Constructor and Description |
---|
BulkFormatMapping(int[] indexMapping,
CastFieldGetter[] castMapping,
Pair<int[],RowType> partitionPair,
FormatReaderFactory bulkFormat,
TableSchema dataSchema,
List<Predicate> dataFilters) |
Constructor and Description |
---|
BulkFormatMappingBuilder(FileFormatDiscover formatDiscover,
List<DataField> readTableFields,
java.util.function.Function<TableSchema,List<DataField>> fieldsExtractor,
List<Predicate> filters) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.