Modifier and Type | Method and Description |
---|---|
Identifier |
MultiTableUnawareAppendCompactionTask.tableIdentifier() |
Constructor and Description |
---|
MultiTableUnawareAppendCompactionTask(BinaryRow partition,
List<DataFileMeta> files,
Identifier identifier) |
Modifier and Type | Field and Description |
---|---|
protected org.apache.paimon.shade.caffeine2.com.github.benmanes.caffeine.cache.Cache<Identifier,List<PartitionEntry>> |
CachingCatalog.partitionCache |
protected org.apache.paimon.shade.caffeine2.com.github.benmanes.caffeine.cache.Cache<Identifier,Table> |
CachingCatalog.tableCache |
Modifier and Type | Method and Description |
---|---|
static Identifier |
Identifier.create(String db,
String object) |
static Identifier |
Identifier.fromString(String fullName) |
Identifier |
Catalog.TableAlreadyExistException.identifier() |
Identifier |
Catalog.TableNotExistException.identifier() |
Identifier |
Catalog.PartitionNotExistException.identifier() |
Identifier |
Catalog.ColumnAlreadyExistException.identifier() |
Identifier |
Catalog.ColumnNotExistException.identifier() |
Identifier |
Catalog.ViewAlreadyExistException.identifier() |
Identifier |
Catalog.ViewNotExistException.identifier() |
Modifier and Type | Method and Description |
---|---|
void |
DelegateCatalog.alterTable(Identifier identifier,
List<SchemaChange> changes,
boolean ignoreIfNotExists) |
void |
Catalog.alterTable(Identifier identifier,
List<SchemaChange> changes,
boolean ignoreIfNotExists)
Modify an existing table from
SchemaChange s. |
void |
AbstractCatalog.alterTable(Identifier identifier,
List<SchemaChange> changes,
boolean ignoreIfNotExists) |
void |
CachingCatalog.alterTable(Identifier identifier,
List<SchemaChange> changes,
boolean ignoreIfNotExists) |
default void |
Catalog.alterTable(Identifier identifier,
SchemaChange change,
boolean ignoreIfNotExists)
Modify an existing table from a
SchemaChange . |
protected void |
FileSystemCatalog.alterTableImpl(Identifier identifier,
List<SchemaChange> changes) |
protected abstract void |
AbstractCatalog.alterTableImpl(Identifier identifier,
List<SchemaChange> changes) |
protected void |
AbstractCatalog.assertMainBranch(Identifier identifier) |
protected static void |
AbstractCatalog.checkNotBranch(Identifier identifier,
String method) |
protected static void |
AbstractCatalog.checkNotSystemTable(Identifier identifier,
String method) |
void |
AbstractCatalog.createFormatTable(Identifier identifier,
Schema schema)
Create a
FormatTable identified by the given Identifier . |
void |
DelegateCatalog.createPartition(Identifier identifier,
Map<String,String> partitions) |
void |
Catalog.createPartition(Identifier identifier,
Map<String,String> partitionSpec)
Create the partition of the specify table.
|
void |
AbstractCatalog.createPartition(Identifier identifier,
Map<String,String> partitionSpec) |
void |
DelegateCatalog.createTable(Identifier identifier,
Schema schema,
boolean ignoreIfExists) |
void |
Catalog.createTable(Identifier identifier,
Schema schema,
boolean ignoreIfExists)
Create a new table.
|
void |
AbstractCatalog.createTable(Identifier identifier,
Schema schema,
boolean ignoreIfExists) |
void |
FileSystemCatalog.createTableImpl(Identifier identifier,
Schema schema) |
protected abstract void |
AbstractCatalog.createTableImpl(Identifier identifier,
Schema schema) |
void |
DelegateCatalog.createView(Identifier identifier,
View view,
boolean ignoreIfExists) |
default void |
Catalog.createView(Identifier identifier,
View view,
boolean ignoreIfExists)
Create a new view.
|
void |
DelegateCatalog.dropPartition(Identifier identifier,
Map<String,String> partitions) |
void |
Catalog.dropPartition(Identifier identifier,
Map<String,String> partitions)
Drop the partition of the specify table.
|
void |
AbstractCatalog.dropPartition(Identifier identifier,
Map<String,String> partitionSpec) |
void |
CachingCatalog.dropPartition(Identifier identifier,
Map<String,String> partitions) |
void |
DelegateCatalog.dropTable(Identifier identifier,
boolean ignoreIfNotExists) |
void |
Catalog.dropTable(Identifier identifier,
boolean ignoreIfNotExists)
Drop a table.
|
void |
AbstractCatalog.dropTable(Identifier identifier,
boolean ignoreIfNotExists) |
void |
CachingCatalog.dropTable(Identifier identifier,
boolean ignoreIfNotExists) |
protected void |
FileSystemCatalog.dropTableImpl(Identifier identifier) |
protected abstract void |
AbstractCatalog.dropTableImpl(Identifier identifier) |
void |
DelegateCatalog.dropView(Identifier identifier,
boolean ignoreIfNotExists) |
default void |
Catalog.dropView(Identifier identifier,
boolean ignoreIfNotExists)
Drop a view.
|
protected Table |
AbstractCatalog.getDataOrFormatTable(Identifier identifier) |
TableSchema |
FileSystemCatalog.getDataTableSchema(Identifier identifier) |
protected abstract TableSchema |
AbstractCatalog.getDataTableSchema(Identifier identifier) |
Table |
DelegateCatalog.getTable(Identifier identifier) |
Table |
Catalog.getTable(Identifier identifier)
Return a
Table identified by the given Identifier . |
Table |
AbstractCatalog.getTable(Identifier identifier) |
Table |
CachingCatalog.getTable(Identifier identifier) |
Path |
DelegateCatalog.getTableLocation(Identifier identifier) |
Path |
Catalog.getTableLocation(Identifier identifier)
Get the table location in this catalog.
|
Path |
AbstractCatalog.getTableLocation(Identifier identifier) |
View |
DelegateCatalog.getView(Identifier identifier) |
default View |
Catalog.getView(Identifier identifier)
Return a
View identified by the given Identifier . |
default void |
Catalog.invalidateTable(Identifier identifier)
Invalidate cached table metadata for an
identifier . |
void |
CachingCatalog.invalidateTable(Identifier identifier) |
static boolean |
AbstractCatalog.isSpecifiedSystemTable(Identifier identifier) |
protected static boolean |
AbstractCatalog.isTableInSystemDatabase(Identifier identifier) |
List<PartitionEntry> |
DelegateCatalog.listPartitions(Identifier identifier) |
List<PartitionEntry> |
Catalog.listPartitions(Identifier identifier)
Get PartitionEntry of all partitions of the table.
|
List<PartitionEntry> |
AbstractCatalog.listPartitions(Identifier identifier) |
List<PartitionEntry> |
CachingCatalog.listPartitions(Identifier identifier) |
Optional<MetastoreClient.Factory> |
AbstractCatalog.metastoreClientFactory(Identifier identifier,
TableSchema schema)
Get metastore client factory for the table specified by
identifier . |
static Path |
AbstractCatalog.newTableLocation(String warehouse,
Identifier identifier) |
void |
CachingCatalog.refreshPartitions(Identifier identifier) |
void |
DelegateCatalog.renameTable(Identifier fromTable,
Identifier toTable,
boolean ignoreIfNotExists) |
void |
Catalog.renameTable(Identifier fromTable,
Identifier toTable,
boolean ignoreIfNotExists)
Rename a table.
|
void |
AbstractCatalog.renameTable(Identifier fromTable,
Identifier toTable,
boolean ignoreIfNotExists) |
void |
CachingCatalog.renameTable(Identifier fromTable,
Identifier toTable,
boolean ignoreIfNotExists) |
void |
FileSystemCatalog.renameTableImpl(Identifier fromTable,
Identifier toTable) |
protected abstract void |
AbstractCatalog.renameTableImpl(Identifier fromTable,
Identifier toTable) |
void |
DelegateCatalog.renameView(Identifier fromView,
Identifier toView,
boolean ignoreIfNotExists) |
default void |
Catalog.renameView(Identifier fromView,
Identifier toView,
boolean ignoreIfNotExists)
Rename a view.
|
void |
DelegateCatalog.repairTable(Identifier identifier) |
default void |
Catalog.repairTable(Identifier identifier) |
protected void |
AbstractCatalog.validateIdentifierNameCaseInsensitive(Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
static Identifier |
FlinkCatalog.toIdentifier(org.apache.flink.table.catalog.ObjectPath path) |
Modifier and Type | Method and Description |
---|---|
protected Schema |
FlinkCatalog.buildPaimonSchema(Identifier identifier,
org.apache.flink.table.catalog.CatalogBaseTable catalogTable,
Map<String,String> options) |
Modifier and Type | Field and Description |
---|---|
protected Identifier |
TableActionBase.identifier |
Modifier and Type | Method and Description |
---|---|
protected FileStoreTable |
SynchronizationActionBase.alterTableOptions(Identifier identifier,
FileStoreTable table) |
String |
TableNameConverter.convert(Identifier originIdentifier) |
Modifier and Type | Method and Description |
---|---|
static String |
CdcActionCommonUtils.combinedModeTableList(String databasePattern,
String includingTablePattern,
List<Identifier> excludedTables) |
static String |
CdcActionCommonUtils.tableList(MultiTablesSinkMode mode,
String databasePattern,
String includingTablePattern,
List<Identifier> monitoredTables,
List<Identifier> excludedTables) |
static String |
CdcActionCommonUtils.tableList(MultiTablesSinkMode mode,
String databasePattern,
String includingTablePattern,
List<Identifier> monitoredTables,
List<Identifier> excludedTables) |
Modifier and Type | Method and Description |
---|---|
List<Identifier> |
MySqlSyncDatabaseAction.excludedTables() |
List<Identifier> |
MySqlSyncDatabaseAction.monitoredTables() |
Modifier and Type | Method and Description |
---|---|
static JdbcSchemasInfo |
MySqlActionUtils.getMySqlTableInfos(org.apache.flink.configuration.Configuration mySqlConfig,
java.util.function.Predicate<String> monitorTablePredication,
List<Identifier> excludedTables,
TypeMapping typeMapping) |
Modifier and Type | Method and Description |
---|---|
static JdbcSchemasInfo |
PostgresActionUtils.getPostgresTableInfos(org.apache.flink.configuration.Configuration postgresConfig,
java.util.function.Predicate<String> monitorTablePredication,
List<Identifier> excludedTables,
TypeMapping typeMapping) |
Modifier and Type | Method and Description |
---|---|
Identifier |
JdbcSchemasInfo.JdbcSchemaInfo.identifier() |
Modifier and Type | Method and Description |
---|---|
List<Identifier> |
JdbcTableInfo.identifiers()
Return all MySQL table identifiers that build this schema.
|
List<Identifier> |
UnmergedJdbcTableInfo.identifiers() |
List<Identifier> |
AllMergedJdbcTableInfo.identifiers() |
List<Identifier> |
ShardsMergedJdbcTableInfo.identifiers() |
List<Identifier> |
JdbcSchemasInfo.nonPkTables() |
Modifier and Type | Method and Description |
---|---|
void |
JdbcSchemasInfo.addSchema(Identifier identifier,
Schema schema) |
void |
JdbcSchemasInfo.addSchema(Identifier identifier,
String schemaName,
Schema schema) |
void |
AllMergedJdbcTableInfo.init(Identifier identifier,
Schema schema) |
void |
ShardsMergedJdbcTableInfo.init(Identifier identifier,
Schema schema) |
AllMergedJdbcTableInfo |
AllMergedJdbcTableInfo.merge(Identifier otherTableId,
Schema other) |
ShardsMergedJdbcTableInfo |
ShardsMergedJdbcTableInfo.merge(Identifier otherTableId,
Schema other) |
Constructor and Description |
---|
JdbcSchemaInfo(Identifier identifier,
String schemaName,
boolean isPkTable,
Schema schema) |
UnmergedJdbcTableInfo(Identifier identifier,
Schema schema) |
Modifier and Type | Field and Description |
---|---|
protected Map<Identifier,StreamTableScan> |
MultiAwareBucketTableScan.scansMap |
protected Map<Identifier,UnawareAppendTableCompactionCoordinator> |
MultiUnawareBucketTableScan.tablesMap |
protected Map<Identifier,CompactBucketsTable> |
MultiAwareBucketTableScan.tablesMap |
Modifier and Type | Method and Description |
---|---|
void |
MultiUnawareBucketTableScan.addScanTable(FileStoreTable fileStoreTable,
Identifier identifier) |
void |
MultiAwareBucketTableScan.addScanTable(FileStoreTable fileStoreTable,
Identifier identifier) |
boolean |
MultiUnawareBucketTableScan.checkTableScanned(Identifier identifier) |
boolean |
MultiAwareBucketTableScan.checkTableScanned(Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
Identifier |
LogStoreTableFactory.RegisterContext.getIdentifier()
Identifier for the table.
|
Modifier and Type | Method and Description |
---|---|
static LogStoreRegister |
LogStoreRegister.getLogStoreRegister(Identifier identifier,
ClassLoader classLoader,
Options tableOptions,
String logStore) |
static void |
LogStoreRegister.registerLogSystem(Catalog catalog,
Identifier identifier,
Map<String,String> options,
ClassLoader classLoader) |
static void |
LogStoreRegister.unRegisterLogSystem(Identifier identifier,
Map<String,String> options,
ClassLoader classLoader) |
Modifier and Type | Field and Description |
---|---|
protected Map<Identifier,FileStoreTable> |
MultiTablesStoreCompactOperator.tables |
protected Map<Identifier,StoreSinkWrite> |
MultiTablesStoreCompactOperator.writes |
Modifier and Type | Method and Description |
---|---|
static MultiTableCommittable |
MultiTableCommittable.fromCommittable(Identifier id,
Committable committable) |
Modifier and Type | Field and Description |
---|---|
static org.apache.flink.util.OutputTag<org.apache.flink.api.java.tuple.Tuple2<Identifier,List<DataField>>> |
CdcDynamicTableParsingProcessFunction.DYNAMIC_SCHEMA_CHANGE_OUTPUT_TAG |
Modifier and Type | Method and Description |
---|---|
Map<Identifier,FileStoreTable> |
CdcRecordStoreMultiWriteOperator.tables() |
Map<Identifier,StoreSinkWrite> |
CdcRecordStoreMultiWriteOperator.writes() |
Modifier and Type | Method and Description |
---|---|
protected void |
UpdatedDataFieldsProcessFunctionBase.applySchemaChange(SchemaManager schemaManager,
SchemaChange schemaChange,
Identifier identifier) |
RichCdcSinkBuilder |
RichCdcSinkBuilder.identifier(Identifier identifier) |
RichCdcSinkBuilder |
RichCdcSinkBuilder.withIdentifier(Identifier identifier)
Deprecated.
|
CdcSinkBuilder<T> |
CdcSinkBuilder.withIdentifier(Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
void |
MultiTableUpdatedDataFieldsProcessFunction.processElement(org.apache.flink.api.java.tuple.Tuple2<Identifier,List<DataField>> updatedDataFields,
org.apache.flink.streaming.api.functions.ProcessFunction.Context context,
org.apache.flink.util.Collector<Void> collector) |
Constructor and Description |
---|
UpdatedDataFieldsProcessFunction(SchemaManager schemaManager,
Identifier identifier,
Catalog.Loader catalogLoader) |
Modifier and Type | Method and Description |
---|---|
static boolean |
MultiTablesCompactorUtil.shouldCompactTable(Identifier tableIdentifier,
Pattern includingPattern,
Pattern excludingPattern) |
Modifier and Type | Method and Description |
---|---|
protected void |
HiveCatalog.alterTableImpl(Identifier identifier,
List<SchemaChange> changes) |
void |
HiveCatalog.createFormatTable(Identifier identifier,
Schema schema) |
protected void |
HiveCatalog.createTableImpl(Identifier identifier,
Schema schema) |
void |
HiveCatalog.createView(Identifier identifier,
View view,
boolean ignoreIfExists) |
void |
HiveCatalog.dropPartition(Identifier identifier,
Map<String,String> partitionSpec) |
protected void |
HiveCatalog.dropTableImpl(Identifier identifier) |
void |
HiveCatalog.dropView(Identifier identifier,
boolean ignoreIfNotExists) |
Table |
HiveCatalog.getDataOrFormatTable(Identifier identifier) |
TableSchema |
HiveCatalog.getDataTableSchema(Identifier identifier) |
Path |
HiveCatalog.getTableLocation(Identifier identifier) |
View |
HiveCatalog.getView(Identifier identifier) |
Optional<MetastoreClient.Factory> |
HiveCatalog.metastoreClientFactory(Identifier identifier,
TableSchema schema) |
protected void |
HiveCatalog.renameTableImpl(Identifier fromTable,
Identifier toTable) |
void |
HiveCatalog.renameView(Identifier fromView,
Identifier toView,
boolean ignoreIfNotExists) |
void |
HiveCatalog.repairTable(Identifier identifier) |
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 |
---|---|
Identifier |
IdentifierSerializer.fromRow(InternalRow rowData) |
Modifier and Type | Method and Description |
---|---|
InternalRow |
IdentifierSerializer.toRow(Identifier record) |
Modifier and Type | Method and Description |
---|---|
protected void |
JdbcCatalog.alterTableImpl(Identifier identifier,
List<SchemaChange> changes) |
protected void |
JdbcCatalog.createTableImpl(Identifier identifier,
Schema schema) |
protected void |
JdbcCatalog.dropTableImpl(Identifier identifier) |
protected TableSchema |
JdbcCatalog.getDataTableSchema(Identifier identifier) |
protected void |
JdbcCatalog.renameTableImpl(Identifier fromTable,
Identifier toTable) |
static void |
JdbcUtils.updateTable(JdbcClientPool connections,
String storeKey,
Identifier fromTable,
Identifier toTable) |
Modifier and Type | Method and Description |
---|---|
Map<Identifier,ManifestCommittable> |
WrappedManifestCommittable.manifestCommittables() |
Modifier and Type | Method and Description |
---|---|
ManifestCommittable |
WrappedManifestCommittable.computeCommittableIfAbsent(Identifier identifier,
long checkpointId,
long watermark) |
void |
WrappedManifestCommittable.putManifestCommittable(Identifier identifier,
ManifestCommittable manifestCommittable) |
Modifier and Type | Method and Description |
---|---|
static Lock.Factory |
Lock.factory(CatalogLockFactory lockFactory,
CatalogLockContext lockContext,
Identifier tablePath) |
static Lock |
Lock.fromCatalog(CatalogLock lock,
Identifier tablePath) |
Constructor and Description |
---|
LockFactory(CatalogLockFactory lockFactory,
CatalogLockContext lockContext,
Identifier tablePath) |
Modifier and Type | Method and Description |
---|---|
void |
PrivilegedCatalog.alterTable(Identifier identifier,
List<SchemaChange> changes,
boolean ignoreIfNotExists) |
void |
PrivilegeChecker.assertCanAlterTable(Identifier identifier) |
void |
AllGrantedPrivilegeChecker.assertCanAlterTable(Identifier identifier) |
void |
PrivilegeCheckerImpl.assertCanAlterTable(Identifier identifier) |
void |
PrivilegeChecker.assertCanDropTable(Identifier identifier) |
void |
AllGrantedPrivilegeChecker.assertCanDropTable(Identifier identifier) |
void |
PrivilegeCheckerImpl.assertCanDropTable(Identifier identifier) |
void |
PrivilegeChecker.assertCanInsert(Identifier identifier) |
void |
AllGrantedPrivilegeChecker.assertCanInsert(Identifier identifier) |
void |
PrivilegeCheckerImpl.assertCanInsert(Identifier identifier) |
void |
PrivilegeChecker.assertCanSelect(Identifier identifier) |
void |
AllGrantedPrivilegeChecker.assertCanSelect(Identifier identifier) |
void |
PrivilegeCheckerImpl.assertCanSelect(Identifier identifier) |
default void |
PrivilegeChecker.assertCanSelectOrInsert(Identifier identifier) |
void |
PrivilegedCatalog.createTable(Identifier identifier,
Schema schema,
boolean ignoreIfExists) |
void |
PrivilegedCatalog.dropPartition(Identifier identifier,
Map<String,String> partitions) |
void |
PrivilegedCatalog.dropTable(Identifier identifier,
boolean ignoreIfNotExists) |
Table |
PrivilegedCatalog.getTable(Identifier identifier) |
void |
PrivilegedCatalog.grantPrivilegeOnTable(String user,
Identifier identifier,
PrivilegeType privilege) |
void |
PrivilegedCatalog.renameTable(Identifier fromTable,
Identifier toTable,
boolean ignoreIfNotExists) |
int |
PrivilegedCatalog.revokePrivilegeOnTable(String user,
Identifier identifier,
PrivilegeType privilege)
Returns the number of privilege revoked.
|
Constructor and Description |
---|
PrivilegedFileStore(FileStore<T> wrapped,
PrivilegeChecker privilegeChecker,
Identifier identifier) |
PrivilegedFileStoreTable(FileStoreTable wrapped,
PrivilegeChecker privilegeChecker,
Identifier identifier) |
Modifier and Type | Method and Description |
---|---|
static Identifier |
SchemaManager.identifierFromPath(String tablePath,
boolean ignoreIfUnknownDatabase) |
static Identifier |
SchemaManager.identifierFromPath(String tablePath,
boolean ignoreIfUnknownDatabase,
String branchName) |
Modifier and Type | Method and Description |
---|---|
protected Identifier |
SparkCatalog.toIdentifier(org.apache.spark.sql.connector.catalog.Identifier ident) |
Modifier and Type | Method and Description |
---|---|
Identifier |
CatalogEnvironment.identifier() |
Modifier and Type | Method and Description |
---|---|
FormatTable.Builder |
FormatTable.Builder.identifier(Identifier identifier) |
Constructor and Description |
---|
CatalogEnvironment(Identifier identifier,
Lock.Factory lockFactory,
MetastoreClient.Factory metastoreClientFactory,
LineageMetaFactory lineageMetaFactory) |
FormatTableImpl(Identifier identifier,
RowType rowType,
List<String> partitionKeys,
String location,
FormatTable.Format format,
Map<String,String> options,
String comment) |
Constructor and Description |
---|
ViewImpl(Identifier identifier,
RowType rowType,
String query,
String comment,
Map<String,String> options) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.