SetFlatteningOptimizer.java
/*
* 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 com.facebook.presto.sql.planner.optimizations;
import com.facebook.presto.Session;
import com.facebook.presto.spi.VariableAllocator;
import com.facebook.presto.spi.WarningCollector;
import com.facebook.presto.spi.plan.AggregationNode;
import com.facebook.presto.spi.plan.ExceptNode;
import com.facebook.presto.spi.plan.IntersectNode;
import com.facebook.presto.spi.plan.PlanNode;
import com.facebook.presto.spi.plan.PlanNodeIdAllocator;
import com.facebook.presto.spi.plan.SetOperationNode;
import com.facebook.presto.spi.plan.UnionNode;
import com.facebook.presto.spi.relation.VariableReferenceExpression;
import com.facebook.presto.sql.planner.TypeProvider;
import com.facebook.presto.sql.planner.plan.SimplePlanRewriter;
import com.google.common.collect.ImmutableList;
import com.google.common.collect.ImmutableListMultimap;
import com.google.common.collect.Iterables;
import com.google.common.collect.ListMultimap;
import java.util.List;
import java.util.Map;
import static com.facebook.presto.sql.planner.optimizations.SetOperationNodeUtils.fromListMultimap;
import static java.util.Objects.requireNonNull;
public class SetFlatteningOptimizer
implements PlanOptimizer
{
@Override
public PlanOptimizerResult optimize(PlanNode plan, Session session, TypeProvider types, VariableAllocator variableAllocator, PlanNodeIdAllocator idAllocator, WarningCollector warningCollector)
{
requireNonNull(plan, "plan is null");
requireNonNull(session, "session is null");
requireNonNull(types, "types is null");
requireNonNull(variableAllocator, "variableAllocator is null");
requireNonNull(idAllocator, "idAllocator is null");
Rewriter rewriter = new Rewriter();
PlanNode rewrittenPlan = SimplePlanRewriter.rewriteWith(rewriter, plan, false);
return PlanOptimizerResult.optimizerResult(rewrittenPlan, rewriter.isPlanChanged());
}
// TODO: remove expectation that UNION DISTINCT => distinct aggregation directly above union node
private static class Rewriter
extends SimplePlanRewriter<Boolean>
{
private boolean planChanged;
public boolean isPlanChanged()
{
return planChanged;
}
@Override
public PlanNode visitPlan(PlanNode node, RewriteContext<Boolean> context)
{
return context.defaultRewrite(node, false);
}
@Override
public PlanNode visitUnion(UnionNode node, RewriteContext<Boolean> context)
{
ImmutableList.Builder<PlanNode> flattenedSources = ImmutableList.builder();
ImmutableListMultimap.Builder<VariableReferenceExpression, VariableReferenceExpression> flattenedVariableMap = ImmutableListMultimap.builder();
flattenSetOperation(node, context, flattenedSources, flattenedVariableMap);
ListMultimap<VariableReferenceExpression, VariableReferenceExpression> mappings = flattenedVariableMap.build();
return new UnionNode(node.getSourceLocation(), node.getId(), flattenedSources.build(), ImmutableList.copyOf(mappings.keySet()), fromListMultimap(mappings));
}
@Override
public PlanNode visitIntersect(IntersectNode node, RewriteContext<Boolean> context)
{
ImmutableList.Builder<PlanNode> flattenedSources = ImmutableList.builder();
ImmutableListMultimap.Builder<VariableReferenceExpression, VariableReferenceExpression> flattenedVariableMap = ImmutableListMultimap.builder();
flattenSetOperation(node, context, flattenedSources, flattenedVariableMap);
ListMultimap<VariableReferenceExpression, VariableReferenceExpression> mappings = flattenedVariableMap.build();
return new IntersectNode(node.getSourceLocation(), node.getId(), flattenedSources.build(), ImmutableList.copyOf(mappings.keySet()), fromListMultimap(mappings));
}
@Override
public PlanNode visitExcept(ExceptNode node, RewriteContext<Boolean> context)
{
ImmutableList.Builder<PlanNode> flattenedSources = ImmutableList.builder();
ImmutableListMultimap.Builder<VariableReferenceExpression, VariableReferenceExpression> flattenedVariableMap = ImmutableListMultimap.builder();
flattenSetOperation(node, context, flattenedSources, flattenedVariableMap);
ListMultimap<VariableReferenceExpression, VariableReferenceExpression> mappings = flattenedVariableMap.build();
return new ExceptNode(node.getSourceLocation(), node.getId(), flattenedSources.build(), ImmutableList.copyOf(mappings.keySet()), fromListMultimap(mappings));
}
private void flattenSetOperation(
SetOperationNode node, RewriteContext<Boolean> context,
ImmutableList.Builder<PlanNode> flattenedSources,
ImmutableListMultimap.Builder<VariableReferenceExpression, VariableReferenceExpression> flattenedVariableMap)
{
for (int i = 0; i < node.getSources().size(); i++) {
PlanNode subplan = node.getSources().get(i);
PlanNode rewrittenSource = context.rewrite(subplan, context.get());
Class<?> setOperationClass = node.getClass();
if (setOperationClass.isInstance(rewrittenSource) && (!setOperationClass.equals(ExceptNode.class) || i == 0)) {
// Absorb source's subplans if it is also a SetOperation of the same type
// ExceptNodes can only flatten their first source because except is not associative
SetOperationNode rewrittenSetOperation = (SetOperationNode) rewrittenSource;
flattenedSources.addAll(rewrittenSetOperation.getSources());
planChanged = true;
for (Map.Entry<VariableReferenceExpression, List<VariableReferenceExpression>> entry : node.getVariableMapping().entrySet()) {
VariableReferenceExpression inputVariable = Iterables.get(entry.getValue(), i);
flattenedVariableMap.putAll(entry.getKey(), rewrittenSetOperation.getVariableMapping().get(inputVariable));
}
}
else {
flattenedSources.add(rewrittenSource);
for (Map.Entry<VariableReferenceExpression, List<VariableReferenceExpression>> entry : node.getVariableMapping().entrySet()) {
flattenedVariableMap.put(entry.getKey(), Iterables.get(entry.getValue(), i));
}
}
}
}
@Override
public PlanNode visitAggregation(AggregationNode node, RewriteContext<Boolean> context)
{
boolean distinct = isDistinctOperator(node);
PlanNode rewrittenNode = context.rewrite(node.getSource(), distinct);
if (context.get() && distinct) {
// Assumes underlying node has same output symbols as this distinct node
return rewrittenNode;
}
return new AggregationNode(
node.getSourceLocation(),
node.getId(),
rewrittenNode,
node.getAggregations(),
node.getGroupingSets(),
ImmutableList.of(),
node.getStep(),
node.getHashVariable(),
node.getGroupIdVariable(),
node.getAggregationId());
}
private static boolean isDistinctOperator(AggregationNode node)
{
return node.getAggregations().isEmpty();
}
}
}