Uses of Package
org.apache.flink.table.operations
-
Classes in org.apache.flink.table.operations used by org.apache.flink.table.api Class Description QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.api.internal Class Description CollectModifyOperation Special, internal kind ofModifyOperation
that collects the content ofQueryOperation
to local.ExecutableOperation.Context The context to execute the operation.ModifyOperation AOperation
that describes the DML queries such as e.g.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL).QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.catalog Class Description QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.delegation Class Description ModifyOperation AOperation
that describes the DML queries such as e.g.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL). -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.expressions Class Description QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.expressions.resolver Class Description QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.expressions.resolver.lookups Class Description QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.functions Class Description QueryOperation Base class for representing an operation structure behind a user-facingTable
API. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.legacy.operations.ddl Class Description ExecutableOperation AnExecutableOperation
represents an operation that is executed for its side effects.ExecutableOperation.Context The context to execute the operation.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL). -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.operations Class Description AbstractShowOperation Base class for SHOW operations.AggregateQueryOperation Relational operation that performs computations on top of subsets of input rows grouped by key.CalculatedQueryOperation Describes a relational operation that was created from applying aTableFunction
.CollectModifyOperation Special, internal kind ofModifyOperation
that collects the content ofQueryOperation
to local.CreateTableASOperation Operation to describe a CREATE TABLE AS statement.DistinctQueryOperation Removes duplicated rows of underlying relational operation.ExecutableOperation AnExecutableOperation
represents an operation that is executed for its side effects.ExecutableOperation.Context The context to execute the operation.ExternalModifyOperation Internal operation used to convert aTable
into a DataStream.FilterQueryOperation Filters out rows of underlying relational operation that do not match given condition.JoinQueryOperation Table operation that joins two relational operations based on given condition.JoinQueryOperation.JoinType Specifies how the two Tables should be joined.ModifyOperation AOperation
that describes the DML queries such as e.g.ModifyOperationVisitor Class that implements visitor pattern.ModifyType The type of sink modification.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL).OutputConversionModifyOperation Special, internal kind ofModifyOperation
that allows converting a tree ofQueryOperation
s to aTransformation
of given type described withTypeInformation
.OutputConversionModifyOperation.UpdateMode Should the output type contain the change flag, and what should the flag represent (retraction or deletion).ProjectQueryOperation Table operation that computes new table using givenExpression
s from its input relational operation.QueryOperation Base class for representing an operation structure behind a user-facingTable
API.QueryOperationVisitor Class that implements visitor pattern.ReplaceTableAsOperation Operation to describe a [CREATE OR] REPLACE TABLE AS statement.SetQueryOperation A set operation on two relations.SetQueryOperation.SetQueryOperationType Represent kind of this set operation.ShowFunctionsOperation.FunctionScope Represent scope of function.ShowOperation AnOperation
that show one kind of objects, e.g.SinkModifyOperation DML operation that tells to write to a sink.SortQueryOperation Expresses sort operation of rows of the underlying relational operation with given order.SourceQueryOperation Describes a query operation from aContextResolvedTable
.StagedSinkModifyOperation DML operation that tells to write to a sink which implementsSupportsStaging
.TableSourceQueryOperation Inline scan of aTableSource
.UnregisteredSinkModifyOperation DML operation that tells to write to the given sink.UseOperation AnOperation
that describes the catalog/database switch statements, e.g.ValuesQueryOperation Table operation that computes new table using givenExpression
s from its input relational operation.WindowAggregateQueryOperation Relational operation that performs computations on top of subsets of input rows grouped by key and group window.WindowAggregateQueryOperation.ResolvedGroupWindow Wrapper for resolved expressions of aGroupWindow
.WindowAggregateQueryOperation.ResolvedGroupWindow.WindowType The type of window. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.operations.command Class Description ExecutableOperation AnExecutableOperation
represents an operation that is executed for its side effects.ExecutableOperation.Context The context to execute the operation.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL).ShowOperation AnOperation
that show one kind of objects, e.g. -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.operations.ddl Class Description ExecutableOperation AnExecutableOperation
represents an operation that is executed for its side effects.ExecutableOperation.Context The context to execute the operation.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL). -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.operations.materializedtable Class Description ExecutableOperation AnExecutableOperation
represents an operation that is executed for its side effects.ExecutableOperation.Context The context to execute the operation.Operation Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL), or control actions(DCL). -
Classes in org.apache.flink.table.operations used by org.apache.flink.table.operations.utils Class Description AggregateQueryOperation Relational operation that performs computations on top of subsets of input rows grouped by key.CalculatedQueryOperation Describes a relational operation that was created from applying aTableFunction
.DistinctQueryOperation Removes duplicated rows of underlying relational operation.FilterQueryOperation Filters out rows of underlying relational operation that do not match given condition.JoinQueryOperation Table operation that joins two relational operations based on given condition.JoinQueryOperation.JoinType Specifies how the two Tables should be joined.ProjectQueryOperation Table operation that computes new table using givenExpression
s from its input relational operation.QueryOperation Base class for representing an operation structure behind a user-facingTable
API.QueryOperationVisitor Class that implements visitor pattern.SetQueryOperation A set operation on two relations.SortQueryOperation Expresses sort operation of rows of the underlying relational operation with given order.SourceQueryOperation Describes a query operation from aContextResolvedTable
.TableSourceQueryOperation Inline scan of aTableSource
.ValuesQueryOperation Table operation that computes new table using givenExpression
s from its input relational operation.WindowAggregateQueryOperation Relational operation that performs computations on top of subsets of input rows grouped by key and group window.