Class WindowAggregateQueryOperation

    • Constructor Detail

      • WindowAggregateQueryOperation

        public 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)
    • Method Detail

      • getResolvedSchema

        public org.apache.flink.table.catalog.ResolvedSchema getResolvedSchema()
        Description copied from interface: QueryOperation
        Resolved schema of this operation.
        Specified by:
        getResolvedSchema in interface QueryOperation
      • asSummaryString

        public String asSummaryString()
        Description copied from interface: Operation
        Returns a string that summarizes this operation for printing to a console. An implementation might skip very specific properties.
        Specified by:
        asSummaryString in interface Operation
        Returns:
        summary string of this operation for debugging purposes
      • asSerializableString

        public String asSerializableString()
        Description copied from interface: QueryOperation
        Returns a string that fully serializes this instance. The serialized string can be used for storing the query in e.g. a Catalog as a view.
        Specified by:
        asSerializableString in interface QueryOperation
        Returns:
        detailed string for persisting in a catalog
        See Also:
        Operation.asSummaryString()
      • getGroupingExpressions

        public List<org.apache.flink.table.expressions.ResolvedExpression> getGroupingExpressions()
      • getAggregateExpressions

        public List<org.apache.flink.table.expressions.ResolvedExpression> getAggregateExpressions()
      • getWindowPropertiesExpressions

        public List<org.apache.flink.table.expressions.ResolvedExpression> getWindowPropertiesExpressions()