All Downloads are FREE. Search and download functionalities are using the official Maven repository.

io.trino.operator.aggregation.state.StateCompiler Maven / Gradle / Ivy

There is a newer version: 468
Show newest version
/*
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package io.trino.operator.aggregation.state;

import com.google.common.annotations.VisibleForTesting;
import com.google.common.collect.ImmutableList;
import com.google.common.collect.ImmutableMap;
import com.google.common.collect.Ordering;
import io.airlift.bytecode.BytecodeBlock;
import io.airlift.bytecode.BytecodeNode;
import io.airlift.bytecode.ClassDefinition;
import io.airlift.bytecode.DynamicClassLoader;
import io.airlift.bytecode.FieldDefinition;
import io.airlift.bytecode.MethodDefinition;
import io.airlift.bytecode.Parameter;
import io.airlift.bytecode.Scope;
import io.airlift.bytecode.Variable;
import io.airlift.bytecode.control.IfStatement;
import io.airlift.bytecode.expression.BytecodeExpression;
import io.airlift.slice.SizeOf;
import io.airlift.slice.Slice;
import io.trino.array.BlockBigArray;
import io.trino.array.BooleanBigArray;
import io.trino.array.ByteBigArray;
import io.trino.array.DoubleBigArray;
import io.trino.array.IntBigArray;
import io.trino.array.LongBigArray;
import io.trino.array.ObjectBigArray;
import io.trino.array.SliceBigArray;
import io.trino.array.SqlMapBigArray;
import io.trino.array.SqlRowBigArray;
import io.trino.spi.block.Block;
import io.trino.spi.block.BlockBuilder;
import io.trino.spi.block.RowBlockBuilder;
import io.trino.spi.block.RowValueBuilder;
import io.trino.spi.block.SqlMap;
import io.trino.spi.block.SqlRow;
import io.trino.spi.function.AccumulatorState;
import io.trino.spi.function.AccumulatorStateFactory;
import io.trino.spi.function.AccumulatorStateMetadata;
import io.trino.spi.function.AccumulatorStateSerializer;
import io.trino.spi.function.GroupedAccumulatorState;
import io.trino.spi.function.InOut;
import io.trino.spi.function.InternalDataAccessor;
import io.trino.spi.type.RowType;
import io.trino.spi.type.Type;
import io.trino.sql.gen.CallSiteBinder;
import io.trino.sql.gen.SqlTypeBytecodeExpression;

import java.lang.annotation.Annotation;
import java.lang.reflect.InvocationTargetException;
import java.lang.reflect.Method;
import java.lang.reflect.Modifier;
import java.util.ArrayList;
import java.util.HashMap;
import java.util.HashSet;
import java.util.List;
import java.util.Map;
import java.util.Optional;
import java.util.Set;
import java.util.function.BiFunction;
import java.util.function.Function;

import static com.google.common.base.CaseFormat.LOWER_CAMEL;
import static com.google.common.base.CaseFormat.UPPER_CAMEL;
import static com.google.common.base.Preconditions.checkArgument;
import static com.google.common.collect.ImmutableList.toImmutableList;
import static com.google.common.collect.Iterables.getOnlyElement;
import static io.airlift.bytecode.Access.FINAL;
import static io.airlift.bytecode.Access.PRIVATE;
import static io.airlift.bytecode.Access.PUBLIC;
import static io.airlift.bytecode.Access.STATIC;
import static io.airlift.bytecode.Access.a;
import static io.airlift.bytecode.Parameter.arg;
import static io.airlift.bytecode.ParameterizedType.type;
import static io.airlift.bytecode.expression.BytecodeExpressions.add;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantBoolean;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantClass;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantFalse;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantInt;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantLong;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantNull;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantNumber;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantString;
import static io.airlift.bytecode.expression.BytecodeExpressions.constantTrue;
import static io.airlift.bytecode.expression.BytecodeExpressions.defaultValue;
import static io.airlift.bytecode.expression.BytecodeExpressions.equal;
import static io.airlift.bytecode.expression.BytecodeExpressions.getStatic;
import static io.airlift.bytecode.expression.BytecodeExpressions.invokeStatic;
import static io.airlift.bytecode.expression.BytecodeExpressions.isNull;
import static io.airlift.bytecode.expression.BytecodeExpressions.newInstance;
import static io.airlift.bytecode.expression.BytecodeExpressions.setStatic;
import static io.trino.spi.type.BigintType.BIGINT;
import static io.trino.spi.type.BooleanType.BOOLEAN;
import static io.trino.spi.type.DoubleType.DOUBLE;
import static io.trino.spi.type.IntegerType.INTEGER;
import static io.trino.spi.type.TinyintType.TINYINT;
import static io.trino.spi.type.VarbinaryType.VARBINARY;
import static io.trino.sql.gen.LambdaMetafactoryGenerator.generateMetafactory;
import static io.trino.sql.gen.SqlTypeBytecodeExpression.constantType;
import static io.trino.type.UnknownType.UNKNOWN;
import static io.trino.util.CompilerUtils.defineClass;
import static io.trino.util.CompilerUtils.makeClassName;
import static java.lang.String.format;
import static java.util.Objects.requireNonNull;

public final class StateCompiler
{
    private StateCompiler() {}

    private static Class getBigArrayType(Class type)
    {
        if (type.equals(long.class)) {
            return LongBigArray.class;
        }
        if (type.equals(byte.class)) {
            return ByteBigArray.class;
        }
        if (type.equals(double.class)) {
            return DoubleBigArray.class;
        }
        if (type.equals(boolean.class)) {
            return BooleanBigArray.class;
        }
        if (type.equals(int.class)) {
            return IntBigArray.class;
        }
        if (type.equals(Slice.class)) {
            return SliceBigArray.class;
        }
        if (type.equals(Block.class)) {
            return BlockBigArray.class;
        }
        if (type.equals(SqlMap.class)) {
            return SqlMapBigArray.class;
        }
        if (type.equals(SqlRow.class)) {
            return SqlRowBigArray.class;
        }
        return ObjectBigArray.class;
    }

    public static  AccumulatorStateSerializer generateStateSerializer(Class clazz)
    {
        return generateStateSerializer(clazz, ImmutableMap.of());
    }

    @VisibleForTesting
    static  AccumulatorStateSerializer generateStateSerializer(Class clazz, Map fieldTypes)
    {
        AccumulatorStateMetadata metadata = getMetadataAnnotation(clazz);
        if (metadata != null && metadata.stateSerializerClass() != AccumulatorStateSerializer.class) {
            try {
                //noinspection unchecked
                return (AccumulatorStateSerializer) metadata.stateSerializerClass().getConstructor().newInstance();
            }
            catch (InstantiationException | IllegalAccessException | NoSuchMethodException | InvocationTargetException e) {
                throw new RuntimeException(e);
            }
        }

        ClassDefinition definition = new ClassDefinition(
                a(PUBLIC, FINAL),
                makeClassName(clazz.getSimpleName() + "Serializer"),
                type(Object.class),
                type(AccumulatorStateSerializer.class));

        CallSiteBinder callSiteBinder = new CallSiteBinder();

        // Generate constructor
        definition.declareDefaultConstructor(a(PUBLIC));

        List fields = enumerateFields(clazz, fieldTypes);
        generateGetSerializedType(definition, fields, callSiteBinder);
        generateSerialize(definition, callSiteBinder, clazz, fields);
        generateDeserialize(definition, callSiteBinder, clazz, fields);

        // grouped aggregation state fields use engine classes, so generated class must be able to see both plugin and system classes
        DynamicClassLoader classLoader = new DynamicClassLoader(clazz.getClassLoader(), StateCompiler.class.getClassLoader());
        Class serializerClass = defineClass(definition, AccumulatorStateSerializer.class, callSiteBinder.getBindings(), classLoader);
        try {
            //noinspection unchecked
            return (AccumulatorStateSerializer) serializerClass.getConstructor().newInstance();
        }
        catch (ReflectiveOperationException e) {
            throw new RuntimeException(e);
        }
    }

    private static void generateGetSerializedType(ClassDefinition definition, List fields, CallSiteBinder callSiteBinder)
    {
        BytecodeBlock body = definition.declareMethod(a(PUBLIC), "getSerializedType", type(Type.class)).getBody();

        Type type = getSerializedType(fields);

        body.comment("return %s", type.getTypeSignature())
                .append(constantType(callSiteBinder, type))
                .retObject();
    }

    private static Type getSerializedType(List fields)
    {
        if (fields.size() > 1) {
            List types = fields.stream().map(StateField::getSqlType).collect(toImmutableList());
            return RowType.anonymous(types);
        }
        if (fields.size() == 1) {
            return getOnlyElement(fields).getSqlType();
        }
        return UNKNOWN;
    }

    public static  AccumulatorStateMetadata getMetadataAnnotation(Class clazz)
    {
        AccumulatorStateMetadata metadata = clazz.getAnnotation(AccumulatorStateMetadata.class);
        if (metadata != null) {
            return metadata;
        }
        // If the annotation wasn't found, then search the super classes
        for (Class superInterface : clazz.getInterfaces()) {
            metadata = superInterface.getAnnotation(AccumulatorStateMetadata.class);
            if (metadata != null) {
                return metadata;
            }
        }

        return null;
    }

    private static  void generateDeserialize(ClassDefinition definition, CallSiteBinder binder, Class clazz, List fields)
    {
        Parameter block = arg("block", Block.class);
        Parameter index = arg("index", int.class);
        Parameter state = arg("state", AccumulatorState.class);
        MethodDefinition method = definition.declareMethod(a(PUBLIC), "deserialize", type(void.class), block, index, state);
        BytecodeBlock deserializerBody = method.getBody();
        Scope scope = method.getScope();
        if (fields.size() == 1) {
            StateField field = getOnlyElement(fields);
            Method setter = getSetter(clazz, field);
            if (!field.isPrimitiveType()) {
                deserializerBody.append(new IfStatement()
                        .condition(block.invoke("isNull", boolean.class, index))
                        .ifTrue(state.cast(setter.getDeclaringClass()).invoke(setter, constantNull(field.getType())))
                        .ifFalse(state.cast(setter.getDeclaringClass()).invoke(setter, constantType(binder, field.getSqlType()).getValue(block, index))));
            }
            else {
                // For primitive type, we need to cast here because we serialize byte fields with TINYINT/INTEGER (whose java type is long).
                deserializerBody.append(
                        state.cast(setter.getDeclaringClass()).invoke(
                                setter,
                                constantType(binder, field.getSqlType()).getValue(block, index).cast(field.getType())));
            }
        }
        else if (fields.size() > 1) {
            Variable row = scope.declareVariable("row", deserializerBody, block.invoke("getObject", Object.class, index, constantClass(SqlRow.class)).cast(SqlRow.class));
            Variable rawIndex = scope.declareVariable("rawIndex", deserializerBody, row.invoke("getRawIndex", int.class));
            Variable fieldBlock = scope.declareVariable(Block.class, "fieldBlock");

            int position = 0;
            for (StateField field : fields) {
                Method setter = getSetter(clazz, field);
                deserializerBody.append(fieldBlock.set(row.invoke("getRawFieldBlock", Block.class, constantInt(position))));
                if (!field.isPrimitiveType()) {
                    deserializerBody.append(new IfStatement()
                            .condition(fieldBlock.invoke("isNull", boolean.class, rawIndex))
                            .ifTrue(state.cast(setter.getDeclaringClass()).invoke(setter, constantNull(field.getType())))
                            .ifFalse(state.cast(setter.getDeclaringClass()).invoke(setter, constantType(binder, field.getSqlType()).getValue(fieldBlock, rawIndex))));
                }
                else {
                    // For primitive type, we need to cast here because we serialize byte fields with TINYINT/INTEGER (whose java type is long).
                    deserializerBody.append(
                            state.cast(setter.getDeclaringClass()).invoke(
                                    setter,
                                    constantType(binder, field.getSqlType()).getValue(fieldBlock, rawIndex).cast(field.getType())));
                }
                position++;
            }
        }
        deserializerBody.ret();
    }

    private static  void generateSerialize(ClassDefinition definition, CallSiteBinder binder, Class clazz, List fields)
    {
        Parameter state = arg("state", AccumulatorState.class);
        Parameter out = arg("out", BlockBuilder.class);
        MethodDefinition method = definition.declareMethod(a(PUBLIC), "serialize", type(void.class), state, out);
        Scope scope = method.getScope();
        BytecodeBlock serializerBody = method.getBody();

        if (fields.isEmpty()) {
            serializerBody.append(out.invoke("appendNull", BlockBuilder.class).pop());
        }
        else if (fields.size() == 1) {
            Method getter = getGetter(clazz, getOnlyElement(fields));
            SqlTypeBytecodeExpression sqlType = constantType(binder, getOnlyElement(fields).getSqlType());
            Variable fieldValue = scope.declareVariable(getter.getReturnType(), "value");
            serializerBody.append(fieldValue.set(state.cast(getter.getDeclaringClass()).invoke(getter)));
            if (!getOnlyElement(fields).isPrimitiveType()) {
                serializerBody.append(new IfStatement()
                        .condition(equal(fieldValue, constantNull(getter.getReturnType())))
                        .ifTrue(out.invoke("appendNull", BlockBuilder.class).pop())
                        .ifFalse(sqlType.writeValue(out, fieldValue)));
            }
            else {
                // For primitive type, we need to cast here because we serialize byte fields with TINYINT/INTEGER (whose java type is long).
                serializerBody.append(sqlType.writeValue(out, fieldValue.cast(getOnlyElement(fields).getSqlType().getJavaType())));
            }
        }
        else {
            MethodDefinition serializeToRow = generateSerializeToRow(definition, binder, clazz, fields);
            BytecodeExpression rowEntryBuilder = generateMetafactory(RowValueBuilder.class, serializeToRow, ImmutableList.of(state));
            serializerBody.append(out.cast(RowBlockBuilder.class).invoke("buildEntry", void.class, rowEntryBuilder));
        }
        serializerBody.ret();
    }

    private static MethodDefinition generateSerializeToRow(
            ClassDefinition definition,
            CallSiteBinder binder,
            Class clazz,
            List fields)
    {
        Parameter state = arg("state", AccumulatorState.class);
        Parameter fieldBuilders = arg("fieldBuilders", type(List.class, BlockBuilder.class));
        MethodDefinition method = definition.declareMethod(a(PRIVATE, STATIC), "serialize", type(void.class), state, fieldBuilders);
        Scope scope = method.getScope();
        BytecodeBlock body = method.getBody();

        Variable fieldBuilder = scope.createTempVariable(BlockBuilder.class);
        for (int i = 0; i < fields.size(); i++) {
            StateField field = fields.get(i);
            Method getter = getGetter(clazz, field);

            SqlTypeBytecodeExpression sqlType = constantType(binder, field.getSqlType());

            Variable fieldValue = scope.createTempVariable(getter.getReturnType());
            body.append(fieldValue.set(state.cast(getter.getDeclaringClass()).invoke(getter)));

            body.append(fieldBuilder.set(fieldBuilders.invoke("get", Object.class, constantInt(i)).cast(BlockBuilder.class)));

            if (!field.isPrimitiveType()) {
                body.append(new IfStatement().condition(equal(fieldValue, constantNull(getter.getReturnType())))
                        .ifTrue(fieldBuilder.invoke("appendNull", BlockBuilder.class).pop())
                        .ifFalse(sqlType.writeValue(fieldBuilder, fieldValue)));
            }
            else {
                // For primitive type, we need to cast here because we serialize byte fields with TINYINT/INTEGER (whose java type is long).
                body.append(sqlType.writeValue(fieldBuilder, fieldValue.cast(field.getSqlType().getJavaType())));
            }
        }
        body.ret();
        return method;
    }

    private static Method getSetter(Class clazz, StateField field)
    {
        try {
            return clazz.getMethod(field.getSetterName(), field.getType());
        }
        catch (NoSuchMethodException e) {
            throw new RuntimeException(e);
        }
    }

    private static Method getGetter(Class clazz, StateField field)
    {
        try {
            return clazz.getMethod(field.getGetterName());
        }
        catch (NoSuchMethodException e) {
            throw new RuntimeException(e);
        }
    }

    public static AccumulatorStateFactory generateInOutStateFactory(Type type)
    {
        CallSiteBinder callSiteBinder = new CallSiteBinder();
        ClassDefinition singleStateClassDefinition = generateInOutSingleStateClass(type, callSiteBinder);
        ClassDefinition groupedStateClassDefinition = generateInOutGroupedStateClass(type, callSiteBinder);

        DynamicClassLoader classLoader = new DynamicClassLoader(StateCompiler.class.getClassLoader(), callSiteBinder.getBindings());
        Class singleStateClass = defineClass(singleStateClassDefinition, InOut.class, classLoader);
        Class groupedStateClass = defineClass(groupedStateClassDefinition, InOut.class, classLoader);

        return generateStateFactory(InOut.class, singleStateClass, groupedStateClass, classLoader);
    }

    private static ClassDefinition generateInOutSingleStateClass(Type type, CallSiteBinder callSiteBinder)
    {
        ClassDefinition definition = new ClassDefinition(
                a(PUBLIC, FINAL),
                makeClassName("SingleInOut"),
                type(Object.class),
                type(InOut.class),
                type(InternalDataAccessor.class));

        estimatedSize(definition);

        // Generate constructor
        MethodDefinition constructor = definition.declareConstructor(a(PUBLIC));

        constructor.getBody()
                .append(constructor.getThis())
                .invokeConstructor(Object.class);

        // Generate fields
        FieldDefinition valueField = definition.declareField(a(PRIVATE), "value", inOutGetterReturnType(type));
        Function valueGetter = scope -> scope.getThis().getField(valueField);

        Optional nullField;
        Function nullGetter;
        if (type.getJavaType().isPrimitive()) {
            nullField = Optional.of(definition.declareField(a(PRIVATE), "valueIdNull", boolean.class));
            constructor.getBody().append(constructor.getThis().setField(nullField.get(), constantTrue()));
            nullGetter = scope -> scope.getThis().getField(nullField.get());
        }
        else {
            nullField = Optional.empty();
            nullGetter = scope -> isNull(valueGetter.apply(scope));
        }

        constructor.getBody()
                .ret();

        inOutSingleCopy(definition, valueField, nullField);

        Function setNullGenerator = scope -> {
            Variable thisVariable = scope.getThis();
            BytecodeBlock bytecodeBlock = new BytecodeBlock();
            nullField.ifPresent(field -> bytecodeBlock.append(thisVariable.setField(field, constantTrue())));
            bytecodeBlock.append(thisVariable.setField(valueField, defaultValue(valueField.getType())));
            return bytecodeBlock;
        };

        BiFunction setValueGenerator = (scope, value) -> {
            Variable thisVariable = scope.getThis();
            BytecodeBlock bytecodeBlock = new BytecodeBlock();
            nullField.ifPresent(field -> bytecodeBlock.append(thisVariable.setField(field, constantFalse())));
            bytecodeBlock.append(thisVariable.setField(valueField, value));
            return bytecodeBlock;
        };

        generateInOutMethods(type, definition, valueGetter, nullGetter, setNullGenerator, setValueGenerator, callSiteBinder);
        return definition;
    }

    private static ClassDefinition generateInOutGroupedStateClass(Type type, CallSiteBinder callSiteBinder)
    {
        ClassDefinition definition = new ClassDefinition(
                a(PUBLIC, FINAL),
                makeClassName("GroupedInOut"), // todo add type
                type(Object.class),
                type(InOut.class),
                type(GroupedAccumulatorState.class),
                type(InternalDataAccessor.class));

        estimatedSize(definition);

        MethodDefinition constructor = definition.declareConstructor(a(PUBLIC));
        constructor.getBody()
                .append(constructor.getThis())
                .invokeConstructor(Object.class);

        FieldDefinition groupIdField = definition.declareField(a(PRIVATE), "groupId", long.class);

        Class valueElementType = inOutGetterReturnType(type);
        FieldDefinition valueField = definition.declareField(a(PRIVATE, FINAL), "value", getBigArrayType(valueElementType));
        constructor.getBody().append(constructor.getThis().setField(valueField, newInstance(valueField.getType())));
        Function valueGetter = scope -> scope.getThis().getField(valueField).invoke("get", valueElementType, scope.getThis().getField(groupIdField));

        Optional nullField;
        Function nullGetter;
        if (type.getJavaType().isPrimitive()) {
            nullField = Optional.of(definition.declareField(a(PRIVATE, FINAL), "valueIdNull", BooleanBigArray.class));
            constructor.getBody().append(constructor.getThis().setField(nullField.get(), newInstance(BooleanBigArray.class, constantTrue())));
            nullGetter = scope -> scope.getThis().getField(nullField.get()).invoke("get", boolean.class, scope.getThis().getField(groupIdField));
        }
        else {
            nullField = Optional.empty();
            nullGetter = scope -> isNull(valueGetter.apply(scope));
        }

        constructor.getBody()
                .ret();

        inOutGroupedSetGroupId(definition, groupIdField);
        inOutGroupedEnsureCapacity(definition, valueField, nullField);
        inOutGroupedCopy(definition, valueField, nullField);

        Function setNullGenerator = scope -> {
            Variable thisVariable = scope.getThis();
            BytecodeBlock bytecodeBlock = new BytecodeBlock();
            nullField.ifPresent(field -> bytecodeBlock.append(thisVariable.getField(field).invoke("set", void.class, thisVariable.getField(groupIdField), constantTrue())));
            bytecodeBlock.append(thisVariable.getField(valueField).invoke("set", void.class, thisVariable.getField(groupIdField), defaultValue(valueElementType)));
            return bytecodeBlock;
        };
        BiFunction setValueGenerator = (scope, value) -> {
            Variable thisVariable = scope.getThis();
            BytecodeBlock bytecodeBlock = new BytecodeBlock();
            nullField.ifPresent(field -> bytecodeBlock.append(thisVariable.getField(field).invoke("set", void.class, thisVariable.getField(groupIdField), constantFalse())));
            bytecodeBlock.append(thisVariable.getField(valueField).invoke("set", void.class, thisVariable.getField(groupIdField), value.cast(valueElementType)));
            return bytecodeBlock;
        };

        generateInOutMethods(type, definition, valueGetter, nullGetter, setNullGenerator, setValueGenerator, callSiteBinder);

        return definition;
    }

    private static void generateInOutMethods(Type type,
            ClassDefinition definition,
            Function valueGetter,
            Function nullGetter,
            Function setNullGenerator,
            BiFunction setValueGenerator,
            CallSiteBinder callSiteBinder)
    {
        SqlTypeBytecodeExpression sqlType = constantType(callSiteBinder, type);

        generateInOutGetType(definition, sqlType);
        generateInOutIsNull(definition, nullGetter);
        generateInOutGetBlockBuilder(definition, sqlType, valueGetter);
        generateInOutSetBlockPosition(definition, sqlType, setNullGenerator, setValueGenerator);
        generateInOutSetInOut(definition, type, setNullGenerator, setValueGenerator);
        generateInOutGetValue(definition, type, valueGetter);
    }

    private static void estimatedSize(ClassDefinition definition)
    {
        FieldDefinition instanceSize = generateInstanceSize(definition);

        // Add getter for class size
        definition.declareMethod(a(PUBLIC), "getEstimatedSize", type(long.class))
                .getBody()
                .getStaticField(instanceSize)
                .retLong();
    }

    private static void inOutSingleCopy(ClassDefinition definition, FieldDefinition valueField, Optional nullField)
    {
        MethodDefinition copy = definition.declareMethod(a(PUBLIC), "copy", type(AccumulatorState.class));
        Variable thisVariable = copy.getThis();
        BytecodeBlock body = copy.getBody();

        Variable copyVariable = copy.getScope().declareVariable(definition.getType(), "copy");
        body.append(copyVariable.set(newInstance(definition.getType())));
        body.append(copyVariable.setField(valueField, thisVariable.getField(valueField)));
        nullField.ifPresent(field -> body.append(copyVariable.setField(field, thisVariable.getField(field))));
        body.append(copyVariable.ret());
    }

    private static void inOutGroupedSetGroupId(ClassDefinition definition, FieldDefinition groupIdField)
    {
        Parameter groupIdArg = arg("groupId", long.class);
        MethodDefinition method = definition.declareMethod(a(PUBLIC), "setGroupId", type(void.class), groupIdArg);
        method.getBody()
                .append(method.getThis().setField(groupIdField, groupIdArg))
                .ret();
    }

    private static void inOutGroupedEnsureCapacity(ClassDefinition definition, FieldDefinition valueField, Optional nullField)
    {
        Parameter size = arg("size", long.class);
        MethodDefinition method = definition.declareMethod(a(PUBLIC), "ensureCapacity", type(void.class), size);
        Variable thisVariable = method.getThis();
        BytecodeBlock body = method.getBody();

        body.append(thisVariable.getField(valueField).invoke("ensureCapacity", void.class, size));
        nullField.ifPresent(field -> body.append(thisVariable.getField(field).invoke("ensureCapacity", void.class, size)));
        body.ret();
    }

    private static void inOutGroupedCopy(ClassDefinition definition, FieldDefinition valueField, Optional nullField)
    {
        MethodDefinition copy = definition.declareMethod(a(PUBLIC), "copy", type(AccumulatorState.class));
        Variable thisVariable = copy.getThis();
        BytecodeBlock body = copy.getBody();

        Variable copyVariable = copy.getScope().declareVariable(definition.getType(), "copy");
        body.append(copyVariable.set(newInstance(definition.getType())));
        copyBigArray(body, thisVariable, copyVariable, valueField);
        nullField.ifPresent(field -> copyBigArray(body, thisVariable, copyVariable, field));
        body.append(copyVariable.ret());
    }

    private static void copyBigArray(BytecodeBlock body, Variable source, Variable destination, FieldDefinition bigArrayField)
    {
        body.append(destination.getField(bigArrayField).invoke("ensureCapacity", void.class, source.getField(bigArrayField).invoke("getCapacity", long.class)));
        body.append(source.getField(bigArrayField).invoke(
                "copyTo",
                void.class,
                constantLong(0),
                destination.getField(bigArrayField),
                constantLong(0),
                source.getField(bigArrayField).invoke("getCapacity", long.class)));
    }

    private static void generateInOutGetType(ClassDefinition definition, SqlTypeBytecodeExpression sqlType)
    {
        definition.declareMethod(a(PUBLIC), "getType", type(Type.class))
                .getBody()
                .append(sqlType.ret());
    }

    private static void generateInOutIsNull(ClassDefinition definition, Function nullGetter)
    {
        MethodDefinition isNullMethod = definition.declareMethod(a(PUBLIC), "isNull", type(boolean.class));
        isNullMethod.getBody().append(nullGetter.apply(isNullMethod.getScope()).ret());
    }

    private static void generateInOutGetBlockBuilder(ClassDefinition definition, SqlTypeBytecodeExpression sqlType, Function valueGetter)
    {
        Parameter blockBuilderArg = arg("blockBuilder", BlockBuilder.class);
        MethodDefinition getBlockBuilderMethod = definition.declareMethod(a(PUBLIC), "get", type(void.class), blockBuilderArg);
        Variable thisVariable = getBlockBuilderMethod.getThis();
        BytecodeBlock body = getBlockBuilderMethod.getBody();

        body.append(new IfStatement()
                .condition(thisVariable.invoke("isNull", boolean.class))
                .ifTrue(blockBuilderArg.invoke("appendNull", BlockBuilder.class).pop())
                .ifFalse(sqlType.writeValue(blockBuilderArg, valueGetter.apply(getBlockBuilderMethod.getScope()))));
        body.ret();
    }

    private static void generateInOutSetBlockPosition(
            ClassDefinition definition,
            SqlTypeBytecodeExpression sqlType,
            Function setNullGenerator,
            BiFunction setValueGenerator)
    {
        Parameter blockArg = arg("block", Block.class);
        Parameter positionArg = arg("position", int.class);
        MethodDefinition setBlockBuilderMethod = definition.declareMethod(a(PUBLIC), "set", type(void.class), blockArg, positionArg);
        BytecodeBlock body = setBlockBuilderMethod.getBody();

        body.append(new IfStatement()
                .condition(blockArg.invoke("isNull", boolean.class, positionArg))
                .ifTrue(setNullGenerator.apply(setBlockBuilderMethod.getScope()))
                .ifFalse(setValueGenerator.apply(setBlockBuilderMethod.getScope(), sqlType.getValue(blockArg, positionArg))));
        body.ret();
    }

    private static void generateInOutSetInOut(
            ClassDefinition definition,
            Type type,
            Function setNullGenerator,
            BiFunction setValueGenerator)
    {
        Parameter otherState = arg("otherState", InOut.class);
        MethodDefinition setter = definition.declareMethod(a(PUBLIC), "set", type(void.class), otherState);
        BytecodeBlock body = setter.getBody();

        body.append(new IfStatement()
                .condition(otherState.invoke("isNull", boolean.class))
                .ifTrue(setNullGenerator.apply(setter.getScope()))
                .ifFalse(setValueGenerator.apply(setter.getScope(), otherState.cast(InternalDataAccessor.class).invoke(inOutGetterName(type), inOutGetterReturnType(type)))));
        body.ret();
    }

    private static void generateInOutGetValue(ClassDefinition definition, Type type, Function valueGetter)
    {
        MethodDefinition getter = definition.declareMethod(a(PUBLIC), inOutGetterName(type), type(inOutGetterReturnType(type)));
        getter.getBody().append(valueGetter.apply(getter.getScope()).ret());
    }

    private static Class inOutGetterReturnType(Type type)
    {
        Class javaType = type.getJavaType();
        if (javaType.equals(boolean.class)) {
            return boolean.class;
        }
        if (javaType.equals(long.class)) {
            return long.class;
        }
        if (javaType.equals(double.class)) {
            return double.class;
        }
        return Object.class;
    }

    private static String inOutGetterName(Type type)
    {
        Class javaType = type.getJavaType();
        if (javaType.equals(boolean.class)) {
            return "getBooleanValue";
        }
        if (javaType.equals(long.class)) {
            return "getLongValue";
        }
        if (javaType.equals(double.class)) {
            return "getDoubleValue";
        }
        return "getObjectValue";
    }

    public static  AccumulatorStateFactory generateStateFactory(Class clazz)
    {
        return generateStateFactory(clazz, ImmutableMap.of());
    }

    @VisibleForTesting
    static  AccumulatorStateFactory generateStateFactory(Class clazz, Map fieldTypes)
    {
        AccumulatorStateMetadata metadata = getMetadataAnnotation(clazz);
        if (metadata != null && metadata.stateFactoryClass() != AccumulatorStateFactory.class) {
            try {
                //noinspection unchecked
                return (AccumulatorStateFactory) metadata.stateFactoryClass().getConstructor().newInstance();
            }
            catch (InstantiationException | IllegalAccessException | NoSuchMethodException | InvocationTargetException e) {
                throw new RuntimeException(e);
            }
        }

        // grouped aggregation state fields use engine classes, so generated class must be able to see both plugin and system classes
        DynamicClassLoader classLoader = new DynamicClassLoader(clazz.getClassLoader(), StateCompiler.class.getClassLoader());
        Class singleStateClass = generateSingleStateClass(clazz, fieldTypes, classLoader);
        Class groupedStateClass = generateGroupedStateClass(clazz, fieldTypes, classLoader);

        return generateStateFactory(clazz, singleStateClass, groupedStateClass, classLoader);
    }

    private static  AccumulatorStateFactory generateStateFactory(
            Class clazz,
            Class singleStateClass,
            Class groupedStateClass,
            DynamicClassLoader classLoader)
    {
        ClassDefinition definition = new ClassDefinition(
                a(PUBLIC, FINAL),
                makeClassName(clazz.getSimpleName() + "Factory"),
                type(Object.class),
                type(AccumulatorStateFactory.class));

        // Generate constructor
        definition.declareDefaultConstructor(a(PUBLIC));

        // Generate single state creation method
        definition.declareMethod(a(PUBLIC), "createSingleState", type(AccumulatorState.class))
                .getBody()
                .newObject(singleStateClass)
                .dup()
                .invokeConstructor(singleStateClass)
                .retObject();

        // Generate grouped state creation method
        definition.declareMethod(a(PUBLIC), "createGroupedState", type(AccumulatorState.class))
                .getBody()
                .newObject(groupedStateClass)
                .dup()
                .invokeConstructor(groupedStateClass)
                .retObject();

        Class factoryClass = defineClass(definition, AccumulatorStateFactory.class, classLoader);
        try {
            //noinspection unchecked
            return (AccumulatorStateFactory) factoryClass.getConstructor().newInstance();
        }
        catch (ReflectiveOperationException e) {
            throw new RuntimeException(e);
        }
    }

    private static  Class generateSingleStateClass(Class clazz, Map fieldTypes, DynamicClassLoader classLoader)
    {
        ClassDefinition definition = new ClassDefinition(
                a(PUBLIC, FINAL),
                makeClassName("Single" + clazz.getSimpleName()),
                type(Object.class),
                type(clazz));

        FieldDefinition instanceSize = generateInstanceSize(definition);

        // Add getter for class size
        definition.declareMethod(a(PUBLIC), "getEstimatedSize", type(long.class))
                .getBody()
                .getStaticField(instanceSize)
                .retLong();

        // Generate constructor
        MethodDefinition constructor = definition.declareConstructor(a(PUBLIC));

        constructor.getBody()
                .append(constructor.getThis())
                .invokeConstructor(Object.class);

        // Generate fields
        List fields = enumerateFields(clazz, fieldTypes);
        List fieldDefinitions = new ArrayList<>();
        for (StateField field : fields) {
            fieldDefinitions.add(generateField(definition, constructor, field));
        }

        constructor.getBody()
                .ret();

        generateCopy(definition, fields, fieldDefinitions);

        return defineClass(definition, clazz, classLoader);
    }

    private static void generateCopy(ClassDefinition definition, List fields, List fieldDefinitions)
    {
        MethodDefinition copy = definition.declareMethod(a(PUBLIC), "copy", type(AccumulatorState.class));
        Variable thisVariable = copy.getThis();
        BytecodeBlock body = copy.getBody();

        List fieldCopyExpressions = new ArrayList<>();
        for (int i = 0; i < fields.size(); i++) {
            Optional fieldCopy = copyField(thisVariable, fieldDefinitions.get(i), fields.get(i).getType());
            if (fieldCopy.isEmpty()) {
                body
                        .append(newInstance(UnsupportedOperationException.class, constantString(format("copy not supported for %s (cannot copy field of type %s)", definition.getName(), fields.get(i).getType()))))
                        .throwObject();

                return;
            }

            fieldCopyExpressions.add(fieldCopy.get());
        }

        Variable instanceCopy = copy.getScope().declareVariable(definition.getType(), "instanceCopy");
        body.append(instanceCopy.set(newInstance(definition.getType())));

        for (int i = 0; i < fieldDefinitions.size(); i++) {
            FieldDefinition fieldDefinition = fieldDefinitions.get(i);
            Class type = fields.get(i).getType();

            if (type == long.class || type == double.class || type == boolean.class || type == byte.class || type == int.class) {
                body.append(instanceCopy.setField(fieldDefinition, fieldCopyExpressions.get(i)));
            }
            else {
                body.append(new IfStatement("if field value is null")
                        .condition(isNull(thisVariable.getField(fieldDefinition)))
                        .ifTrue(instanceCopy.setField(fieldDefinition, thisVariable.getField(fieldDefinition)))
                        .ifFalse(instanceCopy.setField(fieldDefinition, fieldCopyExpressions.get(i))));
            }
        }
        copy.getBody()
                .append(instanceCopy.ret());
    }

    private static Optional copyField(Variable thisVariable, FieldDefinition fieldDefinition, Class type)
    {
        if (type == long.class || type == double.class || type == boolean.class || type == byte.class || type == int.class) {
            return Optional.of(thisVariable.getField(fieldDefinition));
        }

        if (type == Block.class) {
            return Optional.of(thisVariable.getField(fieldDefinition).invoke("copyRegion", Block.class, constantInt(0), thisVariable.getField(fieldDefinition).invoke("getPositionCount", int.class)));
        }

        return Optional.empty();
    }

    private static FieldDefinition generateInstanceSize(ClassDefinition definition)
    {
        // Store instance size in static field
        FieldDefinition instanceSize = definition.declareField(a(PRIVATE, STATIC, FINAL), "INSTANCE_SIZE", long.class);
        definition.getClassInitializer()
                .getBody()
                .append(setStatic(instanceSize, invokeStatic(SizeOf.class, "instanceSize", int.class, constantClass(definition.getType())).cast(long.class)));
        return instanceSize;
    }

    private static  Class generateGroupedStateClass(Class clazz, Map fieldTypes, DynamicClassLoader classLoader)
    {
        ClassDefinition definition = new ClassDefinition(
                a(PUBLIC, FINAL),
                makeClassName("Grouped" + clazz.getSimpleName()),
                type(AbstractGroupedAccumulatorState.class),
                type(clazz));

        FieldDefinition instanceSize = generateInstanceSize(definition);

        List fields = enumerateFields(clazz, fieldTypes);

        // Create constructor
        MethodDefinition constructor = definition.declareConstructor(a(PUBLIC));
        constructor.getBody()
                .append(constructor.getThis())
                .invokeConstructor(AbstractGroupedAccumulatorState.class);

        // Create ensureCapacity
        MethodDefinition ensureCapacity = definition.declareMethod(a(PUBLIC), "ensureCapacity", type(void.class), arg("size", long.class));

        // Generate fields, constructor, and ensureCapacity
        List fieldDefinitions = new ArrayList<>();
        for (StateField field : fields) {
            fieldDefinitions.add(generateGroupedField(definition, constructor, ensureCapacity, field));
        }

        constructor.getBody().ret();
        ensureCapacity.getBody().ret();

        // Generate getEstimatedSize
        MethodDefinition getEstimatedSize = definition.declareMethod(a(PUBLIC), "getEstimatedSize", type(long.class));
        BytecodeBlock body = getEstimatedSize.getBody();

        Variable size = getEstimatedSize.getScope().declareVariable(long.class, "size");

        // initialize size to the size of the instance
        body.append(size.set(getStatic(instanceSize)));

        // add field to size
        for (FieldDefinition field : fieldDefinitions) {
            body.append(size.set(add(size, getEstimatedSize.getThis().getField(field).invoke("sizeOf", long.class))));
        }

        // return size
        body.append(size.ret());

        return defineClass(definition, clazz, classLoader);
    }

    private static FieldDefinition generateField(ClassDefinition definition, MethodDefinition constructor, StateField stateField)
    {
        FieldDefinition field = definition.declareField(a(PRIVATE), UPPER_CAMEL.to(LOWER_CAMEL, stateField.getName()) + "Value", stateField.getType());

        // Generate getter
        MethodDefinition getter = definition.declareMethod(a(PUBLIC), stateField.getGetterName(), type(stateField.getType()));
        getter.getBody()
                .append(getter.getThis().getField(field).ret());

        // Generate setter
        Parameter value = arg("value", stateField.getType());
        MethodDefinition setter = definition.declareMethod(a(PUBLIC), stateField.getSetterName(), type(void.class), value);
        setter.getBody()
                .append(setter.getThis().setField(field, value))
                .ret();

        constructor.getBody()
                .append(constructor.getThis().setField(field, stateField.initialValueExpression()));

        return field;
    }

    private static FieldDefinition generateGroupedField(ClassDefinition definition, MethodDefinition constructor, MethodDefinition ensureCapacity, StateField stateField)
    {
        Class bigArrayType = getBigArrayType(stateField.getType());
        FieldDefinition field = definition.declareField(a(PRIVATE), UPPER_CAMEL.to(LOWER_CAMEL, stateField.getName()) + "Values", bigArrayType);

        // Generate getter
        MethodDefinition getter = definition.declareMethod(a(PUBLIC), stateField.getGetterName(), type(stateField.getType()));
        getter.getBody()
                .append(getter.getThis().getField(field).invoke(
                        "get",
                        stateField.getType(),
                        getter.getThis().invoke("getGroupId", long.class))
                        .ret());

        // Generate setter
        Parameter value = arg("value", stateField.getType());
        MethodDefinition setter = definition.declareMethod(a(PUBLIC), stateField.getSetterName(), type(void.class), value);
        setter.getBody()
                .append(setter.getThis().getField(field).invoke(
                        "set",
                        void.class,
                        setter.getThis().invoke("getGroupId", long.class),
                        value))
                .ret();

        Scope ensureCapacityScope = ensureCapacity.getScope();
        ensureCapacity.getBody()
                .append(ensureCapacity.getThis().getField(field).invoke("ensureCapacity", void.class, ensureCapacityScope.getVariable("size")));

        // Initialize field in constructor
        constructor.getBody()
                .append(constructor.getThis().setField(field, newInstance(field.getType(), stateField.initialValueExpression())));

        return field;
    }

    /**
     * Enumerates all the fields in this state interface.
     *
     * @param clazz a subclass of AccumulatorState
     * @param fieldTypes a map of field name and Type
     * @return list of state fields. Ordering is guaranteed to be stable, and have all primitive fields at the beginning.
     */
    private static List enumerateFields(Class clazz, Map fieldTypes)
    {
        ImmutableList.Builder builder = ImmutableList.builder();
        for (Method method : clazz.getMethods()) {
            // ignore default methods
            if (method.isDefault() || method.getName().equals("getEstimatedSize")) {
                continue;
            }
            if (method.getName().startsWith("get")) {
                Class type = method.getReturnType();
                String name = method.getName().substring(3);
                builder.add(new StateField(name, type, getInitialValue(method), method.getName(), Optional.ofNullable(fieldTypes.get(name))));
            }
            if (method.getName().startsWith("is")) {
                Class type = method.getReturnType();
                checkArgument(type == boolean.class, "Only boolean is support for 'is' methods");
                String name = method.getName().substring(2);
                builder.add(new StateField(name, type, getInitialValue(method), method.getName(), Optional.of(BOOLEAN)));
            }
        }

        // We need this ordering because the serializer and deserializer are on different machines, and so the ordering of fields must be stable
        // NOTE min_max_by depends on this exact ordering, so any changes here will break it
        // TODO remove this when transition from state classes to multiple intermediates is complete
        Ordering ordering = new Ordering<>()
        {
            @Override
            public int compare(StateField left, StateField right)
            {
                return left.getName().compareTo(right.getName());
            }
        };
        List fields = ordering.sortedCopy(builder.build());
        checkInterface(clazz, fields);

        return fields;
    }

    private static Object getInitialValue(Method method)
    {
        Object value = null;

        for (Annotation annotation : method.getAnnotations()) {
            if (annotation instanceof InitialLongValue) {
                checkArgument(value == null, "%s has multiple initialValue annotations", method.getName());
                checkArgument(method.getReturnType() == long.class, "%s does not return a long, but is annotated with @InitialLongValue", method.getName());
                value = ((InitialLongValue) annotation).value();
            }
            else if (annotation instanceof InitialDoubleValue) {
                checkArgument(value == null, "%s has multiple initialValue annotations", method.getName());
                checkArgument(method.getReturnType() == double.class, "%s does not return a double, but is annotated with @InitialDoubleValue", method.getName());
                value = ((InitialDoubleValue) annotation).value();
            }
            else if (annotation instanceof InitialBooleanValue) {
                checkArgument(value == null, "%s has multiple initialValue annotations", method.getName());
                checkArgument(method.getReturnType() == boolean.class, "%s does not return a boolean, but is annotated with @InitialBooleanValue", method.getName());
                value = ((InitialBooleanValue) annotation).value();
            }
        }

        return value;
    }

    private static void checkInterface(Class clazz, List fields)
    {
        checkArgument(clazz.isInterface(), clazz.getName() + " is not an interface");
        Set setters = new HashSet<>();
        Set getters = new HashSet<>();
        Set isGetters = new HashSet<>();

        Map> fieldTypes = new HashMap<>();
        for (StateField field : fields) {
            fieldTypes.put(field.getName(), field.getType());
        }

        for (Method method : clazz.getMethods()) {
            // ignore static and default methods
            if (Modifier.isStatic(method.getModifiers()) || method.isDefault()) {
                continue;
            }

            if (method.getName().equals("copy")) {
                checkArgument(method.getParameterTypes().length == 0, "copy may not have parameters");
                continue;
            }

            if (method.getName().equals("getEstimatedSize")) {
                checkArgument(method.getReturnType().equals(long.class), "getEstimatedSize must return long");
                checkArgument(method.getParameterTypes().length == 0, "getEstimatedSize may not have parameters");
                continue;
            }

            if (method.getName().startsWith("get")) {
                String name = method.getName().substring(3);
                checkArgument(fieldTypes.get(name).equals(method.getReturnType()),
                        "Expected %s to return type %s, but found %s", method.getName(), fieldTypes.get(name), method.getReturnType());
                checkArgument(method.getParameterTypes().length == 0, "Expected %s to have zero parameters", method.getName());
                getters.add(name);
            }
            else if (method.getName().startsWith("is")) {
                String name = method.getName().substring(2);
                checkArgument(fieldTypes.get(name) == boolean.class,
                        "Expected %s to have type boolean, but found %s", name, fieldTypes.get(name));
                checkArgument(method.getParameterTypes().length == 0, "Expected %s to have zero parameters", method.getName());
                checkArgument(method.getReturnType() == boolean.class, "Expected %s to return boolean", method.getName());
                isGetters.add(name);
            }
            else if (method.getName().startsWith("set")) {
                String name = method.getName().substring(3);
                checkArgument(method.getParameterTypes().length == 1, "Expected setter to have one parameter");
                checkArgument(fieldTypes.get(name).equals(method.getParameterTypes()[0]),
                        "Expected %s to accept type %s, but found %s", method.getName(), fieldTypes.get(name), method.getParameterTypes()[0]);
                checkArgument(getInitialValue(method) == null, "initial value annotation not allowed on setter");
                checkArgument(method.getReturnType().equals(void.class), "%s may not return a value", method.getName());
                setters.add(name);
            }
            else {
                throw new IllegalArgumentException("Cannot generate implementation for method: " + method.getName());
            }
        }
        checkArgument(getters.size() + isGetters.size() == setters.size() && setters.size() == fields.size(), "Wrong number of getters/setters");
    }

    private static final class StateField
    {
        private final String name;
        private final String getterName;
        private final Class type;
        private final Object initialValue;
        private final Optional sqlType;

        private StateField(String name, Class type, Object initialValue, String getterName, Optional sqlType)
        {
            this.name = requireNonNull(name, "name is null");
            checkArgument(!name.isEmpty(), "name is empty");
            this.type = requireNonNull(type, "type is null");
            this.getterName = requireNonNull(getterName, "getterName is null");
            this.initialValue = initialValue;
            requireNonNull(sqlType, "sqlType is null");
            if (sqlType.isPresent()) {
                checkArgument(
                        type.isAssignableFrom(sqlType.get().getJavaType()) ||
                                ((type == byte.class) && TINYINT.equals(sqlType.get())) ||
                                ((type == int.class) && INTEGER.equals(sqlType.get())),
                        "Stack type (%s) and provided sql type (%s) are incompatible", type.getName(), sqlType.get().getDisplayName());
            }
            else {
                sqlType = sqlTypeFromStackType(type);
            }
            this.sqlType = sqlType;
        }

        private static Optional sqlTypeFromStackType(Class stackType)
        {
            if (stackType == long.class) {
                return Optional.of(BIGINT);
            }
            if (stackType == double.class) {
                return Optional.of(DOUBLE);
            }
            if (stackType == boolean.class) {
                return Optional.of(BOOLEAN);
            }
            if (stackType == byte.class) {
                return Optional.of(TINYINT);
            }
            if (stackType == int.class) {
                return Optional.of(INTEGER);
            }
            if (stackType == Slice.class) {
                return Optional.of(VARBINARY);
            }
            return Optional.empty();
        }

        String getGetterName()
        {
            return getterName;
        }

        String getSetterName()
        {
            return "set" + getName();
        }

        public String getName()
        {
            return name;
        }

        public Class getType()
        {
            return type;
        }

        Type getSqlType()
        {
            return sqlType.orElseThrow(() -> new IllegalArgumentException("Unsupported type: " + type));
        }

        boolean isPrimitiveType()
        {
            Class type = getType();
            return (type == long.class || type == double.class || type == boolean.class || type == byte.class || type == int.class);
        }

        public BytecodeExpression initialValueExpression()
        {
            if (initialValue == null) {
                return defaultValue(type);
            }
            if (initialValue instanceof Number) {
                return constantNumber((Number) initialValue);
            }
            if (initialValue instanceof Boolean) {
                return constantBoolean((boolean) initialValue);
            }
            throw new IllegalArgumentException("Unsupported initial value type: " + initialValue.getClass());
        }
    }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy