You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@calcite.apache.org by jh...@apache.org on 2017/08/24 19:05:23 UTC

[09/11] calcite git commit: [CALCITE-1963] Upgrade checkstyle, and fix code to comply

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorImpl.java b/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorImpl.java
index c6de052..5509b9f 100644
--- a/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorImpl.java
+++ b/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorImpl.java
@@ -2008,7 +2008,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
       return node;
     case MATCH_RECOGNIZE:
       registerMatchRecognize(parentScope, usingScope,
-        (SqlMatchRecognize) node, enclosingNode, alias, forceNullable);
+          (SqlMatchRecognize) node, enclosingNode, alias, forceNullable);
       return node;
     case TABLESAMPLE:
       call = (SqlCall) node;
@@ -4880,7 +4880,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
     }
 
     List<Map.Entry<String, RelDataType>> measureColumns =
-      validateMeasure(matchRecognize, scope, allRows);
+        validateMeasure(matchRecognize, scope, allRows);
     for (Map.Entry<String, RelDataType> c : measureColumns) {
       if (!typeBuilder.nameExists(c.getKey())) {
         typeBuilder.add(c.getKey(), c.getValue());
@@ -5226,7 +5226,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
   private static class InsertNamespace extends DmlNamespace {
     private final SqlInsert node;
 
-    public InsertNamespace(SqlValidatorImpl validator, SqlInsert node,
+    InsertNamespace(SqlValidatorImpl validator, SqlInsert node,
         SqlNode enclosingNode, SqlValidatorScope parentScope) {
       super(validator, node.getTargetTable(), enclosingNode, parentScope);
       this.node = Preconditions.checkNotNull(node);
@@ -5243,7 +5243,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
   private static class UpdateNamespace extends DmlNamespace {
     private final SqlUpdate node;
 
-    public UpdateNamespace(SqlValidatorImpl validator, SqlUpdate node,
+    UpdateNamespace(SqlValidatorImpl validator, SqlUpdate node,
         SqlNode enclosingNode, SqlValidatorScope parentScope) {
       super(validator, node.getTargetTable(), enclosingNode, parentScope);
       this.node = Preconditions.checkNotNull(node);
@@ -5260,7 +5260,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
   private static class DeleteNamespace extends DmlNamespace {
     private final SqlDelete node;
 
-    public DeleteNamespace(SqlValidatorImpl validator, SqlDelete node,
+    DeleteNamespace(SqlValidatorImpl validator, SqlDelete node,
         SqlNode enclosingNode, SqlValidatorScope parentScope) {
       super(validator, node.getTargetTable(), enclosingNode, parentScope);
       this.node = Preconditions.checkNotNull(node);
@@ -5277,7 +5277,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
   private static class MergeNamespace extends DmlNamespace {
     private final SqlMerge node;
 
-    public MergeNamespace(SqlValidatorImpl validator, SqlMerge node,
+    MergeNamespace(SqlValidatorImpl validator, SqlMerge node,
         SqlNode enclosingNode, SqlValidatorScope parentScope) {
       super(validator, node.getTargetTable(), enclosingNode, parentScope);
       this.node = Preconditions.checkNotNull(node);
@@ -5293,7 +5293,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
    */
   private class PatternVarVisitor implements SqlVisitor<Void> {
     private MatchRecognizeScope scope;
-    public PatternVarVisitor(MatchRecognizeScope scope) {
+    PatternVarVisitor(MatchRecognizeScope scope) {
       this.scope = scope;
     }
 
@@ -5340,7 +5340,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
   private class DeriveTypeVisitor implements SqlVisitor<RelDataType> {
     private final SqlValidatorScope scope;
 
-    public DeriveTypeVisitor(SqlValidatorScope scope) {
+    DeriveTypeVisitor(SqlValidatorScope scope) {
       this.scope = scope;
     }
 
@@ -5500,9 +5500,9 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
           Util.last(id.names),
           id.getParserPosition());
         SqlBasicCall item_call = new SqlBasicCall(
-          SqlStdOperatorTable.ITEM,
-          inputs,
-          id.getParserPosition());
+            SqlStdOperatorTable.ITEM,
+            inputs,
+            id.getParserPosition());
         expandedExpr = item_call;
       }
       validator.setOriginal(expandedExpr, id);
@@ -5795,11 +5795,11 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
     SqlOperator currentOperator;
     SqlNode currentOffset;
 
-    public NavigationExpander() {
+    NavigationExpander() {
 
     }
 
-    public NavigationExpander(SqlOperator operator, SqlNode offset) {
+    NavigationExpander(SqlOperator operator, SqlNode offset) {
       this.currentOffset = offset;
       this.currentOperator = operator;
     }
@@ -5819,7 +5819,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
             List<SqlNode> innerOperands = ((SqlCall) inner).getOperandList();
             SqlNode innerOffset = innerOperands.get(1);
             SqlOperator newOperator = innerKind == kind
-              ? SqlStdOperatorTable.PLUS : SqlStdOperatorTable.MINUS;
+                ? SqlStdOperatorTable.PLUS : SqlStdOperatorTable.MINUS;
             offset = newOperator.createCall(SqlParserPos.ZERO,
               offset, innerOffset);
             inner = call.getOperator().createCall(SqlParserPos.ZERO,
@@ -5855,7 +5855,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
   private class NavigationReplacer extends NavigationModifier {
     private final String alpha;
 
-    public NavigationReplacer(String alpha) {
+    NavigationReplacer(String alpha) {
       this.alpha = alpha;
     }
 
@@ -5887,7 +5887,7 @@ public class SqlValidatorImpl implements SqlValidatorWithHints {
         return id;
       }
       SqlOperator operator = id.names.get(0).equals(alpha)
-        ? SqlStdOperatorTable.PREV : SqlStdOperatorTable.LAST;
+          ? SqlStdOperatorTable.PREV : SqlStdOperatorTable.LAST;
 
       return operator.createCall(SqlParserPos.ZERO, id,
         SqlLiteral.createExactNumeric("0", SqlParserPos.ZERO));

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorUtil.java b/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorUtil.java
index f12c1d9..c56c0ec 100644
--- a/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorUtil.java
+++ b/core/src/main/java/org/apache/calcite/sql/validate/SqlValidatorUtil.java
@@ -655,8 +655,8 @@ public class SqlValidatorUtil {
     return null;
   }
 
-  public static AggregatingSelectScope
-  getEnclosingAggregateSelectScope(SqlValidatorScope scope) {
+  public static AggregatingSelectScope getEnclosingAggregateSelectScope(
+      SqlValidatorScope scope) {
     while (scope instanceof DelegatingScope) {
       if (scope instanceof AggregatingSelectScope) {
         return (AggregatingSelectScope) scope;
@@ -788,9 +788,8 @@ public class SqlValidatorUtil {
    * <p>Gathers into {@code groupExprs} the set of distinct expressions being
    * grouped, and returns a bitmap indicating which expressions this tuple
    * is grouping. */
-  private static List<ImmutableBitSet>
-  analyzeGroupTuple(SqlValidatorScope scope, GroupAnalyzer groupAnalyzer,
-                    List<SqlNode> operandList) {
+  private static List<ImmutableBitSet> analyzeGroupTuple(SqlValidatorScope scope,
+       GroupAnalyzer groupAnalyzer, List<SqlNode> operandList) {
     List<ImmutableBitSet> list = Lists.newArrayList();
     for (SqlNode operand : operandList) {
       list.add(
@@ -893,8 +892,8 @@ public class SqlValidatorUtil {
    * <code>rollup({0, 2}, {3, 5})</code>
    * returns <code>({0, 2, 3, 5}, {0, 2}, {})</code>. */
   @VisibleForTesting
-  public static ImmutableList<ImmutableBitSet>
-  rollup(List<ImmutableBitSet> bitSets) {
+  public static ImmutableList<ImmutableBitSet> rollup(
+      List<ImmutableBitSet> bitSets) {
     Set<ImmutableBitSet> builder = Sets.newLinkedHashSet();
     for (;;) {
       final ImmutableBitSet union = ImmutableBitSet.union(bitSets);
@@ -916,8 +915,8 @@ public class SqlValidatorUtil {
    * <code>rollup({0, 2}, {3, 5})</code>
    * returns <code>({0, 2, 3, 5}, {0, 2}, {})</code>. */
   @VisibleForTesting
-  public static ImmutableList<ImmutableBitSet>
-  cube(List<ImmutableBitSet> bitSets) {
+  public static ImmutableList<ImmutableBitSet> cube(
+      List<ImmutableBitSet> bitSets) {
     // Given the bit sets [{1}, {2, 3}, {5}],
     // form the lists [[{1}, {}], [{2, 3}, {}], [{5}, {}]].
     final Set<List<ImmutableBitSet>> builder = Sets.newLinkedHashSet();

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/sql/validate/TableNamespace.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/sql/validate/TableNamespace.java b/core/src/main/java/org/apache/calcite/sql/validate/TableNamespace.java
index 2e3773c..558ffa4 100644
--- a/core/src/main/java/org/apache/calcite/sql/validate/TableNamespace.java
+++ b/core/src/main/java/org/apache/calcite/sql/validate/TableNamespace.java
@@ -52,7 +52,7 @@ class TableNamespace extends AbstractNamespace {
     this.extendedFields = ImmutableList.copyOf(fields);
   }
 
-  public TableNamespace(SqlValidatorImpl validator, SqlValidatorTable table) {
+  TableNamespace(SqlValidatorImpl validator, SqlValidatorTable table) {
     this(validator, table, ImmutableList.<RelDataTypeField>of());
   }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/sql2rel/RelDecorrelator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/sql2rel/RelDecorrelator.java b/core/src/main/java/org/apache/calcite/sql2rel/RelDecorrelator.java
index bec1205..c21b7c7 100644
--- a/core/src/main/java/org/apache/calcite/sql2rel/RelDecorrelator.java
+++ b/core/src/main/java/org/apache/calcite/sql2rel/RelDecorrelator.java
@@ -1527,7 +1527,7 @@ public class RelDecorrelator implements ReflectiveVisitor {
     final RexInputRef nullIndicator;
     final ImmutableSet<Integer> isCount;
 
-    public RemoveCorrelationRexShuttle(
+    RemoveCorrelationRexShuttle(
         RexBuilder rexBuilder,
         boolean projectPulledAboveLeftCorrelator,
         RexInputRef nullIndicator,
@@ -1722,7 +1722,7 @@ public class RelDecorrelator implements ReflectiveVisitor {
    * AggRel single group</blockquote>
    */
   private final class RemoveSingleAggregateRule extends RelOptRule {
-    public RemoveSingleAggregateRule() {
+    RemoveSingleAggregateRule() {
       super(
           operand(
               LogicalAggregate.class,
@@ -1775,7 +1775,7 @@ public class RelDecorrelator implements ReflectiveVisitor {
 
   /** Planner rule that removes correlations for scalar projects. */
   private final class RemoveCorrelationForScalarProjectRule extends RelOptRule {
-    public RemoveCorrelationForScalarProjectRule() {
+    RemoveCorrelationForScalarProjectRule() {
       super(
           operand(LogicalCorrelate.class,
               operand(RelNode.class, any()),
@@ -1973,7 +1973,7 @@ public class RelDecorrelator implements ReflectiveVisitor {
   /** Planner rule that removes correlations for scalar aggregates. */
   private final class RemoveCorrelationForScalarAggregateRule
       extends RelOptRule {
-    public RemoveCorrelationForScalarAggregateRule() {
+    RemoveCorrelationForScalarAggregateRule() {
       super(
           operand(LogicalCorrelate.class,
               operand(RelNode.class, any()),
@@ -2356,7 +2356,7 @@ public class RelDecorrelator implements ReflectiveVisitor {
   private final class AdjustProjectForCountAggregateRule extends RelOptRule {
     final boolean flavor;
 
-    public AdjustProjectForCountAggregateRule(boolean flavor) {
+    AdjustProjectForCountAggregateRule(boolean flavor) {
       super(
           flavor
               ? operand(LogicalCorrelate.class,

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/sql2rel/SqlToRelConverter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/sql2rel/SqlToRelConverter.java b/core/src/main/java/org/apache/calcite/sql2rel/SqlToRelConverter.java
index 990db38..42986b8 100644
--- a/core/src/main/java/org/apache/calcite/sql2rel/SqlToRelConverter.java
+++ b/core/src/main/java/org/apache/calcite/sql2rel/SqlToRelConverter.java
@@ -1881,11 +1881,9 @@ public class SqlToRelConverter {
       // necessary because the returned expression is not necessarily a call
       // to an agg function. For example, AVG(x) becomes SUM(x) / COUNT(x).
 
-      boolean isDistinct = false;
-      if (aggCall.getFunctionQuantifier() != null
-        && aggCall.getFunctionQuantifier().getValue().equals(SqlSelectKeyword.DISTINCT)) {
-        isDistinct = true;
-      }
+      final SqlLiteral q = aggCall.getFunctionQuantifier();
+      final boolean isDistinct = q != null
+          && q.getValue() == SqlSelectKeyword.DISTINCT;
 
       final RexShuttle visitor =
           new HistogramShuttle(
@@ -2141,31 +2139,31 @@ public class SqlToRelConverter {
     final Set<String> patternVarsSet = new HashSet<>();
     SqlNode pattern = matchRecognize.getPattern();
     final SqlBasicVisitor<RexNode> patternVarVisitor =
-      new SqlBasicVisitor<RexNode>() {
-        @Override public RexNode visit(SqlCall call) {
-          List<SqlNode> operands = call.getOperandList();
-          List<RexNode> newOperands = Lists.newArrayList();
-          for (SqlNode node : operands) {
-            newOperands.add(node.accept(this));
+        new SqlBasicVisitor<RexNode>() {
+          @Override public RexNode visit(SqlCall call) {
+            List<SqlNode> operands = call.getOperandList();
+            List<RexNode> newOperands = Lists.newArrayList();
+            for (SqlNode node : operands) {
+              newOperands.add(node.accept(this));
+            }
+            return rexBuilder.makeCall(
+              validator.getUnknownType(), call.getOperator(), newOperands);
           }
-          return rexBuilder.makeCall(
-            validator.getUnknownType(), call.getOperator(), newOperands);
-        }
 
-        @Override public RexNode visit(SqlIdentifier id) {
-          assert id.isSimple();
-          patternVarsSet.add(id.getSimple());
-          return rexBuilder.makeLiteral(id.getSimple());
-        }
+          @Override public RexNode visit(SqlIdentifier id) {
+            assert id.isSimple();
+            patternVarsSet.add(id.getSimple());
+            return rexBuilder.makeLiteral(id.getSimple());
+          }
 
-        @Override public RexNode visit(SqlLiteral literal) {
-          if (literal instanceof SqlNumericLiteral) {
-            return rexBuilder.makeExactLiteral(BigDecimal.valueOf(literal.intValue(true)));
-          } else {
-            return rexBuilder.makeLiteral(literal.booleanValue());
+          @Override public RexNode visit(SqlLiteral literal) {
+            if (literal instanceof SqlNumericLiteral) {
+              return rexBuilder.makeExactLiteral(BigDecimal.valueOf(literal.intValue(true)));
+            } else {
+              return rexBuilder.makeLiteral(literal.booleanValue());
+            }
           }
-        }
-      };
+        };
     final RexNode patternNode = pattern.accept(patternVarVisitor);
 
     SqlLiteral interval = matchRecognize.getInterval();
@@ -3957,8 +3955,8 @@ public class SqlToRelConverter {
      * Sub-queries can reference group by expressions projected from the
      * "right" to the sub-query.
      */
-    private final Map<RelNode, Map<Integer, Integer>>
-    mapRootRelToFieldProjection = new HashMap<>();
+    private final Map<RelNode, Map<Integer, Integer>> mapRootRelToFieldProjection =
+        new HashMap<>();
 
     private final List<SqlMonotonicity> columnMonotonicities =
         new ArrayList<>();

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/sql2rel/StandardConvertletTable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/sql2rel/StandardConvertletTable.java b/core/src/main/java/org/apache/calcite/sql2rel/StandardConvertletTable.java
index 9c2f641..0d62f9f 100644
--- a/core/src/main/java/org/apache/calcite/sql2rel/StandardConvertletTable.java
+++ b/core/src/main/java/org/apache/calcite/sql2rel/StandardConvertletTable.java
@@ -1264,7 +1264,7 @@ public class StandardConvertletTable extends ReflectiveConvertletTable {
   private static class AvgVarianceConvertlet implements SqlRexConvertlet {
     private final SqlKind kind;
 
-    public AvgVarianceConvertlet(SqlKind kind) {
+    AvgVarianceConvertlet(SqlKind kind) {
       this.kind = kind;
     }
 
@@ -1377,7 +1377,7 @@ public class StandardConvertletTable extends ReflectiveConvertletTable {
   private static class TrimConvertlet implements SqlRexConvertlet {
     private final SqlTrimFunction.Flag flag;
 
-    public TrimConvertlet(SqlTrimFunction.Flag flag) {
+    TrimConvertlet(SqlTrimFunction.Flag flag) {
       this.flag = flag;
     }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/tools/Frameworks.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/tools/Frameworks.java b/core/src/main/java/org/apache/calcite/tools/Frameworks.java
index 6d29152..364e592 100644
--- a/core/src/main/java/org/apache/calcite/tools/Frameworks.java
+++ b/core/src/main/java/org/apache/calcite/tools/Frameworks.java
@@ -65,7 +65,9 @@ public class Frameworks {
 
   /** Piece of code to be run in a context where a planner is available. The
    * planner is accessible from the {@code cluster} parameter, as are several
-   * other useful objects. */
+   * other useful objects.
+   *
+   * @param <R> result type */
   public interface PlannerAction<R> {
     R apply(RelOptCluster cluster, RelOptSchema relOptSchema,
         SchemaPlus rootSchema);
@@ -75,7 +77,9 @@ public class Frameworks {
    * available. The planner is accessible from the {@code cluster} parameter, as
    * are several other useful objects. The connection and
    * {@link org.apache.calcite.DataContext} are accessible from the
-   * statement. */
+   * statement.
+   *
+   * @param <R> result type */
   public abstract static class PrepareAction<R> {
     private final FrameworkConfig config;
     public PrepareAction() {
@@ -294,7 +298,7 @@ public class Frameworks {
     private final RelDataTypeSystem typeSystem;
     private final RexExecutor executor;
 
-    public StdFrameworkConfig(Context context,
+    StdFrameworkConfig(Context context,
         SqlRexConvertletTable convertletTable,
         SqlOperatorTable operatorTable,
         ImmutableList<Program> programs,

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/tools/RelBuilder.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/tools/RelBuilder.java b/core/src/main/java/org/apache/calcite/tools/RelBuilder.java
index 2e7c034..4ef40df 100644
--- a/core/src/main/java/org/apache/calcite/tools/RelBuilder.java
+++ b/core/src/main/java/org/apache/calcite/tools/RelBuilder.java
@@ -1482,8 +1482,8 @@ public class RelBuilder {
 
   /** Converts an iterable of lists into an immutable list of immutable lists
    * with the same contents. Returns the same object if possible. */
-  private static <E> ImmutableList<ImmutableList<E>>
-  copy(Iterable<? extends List<E>> tupleList) {
+  private static <E> ImmutableList<ImmutableList<E>> copy(
+      Iterable<? extends List<E>> tupleList) {
     final ImmutableList.Builder<ImmutableList<E>> builder =
         ImmutableList.builder();
     int changeCount = 0;
@@ -1793,7 +1793,7 @@ public class RelBuilder {
   /** A field that belongs to a stack {@link Frame}. */
   private static class Field
       extends Pair<ImmutableSet<String>, RelDataTypeField> {
-    public Field(ImmutableSet<String> left, RelDataTypeField right) {
+    Field(ImmutableSet<String> left, RelDataTypeField right) {
       super(left, right);
     }
   }

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/tools/RuleSets.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/tools/RuleSets.java b/core/src/main/java/org/apache/calcite/tools/RuleSets.java
index 62bb5a1..dbe0ee4 100644
--- a/core/src/main/java/org/apache/calcite/tools/RuleSets.java
+++ b/core/src/main/java/org/apache/calcite/tools/RuleSets.java
@@ -45,7 +45,7 @@ public class RuleSets {
   private static class ListRuleSet implements RuleSet {
     private final ImmutableList<RelOptRule> rules;
 
-    public ListRuleSet(ImmutableList<RelOptRule> rules) {
+    ListRuleSet(ImmutableList<RelOptRule> rules) {
       this.rules = rules;
     }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/BitSets.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/BitSets.java b/core/src/main/java/org/apache/calcite/util/BitSets.java
index c1dac26..492dcfb 100644
--- a/core/src/main/java/org/apache/calcite/util/BitSets.java
+++ b/core/src/main/java/org/apache/calcite/util/BitSets.java
@@ -327,7 +327,7 @@ public final class BitSets {
     private SortedMap<Integer, BitSet> equivalence;
     private final SortedMap<Integer, BitSet> closure = new TreeMap<>();
 
-    public Closure(SortedMap<Integer, BitSet> equivalence) {
+    Closure(SortedMap<Integer, BitSet> equivalence) {
       this.equivalence = equivalence;
       final ImmutableIntList keys =
           ImmutableIntList.copyOf(equivalence.keySet());

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/CompatibleGuava11.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/CompatibleGuava11.java b/core/src/main/java/org/apache/calcite/util/CompatibleGuava11.java
index 8c2a916..21b437a 100644
--- a/core/src/main/java/org/apache/calcite/util/CompatibleGuava11.java
+++ b/core/src/main/java/org/apache/calcite/util/CompatibleGuava11.java
@@ -55,6 +55,8 @@ class CompatibleGuava11 {
   /**
    * {@link AbstractSet} substitute without the potentially-quadratic
    * {@code removeAll} implementation.
+   *
+   * @param <E> element type
    */
   abstract static class ImprovedAbstractSet<E> extends AbstractSet<E> {
     @Override public boolean removeAll(Collection<?> c) {
@@ -103,7 +105,10 @@ class CompatibleGuava11 {
     }
   }
 
-  /** ImprovedAbstractMap. */
+  /** ImprovedAbstractMap.
+   *
+   * @param <K> key type
+   * @param <V> value type */
   abstract static class ImprovedAbstractMap<K, V> extends AbstractMap<K, V> {
     /**
      * Creates the entry set to be returned by {@link #entrySet()}. This method
@@ -160,7 +165,10 @@ class CompatibleGuava11 {
     };
   }
 
-  /** KeySet. */
+  /** KeySet.
+   *
+   * @param <K> key type
+   * @param <V> value type */
   abstract static class KeySet<K, V> extends ImprovedAbstractSet<K> {
     abstract Map<K, V> map();
 
@@ -218,7 +226,10 @@ class CompatibleGuava11 {
     };
   }
 
-  /** AsMapView. */
+  /** AsMapView.
+   *
+   * @param <K> key type
+   * @param <V> value type */
   private static class AsMapView<K, V> extends ImprovedAbstractMap<K, V> {
     private final Set<K> set;
     final Function<? super K, V> function;
@@ -287,7 +298,10 @@ class CompatibleGuava11 {
     }
   }
 
-  /** EntrySet. */
+  /** EntrySet.
+   *
+   * @param <K> key type
+   * @param <V> value type */
   abstract static class EntrySet<K, V>
       extends ImprovedAbstractSet<Map.Entry<K, V>> {
     abstract Map<K, V> map();
@@ -362,7 +376,10 @@ class CompatibleGuava11 {
     };
   }
 
-  /** Values. */
+  /** Values.
+   *
+   * @param <K> key type
+   * @param <V> value type */
   abstract static class Values<K, V> extends AbstractCollection<V> {
     abstract Map<K, V> map();
 
@@ -429,7 +446,10 @@ class CompatibleGuava11 {
     }
   }
 
-  /** TransformedIterator. */
+  /** TransformedIterator.
+   *
+   * @param <F> from type
+   * @param <T> to type */
   abstract static class TransformedIterator<F, T> implements Iterator<T> {
     final Iterator<? extends F> backingIterator;
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/ImmutableBitSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/ImmutableBitSet.java b/core/src/main/java/org/apache/calcite/util/ImmutableBitSet.java
index 61b3321..c03d5c4 100644
--- a/core/src/main/java/org/apache/calcite/util/ImmutableBitSet.java
+++ b/core/src/main/java/org/apache/calcite/util/ImmutableBitSet.java
@@ -914,7 +914,7 @@ public class ImmutableBitSet
     private final SortedMap<Integer, ImmutableBitSet> closure =
         Maps.newTreeMap();
 
-    public Closure(SortedMap<Integer, ImmutableBitSet> equivalence) {
+    Closure(SortedMap<Integer, ImmutableBitSet> equivalence) {
       this.equivalence = equivalence;
       final ImmutableIntList keys =
           ImmutableIntList.copyOf(equivalence.keySet());

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/ImmutableIntList.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/ImmutableIntList.java b/core/src/main/java/org/apache/calcite/util/ImmutableIntList.java
index 90cbdb0..42842e5 100644
--- a/core/src/main/java/org/apache/calcite/util/ImmutableIntList.java
+++ b/core/src/main/java/org/apache/calcite/util/ImmutableIntList.java
@@ -287,7 +287,9 @@ public class ImmutableIntList extends FlatLists.AbstractFlatList<Integer> {
   }
 
   /** Extension to {@link com.google.common.collect.UnmodifiableListIterator}
-   * that operates by index. */
+   * that operates by index.
+   *
+   * @param <E> element type */
   private abstract static class AbstractIndexedListIterator<E>
       extends UnmodifiableListIterator<E> {
     private final int size;

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/ImmutableNullableList.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/ImmutableNullableList.java b/core/src/main/java/org/apache/calcite/util/ImmutableNullableList.java
index 202ee5e..9345214 100644
--- a/core/src/main/java/org/apache/calcite/util/ImmutableNullableList.java
+++ b/core/src/main/java/org/apache/calcite/util/ImmutableNullableList.java
@@ -200,6 +200,8 @@ public class ImmutableNullableList<E> extends AbstractList<E> {
 
   /**
    * A builder for creating immutable nullable list instances.
+   *
+   * @param <E> element type
    */
   public static final class Builder<E> {
     private final List<E> contents = Lists.newArrayList();

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/PartiallyOrderedSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/PartiallyOrderedSet.java b/core/src/main/java/org/apache/calcite/util/PartiallyOrderedSet.java
index b73a257..ad808a9 100644
--- a/core/src/main/java/org/apache/calcite/util/PartiallyOrderedSet.java
+++ b/core/src/main/java/org/apache/calcite/util/PartiallyOrderedSet.java
@@ -670,7 +670,7 @@ public class PartiallyOrderedSet<E> extends AbstractSet<E> {
     final List<Node<E>> childList = new ArrayList<>();
     final E e;
 
-    public Node(E e) {
+    Node(E e) {
       this.e = e;
     }
 
@@ -688,7 +688,7 @@ public class PartiallyOrderedSet<E> extends AbstractSet<E> {
   private static class TopBottomNode<E> extends Node<E> {
     private final String description;
 
-    public TopBottomNode(boolean top) {
+    TopBottomNode(boolean top) {
       super(null);
       this.description = top ? "top" : "bottom";
     }
@@ -734,7 +734,7 @@ public class PartiallyOrderedSet<E> extends AbstractSet<E> {
   private static class StripList<E> extends AbstractList<E> {
     private final List<Node<E>> list;
 
-    public StripList(List<Node<E>> list) {
+    StripList(List<Node<E>> list) {
       this.list = list;
     }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/ReflectUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/ReflectUtil.java b/core/src/main/java/org/apache/calcite/util/ReflectUtil.java
index 57fbe6a..8dc2f2e 100644
--- a/core/src/main/java/org/apache/calcite/util/ReflectUtil.java
+++ b/core/src/main/java/org/apache/calcite/util/ReflectUtil.java
@@ -410,8 +410,7 @@ public abstract class ReflectUtil {
    * @param visiteeBaseClazz Visitee base class
    * @return cache of methods
    */
-  public static <R extends ReflectiveVisitor, E>
-  ReflectiveVisitDispatcher<R, E> createDispatcher(
+  public static <R extends ReflectiveVisitor, E> ReflectiveVisitDispatcher<R, E> createDispatcher(
       final Class<R> visitorBaseClazz,
       final Class<E> visiteeBaseClazz) {
     assert ReflectiveVisitor.class.isAssignableFrom(visitorBaseClazz);

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/Util.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/Util.java b/core/src/main/java/org/apache/calcite/util/Util.java
index 3430f01..bdea891 100644
--- a/core/src/main/java/org/apache/calcite/util/Util.java
+++ b/core/src/main/java/org/apache/calcite/util/Util.java
@@ -2240,8 +2240,8 @@ public class Util {
 
   /** Returns a copy of a list of lists, making the component lists immutable if
    * they are not already. */
-  public static <E> List<List<E>>
-  immutableCopy(Iterable<? extends Iterable<E>> lists) {
+  public static <E> List<List<E>> immutableCopy(
+      Iterable<? extends Iterable<E>> lists) {
     int n = 0;
     for (Iterable<E> list : lists) {
       if (!(list instanceof ImmutableList)) {

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/XmlOutput.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/XmlOutput.java b/core/src/main/java/org/apache/calcite/util/XmlOutput.java
index 9392b5a..ba1e5c8 100644
--- a/core/src/main/java/org/apache/calcite/util/XmlOutput.java
+++ b/core/src/main/java/org/apache/calcite/util/XmlOutput.java
@@ -540,7 +540,7 @@ public class XmlOutput {
     /**
      * Identity transform
      */
-    public StringEscaper() {
+    StringEscaper() {
       translationVector = new ArrayList<String>();
     }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/graph/Graphs.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/graph/Graphs.java b/core/src/main/java/org/apache/calcite/util/graph/Graphs.java
index fd32f22..72d691f 100644
--- a/core/src/main/java/org/apache/calcite/util/graph/Graphs.java
+++ b/core/src/main/java/org/apache/calcite/util/graph/Graphs.java
@@ -36,8 +36,8 @@ public class Graphs {
   private Graphs() {
   }
 
-  public static <V, E extends DefaultEdge> List<V>
-  predecessorListOf(DirectedGraph<V, E> graph, V vertex) {
+  public static <V, E extends DefaultEdge> List<V> predecessorListOf(
+      DirectedGraph<V, E> graph, V vertex) {
     final List<E> edges = graph.getInwardEdges(vertex);
     return new AbstractList<V>() {
       public V get(int index) {

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/javac/JaninoCompiler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/javac/JaninoCompiler.java b/core/src/main/java/org/apache/calcite/util/javac/JaninoCompiler.java
index 1ac6a39..a84fbdb 100644
--- a/core/src/main/java/org/apache/calcite/util/javac/JaninoCompiler.java
+++ b/core/src/main/java/org/apache/calcite/util/javac/JaninoCompiler.java
@@ -139,7 +139,7 @@ public class JaninoCompiler implements JavaCompiler {
     private final File destDir;
     private int nBytes;
 
-    public AccountingClassLoader(
+    AccountingClassLoader(
         ClassLoader parentClassLoader,
         ResourceFinder sourceFinder,
         String optionalCharacterEncoding,

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/mapping/MappingType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/mapping/MappingType.java b/core/src/main/java/org/apache/calcite/util/mapping/MappingType.java
index c7cee41..7c38a81 100644
--- a/core/src/main/java/org/apache/calcite/util/mapping/MappingType.java
+++ b/core/src/main/java/org/apache/calcite/util/mapping/MappingType.java
@@ -118,7 +118,7 @@ public enum MappingType {
 
   private final int inverseOrdinal;
 
-  private MappingType() {
+  MappingType() {
     this.inverseOrdinal = ((ordinal() & 3) << 2)
         | ((ordinal() & 12) >> 2);
   }

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/mapping/Mappings.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/mapping/Mappings.java b/core/src/main/java/org/apache/calcite/util/mapping/Mappings.java
index 8303bf8..79a7216 100644
--- a/core/src/main/java/org/apache/calcite/util/mapping/Mappings.java
+++ b/core/src/main/java/org/apache/calcite/util/mapping/Mappings.java
@@ -1549,7 +1549,7 @@ public abstract class Mappings {
     private final MappingType mappingType;
     private final int[] targets;
 
-    public PartialFunctionImpl(
+    PartialFunctionImpl(
         int sourceCount,
         int targetCount,
         MappingType mappingType) {

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/main/java/org/apache/calcite/util/trace/CalciteTrace.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/calcite/util/trace/CalciteTrace.java b/core/src/main/java/org/apache/calcite/util/trace/CalciteTrace.java
index b3e46c4..2e01742 100644
--- a/core/src/main/java/org/apache/calcite/util/trace/CalciteTrace.java
+++ b/core/src/main/java/org/apache/calcite/util/trace/CalciteTrace.java
@@ -55,8 +55,7 @@ public abstract class CalciteTrace {
    */
   public static final Logger PARSER_LOGGER = getParserTracer();
 
-  private static final ThreadLocal<Function2<Void, File, String>>
-  DYNAMIC_HANDLER =
+  private static final ThreadLocal<Function2<Void, File, String>> DYNAMIC_HANDLER =
       new ThreadLocal<Function2<Void, File, String>>() {
         @Override protected Function2<Void, File, String> initialValue() {
           return Functions.ignore2();

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/RootHr.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/RootHr.java b/core/src/test/java/RootHr.java
index e537656..2780b6d 100644
--- a/core/src/test/java/RootHr.java
+++ b/core/src/test/java/RootHr.java
@@ -20,9 +20,9 @@
  * belongs to the unnamed (root) package. */
 public class RootHr {
   public final RootEmployee[] emps = {
-    new RootEmployee(100, "Bill"),
-    new RootEmployee(200, "Eric"),
-    new RootEmployee(150, "Sebastian"),
+      new RootEmployee(100, "Bill"),
+      new RootEmployee(200, "Eric"),
+      new RootEmployee(150, "Sebastian"),
   };
 }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/adapter/clone/ArrayTableTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/adapter/clone/ArrayTableTest.java b/core/src/test/java/org/apache/calcite/adapter/clone/ArrayTableTest.java
index 6136e54..8bbb770 100644
--- a/core/src/test/java/org/apache/calcite/adapter/clone/ArrayTableTest.java
+++ b/core/src/test/java/org/apache/calcite/adapter/clone/ArrayTableTest.java
@@ -44,7 +44,7 @@ public class ArrayTableTest {
     assertEquals(0xF0F, values[0]);
 
     values = new long[]{
-      0x1213141516171819L, 0x232425262728292AL, 0x3435363738393A3BL};
+        0x1213141516171819L, 0x232425262728292AL, 0x3435363738393A3BL};
     assertEquals(
         0x324, ArrayTable.BitSlicedPrimitiveArray.getLong(12, values, 9));
     assertEquals(

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/examples/foodmart/java/JdbcExample.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/examples/foodmart/java/JdbcExample.java b/core/src/test/java/org/apache/calcite/examples/foodmart/java/JdbcExample.java
index cf31244..aa98d5a 100644
--- a/core/src/test/java/org/apache/calcite/examples/foodmart/java/JdbcExample.java
+++ b/core/src/test/java/org/apache/calcite/examples/foodmart/java/JdbcExample.java
@@ -71,9 +71,9 @@ public class JdbcExample {
   /** Object that will be used via reflection to create the "hr" schema. */
   public static class Hr {
     public final Employee[] emps = {
-      new Employee(100, "Bill"),
-      new Employee(200, "Eric"),
-      new Employee(150, "Sebastian"),
+        new Employee(100, "Bill"),
+        new Employee(200, "Eric"),
+        new Employee(150, "Sebastian"),
     };
   }
 
@@ -92,8 +92,8 @@ public class JdbcExample {
    * schema. */
   public static class Foodmart {
     public final SalesFact[] sales_fact_1997 = {
-      new SalesFact(100, 10),
-      new SalesFact(150, 20),
+        new SalesFact(100, 10),
+        new SalesFact(150, 20),
     };
   }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/jdbc/CalciteRemoteDriverTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/jdbc/CalciteRemoteDriverTest.java b/core/src/test/java/org/apache/calcite/jdbc/CalciteRemoteDriverTest.java
index e08e3c0..ab68285 100644
--- a/core/src/test/java/org/apache/calcite/jdbc/CalciteRemoteDriverTest.java
+++ b/core/src/test/java/org/apache/calcite/jdbc/CalciteRemoteDriverTest.java
@@ -92,8 +92,7 @@ public class CalciteRemoteDriverTest {
       CalcitePrepareImpl.DEBUG ? Util.printWriter(System.out)
           : new PrintWriter(new StringWriter());
 
-  private static final CalciteAssert.ConnectionFactory
-  REMOTE_CONNECTION_FACTORY =
+  private static final CalciteAssert.ConnectionFactory REMOTE_CONNECTION_FACTORY =
       new CalciteAssert.ConnectionFactory() {
         public Connection createConnection() throws SQLException {
           return remoteConnection;
@@ -384,22 +383,22 @@ public class CalciteRemoteDriverTest {
    * specification */
   @Test public void testTableB5() {
     SqlType[] columns = {
-      SqlType.TINYINT, SqlType.SMALLINT, SqlType.INTEGER, SqlType.BIGINT,
-      SqlType.REAL, SqlType.FLOAT, SqlType.DOUBLE, SqlType.DECIMAL,
-      SqlType.NUMERIC, SqlType.BIT, SqlType.BOOLEAN, SqlType.CHAR,
-      SqlType.VARCHAR, SqlType.LONGVARCHAR, SqlType.BINARY, SqlType.VARBINARY,
-      SqlType.LONGVARBINARY, SqlType.DATE, SqlType.TIME, SqlType.TIMESTAMP,
-      SqlType.ARRAY, SqlType.BLOB, SqlType.CLOB, SqlType.STRUCT, SqlType.REF,
-      SqlType.DATALINK, SqlType.JAVA_OBJECT, SqlType.ROWID, SqlType.NCHAR,
-      SqlType.NVARCHAR, SqlType.LONGNVARCHAR, SqlType.NCLOB, SqlType.SQLXML
+        SqlType.TINYINT, SqlType.SMALLINT, SqlType.INTEGER, SqlType.BIGINT,
+        SqlType.REAL, SqlType.FLOAT, SqlType.DOUBLE, SqlType.DECIMAL,
+        SqlType.NUMERIC, SqlType.BIT, SqlType.BOOLEAN, SqlType.CHAR,
+        SqlType.VARCHAR, SqlType.LONGVARCHAR, SqlType.BINARY, SqlType.VARBINARY,
+        SqlType.LONGVARBINARY, SqlType.DATE, SqlType.TIME, SqlType.TIMESTAMP,
+        SqlType.ARRAY, SqlType.BLOB, SqlType.CLOB, SqlType.STRUCT, SqlType.REF,
+        SqlType.DATALINK, SqlType.JAVA_OBJECT, SqlType.ROWID, SqlType.NCHAR,
+        SqlType.NVARCHAR, SqlType.LONGNVARCHAR, SqlType.NCLOB, SqlType.SQLXML
     };
     Class[] rows = {
-      String.class, BigDecimal.class, Boolean.class, Byte.class, Short.class,
-      Integer.class, Long.class, Float.class, Double.class, byte[].class,
-      BigInteger.class, java.sql.Date.class, Time.class, Timestamp.class,
-      Array.class, Blob.class, Clob.class, Struct.class, Ref.class,
-      URL.class, Class.class, RowId.class, NClob.class, SQLXML.class,
-      Calendar.class, java.util.Date.class
+        String.class, BigDecimal.class, Boolean.class, Byte.class, Short.class,
+        Integer.class, Long.class, Float.class, Double.class, byte[].class,
+        BigInteger.class, java.sql.Date.class, Time.class, Timestamp.class,
+        Array.class, Blob.class, Clob.class, Struct.class, Ref.class,
+        URL.class, Class.class, RowId.class, NClob.class, SQLXML.class,
+        Calendar.class, java.util.Date.class
     };
     for (Class row : rows) {
       final String s = row == Date.class ? row.getName() : row.getSimpleName();
@@ -422,15 +421,15 @@ public class CalciteRemoteDriverTest {
    * specification */
   @Test public void testTableB6() {
     SqlType[] columns = {
-      SqlType.TINYINT, SqlType.SMALLINT, SqlType.INTEGER, SqlType.BIGINT,
-      SqlType.REAL, SqlType.FLOAT, SqlType.DOUBLE, SqlType.DECIMAL,
-      SqlType.NUMERIC, SqlType.BIT, SqlType.BOOLEAN, SqlType.CHAR,
-      SqlType.VARCHAR, SqlType.LONGVARCHAR, SqlType.BINARY, SqlType.VARBINARY,
-      SqlType.LONGVARBINARY, SqlType.DATE, SqlType.TIME, SqlType.TIMESTAMP,
-      SqlType.CLOB, SqlType.BLOB, SqlType.ARRAY, SqlType.REF,
-      SqlType.DATALINK, SqlType.STRUCT, SqlType.JAVA_OBJECT, SqlType.ROWID,
-      SqlType.NCHAR, SqlType.NVARCHAR, SqlType.LONGNVARCHAR, SqlType.NCLOB,
-      SqlType.SQLXML
+        SqlType.TINYINT, SqlType.SMALLINT, SqlType.INTEGER, SqlType.BIGINT,
+        SqlType.REAL, SqlType.FLOAT, SqlType.DOUBLE, SqlType.DECIMAL,
+        SqlType.NUMERIC, SqlType.BIT, SqlType.BOOLEAN, SqlType.CHAR,
+        SqlType.VARCHAR, SqlType.LONGVARCHAR, SqlType.BINARY, SqlType.VARBINARY,
+        SqlType.LONGVARBINARY, SqlType.DATE, SqlType.TIME, SqlType.TIMESTAMP,
+        SqlType.CLOB, SqlType.BLOB, SqlType.ARRAY, SqlType.REF,
+        SqlType.DATALINK, SqlType.STRUCT, SqlType.JAVA_OBJECT, SqlType.ROWID,
+        SqlType.NCHAR, SqlType.NVARCHAR, SqlType.LONGNVARCHAR, SqlType.NCLOB,
+        SqlType.SQLXML
     };
     final PrintWriter out =
         CalcitePrepareImpl.DEBUG

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/plan/volcano/TraitPropagationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/plan/volcano/TraitPropagationTest.java b/core/src/test/java/org/apache/calcite/plan/volcano/TraitPropagationTest.java
index f982384..74e675c 100644
--- a/core/src/test/java/org/apache/calcite/plan/volcano/TraitPropagationTest.java
+++ b/core/src/test/java/org/apache/calcite/plan/volcano/TraitPropagationTest.java
@@ -294,7 +294,7 @@ public class TraitPropagationTest {
 
   /** Physical Aggregate RelNode */
   private static class PhysAgg extends Aggregate implements Phys {
-    public PhysAgg(RelOptCluster cluster, RelTraitSet traits, RelNode child,
+    PhysAgg(RelOptCluster cluster, RelTraitSet traits, RelNode child,
         boolean indicator, ImmutableBitSet groupSet,
         List<ImmutableBitSet> groupSets, List<AggregateCall> aggCalls) {
       super(cluster, traits, child, indicator, groupSet, groupSets, aggCalls);
@@ -316,7 +316,7 @@ public class TraitPropagationTest {
 
   /** Physical Project RelNode */
   private static class PhysProj extends Project implements Phys {
-    public PhysProj(RelOptCluster cluster, RelTraitSet traits, RelNode child,
+    PhysProj(RelOptCluster cluster, RelTraitSet traits, RelNode child,
         List<RexNode> exps, RelDataType rowType) {
       super(cluster, traits, child, exps, rowType);
     }
@@ -350,7 +350,7 @@ public class TraitPropagationTest {
 
   /** Physical Sort RelNode */
   private static class PhysSort extends Sort implements Phys {
-    public PhysSort(RelOptCluster cluster, RelTraitSet traits, RelNode child,
+    PhysSort(RelOptCluster cluster, RelTraitSet traits, RelNode child,
         RelCollation collation, RexNode offset,
         RexNode fetch) {
       super(cluster, traits, child, collation, offset, fetch);
@@ -372,7 +372,7 @@ public class TraitPropagationTest {
 
   /** Physical Table RelNode */
   private static class PhysTable extends AbstractRelNode implements Phys {
-    public PhysTable(RelOptCluster cluster) {
+    PhysTable(RelOptCluster cluster) {
       super(cluster, cluster.traitSet().replace(PHYSICAL).replace(COLLATION));
       RelDataTypeFactory typeFactory = cluster.getTypeFactory();
       final RelDataType stringType = typeFactory.createJavaType(String.class);

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTest.java b/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTest.java
index b4a2557..337d3cf 100644
--- a/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTest.java
+++ b/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTest.java
@@ -461,7 +461,7 @@ public class VolcanoPlannerTest {
 
   /** Converter from PHYS to ENUMERABLE convention. */
   class PhysToIteratorConverter extends ConverterImpl {
-    public PhysToIteratorConverter(
+    PhysToIteratorConverter(
         RelOptCluster cluster,
         RelNode child) {
       super(

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTraitTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTraitTest.java b/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTraitTest.java
index 78a0b7c..66704ed 100644
--- a/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTraitTest.java
+++ b/core/src/test/java/org/apache/calcite/plan/volcano/VolcanoPlannerTraitTest.java
@@ -506,7 +506,7 @@ public class VolcanoPlannerTraitTest {
   /** Relational expression with one input, that implements the {@link FooRel}
    * mix-in interface. */
   private static class IterSingleRel extends TestSingleRel implements FooRel {
-    public IterSingleRel(RelOptCluster cluster, RelNode child) {
+    IterSingleRel(RelOptCluster cluster, RelNode child) {
       super(
           cluster,
           cluster.traitSetOf(EnumerableConvention.INSTANCE),
@@ -678,7 +678,7 @@ public class VolcanoPlannerTraitTest {
 
   /** Planner rule that converts from PHYS to ENUMERABLE convention. */
   private static class PhysToIteratorConverterRule extends ConverterRule {
-    public PhysToIteratorConverterRule() {
+    PhysToIteratorConverterRule() {
       super(
           RelNode.class,
           PHYS_CALLING_CONVENTION,
@@ -695,7 +695,7 @@ public class VolcanoPlannerTraitTest {
 
   /** Planner rule that converts PHYS to ENUMERABLE convention. */
   private static class PhysToIteratorConverter extends ConverterImpl {
-    public PhysToIteratorConverter(
+    PhysToIteratorConverter(
         RelOptCluster cluster,
         RelNode child) {
       super(
@@ -715,7 +715,7 @@ public class VolcanoPlannerTraitTest {
   /** Planner rule that converts an {@link IterSingleRel} on a
    * {@link PhysToIteratorConverter} into a {@link IterMergedRel}. */
   private static class IterSinglePhysMergeRule extends RelOptRule {
-    public IterSinglePhysMergeRule() {
+    IterSinglePhysMergeRule() {
       super(
           operand(IterSingleRel.class,
               operand(PhysToIteratorConverter.class, any())));
@@ -731,7 +731,7 @@ public class VolcanoPlannerTraitTest {
   /** Relational expression with no inputs, that implements the {@link FooRel}
    * mix-in interface. */
   private static class IterMergedRel extends TestLeafRel implements FooRel {
-    public IterMergedRel(RelOptCluster cluster, String label) {
+    IterMergedRel(RelOptCluster cluster, String label) {
       super(
           cluster,
           cluster.traitSetOf(EnumerableConvention.INSTANCE),

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/sql/parser/SqlParserTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/sql/parser/SqlParserTest.java b/core/src/test/java/org/apache/calcite/sql/parser/SqlParserTest.java
index 90e03c4..435e906 100644
--- a/core/src/test/java/org/apache/calcite/sql/parser/SqlParserTest.java
+++ b/core/src/test/java/org/apache/calcite/sql/parser/SqlParserTest.java
@@ -1020,8 +1020,8 @@ public class SqlParserTest {
 
   @Test public void testOverlaps() {
     final String[] ops = {
-      "overlaps", "equals", "precedes", "succeeds",
-      "immediately precedes", "immediately succeeds"
+        "overlaps", "equals", "precedes", "succeeds",
+        "immediately precedes", "immediately succeeds"
     };
     final String[] periods = {"period ", ""};
     for (String period : periods) {
@@ -7269,7 +7269,7 @@ public class SqlParserTest {
 
 
     check("alter system set \"a\".\"number\" = 1",
-      "ALTER SYSTEM SET `a`.`number` = 1");
+        "ALTER SYSTEM SET `a`.`number` = 1");
     sql("set approx = -12.3450")
         .ok("SET `APPROX` = -12.3450")
         .node(isDdl());

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/sql/parser/parserextensiontesting/ExtensionSqlParserTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/sql/parser/parserextensiontesting/ExtensionSqlParserTest.java b/core/src/test/java/org/apache/calcite/sql/parser/parserextensiontesting/ExtensionSqlParserTest.java
index 9d6fcfa..1b58a4c 100644
--- a/core/src/test/java/org/apache/calcite/sql/parser/parserextensiontesting/ExtensionSqlParserTest.java
+++ b/core/src/test/java/org/apache/calcite/sql/parser/parserextensiontesting/ExtensionSqlParserTest.java
@@ -36,13 +36,13 @@ public class ExtensionSqlParserTest extends SqlParserTest {
 
   @Test public void testAlterSystemExtension() throws SqlParseException {
     check("alter system upload jar '/path/to/jar'",
-      "ALTER SYSTEM UPLOAD JAR '/path/to/jar'");
+        "ALTER SYSTEM UPLOAD JAR '/path/to/jar'");
   }
 
   @Test public void testAlterSystemExtensionWithoutAlter() throws SqlParseException {
     // We need to include the scope for custom alter operations
     checkFails("^upload^ jar '/path/to/jar'",
-      "(?s).*Encountered \"upload\" at .*");
+        "(?s).*Encountered \"upload\" at .*");
   }
 
   @Test public void testCreateTable() {

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/sql/test/SqlAdvisorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/sql/test/SqlAdvisorTest.java b/core/src/test/java/org/apache/calcite/sql/test/SqlAdvisorTest.java
index e4ec229..e0f0d94 100644
--- a/core/src/test/java/org/apache/calcite/sql/test/SqlAdvisorTest.java
+++ b/core/src/test/java/org/apache/calcite/sql/test/SqlAdvisorTest.java
@@ -1234,7 +1234,7 @@ public class SqlAdvisorTest extends SqlValidatorTestCase {
 
   /** Factory that creates testers. */
   private static class AdvisorTesterFactory extends DelegatingSqlTestFactory {
-    public AdvisorTesterFactory() {
+    AdvisorTesterFactory() {
       super(DefaultSqlTestFactory.INSTANCE);
     }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/sql/test/SqlOperatorBaseTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/sql/test/SqlOperatorBaseTest.java b/core/src/test/java/org/apache/calcite/sql/test/SqlOperatorBaseTest.java
index 131932e..f73921f 100644
--- a/core/src/test/java/org/apache/calcite/sql/test/SqlOperatorBaseTest.java
+++ b/core/src/test/java/org/apache/calcite/sql/test/SqlOperatorBaseTest.java
@@ -201,59 +201,59 @@ public abstract class SqlOperatorBaseTest {
           "[0-9][0-9][0-9][0-9]-[0-9][0-9]-[0-9][0-9]");
 
   public static final String[] NUMERIC_TYPE_NAMES = {
-    "TINYINT", "SMALLINT", "INTEGER", "BIGINT",
-    "DECIMAL(5, 2)", "REAL", "FLOAT", "DOUBLE"
+      "TINYINT", "SMALLINT", "INTEGER", "BIGINT",
+      "DECIMAL(5, 2)", "REAL", "FLOAT", "DOUBLE"
   };
 
   // REVIEW jvs 27-Apr-2006:  for Float and Double, MIN_VALUE
   // is the smallest positive value, not the smallest negative value
   public static final String[] MIN_NUMERIC_STRINGS = {
-    Long.toString(Byte.MIN_VALUE),
-    Long.toString(Short.MIN_VALUE),
-    Long.toString(Integer.MIN_VALUE),
-    Long.toString(Long.MIN_VALUE),
-    "-999.99",
-
-    // NOTE jvs 26-Apr-2006:  Win32 takes smaller values from win32_values.h
-    "1E-37", /*Float.toString(Float.MIN_VALUE)*/
-    "2E-307", /*Double.toString(Double.MIN_VALUE)*/
-    "2E-307" /*Double.toString(Double.MIN_VALUE)*/,
+      Long.toString(Byte.MIN_VALUE),
+      Long.toString(Short.MIN_VALUE),
+      Long.toString(Integer.MIN_VALUE),
+      Long.toString(Long.MIN_VALUE),
+      "-999.99",
+
+      // NOTE jvs 26-Apr-2006:  Win32 takes smaller values from win32_values.h
+      "1E-37", /*Float.toString(Float.MIN_VALUE)*/
+      "2E-307", /*Double.toString(Double.MIN_VALUE)*/
+      "2E-307" /*Double.toString(Double.MIN_VALUE)*/,
   };
 
   public static final String[] MIN_OVERFLOW_NUMERIC_STRINGS = {
-    Long.toString(Byte.MIN_VALUE - 1),
-    Long.toString(Short.MIN_VALUE - 1),
-    Long.toString((long) Integer.MIN_VALUE - 1),
-    new BigDecimal(Long.MIN_VALUE).subtract(BigDecimal.ONE).toString(),
-    "-1000.00",
-    "1e-46",
-    "1e-324",
-    "1e-324"
+      Long.toString(Byte.MIN_VALUE - 1),
+      Long.toString(Short.MIN_VALUE - 1),
+      Long.toString((long) Integer.MIN_VALUE - 1),
+      new BigDecimal(Long.MIN_VALUE).subtract(BigDecimal.ONE).toString(),
+      "-1000.00",
+      "1e-46",
+      "1e-324",
+      "1e-324"
   };
 
   public static final String[] MAX_NUMERIC_STRINGS = {
-    Long.toString(Byte.MAX_VALUE),
-    Long.toString(Short.MAX_VALUE),
-    Long.toString(Integer.MAX_VALUE),
-    Long.toString(Long.MAX_VALUE), "999.99",
-
-    // NOTE jvs 26-Apr-2006:  use something slightly less than MAX_VALUE
-    // because roundtripping string to approx to string doesn't preserve
-    // MAX_VALUE on win32
-    "3.4028234E38", /*Float.toString(Float.MAX_VALUE)*/
-    "1.79769313486231E308", /*Double.toString(Double.MAX_VALUE)*/
-    "1.79769313486231E308" /*Double.toString(Double.MAX_VALUE)*/
+      Long.toString(Byte.MAX_VALUE),
+      Long.toString(Short.MAX_VALUE),
+      Long.toString(Integer.MAX_VALUE),
+      Long.toString(Long.MAX_VALUE), "999.99",
+
+      // NOTE jvs 26-Apr-2006:  use something slightly less than MAX_VALUE
+      // because roundtripping string to approx to string doesn't preserve
+      // MAX_VALUE on win32
+      "3.4028234E38", /*Float.toString(Float.MAX_VALUE)*/
+      "1.79769313486231E308", /*Double.toString(Double.MAX_VALUE)*/
+      "1.79769313486231E308" /*Double.toString(Double.MAX_VALUE)*/
   };
 
   public static final String[] MAX_OVERFLOW_NUMERIC_STRINGS = {
-    Long.toString(Byte.MAX_VALUE + 1),
-    Long.toString(Short.MAX_VALUE + 1),
-    Long.toString((long) Integer.MAX_VALUE + 1),
-    (new BigDecimal(Long.MAX_VALUE)).add(BigDecimal.ONE).toString(),
-    "1000.00",
-    "1e39",
-    "-1e309",
-    "1e309"
+      Long.toString(Byte.MAX_VALUE + 1),
+      Long.toString(Short.MAX_VALUE + 1),
+      Long.toString((long) Integer.MAX_VALUE + 1),
+      (new BigDecimal(Long.MAX_VALUE)).add(BigDecimal.ONE).toString(),
+      "1000.00",
+      "1e39",
+      "-1e309",
+      "1e309"
   };
   private static final boolean[] FALSE_TRUE = {false, true};
   private static final SqlTester.VmName VM_FENNEL = SqlTester.VmName.FENNEL;
@@ -2428,22 +2428,22 @@ public abstract class SqlOperatorBaseTest {
    * TIMESTAMP values. */
   @Test public void testPeriodOperators() {
     String[] times = {
-      "TIME '01:00:00'",
-      "TIME '02:00:00'",
-      "TIME '03:00:00'",
-      "TIME '04:00:00'",
+        "TIME '01:00:00'",
+        "TIME '02:00:00'",
+        "TIME '03:00:00'",
+        "TIME '04:00:00'",
     };
     String[] dates = {
-      "DATE '1970-01-01'",
-      "DATE '1970-02-01'",
-      "DATE '1970-03-01'",
-      "DATE '1970-04-01'",
+        "DATE '1970-01-01'",
+        "DATE '1970-02-01'",
+        "DATE '1970-03-01'",
+        "DATE '1970-04-01'",
     };
     String[] timestamps = {
-      "TIMESTAMP '1970-01-01 00:00:00'",
-      "TIMESTAMP '1970-02-01 00:00:00'",
-      "TIMESTAMP '1970-03-01 00:00:00'",
-      "TIMESTAMP '1970-04-01 00:00:00'",
+        "TIMESTAMP '1970-01-01 00:00:00'",
+        "TIMESTAMP '1970-02-01 00:00:00'",
+        "TIMESTAMP '1970-03-01 00:00:00'",
+        "TIMESTAMP '1970-04-01 00:00:00'",
     };
     checkOverlaps(new OverlapChecker(times));
     checkOverlaps(new OverlapChecker(dates));
@@ -3806,13 +3806,13 @@ public abstract class SqlOperatorBaseTest {
     final SqlTester tester1 = oracleTester();
     tester1.setFor(OracleSqlOperatorTable.TRANSLATE3);
     tester1.checkString(
-       "translate('aabbcc', 'ab', '+-')",
-       "++--cc",
-       "VARCHAR(6) NOT NULL");
+        "translate('aabbcc', 'ab', '+-')",
+        "++--cc",
+        "VARCHAR(6) NOT NULL");
     tester1.checkString(
         "translate('aabbcc', 'ab', 'ba')",
-       "bbaacc",
-       "VARCHAR(6) NOT NULL");
+        "bbaacc",
+        "VARCHAR(6) NOT NULL");
     tester1.checkString(
         "translate('aabbcc', 'ab', '')",
         "cc",
@@ -3822,15 +3822,15 @@ public abstract class SqlOperatorBaseTest {
         "aabbcc",
         "VARCHAR(6) NOT NULL");
     tester1.checkString(
-       "translate(cast('aabbcc' as varchar(10)), 'ab', '+-')",
-       "++--cc",
-       "VARCHAR(10) NOT NULL");
+        "translate(cast('aabbcc' as varchar(10)), 'ab', '+-')",
+        "++--cc",
+        "VARCHAR(10) NOT NULL");
     tester1.checkNull(
-       "translate(cast(null as varchar(7)), 'ab', '+-')");
+        "translate(cast(null as varchar(7)), 'ab', '+-')");
     tester1.checkNull(
-       "translate('aabbcc', cast(null as varchar(2)), '+-')");
+        "translate('aabbcc', cast(null as varchar(2)), '+-')");
     tester1.checkNull(
-       "translate('aabbcc', 'ab', cast(null as varchar(2)))");
+        "translate('aabbcc', 'ab', cast(null as varchar(2)))");
   }
 
   @Test public void testOverlayFunc() {
@@ -6194,7 +6194,7 @@ public abstract class SqlOperatorBaseTest {
 
     // string values -- note that empty string is not null
     final String[] stringValues = {
-      "'a'", "CAST(NULL AS VARCHAR(1))", "''"
+        "'a'", "CAST(NULL AS VARCHAR(1))", "''"
     };
     tester.checkAgg("COUNT(*)", stringValues, 3, (double) 0);
     tester.checkAgg("COUNT(x)", stringValues, 2, (double) 0);
@@ -6893,7 +6893,7 @@ public abstract class SqlOperatorBaseTest {
       implements SqlTester.ResultChecker {
     private final Pattern[] patterns;
 
-    public ExceptionResultChecker(Pattern... patterns) {
+    ExceptionResultChecker(Pattern... patterns) {
       this.patterns = patterns;
     }
 
@@ -6928,7 +6928,7 @@ public abstract class SqlOperatorBaseTest {
     private final Object expected;
     private final Pattern[] patterns;
 
-    public ValueOrExceptionResultChecker(
+    ValueOrExceptionResultChecker(
         Object expected, Pattern... patterns) {
       this.expected = expected;
       this.patterns = patterns;

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/test/CalciteAssert.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/test/CalciteAssert.java b/core/src/test/java/org/apache/calcite/test/CalciteAssert.java
index 08aba3c..76a464a 100644
--- a/core/src/test/java/org/apache/calcite/test/CalciteAssert.java
+++ b/core/src/test/java/org/apache/calcite/test/CalciteAssert.java
@@ -339,8 +339,8 @@ public class CalciteAssert {
     };
   }
 
-  public static Function<ResultSet, Void>
-  checkResultCount(final Matcher<Integer> expected) {
+  public static Function<ResultSet, Void> checkResultCount(
+      final Matcher<Integer> expected) {
     return new Function<ResultSet, Void>() {
       public Void apply(ResultSet resultSet) {
         try {
@@ -1151,7 +1151,7 @@ public class CalciteAssert {
 
     private final ConnectionFactory factory;
 
-    public PoolingConnectionFactory(final ConnectionFactory factory) {
+    PoolingConnectionFactory(final ConnectionFactory factory) {
       this.factory = factory;
     }
 
@@ -1729,8 +1729,8 @@ public class CalciteAssert {
         return path;
       }
       final String[] dirs = {
-        "../calcite-test-dataset",
-        "../../calcite-test-dataset"
+          "../calcite-test-dataset",
+          "../../calcite-test-dataset"
       };
       for (String s : dirs) {
         if (new File(s).exists() && new File(s, "vm").exists()) {

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/test/CalciteSuite.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/test/CalciteSuite.java b/core/src/test/java/org/apache/calcite/test/CalciteSuite.java
index 6853644..4f9b075 100644
--- a/core/src/test/java/org/apache/calcite/test/CalciteSuite.java
+++ b/core/src/test/java/org/apache/calcite/test/CalciteSuite.java
@@ -175,7 +175,7 @@ import org.junit.runners.Suite;
     // system tests and benchmarks (very slow, but usually only run if
     // '-Dcalcite.test.slow' is specified)
     FoodmartTest.class
-})
+    })
 public class CalciteSuite {
 }
 

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/test/ExceptionMessageTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/test/ExceptionMessageTest.java b/core/src/test/java/org/apache/calcite/test/ExceptionMessageTest.java
index a2ec482..2d61698 100644
--- a/core/src/test/java/org/apache/calcite/test/ExceptionMessageTest.java
+++ b/core/src/test/java/org/apache/calcite/test/ExceptionMessageTest.java
@@ -47,8 +47,8 @@ public class ExceptionMessageTest {
   @SuppressWarnings("UnusedDeclaration")
   public static class TestSchema {
     public Entry[] entries = {
-      new Entry(1, "name1"),
-      new Entry(2, "name2")
+        new Entry(1, "name1"),
+        new Entry(2, "name2")
     };
 
     public Iterable<Entry> badEntries = new Iterable<Entry>() {

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/test/FilteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/test/FilteratorTest.java b/core/src/test/java/org/apache/calcite/test/FilteratorTest.java
index b0d8d94..72a3827 100644
--- a/core/src/test/java/org/apache/calcite/test/FilteratorTest.java
+++ b/core/src/test/java/org/apache/calcite/test/FilteratorTest.java
@@ -72,11 +72,11 @@ public class FilteratorTest {
     final HashSet hashSet = new HashSet();
     final LinkedList linkedList = new LinkedList();
     Collection[] collections = {
-      null,
-      arrayList,
-      hashSet,
-      linkedList,
-      null,
+        null,
+        arrayList,
+        hashSet,
+        linkedList,
+        null,
     };
     final Filterator<List> filterator =
         new Filterator<List>(

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/test/FoodmartTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/test/FoodmartTest.java b/core/src/test/java/org/apache/calcite/test/FoodmartTest.java
index 53c8dc9..1968817 100644
--- a/core/src/test/java/org/apache/calcite/test/FoodmartTest.java
+++ b/core/src/test/java/org/apache/calcite/test/FoodmartTest.java
@@ -43,53 +43,53 @@ import java.util.Map;
 public class FoodmartTest {
 
   private static final int[] DISABLED_IDS = {
-    58, 83, 202, 204, 205, 206, 207, 209, 211, 231, 247, 275, 309, 383, 384,
-    385, 448, 449, 471, 494, 495, 496, 497, 499, 500, 501, 502, 503, 505, 506,
-    507, 514, 516, 518, 520, 534, 551, 563, 566, 571, 628, 629, 630, 644, 649,
-    650, 651, 653, 654, 655, 656, 657, 658, 659, 669, 722, 731, 732, 737, 748,
-    750, 756, 774, 777, 778, 779, 781, 782, 783, 811, 818, 819, 820, 2057,
-    2059, 2060, 2073, 2088, 2098, 2099, 2136, 2151, 2158, 2162, 2163, 2164,
-    2165, 2166, 2167, 2168, 2169, 2170, 2171, 2172, 2173, 2174, 2175, 2176,
-    2177, 2178, 2179, 2180, 2181, 2187, 2190, 2191, 2235, 2245, 2264, 2265,
-    2266, 2267, 2268, 2270, 2271, 2279, 2327, 2328, 2341, 2356, 2365, 2374,
-    2415, 2416, 2424, 2432, 2455, 2456, 2457, 2518, 2521, 2528, 2542, 2570,
-    2578, 2579, 2580, 2581, 2594, 2598, 2749, 2774, 2778, 2780, 2781, 2786,
-    2787, 2790, 2791, 2876, 2883, 5226, 5227, 5228, 5229, 5230, 5238, 5239,
-    5249, 5279, 5281, 5282, 5283, 5284, 5286, 5288, 5291, 5415, 5444, 5445,
-    5446, 5447, 5448, 5452, 5459, 5460, 5461, 5517, 5519, 5558, 5560, 5561,
-    5562, 5572, 5573, 5576, 5577, 5607, 5644, 5648, 5657, 5664, 5665, 5667,
-    5671, 5682, 5700, 5743, 5748, 5749, 5750, 5751, 5775, 5776, 5777, 5785,
-    5793, 5796, 5797, 5810, 5811, 5814, 5816, 5852, 5874, 5875, 5910, 5953,
-    5960, 5971, 5975, 5983, 6016, 6028, 6030, 6031, 6033, 6034, 6081, 6082,
-    6083, 6084, 6085, 6086, 6087, 6088, 6089, 6090, 6097, 6098, 6099, 6100,
-    6101, 6102, 6103, 6104, 6105, 6106, 6107, 6108, 6109, 6110, 6111, 6112,
-    6113, 6114, 6115, 6141, 6150, 6156, 6160, 6164, 6168, 6169, 6172, 6177,
-    6180, 6181, 6185, 6187, 6188, 6190, 6191, 6193, 6194, 6196, 6197, 6199,
-    6200, 6202, 6203, 6205, 6206, 6208, 6209, 6211, 6212, 6214, 6215, 6217,
-    6218, 6220, 6221, 6223, 6224, 6226, 6227, 6229, 6230, 6232, 6233, 6235,
-    6236, 6238, 6239, 6241, 6242, 6244, 6245, 6247, 6248, 6250, 6251, 6253,
-    6254, 6256, 6257, 6259, 6260, 6262, 6263, 6265, 6266, 6268, 6269,
-
-    // failed
-    5677, 5681,
-
-    // 2nd run
-    6271, 6272, 6274, 6275, 6277, 6278, 6280, 6281, 6283, 6284, 6286, 6287,
-    6289, 6290, 6292, 6293, 6295, 6296, 6298, 6299, 6301, 6302, 6304, 6305,
-    6307, 6308, 6310, 6311, 6313, 6314, 6316, 6317, 6319, 6327, 6328, 6337,
-    6338, 6339, 6341, 6345, 6346, 6348, 6349, 6354, 6355, 6359, 6366, 6368,
-    6369, 6375, 6376, 6377, 6389, 6396, 6400, 6422, 6424, 6445, 6447, 6449,
-    6450, 6454, 6456, 6470, 6479, 6480, 6491, 6509, 6518, 6522, 6561, 6562,
-    6564, 6566, 6578, 6581, 6582, 6583, 6587, 6591, 6594, 6603, 6610, 6613,
-    6615, 6618, 6619, 6622, 6627, 6632, 6635, 6643, 6650, 6651, 6652, 6653,
-    6656, 6659, 6668, 6670, 6720, 6726, 6735, 6737, 6739,
-
-    // timeout oor OOM
-    420, 423, 5218, 5219, 5616, 5617, 5618, 5891, 5892, 5895, 5896, 5898, 5899,
-    5900, 5901, 5902, 6080, 6091,
-
-    // bugs
-    6597, // CALCITE-403
+      58, 83, 202, 204, 205, 206, 207, 209, 211, 231, 247, 275, 309, 383, 384,
+      385, 448, 449, 471, 494, 495, 496, 497, 499, 500, 501, 502, 503, 505, 506,
+      507, 514, 516, 518, 520, 534, 551, 563, 566, 571, 628, 629, 630, 644, 649,
+      650, 651, 653, 654, 655, 656, 657, 658, 659, 669, 722, 731, 732, 737, 748,
+      750, 756, 774, 777, 778, 779, 781, 782, 783, 811, 818, 819, 820, 2057,
+      2059, 2060, 2073, 2088, 2098, 2099, 2136, 2151, 2158, 2162, 2163, 2164,
+      2165, 2166, 2167, 2168, 2169, 2170, 2171, 2172, 2173, 2174, 2175, 2176,
+      2177, 2178, 2179, 2180, 2181, 2187, 2190, 2191, 2235, 2245, 2264, 2265,
+      2266, 2267, 2268, 2270, 2271, 2279, 2327, 2328, 2341, 2356, 2365, 2374,
+      2415, 2416, 2424, 2432, 2455, 2456, 2457, 2518, 2521, 2528, 2542, 2570,
+      2578, 2579, 2580, 2581, 2594, 2598, 2749, 2774, 2778, 2780, 2781, 2786,
+      2787, 2790, 2791, 2876, 2883, 5226, 5227, 5228, 5229, 5230, 5238, 5239,
+      5249, 5279, 5281, 5282, 5283, 5284, 5286, 5288, 5291, 5415, 5444, 5445,
+      5446, 5447, 5448, 5452, 5459, 5460, 5461, 5517, 5519, 5558, 5560, 5561,
+      5562, 5572, 5573, 5576, 5577, 5607, 5644, 5648, 5657, 5664, 5665, 5667,
+      5671, 5682, 5700, 5743, 5748, 5749, 5750, 5751, 5775, 5776, 5777, 5785,
+      5793, 5796, 5797, 5810, 5811, 5814, 5816, 5852, 5874, 5875, 5910, 5953,
+      5960, 5971, 5975, 5983, 6016, 6028, 6030, 6031, 6033, 6034, 6081, 6082,
+      6083, 6084, 6085, 6086, 6087, 6088, 6089, 6090, 6097, 6098, 6099, 6100,
+      6101, 6102, 6103, 6104, 6105, 6106, 6107, 6108, 6109, 6110, 6111, 6112,
+      6113, 6114, 6115, 6141, 6150, 6156, 6160, 6164, 6168, 6169, 6172, 6177,
+      6180, 6181, 6185, 6187, 6188, 6190, 6191, 6193, 6194, 6196, 6197, 6199,
+      6200, 6202, 6203, 6205, 6206, 6208, 6209, 6211, 6212, 6214, 6215, 6217,
+      6218, 6220, 6221, 6223, 6224, 6226, 6227, 6229, 6230, 6232, 6233, 6235,
+      6236, 6238, 6239, 6241, 6242, 6244, 6245, 6247, 6248, 6250, 6251, 6253,
+      6254, 6256, 6257, 6259, 6260, 6262, 6263, 6265, 6266, 6268, 6269,
+
+      // failed
+      5677, 5681,
+
+      // 2nd run
+      6271, 6272, 6274, 6275, 6277, 6278, 6280, 6281, 6283, 6284, 6286, 6287,
+      6289, 6290, 6292, 6293, 6295, 6296, 6298, 6299, 6301, 6302, 6304, 6305,
+      6307, 6308, 6310, 6311, 6313, 6314, 6316, 6317, 6319, 6327, 6328, 6337,
+      6338, 6339, 6341, 6345, 6346, 6348, 6349, 6354, 6355, 6359, 6366, 6368,
+      6369, 6375, 6376, 6377, 6389, 6396, 6400, 6422, 6424, 6445, 6447, 6449,
+      6450, 6454, 6456, 6470, 6479, 6480, 6491, 6509, 6518, 6522, 6561, 6562,
+      6564, 6566, 6578, 6581, 6582, 6583, 6587, 6591, 6594, 6603, 6610, 6613,
+      6615, 6618, 6619, 6622, 6627, 6632, 6635, 6643, 6650, 6651, 6652, 6653,
+      6656, 6659, 6668, 6670, 6720, 6726, 6735, 6737, 6739,
+
+      // timeout oor OOM
+      420, 423, 5218, 5219, 5616, 5617, 5618, 5891, 5892, 5895, 5896, 5898,
+      5899, 5900, 5901, 5902, 6080, 6091,
+
+      // bugs
+      6597, // CALCITE-403
   };
 
   // Interesting tests. (We need to fix and remove from the disabled list.)

http://git-wip-us.apache.org/repos/asf/calcite/blob/9ab47c00/core/src/test/java/org/apache/calcite/test/InterpreterTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/calcite/test/InterpreterTest.java b/core/src/test/java/org/apache/calcite/test/InterpreterTest.java
index 1227917..d35c5c8 100644
--- a/core/src/test/java/org/apache/calcite/test/InterpreterTest.java
+++ b/core/src/test/java/org/apache/calcite/test/InterpreterTest.java
@@ -54,7 +54,7 @@ public class InterpreterTest {
   private class MyDataContext implements DataContext {
     private final Planner planner;
 
-    public MyDataContext(Planner planner) {
+    MyDataContext(Planner planner) {
       this.planner = planner;
     }