Uses of Interface
org.apache.flink.table.operations.QueryOperation
-
-
Uses of QueryOperation in org.apache.flink.table.api
Methods in org.apache.flink.table.api that return QueryOperation Modifier and Type Method Description QueryOperationTable. getQueryOperation()Returns underlying logical representation of this table. -
Uses of QueryOperation in org.apache.flink.table.api.internal
Methods in org.apache.flink.table.api.internal that return QueryOperation Modifier and Type Method Description QueryOperationDQLCachedPlan. getOperation()QueryOperationTableImpl. getQueryOperation()protected QueryOperationTableEnvironmentImpl. qualifyQueryOperation(org.apache.flink.table.catalog.ObjectIdentifier identifier, QueryOperation queryOperation)Subclasses can override this method to transform the given QueryOperation to a new one with the qualified object identifier.Methods in org.apache.flink.table.api.internal with parameters of type QueryOperation Modifier and Type Method Description TableImplTableEnvironmentImpl. createTable(QueryOperation tableOperation)static TableImplTableImpl. createTable(TableEnvironmentInternal tableEnvironment, QueryOperation operationTree, OperationTreeBuilder operationTreeBuilder, FunctionLookup functionLookup)org.apache.flink.api.dag.PipelineTableEnvironmentImpl. generatePipelineFromQueryOperation(QueryOperation operation, List<org.apache.flink.api.dag.Transformation<?>> transformations)generate executionPipelinefromQueryOperation.protected QueryOperationTableEnvironmentImpl. qualifyQueryOperation(org.apache.flink.table.catalog.ObjectIdentifier identifier, QueryOperation queryOperation)Subclasses can override this method to transform the given QueryOperation to a new one with the qualified object identifier.Constructors in org.apache.flink.table.api.internal with parameters of type QueryOperation Constructor Description DQLCachedPlan(QueryOperation queryOperation, CollectModifyOperation sinkOperation, List<org.apache.flink.api.dag.Transformation<?>> transformations) -
Uses of QueryOperation in org.apache.flink.table.catalog
Methods in org.apache.flink.table.catalog that return QueryOperation Modifier and Type Method Description QueryOperationQueryOperationCatalogView. getQueryOperation()Constructors in org.apache.flink.table.catalog with parameters of type QueryOperation Constructor Description QueryOperationCatalogView(QueryOperation queryOperation)QueryOperationCatalogView(QueryOperation queryOperation, org.apache.flink.table.catalog.CatalogView originalView) -
Uses of QueryOperation in org.apache.flink.table.expressions
Methods in org.apache.flink.table.expressions that return QueryOperation Modifier and Type Method Description QueryOperationTableReferenceExpression. getQueryOperation()Methods in org.apache.flink.table.expressions with parameters of type QueryOperation Modifier and Type Method Description static TableReferenceExpressionApiExpressionUtils. tableRef(String name, QueryOperation queryOperation, TableEnvironment env) -
Uses of QueryOperation in org.apache.flink.table.expressions.resolver
Methods in org.apache.flink.table.expressions.resolver with parameters of type QueryOperation Modifier and Type Method Description static ExpressionResolver.ExpressionResolverBuilderExpressionResolver. resolverFor(TableConfig tableConfig, ClassLoader userClassLoader, TableReferenceLookup tableCatalog, FunctionLookup functionLookup, org.apache.flink.table.catalog.DataTypeFactory typeFactory, SqlExpressionResolver sqlExpressionResolver, QueryOperation... inputs)Creates a builder forExpressionResolver. -
Uses of QueryOperation in org.apache.flink.table.expressions.resolver.lookups
Constructor parameters in org.apache.flink.table.expressions.resolver.lookups with type arguments of type QueryOperation Constructor Description FieldReferenceLookup(List<QueryOperation> queryOperations) -
Uses of QueryOperation in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions that return QueryOperation Modifier and Type Method Description QueryOperationTemporalTableFunctionImpl. getUnderlyingHistoryTable()Methods in org.apache.flink.table.functions with parameters of type QueryOperation Modifier and Type Method Description static org.apache.flink.table.functions.TemporalTableFunctionTemporalTableFunctionImpl. create(QueryOperation operationTree, org.apache.flink.table.expressions.Expression timeAttribute, org.apache.flink.table.expressions.Expression primaryKey) -
Uses of QueryOperation in org.apache.flink.table.operations
Classes in org.apache.flink.table.operations that implement QueryOperation Modifier and Type Class Description classAggregateQueryOperationRelational operation that performs computations on top of subsets of input rows grouped by key.classCorrelatedFunctionQueryOperationDescribes a relational operation that was created from applying a correlated (process) table function.classDistinctQueryOperationRemoves duplicated rows of underlying relational operation.classFilterQueryOperationFilters out rows of underlying relational operation that do not match given condition.classFunctionQueryOperationDescribes a relational operation that was created from applying a (process) table function.classJoinQueryOperationTable operation that joins two relational operations based on given condition.classPartitionQueryOperationDescribes a relational operation that was created from applying a partitioning.classProjectQueryOperationTable operation that computes new table using givenExpressions from its input relational operation.classSetQueryOperationA set operation on two relations.classSortQueryOperationExpresses sort operation of rows of the underlying relational operation with given order.classSourceQueryOperationDescribes a query operation from aContextResolvedTable.classTableSourceQueryOperation<T>Inline scan of aTableSource.classValuesQueryOperationTable operation that computes new table using givenExpressions from its input relational operation.classWindowAggregateQueryOperationRelational operation that performs computations on top of subsets of input rows grouped by key and group window.Methods in org.apache.flink.table.operations that return QueryOperation Modifier and Type Method Description QueryOperationCollectModifyOperation. getChild()QueryOperationCreateTableASOperation. getChild()QueryOperationDeleteFromFilterOperation. getChild()QueryOperationExternalModifyOperation. getChild()QueryOperationModifyOperation. getChild()QueryOperationOutputConversionModifyOperation. getChild()QueryOperationReplaceTableAsOperation. getChild()QueryOperationSinkModifyOperation. getChild()QueryOperationSortQueryOperation. getChild()QueryOperationUnregisteredSinkModifyOperation. getChild()Methods in org.apache.flink.table.operations that return types with arguments of type QueryOperation Modifier and Type Method Description List<QueryOperation>AggregateQueryOperation. getChildren()List<QueryOperation>CorrelatedFunctionQueryOperation. getChildren()List<QueryOperation>DistinctQueryOperation. getChildren()List<QueryOperation>FilterQueryOperation. getChildren()List<QueryOperation>FunctionQueryOperation. getChildren()List<QueryOperation>JoinQueryOperation. getChildren()List<QueryOperation>PartitionQueryOperation. getChildren()List<QueryOperation>ProjectQueryOperation. getChildren()List<QueryOperation>QueryOperation. getChildren()List<QueryOperation>SetQueryOperation. getChildren()List<QueryOperation>SortQueryOperation. getChildren()List<QueryOperation>SourceQueryOperation. getChildren()List<QueryOperation>TableSourceQueryOperation. getChildren()List<QueryOperation>ValuesQueryOperation. getChildren()List<QueryOperation>WindowAggregateQueryOperation. getChildren()Methods in org.apache.flink.table.operations with parameters of type QueryOperation Modifier and Type Method Description TQueryOperationVisitor. visit(QueryOperation other)Constructors in org.apache.flink.table.operations with parameters of type QueryOperation Constructor Description AggregateQueryOperation(List<org.apache.flink.table.expressions.ResolvedExpression> groupingExpressions, List<org.apache.flink.table.expressions.ResolvedExpression> aggregateExpressions, QueryOperation child, org.apache.flink.table.catalog.ResolvedSchema resolvedSchema)CollectModifyOperation(QueryOperation child)CreateTableASOperation(CreateTableOperation createTableOperation, Map<String,String> sinkModifyStaticPartitions, QueryOperation sinkModifyQuery, boolean sinkModifyOverwrite)DistinctQueryOperation(QueryOperation child)ExternalModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, org.apache.flink.table.connector.ChangelogMode changelogMode, org.apache.flink.table.types.DataType physicalDataType)FilterQueryOperation(org.apache.flink.table.expressions.ResolvedExpression condition, QueryOperation child)JoinQueryOperation(QueryOperation left, QueryOperation right, JoinQueryOperation.JoinType joinType, org.apache.flink.table.expressions.ResolvedExpression condition, boolean correlated)OutputConversionModifyOperation(QueryOperation child, org.apache.flink.table.types.DataType type, OutputConversionModifyOperation.UpdateMode updateMode)PartitionQueryOperation(List<org.apache.flink.table.expressions.ResolvedExpression> partitionExpressions, QueryOperation child)ProjectQueryOperation(List<org.apache.flink.table.expressions.ResolvedExpression> projectList, QueryOperation child, org.apache.flink.table.catalog.ResolvedSchema resolvedSchema)ReplaceTableAsOperation(CreateTableOperation createTableOperation, QueryOperation sinkModifyQuery, boolean isCreateOrReplace)SetQueryOperation(QueryOperation leftOperation, QueryOperation rightOperation, SetQueryOperation.SetQueryOperationType type, boolean all, org.apache.flink.table.catalog.ResolvedSchema resolvedSchema)SinkModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child)SinkModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, int[][] targetColumns, ModifyType modifyType)SinkModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, Map<String,String> staticPartitions, int[][] targetColumns, boolean overwrite, Map<String,String> dynamicOptions)SinkModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, Map<String,String> staticPartitions, int[][] targetColumns, boolean overwrite, Map<String,String> dynamicOptions, ModifyType modifyType)SortQueryOperation(List<org.apache.flink.table.expressions.ResolvedExpression> order, QueryOperation child)SortQueryOperation(List<org.apache.flink.table.expressions.ResolvedExpression> order, QueryOperation child, int offset, int fetch)StagedSinkModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, Map<String,String> staticPartitions, int[][] targetColumns, boolean overwrite, Map<String,String> dynamicOptions, org.apache.flink.table.connector.sink.DynamicTableSink dynamicTableSink)StagedSinkModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, Map<String,String> staticPartitions, int[][] targetColumns, boolean overwrite, Map<String,String> dynamicOptions, ModifyType modifyType, org.apache.flink.table.connector.sink.DynamicTableSink dynamicTableSink)UnregisteredSinkModifyOperation(org.apache.flink.table.legacy.sinks.TableSink<T> sink, QueryOperation child)WindowAggregateQueryOperation(List<org.apache.flink.table.expressions.ResolvedExpression> groupingExpressions, List<org.apache.flink.table.expressions.ResolvedExpression> aggregateExpressions, List<org.apache.flink.table.expressions.ResolvedExpression> windowPropertiesExpressions, WindowAggregateQueryOperation.ResolvedGroupWindow groupWindow, QueryOperation child, org.apache.flink.table.catalog.ResolvedSchema resolvedSchema) -
Uses of QueryOperation in org.apache.flink.table.operations.utils
Methods in org.apache.flink.table.operations.utils that return QueryOperation Modifier and Type Method Description QueryOperationOperationTreeBuilder. addColumns(boolean replaceIfExist, List<org.apache.flink.table.expressions.Expression> fieldLists, QueryOperation child)Adds additional columns.QueryOperationOperationTreeBuilder. aggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, List<org.apache.flink.table.expressions.Expression> aggregates, QueryOperation child)QueryOperationOperationTreeBuilder. aggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, org.apache.flink.table.expressions.Expression aggregate, QueryOperation child)QueryOperationOperationTreeBuilder. alias(List<org.apache.flink.table.expressions.Expression> fields, QueryOperation child)QueryOperationOperationTreeBuilder. distinct(QueryOperation child)QueryOperationOperationTreeBuilder. dropColumns(List<org.apache.flink.table.expressions.Expression> fieldLists, QueryOperation child)QueryOperationOperationTreeBuilder. filter(org.apache.flink.table.expressions.Expression condition, QueryOperation child)QueryOperationOperationTreeBuilder. flatMap(org.apache.flink.table.expressions.Expression tableFunctionCall, QueryOperation child)QueryOperationOperationTreeBuilder. intersect(QueryOperation left, QueryOperation right, boolean all)QueryOperationOperationTreeBuilder. join(QueryOperation left, QueryOperation right, JoinQueryOperation.JoinType joinType, Optional<org.apache.flink.table.expressions.Expression> condition, boolean correlated)QueryOperationOperationTreeBuilder. joinLateral(QueryOperation left, org.apache.flink.table.expressions.Expression tableFunction, JoinQueryOperation.JoinType joinType, Optional<org.apache.flink.table.expressions.Expression> condition)QueryOperationOperationTreeBuilder. limitWithFetch(int fetch, QueryOperation child)QueryOperationOperationTreeBuilder. limitWithOffset(int offset, QueryOperation child)QueryOperationOperationTreeBuilder. map(org.apache.flink.table.expressions.Expression mapFunction, QueryOperation child)QueryOperationOperationTreeBuilder. minus(QueryOperation left, QueryOperation right, boolean all)QueryOperationOperationTreeBuilder. partition(List<org.apache.flink.table.expressions.Expression> partitionKeys, QueryOperation child)QueryOperationOperationTreeBuilder. project(List<org.apache.flink.table.expressions.Expression> projectList, QueryOperation child)QueryOperationOperationTreeBuilder. project(List<org.apache.flink.table.expressions.Expression> projectList, QueryOperation child, boolean explicitAlias)QueryOperationOperationTreeBuilder. project(List<org.apache.flink.table.expressions.Expression> projectList, QueryOperation child, List<OverWindow> overWindows)QueryOperationOperationTreeBuilder. renameColumns(List<org.apache.flink.table.expressions.Expression> aliases, QueryOperation child)QueryOperationOperationTreeBuilder. sort(List<org.apache.flink.table.expressions.Expression> fields, QueryOperation child)QueryOperationOperationTreeBuilder. tableAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, org.apache.flink.table.expressions.Expression tableAggFunction, QueryOperation child)QueryOperationOperationTreeBuilder. tableFunction(org.apache.flink.table.expressions.Expression call)QueryOperationOperationTreeBuilder. union(QueryOperation left, QueryOperation right, boolean all)QueryOperationOperationTreeBuilder. values(org.apache.flink.table.expressions.Expression... expressions)QueryOperationOperationTreeBuilder. values(org.apache.flink.table.types.DataType rowType, org.apache.flink.table.expressions.Expression... expressions)QueryOperationOperationTreeBuilder. windowAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, GroupWindow window, List<org.apache.flink.table.expressions.Expression> windowProperties, List<org.apache.flink.table.expressions.Expression> aggregates, QueryOperation child)QueryOperationOperationTreeBuilder. windowAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, GroupWindow window, List<org.apache.flink.table.expressions.Expression> windowProperties, org.apache.flink.table.expressions.Expression aggregateFunction, QueryOperation child)QueryOperationOperationTreeBuilder. windowTableAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, GroupWindow window, List<org.apache.flink.table.expressions.Expression> windowProperties, org.apache.flink.table.expressions.Expression tableAggFunction, QueryOperation child)Methods in org.apache.flink.table.operations.utils with parameters of type QueryOperation Modifier and Type Method Description QueryOperationOperationTreeBuilder. addColumns(boolean replaceIfExist, List<org.apache.flink.table.expressions.Expression> fieldLists, QueryOperation child)Adds additional columns.QueryOperationOperationTreeBuilder. aggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, List<org.apache.flink.table.expressions.Expression> aggregates, QueryOperation child)QueryOperationOperationTreeBuilder. aggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, org.apache.flink.table.expressions.Expression aggregate, QueryOperation child)QueryOperationOperationTreeBuilder. alias(List<org.apache.flink.table.expressions.Expression> fields, QueryOperation child)abstract TQueryOperationDefaultVisitor. defaultMethod(QueryOperation other)QueryOperationOperationTreeBuilder. distinct(QueryOperation child)QueryOperationOperationTreeBuilder. dropColumns(List<org.apache.flink.table.expressions.Expression> fieldLists, QueryOperation child)QueryOperationOperationTreeBuilder. filter(org.apache.flink.table.expressions.Expression condition, QueryOperation child)QueryOperationOperationTreeBuilder. flatMap(org.apache.flink.table.expressions.Expression tableFunctionCall, QueryOperation child)ExpressionResolver.ExpressionResolverBuilderOperationTreeBuilder. getResolverBuilder(QueryOperation... tableOperation)QueryOperationOperationTreeBuilder. intersect(QueryOperation left, QueryOperation right, boolean all)QueryOperationOperationTreeBuilder. join(QueryOperation left, QueryOperation right, JoinQueryOperation.JoinType joinType, Optional<org.apache.flink.table.expressions.Expression> condition, boolean correlated)QueryOperationOperationTreeBuilder. joinLateral(QueryOperation left, org.apache.flink.table.expressions.Expression tableFunction, JoinQueryOperation.JoinType joinType, Optional<org.apache.flink.table.expressions.Expression> condition)QueryOperationOperationTreeBuilder. limitWithFetch(int fetch, QueryOperation child)QueryOperationOperationTreeBuilder. limitWithOffset(int offset, QueryOperation child)QueryOperationOperationTreeBuilder. map(org.apache.flink.table.expressions.Expression mapFunction, QueryOperation child)QueryOperationOperationTreeBuilder. minus(QueryOperation left, QueryOperation right, boolean all)QueryOperationOperationTreeBuilder. partition(List<org.apache.flink.table.expressions.Expression> partitionKeys, QueryOperation child)QueryOperationOperationTreeBuilder. project(List<org.apache.flink.table.expressions.Expression> projectList, QueryOperation child)QueryOperationOperationTreeBuilder. project(List<org.apache.flink.table.expressions.Expression> projectList, QueryOperation child, boolean explicitAlias)QueryOperationOperationTreeBuilder. project(List<org.apache.flink.table.expressions.Expression> projectList, QueryOperation child, List<OverWindow> overWindows)QueryOperationOperationTreeBuilder. renameColumns(List<org.apache.flink.table.expressions.Expression> aliases, QueryOperation child)org.apache.flink.table.expressions.ResolvedExpressionOperationTreeBuilder. resolveExpression(org.apache.flink.table.expressions.Expression expression, QueryOperation... tableOperation)QueryOperationOperationTreeBuilder. sort(List<org.apache.flink.table.expressions.Expression> fields, QueryOperation child)QueryOperationOperationTreeBuilder. tableAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, org.apache.flink.table.expressions.Expression tableAggFunction, QueryOperation child)QueryOperationOperationTreeBuilder. union(QueryOperation left, QueryOperation right, boolean all)TQueryOperationDefaultVisitor. visit(QueryOperation other)QueryOperationOperationTreeBuilder. windowAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, GroupWindow window, List<org.apache.flink.table.expressions.Expression> windowProperties, List<org.apache.flink.table.expressions.Expression> aggregates, QueryOperation child)QueryOperationOperationTreeBuilder. windowAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, GroupWindow window, List<org.apache.flink.table.expressions.Expression> windowProperties, org.apache.flink.table.expressions.Expression aggregateFunction, QueryOperation child)QueryOperationOperationTreeBuilder. windowTableAggregate(List<org.apache.flink.table.expressions.Expression> groupingExpressions, GroupWindow window, List<org.apache.flink.table.expressions.Expression> windowProperties, org.apache.flink.table.expressions.Expression tableAggFunction, QueryOperation child)
-