Modifier and Type | Method and Description |
---|---|
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 |
---|---|
protected QueryOperation |
StreamTableEnvironmentImpl.qualifyQueryOperation(ObjectIdentifier identifier,
QueryOperation queryOperation) |
Modifier and Type | Method and Description |
---|---|
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. |
Modifier and Type | Method and Description |
---|---|
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 replace)
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.
|
void |
FunctionCatalog.dropTempCatalogFunction(ObjectIdentifier identifier,
boolean ignoreIfNotExist)
Drop a temporary catalog function.
|
Optional<CatalogManager.TableLookupResult> |
CatalogManager.getTable(ObjectIdentifier objectIdentifier)
Retrieves a fully qualified table.
|
boolean |
FunctionCatalog.hasTemporaryCatalogFunction(ObjectIdentifier functionIdentifier)
Check whether a temporary catalog function is already registered.
|
<T,ACC> void |
FunctionCatalog.registerTempCatalogAggregateFunction(ObjectIdentifier oi,
UserDefinedAggregateFunction<T,ACC> function,
TypeInformation<T> resultType,
TypeInformation<ACC> accType) |
void |
FunctionCatalog.registerTempCatalogScalarFunction(ObjectIdentifier oi,
ScalarFunction function) |
<T> void |
FunctionCatalog.registerTempCatalogTableFunction(ObjectIdentifier oi,
TableFunction<T> function,
TypeInformation<T> resultType) |
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 |
---|---|
ObjectIdentifier |
CatalogQueryOperation.getTableIdentifier() |
ObjectIdentifier |
CatalogSinkModifyOperation.getTableIdentifier() |
Modifier and Type | Method and Description |
---|---|
Optional<ObjectIdentifier> |
ScalaDataStreamQueryOperation.getIdentifier() |
Optional<ObjectIdentifier> |
JavaDataStreamQueryOperation.getIdentifier() |
Constructor and Description |
---|
CatalogQueryOperation(ObjectIdentifier tableIdentifier,
TableSchema tableSchema) |
CatalogSinkModifyOperation(ObjectIdentifier tableIdentifier,
QueryOperation child) |
CatalogSinkModifyOperation(ObjectIdentifier tableIdentifier,
QueryOperation child,
Map<String,String> staticPartitions,
boolean overwrite) |
JavaDataStreamQueryOperation(ObjectIdentifier identifier,
DataStream<E> dataStream,
int[] fieldIndices,
TableSchema tableSchema) |
ScalaDataStreamQueryOperation(ObjectIdentifier identifier,
DataStream<E> dataStream,
int[] fieldIndices,
TableSchema tableSchema) |
Modifier and Type | Field and Description |
---|---|
protected ObjectIdentifier |
AlterTableOperation.tableIdentifier |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
DropFunctionOperation.getFunctionIdentifier() |
ObjectIdentifier |
CreateFunctionOperation.getFunctionIdentifier() |
ObjectIdentifier |
AlterFunctionOperation.getFunctionIdentifier() |
ObjectIdentifier |
AlterTableRenameOperation.getNewTableIdentifier() |
ObjectIdentifier |
CreateTableOperation.getTableIdentifier() |
ObjectIdentifier |
AlterTableOperation.getTableIdentifier() |
ObjectIdentifier |
DropTableOperation.getTableIdentifier() |
Constructor and Description |
---|
AlterFunctionOperation(ObjectIdentifier functionIdentifier,
CatalogFunction catalogFunction,
boolean ifExists,
boolean isTemporary) |
AlterTableOperation(ObjectIdentifier tableIdentifier) |
AlterTablePropertiesOperation(ObjectIdentifier tableIdentifier,
CatalogTable catalogTable) |
AlterTableRenameOperation(ObjectIdentifier tableIdentifier,
ObjectIdentifier newTableIdentifier) |
CreateFunctionOperation(ObjectIdentifier functionIdentifier,
CatalogFunction catalogFunction,
boolean ignoreIfExists,
boolean isTemporary) |
CreateTableOperation(ObjectIdentifier tableIdentifier,
CatalogTable catalogTable,
boolean ignoreIfExists) |
DropFunctionOperation(ObjectIdentifier functionIdentifier,
boolean ifExists,
boolean isTemporary) |
DropTableOperation(ObjectIdentifier tableIdentifier,
boolean ifExists) |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
CatalogSchemaTable.getTableIdentifier() |
Constructor and Description |
---|
CatalogSchemaTable(ObjectIdentifier tableIdentifier,
CatalogBaseTable catalogBaseTable,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic,
TableFactory tableFactory,
boolean isStreaming,
boolean isTemporary)
Create a CatalogSchemaTable instance.
|
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
DataStreamQueryOperation.getIdentifier() |
ObjectIdentifier |
RichTableSourceQueryOperation.getIdentifier() |
Constructor and Description |
---|
DataStreamQueryOperation(ObjectIdentifier identifier,
DataStream<E> dataStream,
int[] fieldIndices,
TableSchema tableSchema,
boolean[] fieldNullables,
boolean producesUpdates,
boolean isAccRetract,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic) |
RichTableSourceQueryOperation(ObjectIdentifier identifier,
TableSource<T> tableSource,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic) |
Modifier and Type | Method and Description |
---|---|
ObjectIdentifier |
DistinctType.getObjectIdentifier() |
Modifier and Type | Method and Description |
---|---|
Optional<ObjectIdentifier> |
UserDefinedType.getOptionalObjectIdentifier() |
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–2020 The Apache Software Foundation. All rights reserved.