com.hazelcast.shaded.org.apache.calcite.tools.PigRelBuilder Maven / Gradle / Ivy
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to you 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 com.hazelcast.shaded.org.apache.calcite.tools;
import com.hazelcast.shaded.org.apache.calcite.linq4j.Ord;
import com.hazelcast.shaded.org.apache.calcite.plan.Context;
import com.hazelcast.shaded.org.apache.calcite.plan.RelOptCluster;
import com.hazelcast.shaded.org.apache.calcite.plan.RelOptSchema;
import com.hazelcast.shaded.org.apache.calcite.rel.RelNode;
import com.hazelcast.shaded.org.apache.calcite.rel.core.JoinRelType;
import com.hazelcast.shaded.org.apache.calcite.rel.core.TableScan;
import com.hazelcast.shaded.org.apache.calcite.rel.type.RelDataType;
import com.hazelcast.shaded.org.apache.calcite.rex.RexNode;
import com.hazelcast.shaded.org.apache.calcite.sql.fun.SqlStdOperatorTable;
import com.hazelcast.shaded.org.apache.calcite.util.Util;
import com.hazelcast.shaded.com.google.common.collect.ImmutableList;
import com.hazelcast.shaded.org.checkerframework.checker.nullness.qual.Nullable;
import java.util.ArrayList;
import java.util.List;
import static java.util.Objects.requireNonNull;
/**
* Extension to {@link RelBuilder} for Pig relational operators.
*/
public class PigRelBuilder extends RelBuilder {
private @Nullable String lastAlias;
protected PigRelBuilder(Context context,
RelOptCluster cluster,
@Nullable RelOptSchema relOptSchema) {
super(context, cluster, relOptSchema);
}
/** Creates a PigRelBuilder. */
public static PigRelBuilder create(FrameworkConfig config) {
final RelBuilder relBuilder = RelBuilder.create(config);
return new PigRelBuilder(config.getContext(), relBuilder.cluster,
relBuilder.relOptSchema);
}
@Override public PigRelBuilder scan(String... tableNames) {
lastAlias = null;
return (PigRelBuilder) super.scan(tableNames);
}
@Override public PigRelBuilder scan(Iterable tableNames) {
lastAlias = null;
return (PigRelBuilder) super.scan(tableNames);
}
/** Loads a data set.
*
* Equivalent to Pig Latin:
*
{@code LOAD 'path' USING loadFunction AS rowType}
*
* {@code loadFunction} and {@code rowType} are optional.
*
* @param path File path
* @param loadFunction Load function
* @param rowType Row type (what Pig calls 'schema')
*
* @return This builder
*/
public PigRelBuilder load(String path, RexNode loadFunction,
RelDataType rowType) {
scan(path.replace(".csv", "")); // TODO: use a UDT
return this;
}
/** Removes duplicate tuples in a relation.
*
*
Equivalent Pig Latin:
*
* alias = DISTINCT alias [PARTITION BY partitioner] [PARALLEL n];
*
*
* @param partitioner Partitioner; null means no partitioner
* @param parallel Degree of parallelism; negative means unspecified
*
* @return This builder
*/
public PigRelBuilder distinct(Partitioner partitioner, int parallel) {
// TODO: Use partitioner and parallel
distinct();
return this;
}
/** Groups the data in one or more relations.
*
* Pig Latin syntax:
*
* alias = GROUP alias { ALL | BY expression }
* [, alias ALL | BY expression ...]
* [USING 'collected' | 'merge'] [PARTITION BY partitioner] [PARALLEL n];
*
*
* @param groupKeys One of more group keys; use {@link #groupKey()} for ALL
* @param option Whether to use an optimized method combining the data
* (COLLECTED for one input or MERGE for two or more inputs)
* @param partitioner Partitioner; null means no partitioner
* @param parallel Degree of parallelism; negative means unspecified
*
* @return This builder
*/
public PigRelBuilder group(GroupOption option, Partitioner partitioner,
int parallel, GroupKey... groupKeys) {
return group(option, partitioner, parallel, ImmutableList.copyOf(groupKeys));
}
public PigRelBuilder group(GroupOption option, Partitioner partitioner,
int parallel, Iterable extends GroupKey> groupKeys) {
final List groupKeyList = ImmutableList.copyOf(groupKeys);
validateGroupList(groupKeyList);
final int groupCount = groupKeyList.get(0).groupKeyCount();
final int n = groupKeyList.size();
for (Ord groupKey : Ord.reverse(groupKeyList)) {
RelNode r = null;
if (groupKey.i < n - 1) {
r = build();
}
// Create a ROW to pass to COLLECT. Interestingly, this is not allowed
// by standard SQL; see [CALCITE-877] Allow ROW as argument to COLLECT.
final RexNode row =
cluster.getRexBuilder().makeCall(peek(1, 0).getRowType(),
SqlStdOperatorTable.ROW, fields());
aggregate(groupKey.e,
aggregateCall(SqlStdOperatorTable.COLLECT, row).as(getAlias()));
if (groupKey.i < n - 1) {
push(requireNonNull(r, "r"));
List predicates = new ArrayList<>();
for (int key : Util.range(groupCount)) {
predicates.add(equals(field(2, 0, key), field(2, 1, key)));
}
join(JoinRelType.INNER, and(predicates));
}
}
return this;
}
protected void validateGroupList(List groupKeyList) {
if (groupKeyList.isEmpty()) {
throw new IllegalArgumentException("must have at least one group");
}
final int groupCount = groupKeyList.get(0).groupKeyCount();
for (GroupKey groupKey : groupKeyList) {
if (groupKey.groupKeyCount() != groupCount) {
throw new IllegalArgumentException("group key size mismatch");
}
}
}
public @Nullable String getAlias() {
if (lastAlias != null) {
return lastAlias;
} else {
RelNode top = peek();
if (top instanceof TableScan) {
TableScan scan = (TableScan) top;
return Util.last(scan.getTable().getQualifiedName());
} else {
return null;
}
}
}
/** As super-class method, but also retains alias for naming of aggregates. */
@Override public RelBuilder as(final String alias) {
lastAlias = alias;
return super.as(alias);
}
/** Partitioner for group and join. */
interface Partitioner {
}
/** Option for performing group efficiently if data set is already sorted. */
public enum GroupOption {
MERGE,
COLLECTED
}
}
© 2015 - 2024 Weber Informatics LLC | Privacy Policy