Modifier and Type | Method and Description |
---|---|
String |
TableEnvironmentInternal.explainInternal(List<Operation> operations,
ExplainDetail... extraDetails)
Returns the AST of this table and the execution plan to compute the result of this table.
|
String |
TableEnvironmentImpl.explainInternal(List<Operation> operations,
ExplainDetail... extraDetails) |
Modifier and Type | Method and Description |
---|---|
List<Operation> |
Parser.parse(String statement)
Entry point for parsing SQL queries expressed as a String.
|
Modifier and Type | Method and Description |
---|---|
String |
Planner.explain(List<Operation> operations,
ExplainDetail... extraDetails)
Returns the AST of the specified Table API and SQL queries and the execution plan to compute
the result of the given collection of
QueryOperation s. |
Modifier and Type | Interface and Description |
---|---|
interface |
ModifyOperation
A
Operation that describes the DML queries such as e.g. |
interface |
QueryOperation
Base class for representing an operation structure behind a user-facing
Table API. |
interface |
ShowOperation
An
Operation that show one kind of objects, e.g. |
interface |
UseOperation
An
Operation that describes the catalog/database switch statements, e.g. |
Modifier and Type | Class and Description |
---|---|
class |
AggregateQueryOperation
Relational operation that performs computations on top of subsets of input rows grouped by key.
|
class |
CalculatedQueryOperation
Describes a relational operation that was created from applying a
TableFunction . |
class |
CatalogQueryOperation
Describes a relational operation that was created from a lookup to a catalog.
|
class |
CatalogSinkModifyOperation
DML operation that tells to write to a sink.
|
class |
DataSetQueryOperation<E>
Describes a relational operation that reads from a
DataSet . |
class |
DescribeTableOperation
Operation to describe a DESCRIBE [EXTENDED] [[catalogName.] dataBasesName].sqlIdentifier
statement.
|
class |
DistinctQueryOperation
Removes duplicated rows of underlying relational operation.
|
class |
ExplainOperation
Operation to describe an EXPLAIN statement.
|
class |
FilterQueryOperation
Filters out rows of underlying relational operation that do not match given condition.
|
class |
JavaDataStreamQueryOperation<E>
Describes a relational operation that reads from a
DataStream . |
class |
JoinQueryOperation
Table operation that joins two relational operations based on given condition.
|
class |
OutputConversionModifyOperation
Special, internal kind of
ModifyOperation that allows converting a tree of QueryOperation s to a Transformation of given type described with TypeInformation . |
class |
ProjectQueryOperation
Table operation that computes new table using given
Expression s from its input relational
operation. |
class |
ScalaDataStreamQueryOperation<E>
Describes a relational operation that reads from a
DataStream . |
class |
SetQueryOperation
A set operation on two relations.
|
class |
ShowCatalogsOperation
Operation to describe a SHOW CATALOGS statement.
|
class |
ShowDatabasesOperation
Operation to describe a SHOW DATABASES statement.
|
class |
ShowFunctionsOperation
Operation to describe a SHOW FUNCTIONS statement.
|
class |
ShowTablesOperation
Operation to describe a SHOW TABLES statement.
|
class |
ShowViewsOperation
Operation to describe a SHOW VIEWS statement.
|
class |
SortQueryOperation
Expresses sort operation of rows of the underlying relational operation with given order.
|
class |
TableSourceQueryOperation<T>
Inline scan of a
TableSource . |
class |
UnregisteredSinkModifyOperation<T>
DML operation that tells to write to the given sink.
|
class |
UseCatalogOperation
Operation to describe a USE CATALOG statement.
|
class |
UseDatabaseOperation
Operation to describe a USE [catalogName.]dataBaseName statement.
|
class |
ValuesQueryOperation
Table operation that computes new table using given
Expression s from its input relational
operation. |
class |
WindowAggregateQueryOperation
Relational operation that performs computations on top of subsets of input rows grouped by key
and group window.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Operation> |
OperationUtils.formatWithChildren(String operationName,
Map<String,Object> parameters,
List<T> children,
java.util.function.Function<T,String> childToString)
Formats a Tree of
Operation in a unified way. |
Modifier and Type | Method and Description |
---|---|
Operation |
ExplainOperation.getChild() |
Constructor and Description |
---|
ExplainOperation(Operation child) |
Modifier and Type | Interface and Description |
---|---|
interface |
AlterOperation
A
Operation that describes the DDL statements, e.g. |
interface |
CreateOperation
A
Operation that describes the DDL statements, e.g. |
interface |
DropOperation
A
Operation that describes the DROP DDL statements, e.g. |
Modifier and Type | Class and Description |
---|---|
class |
AddPartitionsOperation
Operation to describe ALTER TABLE ADD PARTITION statement.
|
class |
AlterCatalogFunctionOperation
Operation to describe a ALTER FUNCTION statement for catalog functions.
|
class |
AlterDatabaseOperation
Operation to describe a ALTER DATABASE statement.
|
class |
AlterPartitionOperation
Abstract Operation to describe all ALTER TABLE statements that should be applied to partitions.
|
class |
AlterPartitionPropertiesOperation
Operation to alter the properties of partition.
|
class |
AlterTableAddConstraintOperation
Operation of "ALTER TABLE ADD [CONSTRAINT constraintName] ..." clause.
|
class |
AlterTableDropConstraintOperation
Operation of "ALTER TABLE ADD [CONSTRAINT constraintName] ..." clause.
|
class |
AlterTableOperation
Abstract Operation to describe all ALTER TABLE statements such as rename table /set properties.
|
class |
AlterTablePropertiesOperation
Operation to describe a ALTER TABLE ..
|
class |
AlterTableRenameOperation
Operation to describe a ALTER TABLE ..
|
class |
AlterTableSchemaOperation
Operation to describe altering the schema of a table.
|
class |
AlterViewAsOperation
Operation to describe an ALTER VIEW ...
|
class |
AlterViewOperation
Abstract Operation to describe all ALTER VIEW statements.
|
class |
AlterViewPropertiesOperation
Operation to describe a ALTER VIEW ..
|
class |
AlterViewRenameOperation
Operation to describe a ALTER VIEW ..
|
class |
CreateCatalogFunctionOperation
Operation to describe a CREATE FUNCTION statement for catalog functions.
|
class |
CreateCatalogOperation
Operation to describe a CREATE CATALOG statement.
|
class |
CreateDatabaseOperation
Operation to describe a CREATE DATABASE statement.
|
class |
CreateTableOperation
Operation to describe a CREATE TABLE statement.
|
class |
CreateTempSystemFunctionOperation
Operation to describe a CREATE FUNCTION statement for temporary system function.
|
class |
CreateViewOperation
Operation to describe a CREATE VIEW statement.
|
class |
DropCatalogFunctionOperation
Operation to describe a DROP FUNCTION statement for catalog functions.
|
class |
DropCatalogOperation
Operation to describe a DROP CATALOG statement.
|
class |
DropDatabaseOperation
Operation to describe a DROP DATABASE statement.
|
class |
DropPartitionsOperation
Operation to describe ALTER TABLE DROP PARTITION statement.
|
class |
DropTableOperation
Operation to describe a DROP TABLE statement.
|
class |
DropTempSystemFunctionOperation
Operation to describe a DROP FUNCTION statement for temporary system function.
|
class |
DropViewOperation
Operation to describe a DROP VIEW statement.
|
Modifier and Type | Method and Description |
---|---|
List<Operation> |
ParserImpl.parse(String statement) |
Modifier and Type | Method and Description |
---|---|
List<Operation> |
ParserImpl.parse(String statement) |
Modifier and Type | Class and Description |
---|---|
class |
DataStreamQueryOperation<E>
Describes a relational operation that reads from a
DataStream . |
class |
PlannerQueryOperation
Wrapper for valid logical plans generated by Planner.
|
class |
RichTableSourceQueryOperation<T>
A
TableSourceQueryOperation with FlinkStatistic and qualifiedName. |
Modifier and Type | Method and Description |
---|---|
static Optional<Operation> |
SqlToOperationConverter.convert(org.apache.flink.table.planner.calcite.FlinkPlannerImpl flinkPlanner,
CatalogManager catalogManager,
org.apache.calcite.sql.SqlNode sqlNode)
This is the main entrance for executing all kinds of DDL/DML
SqlNode s, different
SqlNode will have it's implementation in the #convert(type) method whose 'type' argument is
subclass of SqlNode . |
Modifier and Type | Method and Description |
---|---|
static Operation |
OperationConverterUtils.convertAddReplaceColumns(ObjectIdentifier tableIdentifier,
SqlAddReplaceColumns addReplaceColumns,
CatalogTable catalogTable,
org.apache.calcite.sql.validate.SqlValidator sqlValidator) |
static Operation |
OperationConverterUtils.convertChangeColumn(ObjectIdentifier tableIdentifier,
SqlChangeColumn changeColumn,
CatalogTable catalogTable,
org.apache.calcite.sql.validate.SqlValidator sqlValidator) |
Modifier and Type | Method and Description |
---|---|
static Optional<Operation> |
SqlToOperationConverter.convert(org.apache.flink.table.calcite.FlinkPlannerImpl flinkPlanner,
CatalogManager catalogManager,
org.apache.calcite.sql.SqlNode sqlNode)
This is the main entrance for executing all kinds of DDL/DML
SqlNode s, different
SqlNode will have it's implementation in the #convert(type) method whose 'type' argument is
subclass of SqlNode . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.