Search in sources :

Example 1 with Function0

use of org.apache.calcite.linq4j.function.Function0 in project calcite by apache.

the class ResultSetEnumerable method primitiveRowBuilderFactory.

private static Function1<ResultSet, Function0<Object>> primitiveRowBuilderFactory(final Primitive[] primitives) {
    return new Function1<ResultSet, Function0<Object>>() {

        public Function0<Object> apply(final ResultSet resultSet) {
            final ResultSetMetaData metaData;
            final int columnCount;
            try {
                metaData = resultSet.getMetaData();
                columnCount = metaData.getColumnCount();
            } catch (SQLException e) {
                throw new RuntimeException(e);
            }
            assert columnCount == primitives.length;
            if (columnCount == 1) {
                return new Function0<Object>() {

                    public Object apply() {
                        try {
                            return resultSet.getObject(1);
                        } catch (SQLException e) {
                            throw new RuntimeException(e);
                        }
                    }
                };
            }
            // noinspection unchecked
            return (Function0) new Function0<Object[]>() {

                public Object[] apply() {
                    try {
                        final List<Object> list = new ArrayList<Object>();
                        for (int i = 0; i < columnCount; i++) {
                            list.add(primitives[i].jdbcGet(resultSet, i + 1));
                        }
                        return list.toArray();
                    } catch (SQLException e) {
                        throw new RuntimeException(e);
                    }
                }
            };
        }
    };
}
Also used : ResultSetMetaData(java.sql.ResultSetMetaData) SQLException(java.sql.SQLException) Function1(org.apache.calcite.linq4j.function.Function1) ResultSet(java.sql.ResultSet) Function0(org.apache.calcite.linq4j.function.Function0) ArrayList(java.util.ArrayList) List(java.util.List)

Example 2 with Function0

use of org.apache.calcite.linq4j.function.Function0 in project calcite by apache.

the class EnumerableAggregate method implement.

public Result implement(EnumerableRelImplementor implementor, Prefer pref) {
    final JavaTypeFactory typeFactory = implementor.getTypeFactory();
    final BlockBuilder builder = new BlockBuilder();
    final EnumerableRel child = (EnumerableRel) getInput();
    final Result result = implementor.visitChild(this, 0, child, pref);
    Expression childExp = builder.append("child", result.block);
    final PhysType physType = PhysTypeImpl.of(typeFactory, getRowType(), pref.preferCustom());
    // final Enumerable<Employee> child = <<child adapter>>;
    // Function1<Employee, Integer> keySelector =
    // new Function1<Employee, Integer>() {
    // public Integer apply(Employee a0) {
    // return a0.deptno;
    // }
    // };
    // Function1<Employee, Object[]> accumulatorInitializer =
    // new Function1<Employee, Object[]>() {
    // public Object[] apply(Employee a0) {
    // return new Object[] {0, 0};
    // }
    // };
    // Function2<Object[], Employee, Object[]> accumulatorAdder =
    // new Function2<Object[], Employee, Object[]>() {
    // public Object[] apply(Object[] a1, Employee a0) {
    // a1[0] = ((Integer) a1[0]) + 1;
    // a1[1] = ((Integer) a1[1]) + a0.salary;
    // return a1;
    // }
    // };
    // Function2<Integer, Object[], Object[]> resultSelector =
    // new Function2<Integer, Object[], Object[]>() {
    // public Object[] apply(Integer a0, Object[] a1) {
    // return new Object[] { a0, a1[0], a1[1] };
    // }
    // };
    // return childEnumerable
    // .groupBy(
    // keySelector, accumulatorInitializer, accumulatorAdder,
    // resultSelector);
    // 
    // or, if key has 0 columns,
    // 
    // return childEnumerable
    // .aggregate(
    // accumulatorInitializer.apply(),
    // accumulatorAdder,
    // resultSelector);
    // 
    // with a slightly different resultSelector; or if there are no aggregate
    // functions
    // 
    // final Enumerable<Employee> child = <<child adapter>>;
    // Function1<Employee, Integer> keySelector =
    // new Function1<Employee, Integer>() {
    // public Integer apply(Employee a0) {
    // return a0.deptno;
    // }
    // };
    // EqualityComparer<Employee> equalityComparer =
    // new EqualityComparer<Employee>() {
    // boolean equal(Employee a0, Employee a1) {
    // return a0.deptno;
    // }
    // };
    // return child
    // .distinct(equalityComparer);
    final PhysType inputPhysType = result.physType;
    ParameterExpression parameter = Expressions.parameter(inputPhysType.getJavaRowType(), "a0");
    final PhysType keyPhysType = inputPhysType.project(groupSet.asList(), getGroupType() != Group.SIMPLE, JavaRowFormat.LIST);
    final int groupCount = getGroupCount();
    final List<AggImpState> aggs = new ArrayList<>(aggCalls.size());
    for (Ord<AggregateCall> call : Ord.zip(aggCalls)) {
        aggs.add(new AggImpState(call.i, call.e, false));
    }
    // Function0<Object[]> accumulatorInitializer =
    // new Function0<Object[]>() {
    // public Object[] apply() {
    // return new Object[] {0, 0};
    // }
    // };
    final List<Expression> initExpressions = new ArrayList<>();
    final BlockBuilder initBlock = new BlockBuilder();
    final List<Type> aggStateTypes = new ArrayList<>();
    for (final AggImpState agg : aggs) {
        agg.context = new AggContextImpl(agg, typeFactory);
        final List<Type> state = agg.implementor.getStateType(agg.context);
        if (state.isEmpty()) {
            agg.state = ImmutableList.of();
            continue;
        }
        aggStateTypes.addAll(state);
        final List<Expression> decls = new ArrayList<>(state.size());
        for (int i = 0; i < state.size(); i++) {
            String aggName = "a" + agg.aggIdx;
            if (CalcitePrepareImpl.DEBUG) {
                aggName = Util.toJavaId(agg.call.getAggregation().getName(), 0).substring("ID$0$".length()) + aggName;
            }
            Type type = state.get(i);
            ParameterExpression pe = Expressions.parameter(type, initBlock.newName(aggName + "s" + i));
            initBlock.add(Expressions.declare(0, pe, null));
            decls.add(pe);
        }
        agg.state = decls;
        initExpressions.addAll(decls);
        agg.implementor.implementReset(agg.context, new AggResultContextImpl(initBlock, agg.call, decls, null, null));
    }
    final PhysType accPhysType = PhysTypeImpl.of(typeFactory, typeFactory.createSyntheticType(aggStateTypes));
    if (accPhysType.getJavaRowType() instanceof JavaTypeFactoryImpl.SyntheticRecordType) {
        // We have to initialize the SyntheticRecordType instance this way, to avoid using
        // class constructor with too many parameters.
        JavaTypeFactoryImpl.SyntheticRecordType synType = (JavaTypeFactoryImpl.SyntheticRecordType) accPhysType.getJavaRowType();
        final ParameterExpression record0_ = Expressions.parameter(accPhysType.getJavaRowType(), "record0");
        initBlock.add(Expressions.declare(0, record0_, null));
        initBlock.add(Expressions.statement(Expressions.assign(record0_, Expressions.new_(accPhysType.getJavaRowType()))));
        List<Types.RecordField> fieldList = synType.getRecordFields();
        for (int i = 0; i < initExpressions.size(); i++) {
            Expression right = initExpressions.get(i);
            initBlock.add(Expressions.statement(Expressions.assign(Expressions.field(record0_, fieldList.get(i)), right)));
        }
        initBlock.add(record0_);
    } else {
        initBlock.add(accPhysType.record(initExpressions));
    }
    final Expression accumulatorInitializer = builder.append("accumulatorInitializer", Expressions.lambda(Function0.class, initBlock.toBlock()));
    // Function2<Object[], Employee, Object[]> accumulatorAdder =
    // new Function2<Object[], Employee, Object[]>() {
    // public Object[] apply(Object[] acc, Employee in) {
    // acc[0] = ((Integer) acc[0]) + 1;
    // acc[1] = ((Integer) acc[1]) + in.salary;
    // return acc;
    // }
    // };
    final BlockBuilder builder2 = new BlockBuilder();
    final ParameterExpression inParameter = Expressions.parameter(inputPhysType.getJavaRowType(), "in");
    final ParameterExpression acc_ = Expressions.parameter(accPhysType.getJavaRowType(), "acc");
    for (int i = 0, stateOffset = 0; i < aggs.size(); i++) {
        final AggImpState agg = aggs.get(i);
        final int stateSize = agg.state.size();
        final List<Expression> accumulator = new ArrayList<>(stateSize);
        for (int j = 0; j < stateSize; j++) {
            accumulator.add(accPhysType.fieldReference(acc_, j + stateOffset));
        }
        agg.state = accumulator;
        stateOffset += stateSize;
        AggAddContext addContext = new AggAddContextImpl(builder2, accumulator) {

            public List<RexNode> rexArguments() {
                List<RelDataTypeField> inputTypes = inputPhysType.getRowType().getFieldList();
                List<RexNode> args = new ArrayList<>();
                for (int index : agg.call.getArgList()) {
                    args.add(RexInputRef.of(index, inputTypes));
                }
                return args;
            }

            public RexNode rexFilterArgument() {
                return agg.call.filterArg < 0 ? null : RexInputRef.of(agg.call.filterArg, inputPhysType.getRowType());
            }

            public RexToLixTranslator rowTranslator() {
                return RexToLixTranslator.forAggregation(typeFactory, currentBlock(), new RexToLixTranslator.InputGetterImpl(Collections.singletonList(Pair.of((Expression) inParameter, inputPhysType)))).setNullable(currentNullables());
            }
        };
        agg.implementor.implementAdd(agg.context, addContext);
    }
    builder2.add(acc_);
    final Expression accumulatorAdder = builder.append("accumulatorAdder", Expressions.lambda(Function2.class, builder2.toBlock(), acc_, inParameter));
    // Function2<Integer, Object[], Object[]> resultSelector =
    // new Function2<Integer, Object[], Object[]>() {
    // public Object[] apply(Integer key, Object[] acc) {
    // return new Object[] { key, acc[0], acc[1] };
    // }
    // };
    final BlockBuilder resultBlock = new BlockBuilder();
    final List<Expression> results = Expressions.list();
    final ParameterExpression key_;
    if (groupCount == 0) {
        key_ = null;
    } else {
        final Type keyType = keyPhysType.getJavaRowType();
        key_ = Expressions.parameter(keyType, "key");
        for (int j = 0; j < groupCount; j++) {
            final Expression ref = keyPhysType.fieldReference(key_, j);
            if (getGroupType() == Group.SIMPLE) {
                results.add(ref);
            } else {
                results.add(Expressions.condition(keyPhysType.fieldReference(key_, groupCount + j), Expressions.constant(null), Expressions.box(ref)));
            }
        }
    }
    for (final AggImpState agg : aggs) {
        results.add(agg.implementor.implementResult(agg.context, new AggResultContextImpl(resultBlock, agg.call, agg.state, key_, keyPhysType)));
    }
    resultBlock.add(physType.record(results));
    if (getGroupType() != Group.SIMPLE) {
        final List<Expression> list = Lists.newArrayList();
        for (ImmutableBitSet set : groupSets) {
            list.add(inputPhysType.generateSelector(parameter, groupSet.asList(), set.asList(), keyPhysType.getFormat()));
        }
        final Expression keySelectors_ = builder.append("keySelectors", Expressions.call(BuiltInMethod.ARRAYS_AS_LIST.method, list));
        final Expression resultSelector = builder.append("resultSelector", Expressions.lambda(Function2.class, resultBlock.toBlock(), key_, acc_));
        builder.add(Expressions.return_(null, Expressions.call(BuiltInMethod.GROUP_BY_MULTIPLE.method, Expressions.list(childExp, keySelectors_, accumulatorInitializer, accumulatorAdder, resultSelector).appendIfNotNull(keyPhysType.comparer()))));
    } else if (groupCount == 0) {
        final Expression resultSelector = builder.append("resultSelector", Expressions.lambda(Function1.class, resultBlock.toBlock(), acc_));
        builder.add(Expressions.return_(null, Expressions.call(BuiltInMethod.SINGLETON_ENUMERABLE.method, Expressions.call(childExp, BuiltInMethod.AGGREGATE.method, Expressions.call(accumulatorInitializer, "apply"), accumulatorAdder, resultSelector))));
    } else if (aggCalls.isEmpty() && groupSet.equals(ImmutableBitSet.range(child.getRowType().getFieldCount()))) {
        builder.add(Expressions.return_(null, Expressions.call(inputPhysType.convertTo(childExp, physType), BuiltInMethod.DISTINCT.method, Expressions.<Expression>list().appendIfNotNull(physType.comparer()))));
    } else {
        final Expression keySelector_ = builder.append("keySelector", inputPhysType.generateSelector(parameter, groupSet.asList(), keyPhysType.getFormat()));
        final Expression resultSelector_ = builder.append("resultSelector", Expressions.lambda(Function2.class, resultBlock.toBlock(), key_, acc_));
        builder.add(Expressions.return_(null, Expressions.call(childExp, BuiltInMethod.GROUP_BY2.method, Expressions.list(keySelector_, accumulatorInitializer, accumulatorAdder, resultSelector_).appendIfNotNull(keyPhysType.comparer()))));
    }
    return implementor.result(physType, builder.toBlock());
}
Also used : ImmutableBitSet(org.apache.calcite.util.ImmutableBitSet) ArrayList(java.util.ArrayList) JavaTypeFactoryImpl(org.apache.calcite.jdbc.JavaTypeFactoryImpl) JavaTypeFactory(org.apache.calcite.adapter.java.JavaTypeFactory) BlockBuilder(org.apache.calcite.linq4j.tree.BlockBuilder) Function0(org.apache.calcite.linq4j.function.Function0) Function2(org.apache.calcite.linq4j.function.Function2) AggregateCall(org.apache.calcite.rel.core.AggregateCall) AggAddContextImpl(org.apache.calcite.adapter.enumerable.impl.AggAddContextImpl) RelDataType(org.apache.calcite.rel.type.RelDataType) Type(java.lang.reflect.Type) AggResultContextImpl(org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl) RelDataTypeField(org.apache.calcite.rel.type.RelDataTypeField) Expression(org.apache.calcite.linq4j.tree.Expression) ParameterExpression(org.apache.calcite.linq4j.tree.ParameterExpression) ParameterExpression(org.apache.calcite.linq4j.tree.ParameterExpression) RexNode(org.apache.calcite.rex.RexNode)

Example 3 with Function0

use of org.apache.calcite.linq4j.function.Function0 in project calcite by apache.

the class ChunkListTest method testPerformance.

@Test
public void testPerformance() {
    if (!Benchmark.enabled()) {
        return;
    }
    // noinspection unchecked
    final Iterable<Pair<Function0<List<Integer>>, String>> factories0 = Pair.zip(Arrays.asList(new Function0<List<Integer>>() {

        public List<Integer> apply() {
            return new ArrayList<>();
        }
    }, new Function0<List<Integer>>() {

        public List<Integer> apply() {
            return new LinkedList<>();
        }
    }, new Function0<List<Integer>>() {

        public List<Integer> apply() {
            return new ChunkList<>();
        }
    }), Arrays.asList("ArrayList", "LinkedList", "ChunkList-64"));
    final List<Pair<Function0<List<Integer>>, String>> factories1 = new ArrayList<>();
    for (Pair<Function0<List<Integer>>, String> pair : factories0) {
        factories1.add(pair);
    }
    List<Pair<Function0<List<Integer>>, String>> factories = factories1.subList(2, 3);
    Iterable<Pair<Integer, String>> sizes = Pair.zip(Arrays.asList(100000, 1000000, 10000000), Arrays.asList("100k", "1m", "10m"));
    for (final Pair<Function0<List<Integer>>, String> pair : factories) {
        new Benchmark("add 10m values, " + pair.right, new Function1<Benchmark.Statistician, Void>() {

            public Void apply(Benchmark.Statistician statistician) {
                final List<Integer> list = pair.left.apply();
                long start = System.currentTimeMillis();
                for (int i = 0; i < 10000000; i++) {
                    list.add(1);
                }
                statistician.record(start);
                return null;
            }
        }, 10).run();
    }
    for (final Pair<Function0<List<Integer>>, String> pair : factories) {
        new Benchmark("iterate over 10m values, " + pair.right, new Function1<Benchmark.Statistician, Void>() {

            public Void apply(Benchmark.Statistician statistician) {
                final List<Integer> list = pair.left.apply();
                list.addAll(Collections.nCopies(10000000, 1));
                long start = System.currentTimeMillis();
                int count = 0;
                for (Integer integer : list) {
                    count += integer;
                }
                statistician.record(start);
                assert count == 10000000;
                return null;
            }
        }, 10).run();
    }
    for (final Pair<Function0<List<Integer>>, String> pair : factories) {
        for (final Pair<Integer, String> size : sizes) {
            if (size.left > 1000000) {
                continue;
            }
            new Benchmark("delete 10% of " + size.right + " values, " + pair.right, new Function1<Benchmark.Statistician, Void>() {

                public Void apply(Benchmark.Statistician statistician) {
                    final List<Integer> list = pair.left.apply();
                    list.addAll(Collections.nCopies(size.left, 1));
                    long start = System.currentTimeMillis();
                    int n = 0;
                    for (Iterator<Integer> it = list.iterator(); it.hasNext(); ) {
                        Integer integer = it.next();
                        Util.discard(integer);
                        if (n++ % 10 == 0) {
                            it.remove();
                        }
                    }
                    statistician.record(start);
                    return null;
                }
            }, 10).run();
        }
    }
    for (final Pair<Function0<List<Integer>>, String> pair : factories) {
        for (final Pair<Integer, String> size : sizes) {
            if (size.left > 1000000) {
                continue;
            }
            new Benchmark("get from " + size.right + " values, " + (size.left / 1000) + " times, " + pair.right, new Function1<Benchmark.Statistician, Void>() {

                public Void apply(Benchmark.Statistician statistician) {
                    final List<Integer> list = pair.left.apply();
                    list.addAll(Collections.nCopies(size.left, 1));
                    final int probeCount = size.left / 1000;
                    final Random random = new Random(1);
                    long start = System.currentTimeMillis();
                    int n = 0;
                    for (int i = 0; i < probeCount; i++) {
                        n += list.get(random.nextInt(list.size()));
                    }
                    assert n == probeCount;
                    statistician.record(start);
                    return null;
                }
            }, 10).run();
        }
    }
    for (final Pair<Function0<List<Integer>>, String> pair : factories) {
        for (final Pair<Integer, String> size : sizes) {
            if (size.left > 1000000) {
                continue;
            }
            new Benchmark("add " + size.right + " values, delete 10%, insert 20%, get 1%, using " + pair.right, new Function1<Benchmark.Statistician, Void>() {

                public Void apply(Benchmark.Statistician statistician) {
                    final List<Integer> list = pair.left.apply();
                    final int probeCount = size.left / 100;
                    long start = System.currentTimeMillis();
                    list.addAll(Collections.nCopies(size.left, 1));
                    final Random random = new Random(1);
                    for (Iterator<Integer> it = list.iterator(); it.hasNext(); ) {
                        Integer integer = it.next();
                        Util.discard(integer);
                        if (random.nextInt(10) == 0) {
                            it.remove();
                        }
                    }
                    for (ListIterator<Integer> it = list.listIterator(); it.hasNext(); ) {
                        Integer integer = it.next();
                        Util.discard(integer);
                        if (random.nextInt(5) == 0) {
                            it.add(2);
                        }
                    }
                    int n = 0;
                    for (int i = 0; i < probeCount; i++) {
                        n += list.get(random.nextInt(list.size()));
                    }
                    assert n > probeCount;
                    statistician.record(start);
                    return null;
                }
            }, 10).run();
        }
    }
}
Also used : ArrayList(java.util.ArrayList) Function1(org.apache.calcite.linq4j.function.Function1) Function0(org.apache.calcite.linq4j.function.Function0) LinkedList(java.util.LinkedList) Random(java.util.Random) ArrayList(java.util.ArrayList) List(java.util.List) ImmutableList(com.google.common.collect.ImmutableList) LinkedList(java.util.LinkedList) Test(org.junit.Test)

Aggregations

ArrayList (java.util.ArrayList)3 Function0 (org.apache.calcite.linq4j.function.Function0)3 List (java.util.List)2 Function1 (org.apache.calcite.linq4j.function.Function1)2 ImmutableList (com.google.common.collect.ImmutableList)1 Type (java.lang.reflect.Type)1 ResultSet (java.sql.ResultSet)1 ResultSetMetaData (java.sql.ResultSetMetaData)1 SQLException (java.sql.SQLException)1 LinkedList (java.util.LinkedList)1 Random (java.util.Random)1 AggAddContextImpl (org.apache.calcite.adapter.enumerable.impl.AggAddContextImpl)1 AggResultContextImpl (org.apache.calcite.adapter.enumerable.impl.AggResultContextImpl)1 JavaTypeFactory (org.apache.calcite.adapter.java.JavaTypeFactory)1 JavaTypeFactoryImpl (org.apache.calcite.jdbc.JavaTypeFactoryImpl)1 Function2 (org.apache.calcite.linq4j.function.Function2)1 BlockBuilder (org.apache.calcite.linq4j.tree.BlockBuilder)1 Expression (org.apache.calcite.linq4j.tree.Expression)1 ParameterExpression (org.apache.calcite.linq4j.tree.ParameterExpression)1 AggregateCall (org.apache.calcite.rel.core.AggregateCall)1