All Classes Interface Summary Class Summary Enum Summary Exception Summary
| Class |
Description |
| AbstractCatalogTable |
An abstract catalog table.
|
| AbstractCatalogView |
An abstract catalog view.
|
| AbstractShowOperation |
Base class for SHOW operations.
|
| AddJarOperation |
Operation to describe an ADD JAR statement.
|
| AddPartitionsOperation |
Operation to describe ALTER TABLE ADD PARTITION statement.
|
| AggregatedTable |
A table that has been performed on the aggregate function.
|
| AggregatePhaseStrategy |
|
| AggregateQueryOperation |
Relational operation that performs computations on top of subsets of input rows grouped by key.
|
| AlterCatalogCommentOperation |
Operation to describe a ALTER CATALOG COMMENT statement.
|
| AlterCatalogFunctionOperation |
Operation to describe a ALTER FUNCTION statement for catalog functions.
|
| AlterCatalogOptionsOperation |
Operation to describe a ALTER CATALOG SET statement.
|
| AlterCatalogResetOperation |
Operation to describe an ALTER CATALOG RESET statement.
|
| AlterDatabaseEvent |
When a database is altered, an AlterDatabaseEvent event will be created and fired which
has the old database and new database.
|
| AlterDatabaseOperation |
Operation to describe a ALTER DATABASE statement.
|
| AlterMaterializedTableAsQueryOperation |
Operation to describe an ALTER MATERIALIZED TABLE AS query operation.
|
| AlterMaterializedTableChangeOperation |
Alter materialized table with new table definition and table changes represents the modification.
|
| AlterMaterializedTableOperation |
Abstract Operation to describe all ALTER MATERIALIZED TABLE statements such as rename table /set
properties.
|
| AlterMaterializedTableRefreshOperation |
Operation to describe clause like: ALTER MATERIALIZED TABLE [catalog_name.]
|
| AlterMaterializedTableResumeOperation |
Operation to describe a ALTER MATERIALIZED TABLE ...
|
| AlterMaterializedTableSuspendOperation |
Operation to describe a ALTER MATERIALIZED TABLE ...
|
| AlterModelEvent |
When a model is altered, a AlterModelEvent event will be created and fired.
|
| AlterOperation |
A Operation that describes the DDL statements, e.g.
|
| AlterPartitionOperation |
Abstract Operation to describe all ALTER TABLE statements that should be applied to partitions.
|
| AlterPartitionPropertiesOperation |
Operation to alter the properties of partition.
|
| AlterTableChangeOperation |
Alter table with new table definition and table changes represents the modification.
|
| AlterTableEvent |
When a table is altered, a AlterTableEvent event will be created and fired.
|
| AlterTableOperation |
Abstract Operation to describe all ALTER TABLE statements such as rename table /set properties.
|
| AlterTableOptionsOperation |
Deprecated.
|
| AlterTableRenameOperation |
Operation to describe a ALTER TABLE ..
|
| AlterTableSchemaOperation |
Operation to describe altering the schema of a table.
|
| AlterViewAsOperation |
Operation to describe an ALTER VIEW ...
|
| AlterViewOperation |
Abstract Operation to describe all ALTER VIEW statements.
|
| AlterViewPropertiesOperation |
Operation to describe a ALTER VIEW ..
|
| AlterViewRenameOperation |
Operation to describe a ALTER VIEW ..
|
| AnalyzeTableOperation |
Operation to describe an ANALYZE TABLE statement.
|
| AnalyzeTableUtil |
ANALYZE TABLE statement Util.
|
| ApiExpression |
Java API class that gives access to expression operations.
|
| ApiExpressionDefaultVisitor<T> |
|
| ApiExpressionUtils |
Utilities for API-specific Expressions.
|
| ApiExpressionVisitor<R> |
A visitor for all Expressions that might be created during API translation.
|
| BaseExpressions<InType,OutType> |
These are Java and Scala common operations that can be used to construct an Expression
AST for expression operations.
|
| BeginStatementSetOperation |
Operation to describe a BEGIN STATEMENT SET statement.
|
| CachedPlan |
SQL execution plan cache.
|
| CalculatedQueryOperation |
Describes a relational operation that was created from applying a TableFunction.
|
| CallProcedureOperation |
A Operation that describes the call procedure statement.
|
| CatalogContext |
Context for catalog which provides the name, factory identifier and configuration to identify the
same physical catalog for different logical catalog.
|
| CatalogDatabaseImpl |
A implementation of CatalogDatabase.
|
| CatalogFunctionImpl |
A catalog function implementation.
|
| CatalogManager |
A manager for dealing with catalog objects such as tables, views, functions, and types.
|
| CatalogManager.Builder |
|
| CatalogModificationEvent |
The basic interface for catalog modification event, all database and table related events are
implements this interface.
|
| CatalogModificationListener |
A listener that is notified on specific catalog changed in catalog manager.
|
| CatalogModificationListenerFactory |
A factory to create catalog modification listener instances based on context which contains job
configuration and user classloader.
|
| CatalogModificationListenerFactory.Context |
Context provided when a listener is created.
|
| CatalogPartitionImpl |
A catalog partition implementation.
|
| CatalogRegistry |
A catalog registry for dealing with catalogs.
|
| CatalogViewImpl |
Deprecated.
|
| ClearOperation |
Operation to represent CLEAR command.
|
| CollectModifyOperation |
|
| Compilable |
Represents an artifact that can be compiled to a CompiledPlan.
|
| CompileAndExecutePlanOperation |
Operation to describe an COMPILE AND EXECUTE PLAN statement.
|
| CompiledPlan |
Represents an immutable, fully optimized, and executable entity that has been compiled from a
Table & SQL API pipeline definition.
|
| CompilePlanOperation |
Operation to describe an COMPILE PLAN statement.
|
| ConnectorCatalogTable<T1,T2> |
A CatalogTable that wraps a TableSource and/or TableSink.
|
| ContextResolvedFunction |
This class contains information about a function and its relationship with a Catalog, if
any.
|
| ContextResolvedModel |
This class contains information about a model and its relationship with a Catalog, if
any.
|
| ContextResolvedProcedure |
This class contains information about a procedure and its relationship with a Catalog.
|
| ContextResolvedTable |
This class contains information about a table, its ResolvedSchema, its options and its
relationship with a Catalog, if any.
|
| CreateCatalogFunctionOperation |
Operation to describe a CREATE FUNCTION statement for catalog functions.
|
| CreateCatalogOperation |
Operation to describe a CREATE CATALOG statement.
|
| CreateDatabaseEvent |
|
| CreateDatabaseOperation |
Operation to describe a CREATE DATABASE statement.
|
| CreateMaterializedTableOperation |
Operation to describe a CREATE MATERIALIZED TABLE statement.
|
| CreateModelEvent |
|
| CreateOperation |
A Operation that describes the DDL statements, e.g.
|
| CreateTableASOperation |
Operation to describe a CREATE TABLE AS statement.
|
| CreateTableEvent |
|
| CreateTableOperation |
Operation to describe a CREATE TABLE statement.
|
| CreateTempSystemFunctionOperation |
Operation to describe a CREATE FUNCTION statement for temporary system function.
|
| CreateViewOperation |
Operation to describe a CREATE VIEW statement.
|
| DatabaseModificationEvent |
Basic event for database modification such as create, alter and drop, it has the database name
and CatalogDatabase.
|
| DeclarativeAggregateFunction |
API for aggregation functions that are expressed in terms of expressions.
|
| DeleteFromFilterOperation |
The operation for deleting data in a table according to filters directly.
|
| DescribeCatalogOperation |
Operation to describe a DESCRIBE CATALOG catalog_name statement.
|
| DescribeFunctionOperation |
Operation to describe a FUNCTION.
|
| DescribeJobOperation |
Operation to describe a DESCRIBE JOB statement.
|
| DescribeTableOperation |
Operation to describe a DESCRIBE [EXTENDED] [[catalogName.] dataBasesName].sqlIdentifier
statement.
|
| DistinctQueryOperation |
Removes duplicated rows of underlying relational operation.
|
| DQLCachedPlan |
PlanCache for DQL.
|
| DropCatalogFunctionOperation |
Operation to describe a DROP FUNCTION statement for catalog functions.
|
| DropCatalogOperation |
Operation to describe a DROP CATALOG statement.
|
| DropDatabaseEvent |
|
| DropDatabaseOperation |
Operation to describe a DROP DATABASE statement.
|
| DropMaterializedTableOperation |
Operation to describe a DROP MATERIALIZED TABLE statement.
|
| DropModelEvent |
When a model is dropped, a DropModelEvent event will be created and fired.
|
| DropOperation |
A Operation that describes the DROP DDL statements, e.g.
|
| DropPartitionsOperation |
Operation to describe ALTER TABLE DROP PARTITION statement.
|
| DropTableEvent |
When a table is dropped, a DropTableEvent event will be created and fired.
|
| DropTableOperation |
Operation to describe a DROP TABLE statement.
|
| DropTempSystemFunctionOperation |
Operation to describe a DROP FUNCTION statement for temporary system function.
|
| DropViewOperation |
Operation to describe a DROP VIEW statement.
|
| EndStatementSetOperation |
Operation to describe a End statement.
|
| EnvironmentSettings |
Defines all parameters that initialize a table environment.
|
| EnvironmentSettings.Builder |
|
| Executable |
Represents an artifact that can be executed.
|
| ExecutableOperation |
|
| ExecutableOperation.Context |
The context to execute the operation.
|
| ExecutableOperationContextImpl |
|
| ExecutableOperationUtils |
Utils for the executable operation.
|
| ExecutePlanOperation |
Operation to describe an EXECUTE PLAN statement.
|
| ExecutionConfigOptions |
This class holds configuration constants used by Flink's table module.
|
| ExecutionConfigOptions.AsyncOutputMode |
Output mode for asynchronous operations, equivalent to {@see AsyncDataStream.OutputMode}.
|
| ExecutionConfigOptions.LegacyCastBehaviour |
Deprecated. |
| ExecutionConfigOptions.NotNullEnforcer |
The enforcer to guarantee NOT NULL column constraint when writing data into sink.
|
| ExecutionConfigOptions.RetryStrategy |
Retry strategy in the case of failure.
|
| ExecutionConfigOptions.RowtimeInserter |
Rowtime attribute insertion strategy for the sink.
|
| ExecutionConfigOptions.SinkKeyedShuffle |
Shuffle by primary key before sink.
|
| ExecutionConfigOptions.TypeLengthEnforcer |
The enforcer to guarantee that length of CHAR/VARCHAR/BINARY/VARBINARY columns is respected
when writing data into a sink.
|
| ExecutionConfigOptions.UidGeneration |
Strategy for generating transformation UIDs for remapping state to operators during restore.
|
| ExecutionConfigOptions.UpsertMaterialize |
Upsert materialize strategy before sink.
|
| Executor |
It enables the execution of a graph of Transformations generated by the Planner.
|
| ExecutorFactory |
Factory that creates an Executor for submitting table programs.
|
| ExistingField |
Deprecated.
|
| Explainable<SELF extends Explainable<SELF>> |
Represents an artifact that can be explained using a summary string.
|
| ExplainDetail |
ExplainDetail defines the types of details for explain result.
|
| ExplainFormat |
Explain format categorizes the output format of explain result.
|
| ExplainOperation |
Operation to describe an EXPLAIN statement.
|
| ExpressionResolver |
|
| ExpressionResolver.ExpressionResolverBuilder |
|
| Expressions |
Entry point of the Table API Expression DSL such as: $("myField").plus(10).abs()
|
| ExternalCatalogTable |
Helper CatalogTable for representing a table that is backed by some inline connector
(i.e.
|
| ExternalModifyOperation |
Internal operation used to convert a Table into a DataStream.
|
| FieldInfoUtils |
Utility methods for extracting names and indices of fields from different TypeInformations.
|
| FieldInfoUtils.TypeInfoSchema |
Describes fields' names, indices and DataTypes extracted from a TypeInformation and possibly transformed via Expression application.
|
| FieldReferenceLookup |
Provides a way to look up field reference by the name of the field.
|
| FileCatalogStore |
A CatalogStore that stores all catalog configuration to a directory.
|
| FileCatalogStoreFactory |
|
| FileCatalogStoreFactoryOptions |
|
| FilterQueryOperation |
Filters out rows of underlying relational operation that do not match given condition.
|
| FlatAggregateTable |
|
| FormatDescriptor |
|
| FormatDescriptor.Builder |
|
| FunctionCatalog |
Simple function catalog to store FunctionDefinitions in catalogs.
|
| FunctionCatalog.InlineCatalogFunction |
The CatalogFunction which holds an instantiated UDF.
|
| FunctionLookup |
|
| GenericInMemoryCatalog |
A generic catalog implementation that holds all meta objects in memory.
|
| GenericInMemoryCatalogFactory |
|
| GenericInMemoryCatalogFactoryOptions |
|
| GenericInMemoryCatalogStore |
A generic catalog store implementation that store all catalog configuration in memory.
|
| GenericInMemoryCatalogStoreFactory |
|
| GenericInMemoryCatalogStoreFactoryOptions |
|
| GroupedTable |
A table that has been grouped on a set of grouping keys.
|
| GroupWindow |
A group window specification.
|
| GroupWindowedTable |
|
| HelpOperation |
Operation that represents HELP command.
|
| InternalPlan |
Internal interface wrapping a plan.
|
| JoinQueryOperation |
Table operation that joins two relational operations based on given condition.
|
| JoinQueryOperation.JoinType |
Specifies how the two Tables should be joined.
|
| LikeType |
Like types enums.
|
| LoadModuleOperation |
Operation to describe a LOAD MODULE statement.
|
| LocalOverWindow |
Local over window created during expression resolution.
|
| LocalReferenceExpression |
|
| LookupCallExpression |
A call expression where the target function has not been resolved yet.
|
| LookupCallResolver |
Resolves calls with function names to calls with actual function definitions.
|
| LookupJoinHintOptions |
This class holds hint option name definitions for LOOKUP join hints based on ConfigOption.
|
| LookupJoinHintOptions.RetryStrategy |
Supported retry strategies.
|
| MaterializedTableConfigOptions |
This class holds ConfigOptions used by table module for
materialized table.
|
| MaterializedTableOperation |
The marker interface for materialized table.
|
| ModifyOperation |
A Operation that describes the DML queries such as e.g.
|
| ModifyOperationVisitor<T> |
Class that implements visitor pattern.
|
| ModifyType |
The type of sink modification.
|
| ModuleEntry |
A POJO to represent a module's name and use status.
|
| ModuleManager |
Responsible for loading/unloading modules, managing their life cycles, and resolving module
objects.
|
| NopOperation |
An Operation to represent that nothing needs to be done.
|
| Operation |
Covers all sort of Table operations such as queries(DQL), modifications(DML), definitions(DDL),
or control actions(DCL).
|
| OperationExpressionsUtils |
Utility methods for transforming Expression to use them in QueryOperations.
|
| OperationExpressionsUtils.CategorizedExpressions |
Container for extracted expressions of the same family.
|
| OperationTreeBuilder |
|
| OperationUtils |
|
| OptimizerConfigOptions |
This class holds configuration constants used by Flink's table planner module.
|
| OptimizerConfigOptions.AdaptiveBroadcastJoinStrategy |
|
| OptimizerConfigOptions.AdaptiveSkewedJoinOptimizationStrategy |
|
| OptimizerConfigOptions.NonDeterministicUpdateStrategy |
Strategy for handling non-deterministic updates.
|
| OutputConversionModifyOperation |
Special, internal kind of ModifyOperation that allows converting a tree of QueryOperations to a Transformation of given type described with TypeInformation.
|
| OutputConversionModifyOperation.UpdateMode |
Should the output type contain the change flag, and what should the flag represent
(retraction or deletion).
|
| Over |
Helper class for creating an over window.
|
| OverWindow |
An over window specification.
|
| OverWindowedTable |
|
| OverWindowPartitioned |
Partially defined over window with partitioning.
|
| OverWindowPartitionedOrdered |
Partially defined over window with (optional) partitioning and order.
|
| OverWindowPartitionedOrderedPreceding |
Partially defined over window with (optional) partitioning, order, and preceding.
|
| Parser |
Provides methods for parsing SQL objects from a SQL string.
|
| ParserFactory |
|
| ParserFactory.Context |
Context provided when a parser is created.
|
| PlanCacheManager |
This manages all the plan caches.
|
| Planner |
This interface serves two purposes:
SQL parser via Planner.getParser() - transforms a SQL string into a Table API specific
objects e.g. tree of Operations
relational planner - provides a way to plan, optimize and transform tree of ModifyOperation into a runnable form ( Transformation)
|
| PlannerConfig |
The PlannerConfig holds parameters to configure the behavior of queries.
|
| PlannerFactory |
|
| PlannerFactory.Context |
Context used when creating a planner.
|
| PlannerFactory.DefaultPlannerContext |
|
| PlannerFactoryUtil |
|
| PlannerModule |
Module holder that loads the flink-table-planner module in a separate classpath.
|
| PlanReference |
Unresolved pointer to a persisted plan.
|
| PlanReference.ContentPlanReference |
Plan reference to a string containing the serialized persisted plan in JSON.
|
| PlanReference.FilePlanReference |
Plan reference to a file in the local filesystem.
|
| PlanReference.ResourcePlanReference |
|
| ProjectQueryOperation |
Table operation that computes new table using given Expressions from its input relational
operation.
|
| QueryOperation |
Base class for representing an operation structure behind a user-facing Table API.
|
| QueryOperationCatalogView |
|
| QueryOperationDefaultVisitor<T> |
|
| QueryOperationVisitor<T> |
Class that implements visitor pattern.
|
| QuitOperation |
Operation that represent QUIT command.
|
| Registration |
A way to register a table in a TableEnvironment that this descriptor originates from.
|
| RemoveJarOperation |
Operation to describe an REMOVE JAR statement.
|
| ReplaceTableAsOperation |
Operation to describe a [CREATE OR] REPLACE TABLE AS statement.
|
| ResetOperation |
Operation to represent RESET command.
|
| ResolvedExpressionDefaultVisitor<T> |
|
| ResolvedExpressionVisitor<R> |
A visitor for all ResolvedExpressions.
|
| ResolverRule |
Rule that can be applied during resolution of Expression.
|
| ResolverRule.ResolutionContext |
Contextual information that can be used during application of the rule.
|
| ResolverRules |
|
| ResourceManager |
A manager for dealing with all user defined resource.
|
| ResultKind |
ResultKind defines the types of the result.
|
| ResultProvider |
An internal class which helps the client to get the execute result from a specific sink.
|
| SchemaTranslator |
Utility to derive a physical DataType, Schema, and projections for sinks and
sources.
|
| SchemaTranslator.ConsumingResult |
|
| SchemaTranslator.ProducingResult |
|
| Session |
Helper class for creating a session window.
|
| SessionWithGap |
Session window.
|
| SessionWithGapOnTime |
Session window on time.
|
| SessionWithGapOnTimeWithAlias |
Session window on time with alias.
|
| SetOperation |
Operation to represent SET command.
|
| SetQueryOperation |
A set operation on two relations.
|
| SetQueryOperation.SetQueryOperationType |
Represent kind of this set operation.
|
| ShowCatalogsOperation |
Operation to describe a SHOW CATALOGS statement.
|
| ShowColumnsOperation |
Operation to describe a SHOW COLUMNS statement.
|
| ShowCreateCatalogOperation |
Operation to describe a SHOW CREATE CATALOG statement.
|
| ShowCreateTableOperation |
Operation to describe a SHOW CREATE TABLE statement.
|
| ShowCreateUtil |
SHOW CREATE statement Util.
|
| ShowCreateViewOperation |
Operation to describe a SHOW CREATE VIEW statement.
|
| ShowCurrentCatalogOperation |
Operation to describe a SHOW CURRENT CATALOG statement.
|
| ShowCurrentDatabaseOperation |
Operation to describe SHOW CURRENT DATABASE operation.
|
| ShowDatabasesOperation |
Operation to describe a SHOW DATABASES statement.
|
| ShowFunctionsOperation |
Operation to describe a SHOW FUNCTIONS statement.
|
| ShowFunctionsOperation.FunctionScope |
Represent scope of function.
|
| ShowJarsOperation |
Operation to describe a SHOW JARS statement.
|
| ShowJobsOperation |
Operation to describe a SHOW JOBS statement.
|
| ShowLikeOperator |
Like operator for SHOW operations.
|
| ShowModulesOperation |
Operation to describe a SHOW [FULL] MODULES statement.
|
| ShowOperation |
An Operation that show one kind of objects, e.g.
|
| ShowPartitionsOperation |
Operation to describe a SHOW PARTITIONS statement.
|
| ShowProceduresOperation |
Operation to describe a SHOW PROCEDURES statement.
|
| ShowTablesOperation |
Operation to describe a SHOW TABLES statement.
|
| ShowViewsOperation |
Operation to describe a SHOW VIEWS statement.
|
| SinkModifyOperation |
DML operation that tells to write to a sink.
|
| Slide |
Helper class for creating a sliding window.
|
| SlideWithSize |
Partially specified sliding window.
|
| SlideWithSizeAndSlide |
Sliding window.
|
| SlideWithSizeAndSlideOnTime |
Sliding window on time.
|
| SlideWithSizeAndSlideOnTimeWithAlias |
Sliding window on time with alias.
|
| SortQueryOperation |
Expresses sort operation of rows of the underlying relational operation with given order.
|
| SourceQueryOperation |
|
| SqlDialect |
Enumeration of valid SQL compatibility modes.
|
| SqlExpressionResolver |
Translates a SQL expression string into a ResolvedExpression.
|
| SqlLikeUtils |
Utilities for converting SQL LIKE and SIMILAR operators to regular expressions.
|
| SqlParserEOFException |
Exception for incomplete sql statement found while sql parsing.
|
| SqlParserException |
Exception for all errors occurring during sql parsing.
|
| StagedSinkModifyOperation |
DML operation that tells to write to a sink which implements SupportsStaging.
|
| StagingSinkJobStatusHook |
This hook is used to implement atomic semantics for CTAS(CREATE TABLE AS SELECT) or RTAS([CREATE
OR] REPLACE TABLE AS SELECT) statement.
|
| StatementSet |
|
| StatementSetImpl<E extends TableEnvironmentInternal> |
|
| StatementSetOperation |
A Operation that describes the statement set, e.g.
|
| StaticResultProvider |
Create result provider from a static set of data using external types.
|
| StopJobOperation |
Operation to stop a running job.
|
| StreamRecordTimestamp |
Deprecated.
|
| Table |
The Table object is the core abstraction of the Table API.
|
| TableConfig |
Configuration for the current TableEnvironment session to adjust Table & SQL API
programs.
|
| TableConfigOptions |
This class holds ConfigOptions used by table planner.
|
| TableConfigOptions.CatalogPlanCompilation |
Strategy to compile Catalog objects into a plan.
|
| TableConfigOptions.CatalogPlanRestore |
Strategy to restore Catalog objects using the plan and lookups if necessary.
|
| TableConfigOptions.ColumnExpansionStrategy |
Strategy to expand columns in SELECT * queries.
|
| TableConfigValidation |
|
| TableDescriptor |
Describes a CatalogTable representing a source or sink.
|
| TableDescriptor.Builder |
|
| TableEnvironment |
A table environment is the base class, entry point, and central context for creating Table and
SQL API programs.
|
| TableEnvironmentImpl |
Implementation of TableEnvironment that works exclusively with Table API interfaces.
|
| TableEnvironmentInternal |
|
| TableFactoryUtil |
Utility for dealing with TableFactory using the TableFactoryService.
|
| TableImpl |
Implementation for Table.
|
| TableModificationEvent |
Base table event, provides column list, primary keys, partition keys, watermarks and properties
in CatalogBaseTable.
|
| TablePipeline |
Describes a complete pipeline from one or more source tables to a sink table.
|
| TableReferenceExpression |
Expression that references another table.
|
| TableReferenceLookup |
Provides a way to look up table reference by the name of the table.
|
| TableResult |
A TableResult is the representation of the statement execution result.
|
| TableResultImpl |
|
| TableResultImpl.Builder |
|
| TableResultInternal |
Internal interface with internal methods for TableResult.
|
| TableResultUtils |
|
| TableSourceQueryOperation<T> |
Inline scan of a TableSource.
|
| TemporalTableFunctionImpl |
Class representing temporal table function over some history table.
|
| TruncateTableOperation |
Operation to describe an TRUNCATE TABLE statement.
|
| Tumble |
Helper class for creating a tumbling window.
|
| TumbleWithSize |
Tumbling window.
|
| TumbleWithSizeOnTime |
Tumbling window on time.
|
| TumbleWithSizeOnTimeWithAlias |
Tumbling window on time with alias.
|
| UnloadModuleOperation |
Operation to describe an UNLOAD MODULE statement.
|
| UnregisteredSinkModifyOperation<T> |
DML operation that tells to write to the given sink.
|
| UnresolvedCallExpression |
Unresolved call expression for calling a function identified by a FunctionDefinition.
|
| UnresolvedReferenceExpression |
An unresolved reference to a field, table, or local reference.
|
| UseCatalogOperation |
Operation to describe a USE CATALOG statement.
|
| UseDatabaseOperation |
Operation to describe a USE [catalogName.]dataBaseName statement.
|
| UseModulesOperation |
Operation to describe a USE MODULES statement.
|
| UseOperation |
An Operation that describes the catalog/database switch statements, e.g.
|
| ValuesQueryOperation |
Table operation that computes new table using given Expressions 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 |
|
| WindowAggregateQueryOperation.ResolvedGroupWindow.WindowType |
The type of window.
|
| WindowGroupedTable |
A table that has been windowed and grouped for GroupWindows.
|