Modifier and Type | Method and Description |
---|---|
FileSystemOutputFormat.Builder<T> |
FileSystemOutputFormat.Builder.setIdentifier(ObjectIdentifier identifier) |
Constructor and 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) |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
BatchPartitionCommitterSink(FileSystemFactory fsFactory,
TableMetaStoreFactory msFactory,
boolean overwrite,
boolean isToLocal,
Path tmpPath,
String[] partitionColumns,
LinkedHashMap<String,String> staticPartitions,
ObjectIdentifier identifier,
PartitionCommitPolicyFactory partitionCommitPolicyFactory) |
Modifier and Type | Method and 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.
|
Constructor and Description |
---|
PartitionCommitter(Path locationPath,
ObjectIdentifier tableIdentifier,
List<String> partitionKeys,
TableMetaStoreFactory metaStoreFactory,
FileSystemFactory fsFactory,
Configuration conf) |
Constructor and Description |
---|
HiveTableSink(ReadableConfig flinkConf,
org.apache.hadoop.mapred.JobConf jobConf,
ObjectIdentifier identifier,
ResolvedCatalogTable table,
Integer configuredSinkParallelism) |
Modifier and Type | Method and Description |
---|---|
Optional<ObjectIdentifier> |
TablePipeline.getSinkIdentifier() |
Modifier and Type | Method and Description |
---|---|
protected QueryOperation |
AbstractStreamTableEnvironmentImpl.qualifyQueryOperation(ObjectIdentifier identifier,
QueryOperation queryOperation) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and 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 the
identifier'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 the
identifier's length. |
Modifier and Type | Method and 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.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)
Like
CatalogManager.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 an
UnresolvedIdentifier from an ObjectIdentifier . |
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) |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
TableModificationEvent.identifier() |
Modifier and Type | Method and Description |
---|---|
static AlterTableEvent |
AlterTableEvent.createEvent(CatalogContext context,
ObjectIdentifier identifier,
CatalogBaseTable newTable,
boolean ignoreIfNotExists) |
static DropTableEvent |
DropTableEvent.createEvent(CatalogContext context,
ObjectIdentifier identifier,
CatalogBaseTable table,
boolean ignoreIfNotExists,
boolean isTemporary) |
static CreateTableEvent |
CreateTableEvent.createEvent(CatalogContext context,
ObjectIdentifier identifier,
CatalogBaseTable table,
boolean ignoreIfExists,
boolean isTemporary) |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
TableSourceFactoryContextImpl.getObjectIdentifier()
Deprecated.
|
ObjectIdentifier |
TableSinkFactoryContextImpl.getObjectIdentifier()
Deprecated.
|
ObjectIdentifier |
TableSinkFactory.Context.getObjectIdentifier() |
ObjectIdentifier |
TableSourceFactory.Context.getObjectIdentifier() |
ObjectIdentifier |
FactoryUtil.DefaultDynamicTableContext.getObjectIdentifier() |
ObjectIdentifier |
DynamicTableFactory.Context.getObjectIdentifier()
Returns the identifier of the table in the
Catalog . |
Modifier and Type | Method and Description |
---|---|
static DynamicTableSink |
FactoryUtil.createDynamicTableSink(DynamicTableSinkFactory preferredFactory,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
Map<String,String> enrichmentOptions,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
Creates a
DynamicTableSink from a CatalogTable . |
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 a
DynamicTableSource from a CatalogTable . |
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 a
TableSink from a CatalogTable . |
static <T> TableSource<T> |
TableFactoryUtil.findAndCreateTableSource(Catalog catalog,
ObjectIdentifier objectIdentifier,
CatalogTable catalogTable,
ReadableConfig configuration,
boolean isTemporary)
Creates a
TableSource from a CatalogTable . |
static boolean |
TableFactoryUtil.isLegacyConnectorOptions(Catalog catalog,
ReadableConfig configuration,
boolean isStreamingMode,
ObjectIdentifier objectIdentifier,
CatalogTable catalogTable,
boolean isTemporary)
Checks whether the
CatalogTable uses legacy connector sink options. |
Constructor and 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.
|
Modifier and Type | Method and Description |
---|---|
static ObjectIdentifier |
FunctionIdentifier.normalizeObjectIdentifier(ObjectIdentifier oi)
Normalize an object identifier by only normalizing the function name.
|
Modifier and Type | Method and Description |
---|---|
Optional<ObjectIdentifier> |
FunctionIdentifier.getIdentifier() |
Modifier and Type | Method and Description |
---|---|
static ObjectIdentifier |
FunctionIdentifier.normalizeObjectIdentifier(ObjectIdentifier oi)
Normalize an object identifier by only normalizing the function name.
|
static FunctionIdentifier |
FunctionIdentifier.of(ObjectIdentifier oi) |
Modifier and Type | Method and Description |
---|---|
ResolvedCatalogBaseTable<?> |
SqlGatewayService.getTable(SessionHandle sessionHandle,
ObjectIdentifier tableIdentifier)
Return table of the given fully qualified name.
|
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
TableInfo.getIdentifier() |
Constructor and Description |
---|
TableInfo(ObjectIdentifier identifier,
CatalogBaseTable.TableKind tableKind) |
Modifier and Type | Method and Description |
---|---|
ResolvedCatalogBaseTable<?> |
SqlGatewayServiceImpl.getTable(SessionHandle sessionHandle,
ObjectIdentifier tableIdentifier) |
Modifier and Type | Method and Description |
---|---|
ResolvedCatalogBaseTable<?> |
OperationExecutor.getTable(ObjectIdentifier tableIdentifier) |
Modifier and Type | Field and Description |
---|---|
protected ObjectIdentifier |
ShowPartitionsOperation.tableIdentifier |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
DescribeTableOperation.getSqlIdentifier() |
ObjectIdentifier |
ShowCreateTableOperation.getTableIdentifier() |
ObjectIdentifier |
TruncateTableOperation.getTableIdentifier() |
ObjectIdentifier |
ShowPartitionsOperation.getTableIdentifier() |
ObjectIdentifier |
ShowColumnsOperation.getTableIdentifier() |
ObjectIdentifier |
ShowCreateViewOperation.getViewIdentifier() |
Modifier and Type | Method and Description |
---|---|
Optional<ObjectIdentifier> |
DataStreamQueryOperation.getIdentifier()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
StagedSinkModifyOperation |
CreateTableASOperation.toStagedSinkModifyOperation(ObjectIdentifier tableIdentifier,
ResolvedCatalogTable catalogTable,
Catalog catalog,
DynamicTableSink dynamicTableSink) |
StagedSinkModifyOperation |
ReplaceTableAsOperation.toStagedSinkModifyOperation(ObjectIdentifier tableIdentifier,
ResolvedCatalogTable catalogTable,
Catalog catalog,
DynamicTableSink dynamicTableSink) |
Constructor and Description |
---|
DataStreamQueryOperation(ObjectIdentifier identifier,
DataStream<E> dataStream,
int[] fieldIndices,
ResolvedSchema resolvedSchema)
Deprecated.
|
DescribeTableOperation(ObjectIdentifier sqlIdentifier,
boolean isExtended) |
ShowColumnsOperation(ObjectIdentifier tableIdentifier,
String likePattern,
boolean useLike,
boolean notLike,
String preposition) |
ShowCreateTableOperation(ObjectIdentifier sqlIdentifier) |
ShowCreateViewOperation(ObjectIdentifier sqlIdentifier) |
ShowPartitionsOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec) |
ShowPartitionsOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec,
String defaultPartitionName) |
TruncateTableOperation(ObjectIdentifier tableIdentifier) |
Modifier and Type | Field and Description |
---|---|
protected ObjectIdentifier |
AlterTableOperation.tableIdentifier |
protected ObjectIdentifier |
AlterViewOperation.viewIdentifier |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
AlterCatalogFunctionOperation.getFunctionIdentifier() |
ObjectIdentifier |
DropCatalogFunctionOperation.getFunctionIdentifier() |
ObjectIdentifier |
CreateCatalogFunctionOperation.getFunctionIdentifier() |
ObjectIdentifier |
AlterTableRenameOperation.getNewTableIdentifier() |
ObjectIdentifier |
AlterViewRenameOperation.getNewViewIdentifier() |
ObjectIdentifier |
DropTableOperation.getTableIdentifier() |
ObjectIdentifier |
CreateTableOperation.getTableIdentifier() |
ObjectIdentifier |
AnalyzeTableOperation.getTableIdentifier() |
ObjectIdentifier |
AlterTableOperation.getTableIdentifier() |
ObjectIdentifier |
CreateViewOperation.getViewIdentifier() |
ObjectIdentifier |
AlterViewOperation.getViewIdentifier() |
ObjectIdentifier |
DropViewOperation.getViewIdentifier() |
Constructor and 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) |
AlterTableOptionsOperation(ObjectIdentifier tableIdentifier,
CatalogTable catalogTable,
boolean ignoreIfNotExists)
Deprecated.
|
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) |
Modifier and Type | Method and 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 a
DynamicTableSink from a CatalogTable . |
Modifier and Type | Method and Description |
---|---|
RelBuilder |
FlinkRelBuilder.scan(ObjectIdentifier identifier,
Map<String,String> dynamicOptions) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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) |
Modifier and Type | Field and Description |
---|---|
ObjectIdentifier |
HiveParserBaseSemanticAnalyzer.TableSpec.tableIdentifier |
Modifier and Type | Method and Description |
---|---|
static ObjectIdentifier |
HiveParserBaseSemanticAnalyzer.getObjectIdentifier(CatalogRegistry catalogRegistry,
HiveParserASTNode tabNameNode) |
static ObjectIdentifier |
HiveParserBaseSemanticAnalyzer.parseCompoundName(CatalogRegistry catalogRegistry,
String compoundName) |
Modifier and Type | Method and Description |
---|---|
static ResolvedCatalogBaseTable<?> |
HiveParserBaseSemanticAnalyzer.getResolvedCatalogBaseTable(CatalogRegistry catalogRegistry,
ObjectIdentifier tableIdentifier) |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
RichTableSourceQueryOperation.getIdentifier() |
ObjectIdentifier |
InternalDataStreamQueryOperation.getIdentifier()
Deprecated.
|
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
Optional<ObjectIdentifier> |
UserDefinedType.getObjectIdentifier() |
Modifier and Type | Method and Description |
---|---|
static StructuredType.Builder |
StructuredType.newBuilder(ObjectIdentifier objectIdentifier)
Creates a builder for a
StructuredType that has been stored in a catalog and is
identified by an ObjectIdentifier . |
static StructuredType.Builder |
StructuredType.newBuilder(ObjectIdentifier objectIdentifier,
Class<?> implementationClass)
Creates a builder for a
StructuredType that has been stored in a catalog and is
identified by an ObjectIdentifier . |
static DistinctType.Builder |
DistinctType.newBuilder(ObjectIdentifier objectIdentifier,
LogicalType sourceType)
Creates a builder for a
DistinctType . |
Constructor and Description |
---|
Builder(ObjectIdentifier objectIdentifier) |
Builder(ObjectIdentifier objectIdentifier,
Class<?> implementationClass) |
Builder(ObjectIdentifier objectIdentifier,
LogicalType sourceType) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.