Interface ResolverRule.ResolutionContext

  • Enclosing interface:
    ResolverRule

    @Internal
    public static interface ResolverRule.ResolutionContext
    Contextual information that can be used during application of the rule. E.g. one can access fields in inputs by name etc.
    • Method Detail

      • configuration

        org.apache.flink.configuration.ReadableConfig configuration()
        Access to configuration.
      • userClassLoader

        ClassLoader userClassLoader()
        Access to user classloader.
      • referenceLookup

        FieldReferenceLookup referenceLookup()
        Access to available FieldReferenceExpression in inputs.
      • functionLookup

        FunctionLookup functionLookup()
        Access to available FunctionDefinitions.
      • typeFactory

        org.apache.flink.table.catalog.DataTypeFactory typeFactory()
        Access to DataTypeFactory.
      • sqlExpressionResolver

        SqlExpressionResolver sqlExpressionResolver()
        Translates a SQL expression to ResolvedExpression.
      • getOutputDataType

        Optional<org.apache.flink.table.types.DataType> getOutputDataType()
        Access to the expected top-level output data type.
      • getOverWindow

        Optional<LocalOverWindow> getOverWindow​(org.apache.flink.table.expressions.Expression alias)
        Access to available local over windows.
      • isGroupedAggregation

        boolean isGroupedAggregation()
        Whether the expression is evaluated for a grouped aggregation.