Class JsonArrayAggFunction

  • All Implemented Interfaces:
    Serializable, org.apache.flink.table.functions.FunctionDefinition

    @Internal
    public class JsonArrayAggFunction
    extends BuiltInAggregateFunction<String,​JsonArrayAggFunction.Accumulator>
    Implementation for BuiltInFunctionDefinitions.JSON_ARRAYAGG_ABSENT_ON_NULL / BuiltInFunctionDefinitions.JSON_ARRAYAGG_NULL_ON_NULL.

    Note that this function only ever receives strings to accumulate because WrapJsonAggFunctionArgumentsRule wraps arguments into BuiltInFunctionDefinitions.JSON_STRING.

    See Also:
    Serialized Form