Uses of Class
org.apache.flink.table.catalog.ObjectIdentifier
-
-
Uses of ObjectIdentifier in org.apache.flink.connector.file.table
Methods in org.apache.flink.connector.file.table with parameters of type ObjectIdentifier Modifier and Type Method Description FileSystemOutputFormat.Builder<T>
FileSystemOutputFormat.Builder. setIdentifier(ObjectIdentifier identifier)
Constructors in org.apache.flink.connector.file.table with parameters of type ObjectIdentifier Constructor Description FileSystemCommitter(FileSystemFactory factory, TableMetaStoreFactory metaStoreFactory, boolean overwrite, Path tmpPath, int partitionColumnSize, boolean isToLocal, ObjectIdentifier identifier, LinkedHashMap<String,String> staticPartitions, List<PartitionCommitPolicy> policies)
FileSystemTableSource(ObjectIdentifier tableIdentifier, DataType physicalRowDataType, List<String> partitionKeys, ReadableConfig tableOptions, DecodingFormat<BulkFormat<RowData,FileSourceSplit>> bulkReaderFormat, DecodingFormat<DeserializationSchema<RowData>> deserializationFormat)
PartitionLoader(boolean overwrite, FileSystem sourceFs, TableMetaStoreFactory factory, boolean isToLocal, ObjectIdentifier identifier, List<PartitionCommitPolicy> policies)
-
Uses of ObjectIdentifier in org.apache.flink.connector.file.table.batch
Methods in org.apache.flink.connector.file.table.batch with parameters of type ObjectIdentifier Modifier and Type Method Description static <T> DataStreamSink<?>
BatchSink. createBatchCompactSink(DataStream<CompactMessages.CoordinatorInput> dataStream, StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> builder, CompactReader.Factory<T> readFactory, FileSystemFactory fsFactory, TableMetaStoreFactory metaStoreFactory, PartitionCommitPolicyFactory partitionCommitPolicyFactory, String[] partitionColumns, LinkedHashMap<String,String> staticPartitionSpec, Path tmpPath, ObjectIdentifier identifier, long compactAverageSize, long compactTargetSize, boolean isToLocal, boolean overwrite, int compactParallelism, boolean compactParallelismConfigured)
-
Uses of ObjectIdentifier in org.apache.flink.connector.file.table.batch.compact
Constructors in org.apache.flink.connector.file.table.batch.compact with parameters of type ObjectIdentifier Constructor Description BatchPartitionCommitterSink(FileSystemFactory fsFactory, TableMetaStoreFactory msFactory, boolean overwrite, boolean isToLocal, Path tmpPath, String[] partitionColumns, LinkedHashMap<String,String> staticPartitions, ObjectIdentifier identifier, PartitionCommitPolicyFactory partitionCommitPolicyFactory)
-
Uses of ObjectIdentifier in org.apache.flink.connector.file.table.stream
Methods in org.apache.flink.connector.file.table.stream with parameters of type ObjectIdentifier Modifier and Type Method Description static DataStreamSink<?>
StreamingSink. sink(ProviderContext providerContext, DataStream<PartitionCommitInfo> writer, Path locationPath, ObjectIdentifier identifier, List<String> partitionKeys, TableMetaStoreFactory msFactory, FileSystemFactory fsFactory, Configuration options)
Create a sink from file writer.Constructors in org.apache.flink.connector.file.table.stream with parameters of type ObjectIdentifier Constructor Description PartitionCommitter(Path locationPath, ObjectIdentifier tableIdentifier, List<String> partitionKeys, TableMetaStoreFactory metaStoreFactory, FileSystemFactory fsFactory, Configuration conf)
-
Uses of ObjectIdentifier in org.apache.flink.connectors.hive
Constructors in org.apache.flink.connectors.hive with parameters of type ObjectIdentifier Constructor Description HiveTableSink(ReadableConfig flinkConf, org.apache.hadoop.mapred.JobConf jobConf, ObjectIdentifier identifier, ResolvedCatalogTable table, Integer configuredSinkParallelism)
-
Uses of ObjectIdentifier in org.apache.flink.table.api
Methods in org.apache.flink.table.api that return types with arguments of type ObjectIdentifier Modifier and Type Method Description Optional<ObjectIdentifier>
TablePipeline. getSinkIdentifier()
-
Uses of ObjectIdentifier in org.apache.flink.table.api.bridge.internal
Methods in org.apache.flink.table.api.bridge.internal with parameters of type ObjectIdentifier Modifier and Type Method Description protected QueryOperation
AbstractStreamTableEnvironmentImpl. qualifyQueryOperation(ObjectIdentifier identifier, QueryOperation queryOperation)
-
Uses of ObjectIdentifier in org.apache.flink.table.api.internal
Methods in org.apache.flink.table.api.internal with parameters of type ObjectIdentifier Modifier and Type Method Description static String
ShowCreateUtil. buildShowCreateTableRow(ResolvedCatalogBaseTable<?> table, ObjectIdentifier tableIdentifier, boolean isTemporary)
static String
ShowCreateUtil. buildShowCreateViewRow(ResolvedCatalogBaseTable<?> view, ObjectIdentifier viewIdentifier, boolean isTemporary)
Show create view statement only for views.protected QueryOperation
TableEnvironmentImpl. qualifyQueryOperation(ObjectIdentifier identifier, QueryOperation queryOperation)
Subclasses can override this method to transform the given QueryOperation to a new one with the qualified object identifier. -
Uses of ObjectIdentifier in org.apache.flink.table.catalog
Methods in org.apache.flink.table.catalog that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
ContextResolvedTable. getIdentifier()
static ObjectIdentifier
ObjectIdentifier. of(String catalogName, String databaseName, String objectName)
ObjectIdentifier
CatalogManager. qualifyIdentifier(UnresolvedIdentifier identifier)
Returns the full name of the given table path, this name may be padded with current catalog/database name based on theidentifier's
length.ObjectIdentifier
CatalogRegistry. qualifyIdentifier(UnresolvedIdentifier identifier)
Returns the full name of the given table path, this name may be padded with current catalog/database name based on theidentifier's
length.Methods in org.apache.flink.table.catalog with parameters of type ObjectIdentifier Modifier and Type Method Description void
CatalogManager. alterTable(CatalogBaseTable table, List<TableChange> changes, ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Alters a table in a given fully qualified path with table changes.void
CatalogManager. alterTable(CatalogBaseTable table, ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Alters a table in a given fully qualified path.void
CatalogManager. createTable(CatalogBaseTable table, ObjectIdentifier objectIdentifier, boolean ignoreIfExists)
Creates a table in a given fully qualified path.void
CatalogManager. createTemporaryTable(CatalogBaseTable table, ObjectIdentifier objectIdentifier, boolean ignoreIfExists)
Creates a temporary table in a given fully qualified path.void
CatalogManager. dropMaterializedTable(ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Drops a materialized table in a given fully qualified path.void
CatalogManager. dropTable(ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Drops a table in a given fully qualified path.CatalogFunction
FunctionCatalog. dropTempCatalogFunction(ObjectIdentifier identifier, boolean ignoreIfNotExist)
Drop a temporary catalog function.void
CatalogManager. dropTemporaryTable(ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Drop a temporary table in a given fully qualified path.void
CatalogManager. dropTemporaryView(ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Drop a temporary view in a given fully qualified path.void
CatalogManager. dropView(ObjectIdentifier objectIdentifier, boolean ignoreIfNotExists)
Drops a view in a given fully qualified path.Optional<ResolvedCatalogBaseTable<?>>
CatalogManager. getCatalogBaseTable(ObjectIdentifier objectIdentifier)
Retrieves a fully qualified table.Optional<ResolvedCatalogBaseTable<?>>
CatalogRegistry. getCatalogBaseTable(ObjectIdentifier objectIdentifier)
Retrieves a fully qualified table.Optional<CatalogPartition>
CatalogManager. getPartition(ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec)
Retrieves a partition with a fully qualified table path and partition spec.Optional<CatalogPartition>
CatalogRegistry. getPartition(ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec)
Retrieves a partition with a fully qualified table path and partition spec.Optional<ContextResolvedTable>
CatalogManager. getTable(ObjectIdentifier objectIdentifier)
Retrieves a fully qualified table.Optional<ContextResolvedTable>
CatalogManager. getTable(ObjectIdentifier objectIdentifier, long timestamp)
Retrieves a fully qualified table with a specific time.ContextResolvedTable
CatalogManager. getTableOrError(ObjectIdentifier objectIdentifier)
LikeCatalogManager.getTable(ObjectIdentifier)
, but throws an error when the table is not available in any of the catalogs.protected Optional<TemporaryOperationListener>
CatalogManager. getTemporaryOperationListener(ObjectIdentifier identifier)
boolean
FunctionCatalog. hasTemporaryCatalogFunction(ObjectIdentifier functionIdentifier)
Check whether a temporary catalog function is already registered.boolean
CatalogManager. isTemporaryTable(ObjectIdentifier objectIdentifier)
Return whether the table with a fully qualified table path is temporary or not.boolean
CatalogRegistry. isTemporaryTable(ObjectIdentifier objectIdentifier)
Return whether the table with a fully qualified table path is temporary or not.Map<String,String>
ManagedTableListener. notifyTableCompaction(Catalog catalog, ObjectIdentifier identifier, ResolvedCatalogBaseTable<?> table, CatalogPartitionSpec partitionSpec, boolean isTemporary)
Deprecated.Notify compaction for managed table.ResolvedCatalogBaseTable<?>
ManagedTableListener. notifyTableCreation(Catalog catalog, ObjectIdentifier identifier, ResolvedCatalogBaseTable<?> table, boolean isTemporary, boolean ignoreIfExists)
Deprecated.Notify for creating managed table.void
ManagedTableListener. notifyTableDrop(Catalog catalog, ObjectIdentifier identifier, ResolvedCatalogBaseTable<?> table, boolean isTemporary, boolean ignoreIfNotExists)
Deprecated.Notify for dropping managed table.static UnresolvedIdentifier
UnresolvedIdentifier. of(ObjectIdentifier objectIdentifier)
Constructs anUnresolvedIdentifier
from anObjectIdentifier
.static ContextResolvedTable
ContextResolvedTable. permanent(ObjectIdentifier identifier, Catalog catalog, ResolvedCatalogBaseTable<?> resolvedTable)
void
FunctionCatalog. registerTempCatalogScalarFunction(ObjectIdentifier oi, ScalarFunction function)
Deprecated.Map<String,String>
CatalogManager. resolveCompactManagedTableOptions(ResolvedCatalogTable origin, ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec)
Resolve dynamic options for compact operation on a Flink's managed table.static ContextResolvedTable
ContextResolvedTable. temporary(ObjectIdentifier identifier, ResolvedCatalogBaseTable<?> resolvedTable)
-
Uses of ObjectIdentifier in org.apache.flink.table.catalog.listener
Methods in org.apache.flink.table.catalog.listener that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
TableModificationEvent. identifier()
Methods in org.apache.flink.table.catalog.listener with parameters of type ObjectIdentifier Modifier and Type Method Description static AlterTableEvent
AlterTableEvent. createEvent(CatalogContext context, ObjectIdentifier identifier, CatalogBaseTable newTable, boolean ignoreIfNotExists)
static CreateTableEvent
CreateTableEvent. createEvent(CatalogContext context, ObjectIdentifier identifier, CatalogBaseTable table, boolean ignoreIfExists, boolean isTemporary)
static DropTableEvent
DropTableEvent. createEvent(CatalogContext context, ObjectIdentifier identifier, CatalogBaseTable table, boolean ignoreIfNotExists, boolean isTemporary)
-
Uses of ObjectIdentifier in org.apache.flink.table.factories
Methods in org.apache.flink.table.factories that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
DynamicTableFactory.Context. getObjectIdentifier()
Returns the identifier of the table in theCatalog
.ObjectIdentifier
FactoryUtil.DefaultDynamicTableContext. getObjectIdentifier()
ObjectIdentifier
TableSinkFactoryContextImpl. getObjectIdentifier()
Deprecated.ObjectIdentifier
TableSourceFactoryContextImpl. getObjectIdentifier()
Deprecated.Methods in org.apache.flink.table.factories with parameters of type ObjectIdentifier Modifier and Type Method Description static DynamicTableSink
FactoryUtil. createDynamicTableSink(DynamicTableSinkFactory preferredFactory, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSink
from aCatalogTable
.static DynamicTableSink
FactoryUtil. createDynamicTableSink(DynamicTableSinkFactory preferredFactory, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
static DynamicTableSource
FactoryUtil. createDynamicTableSource(DynamicTableSourceFactory preferredFactory, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSource
from aCatalogTable
.static DynamicTableSource
FactoryUtil. createDynamicTableSource(DynamicTableSourceFactory preferredFactory, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
static DynamicTableSink
FactoryUtil. createTableSink(Catalog catalog, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
static DynamicTableSource
FactoryUtil. createTableSource(Catalog catalog, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
static <T> TableSink<T>
TableFactoryUtil. findAndCreateTableSink(Catalog catalog, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, ReadableConfig configuration, boolean isStreamingMode, boolean isTemporary)
Creates aTableSink
from aCatalogTable
.static <T> TableSource<T>
TableFactoryUtil. findAndCreateTableSource(Catalog catalog, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, ReadableConfig configuration, boolean isTemporary)
Creates aTableSource
from aCatalogTable
.static boolean
TableFactoryUtil. isLegacyConnectorOptions(Catalog catalog, ReadableConfig configuration, boolean isStreamingMode, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, boolean isTemporary)
Checks whether theCatalogTable
uses legacy connector sink options.Constructors in org.apache.flink.table.factories with parameters of type ObjectIdentifier Constructor Description DefaultDynamicTableContext(ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
TableSinkFactoryContextImpl(ObjectIdentifier identifier, CatalogTable table, ReadableConfig config, boolean isBounded, boolean isTemporary)
Deprecated.TableSourceFactoryContextImpl(ObjectIdentifier identifier, CatalogTable table, ReadableConfig config, boolean isTemporary)
Deprecated. -
Uses of ObjectIdentifier in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions that return ObjectIdentifier Modifier and Type Method Description static ObjectIdentifier
FunctionIdentifier. normalizeObjectIdentifier(ObjectIdentifier oi)
Normalize an object identifier by only normalizing the function name.Methods in org.apache.flink.table.functions that return types with arguments of type ObjectIdentifier Modifier and Type Method Description Optional<ObjectIdentifier>
FunctionIdentifier. getIdentifier()
Methods in org.apache.flink.table.functions with parameters of type ObjectIdentifier Modifier and Type Method Description static ObjectIdentifier
FunctionIdentifier. normalizeObjectIdentifier(ObjectIdentifier oi)
Normalize an object identifier by only normalizing the function name.static FunctionIdentifier
FunctionIdentifier. of(ObjectIdentifier oi)
-
Uses of ObjectIdentifier in org.apache.flink.table.gateway.api
Methods in org.apache.flink.table.gateway.api with parameters of type ObjectIdentifier Modifier and Type Method Description ResolvedCatalogBaseTable<?>
SqlGatewayService. getTable(SessionHandle sessionHandle, ObjectIdentifier tableIdentifier)
Return table of the given fully qualified name. -
Uses of ObjectIdentifier in org.apache.flink.table.gateway.api.results
Methods in org.apache.flink.table.gateway.api.results that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
TableInfo. getIdentifier()
Constructors in org.apache.flink.table.gateway.api.results with parameters of type ObjectIdentifier Constructor Description TableInfo(ObjectIdentifier identifier, CatalogBaseTable.TableKind tableKind)
-
Uses of ObjectIdentifier in org.apache.flink.table.gateway.service
Methods in org.apache.flink.table.gateway.service with parameters of type ObjectIdentifier Modifier and Type Method Description ResolvedCatalogBaseTable<?>
SqlGatewayServiceImpl. getTable(SessionHandle sessionHandle, ObjectIdentifier tableIdentifier)
-
Uses of ObjectIdentifier in org.apache.flink.table.gateway.service.materializedtable
Methods in org.apache.flink.table.gateway.service.materializedtable with parameters of type ObjectIdentifier Modifier and Type Method Description protected static String
MaterializedTableManager. getInsertStatement(ObjectIdentifier materializedTableIdentifier, String definitionQuery, Map<String,String> dynamicOptions)
Generate insert statement for materialized table.protected static String
MaterializedTableManager. getRefreshStatement(ObjectIdentifier tableIdentifier, String definitionQuery, Map<String,String> partitionSpec, Map<String,String> dynamicOptions)
ResultFetcher
MaterializedTableManager. refreshMaterializedTable(OperationExecutor operationExecutor, OperationHandle handle, ObjectIdentifier materializedTableIdentifier, Map<String,String> staticPartitions, Map<String,String> dynamicOptions, boolean isPeriodic, String scheduleTime)
-
Uses of ObjectIdentifier in org.apache.flink.table.gateway.service.operation
Methods in org.apache.flink.table.gateway.service.operation with parameters of type ObjectIdentifier Modifier and Type Method Description ResolvedCatalogBaseTable<?>
OperationExecutor. getTable(ObjectIdentifier tableIdentifier)
boolean
OperationExecutor. tableExists(ObjectIdentifier tableIdentifier)
-
Uses of ObjectIdentifier in org.apache.flink.table.legacy.factories
Methods in org.apache.flink.table.legacy.factories that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
TableSinkFactory.Context. getObjectIdentifier()
ObjectIdentifier
TableSourceFactory.Context. getObjectIdentifier()
-
Uses of ObjectIdentifier in org.apache.flink.table.legacy.operations.ddl
Constructors in org.apache.flink.table.legacy.operations.ddl with parameters of type ObjectIdentifier Constructor Description AlterTableOptionsOperation(ObjectIdentifier tableIdentifier, CatalogTable catalogTable, boolean ignoreIfNotExists)
Deprecated. -
Uses of ObjectIdentifier in org.apache.flink.table.operations
Fields in org.apache.flink.table.operations declared as ObjectIdentifier Modifier and Type Field Description protected ObjectIdentifier
ShowPartitionsOperation. tableIdentifier
Methods in org.apache.flink.table.operations that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
DescribeTableOperation. getSqlIdentifier()
ObjectIdentifier
ShowColumnsOperation. getTableIdentifier()
ObjectIdentifier
ShowCreateTableOperation. getTableIdentifier()
ObjectIdentifier
ShowPartitionsOperation. getTableIdentifier()
ObjectIdentifier
TruncateTableOperation. getTableIdentifier()
ObjectIdentifier
ShowCreateViewOperation. getViewIdentifier()
Methods in org.apache.flink.table.operations that return types with arguments of type ObjectIdentifier Modifier and Type Method Description Optional<ObjectIdentifier>
DataStreamQueryOperation. getIdentifier()
Deprecated.Methods in org.apache.flink.table.operations with parameters of type ObjectIdentifier Modifier and Type Method Description StagedSinkModifyOperation
CreateTableASOperation. toStagedSinkModifyOperation(ObjectIdentifier tableIdentifier, ResolvedCatalogTable catalogTable, Catalog catalog, DynamicTableSink dynamicTableSink)
StagedSinkModifyOperation
ReplaceTableAsOperation. toStagedSinkModifyOperation(ObjectIdentifier tableIdentifier, ResolvedCatalogTable catalogTable, Catalog catalog, DynamicTableSink dynamicTableSink)
Constructors in org.apache.flink.table.operations with parameters of type ObjectIdentifier Constructor Description DataStreamQueryOperation(ObjectIdentifier identifier, DataStream<E> dataStream, int[] fieldIndices, ResolvedSchema resolvedSchema)
Deprecated.DescribeTableOperation(ObjectIdentifier sqlIdentifier, boolean isExtended)
ShowColumnsOperation(ObjectIdentifier tableIdentifier, String preposition, ShowLikeOperator likeOp)
ShowCreateTableOperation(ObjectIdentifier sqlIdentifier)
ShowCreateViewOperation(ObjectIdentifier sqlIdentifier)
ShowPartitionsOperation(ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec)
ShowPartitionsOperation(ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec, String defaultPartitionName)
TruncateTableOperation(ObjectIdentifier tableIdentifier)
-
Uses of ObjectIdentifier in org.apache.flink.table.operations.ddl
Fields in org.apache.flink.table.operations.ddl declared as ObjectIdentifier Modifier and Type Field Description protected ObjectIdentifier
AlterTableOperation. tableIdentifier
protected ObjectIdentifier
AlterViewOperation. viewIdentifier
Methods in org.apache.flink.table.operations.ddl that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
AlterCatalogFunctionOperation. getFunctionIdentifier()
ObjectIdentifier
CreateCatalogFunctionOperation. getFunctionIdentifier()
ObjectIdentifier
DropCatalogFunctionOperation. getFunctionIdentifier()
ObjectIdentifier
AlterTableRenameOperation. getNewTableIdentifier()
ObjectIdentifier
AlterViewRenameOperation. getNewViewIdentifier()
ObjectIdentifier
AlterTableOperation. getTableIdentifier()
ObjectIdentifier
AnalyzeTableOperation. getTableIdentifier()
ObjectIdentifier
CreateTableOperation. getTableIdentifier()
ObjectIdentifier
DropTableOperation. getTableIdentifier()
ObjectIdentifier
AlterViewOperation. getViewIdentifier()
ObjectIdentifier
CreateViewOperation. getViewIdentifier()
ObjectIdentifier
DropViewOperation. getViewIdentifier()
Constructors in org.apache.flink.table.operations.ddl with parameters of type ObjectIdentifier Constructor Description AddPartitionsOperation(ObjectIdentifier tableIdentifier, boolean ignoreIfPartitionExists, List<CatalogPartitionSpec> partitionSpecs, List<CatalogPartition> catalogPartitions)
AlterCatalogFunctionOperation(ObjectIdentifier functionIdentifier, CatalogFunction catalogFunction, boolean ifExists, boolean isTemporary)
AlterPartitionOperation(ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec)
AlterPartitionPropertiesOperation(ObjectIdentifier tableIdentifier, CatalogPartitionSpec partitionSpec, CatalogPartition catalogPartition)
AlterTableChangeOperation(ObjectIdentifier tableIdentifier, List<TableChange> tableChanges, CatalogTable newTable, boolean ignoreIfNotExists)
AlterTableOperation(ObjectIdentifier tableIdentifier, boolean ignoreIfTableNotExists)
AlterTableRenameOperation(ObjectIdentifier tableIdentifier, ObjectIdentifier newTableIdentifier, boolean ignoreIfNotExists)
AlterTableSchemaOperation(ObjectIdentifier tableIdentifier, CatalogTable catalogTable, boolean ignoreIfNotExists)
AlterViewAsOperation(ObjectIdentifier viewIdentifier, CatalogView newView)
AlterViewOperation(ObjectIdentifier viewIdentifier)
AlterViewPropertiesOperation(ObjectIdentifier viewIdentifier, CatalogView catalogView)
AlterViewRenameOperation(ObjectIdentifier viewIdentifier, ObjectIdentifier newViewIdentifier)
AnalyzeTableOperation(ObjectIdentifier tableIdentifier, List<CatalogPartitionSpec> partitionSpecs, List<Column> columns)
CreateCatalogFunctionOperation(ObjectIdentifier functionIdentifier, CatalogFunction catalogFunction, boolean ignoreIfExists, boolean isTemporary)
CreateTableOperation(ObjectIdentifier tableIdentifier, CatalogTable catalogTable, boolean ignoreIfExists, boolean isTemporary)
CreateViewOperation(ObjectIdentifier viewIdentifier, CatalogView catalogView, boolean ignoreIfExists, boolean isTemporary)
DropCatalogFunctionOperation(ObjectIdentifier functionIdentifier, boolean ifExists, boolean isTemporary)
DropPartitionsOperation(ObjectIdentifier tableIdentifier, boolean ignoreIfPartitionNotExists, List<CatalogPartitionSpec> partitionSpecs)
DropTableOperation(ObjectIdentifier tableIdentifier, boolean ifExists, boolean isTemporary)
DropViewOperation(ObjectIdentifier viewIdentifier, boolean ifExists, boolean isTemporary)
-
Uses of ObjectIdentifier in org.apache.flink.table.operations.materializedtable
Fields in org.apache.flink.table.operations.materializedtable declared as ObjectIdentifier Modifier and Type Field Description protected ObjectIdentifier
AlterMaterializedTableOperation. tableIdentifier
Methods in org.apache.flink.table.operations.materializedtable that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
AlterMaterializedTableOperation. getTableIdentifier()
ObjectIdentifier
CreateMaterializedTableOperation. getTableIdentifier()
ObjectIdentifier
DropMaterializedTableOperation. getTableIdentifier()
Constructors in org.apache.flink.table.operations.materializedtable with parameters of type ObjectIdentifier Constructor Description AlterMaterializedTableChangeOperation(ObjectIdentifier tableIdentifier, List<TableChange> tableChanges, CatalogMaterializedTable catalogMaterializedTable)
AlterMaterializedTableOperation(ObjectIdentifier tableIdentifier)
AlterMaterializedTableRefreshOperation(ObjectIdentifier tableIdentifier, Map<String,String> partitionSpec)
AlterMaterializedTableResumeOperation(ObjectIdentifier tableIdentifier, Map<String,String> options)
AlterMaterializedTableSuspendOperation(ObjectIdentifier tableIdentifier)
CreateMaterializedTableOperation(ObjectIdentifier tableIdentifier, ResolvedCatalogMaterializedTable materializedTable)
DropMaterializedTableOperation(ObjectIdentifier tableIdentifier, boolean ifExists)
-
Uses of ObjectIdentifier in org.apache.flink.table.operations.utils
Methods in org.apache.flink.table.operations.utils with parameters of type ObjectIdentifier Modifier and Type Method Description static DynamicTableSink
ExecutableOperationUtils. createDynamicTableSink(Catalog catalog, Supplier<Optional<DynamicTableSinkFactory>> sinkFactorySupplier, ObjectIdentifier objectIdentifier, ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSink
from aCatalogTable
. -
Uses of ObjectIdentifier in org.apache.flink.table.planner.calcite
Methods in org.apache.flink.table.planner.calcite with parameters of type ObjectIdentifier Modifier and Type Method Description RelBuilder
FlinkRelBuilder. scan(ObjectIdentifier identifier, Map<String,String> dynamicOptions)
-
Uses of ObjectIdentifier in org.apache.flink.table.planner.delegation.hive
Methods in org.apache.flink.table.planner.delegation.hive that return types with arguments of type ObjectIdentifier Modifier and Type Method Description Tuple4<ObjectIdentifier,QueryOperation,Map<String,String>,Boolean>
HiveParserDMLHelper. createInsertOperationInfo(org.apache.calcite.rel.RelNode queryRelNode, CatalogTable destTable, ObjectIdentifier destTableIdentifier, Map<String,String> staticPartSpec, List<String> destSchema, boolean overwrite)
Methods in org.apache.flink.table.planner.delegation.hive with parameters of type ObjectIdentifier Modifier and Type Method Description Tuple4<ObjectIdentifier,QueryOperation,Map<String,String>,Boolean>
HiveParserDMLHelper. createInsertOperationInfo(org.apache.calcite.rel.RelNode queryRelNode, CatalogTable destTable, ObjectIdentifier destTableIdentifier, Map<String,String> staticPartSpec, List<String> destSchema, boolean overwrite)
-
Uses of ObjectIdentifier in org.apache.flink.table.planner.delegation.hive.copy
Fields in org.apache.flink.table.planner.delegation.hive.copy declared as ObjectIdentifier Modifier and Type Field Description ObjectIdentifier
HiveParserBaseSemanticAnalyzer.TableSpec. tableIdentifier
Methods in org.apache.flink.table.planner.delegation.hive.copy that return ObjectIdentifier Modifier and Type Method Description static ObjectIdentifier
HiveParserBaseSemanticAnalyzer. getObjectIdentifier(CatalogRegistry catalogRegistry, HiveParserASTNode tabNameNode)
static ObjectIdentifier
HiveParserBaseSemanticAnalyzer. parseCompoundName(CatalogRegistry catalogRegistry, String compoundName)
Methods in org.apache.flink.table.planner.delegation.hive.copy with parameters of type ObjectIdentifier Modifier and Type Method Description static ResolvedCatalogBaseTable<?>
HiveParserBaseSemanticAnalyzer. getResolvedCatalogBaseTable(CatalogRegistry catalogRegistry, ObjectIdentifier tableIdentifier)
-
Uses of ObjectIdentifier in org.apache.flink.table.planner.operations
Methods in org.apache.flink.table.planner.operations that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
InternalDataStreamQueryOperation. getIdentifier()
Deprecated.ObjectIdentifier
RichTableSourceQueryOperation. getIdentifier()
Constructors in org.apache.flink.table.planner.operations with parameters of type ObjectIdentifier Constructor Description InternalDataStreamQueryOperation(ObjectIdentifier identifier, DataStream<E> dataStream, int[] fieldIndices, ResolvedSchema resolvedSchema, boolean[] fieldNullables, org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic)
Deprecated.PlannerCallProcedureOperation(ObjectIdentifier procedureIdentifier, Procedure procedure, Object[] internalInputArguments, DataType[] inputTypes, DataType outputType)
RichTableSourceQueryOperation(ObjectIdentifier identifier, TableSource<T> tableSource, org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic)
-
Uses of ObjectIdentifier in org.apache.flink.table.types.logical
Methods in org.apache.flink.table.types.logical that return types with arguments of type ObjectIdentifier Modifier and Type Method Description Optional<ObjectIdentifier>
UserDefinedType. getObjectIdentifier()
Methods in org.apache.flink.table.types.logical with parameters of type ObjectIdentifier Modifier and Type Method Description static DistinctType.Builder
DistinctType. newBuilder(ObjectIdentifier objectIdentifier, LogicalType sourceType)
Creates a builder for aDistinctType
.static StructuredType.Builder
StructuredType. newBuilder(ObjectIdentifier objectIdentifier)
Creates a builder for aStructuredType
that has been stored in a catalog and is identified by anObjectIdentifier
.static StructuredType.Builder
StructuredType. newBuilder(ObjectIdentifier objectIdentifier, Class<?> implementationClass)
Creates a builder for aStructuredType
that has been stored in a catalog and is identified by anObjectIdentifier
.Constructors in org.apache.flink.table.types.logical with parameters of type ObjectIdentifier Constructor Description Builder(ObjectIdentifier objectIdentifier, LogicalType sourceType)
Builder(ObjectIdentifier objectIdentifier)
Builder(ObjectIdentifier objectIdentifier, Class<?> implementationClass)
-
Uses of ObjectIdentifier in org.apache.flink.table.workflow
Methods in org.apache.flink.table.workflow that return ObjectIdentifier Modifier and Type Method Description ObjectIdentifier
CreatePeriodicRefreshWorkflow. getMaterializedTableIdentifier()
Constructors in org.apache.flink.table.workflow with parameters of type ObjectIdentifier Constructor Description CreatePeriodicRefreshWorkflow(ObjectIdentifier materializedTableIdentifier, String descriptionStatement, String cronExpression, Map<String,String> initConfig, Map<String,String> executionConfig, String restEndpointUrl)
-