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 2014/10/01 01:08:39 UTC

[1/3] [OPTIQ-430] Rename project from "Optiq" to "Calcite"

Repository: incubator-optiq
Updated Branches:
  refs/heads/master 356a60609 -> 7fc4f6e08


http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/JdbcTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/JdbcTest.java b/core/src/test/java/net/hydromatic/optiq/test/JdbcTest.java
index 9ce3b1a..3869aec 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/JdbcTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/JdbcTest.java
@@ -79,7 +79,7 @@ import static org.hamcrest.CoreMatchers.*;
 import static org.junit.Assert.*;
 
 /**
- * Tests for using Optiq via JDBC.
+ * Tests for using Calcite via JDBC.
  */
 public class JdbcTest {
   public static final Method GENERATE_STRINGS_METHOD =
@@ -170,7 +170,7 @@ public class JdbcTest {
       throws SQLException, ClassNotFoundException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -236,7 +236,7 @@ public class JdbcTest {
       throws ClassNotFoundException, SQLException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -256,7 +256,7 @@ public class JdbcTest {
       throws SQLException, ClassNotFoundException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -365,7 +365,7 @@ public class JdbcTest {
     info.put("lex", "JAVA");
     info.put("quoting", "DOUBLE_QUOTE");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:", info);
+        DriverManager.getConnection("jdbc:calcite:", info);
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -395,7 +395,7 @@ public class JdbcTest {
       throws SQLException, ClassNotFoundException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -628,7 +628,7 @@ public class JdbcTest {
     final HandlerDriver driver =
         new HandlerDriver();
     OptiqConnection connection = (OptiqConnection)
-        driver.connect("jdbc:optiq:", new Properties());
+        driver.connect("jdbc:calcite:", new Properties());
     SchemaPlus rootSchema = connection.getRootSchema();
     rootSchema.add("hr", new ReflectiveSchema(new HrSchema()));
     connection.setSchema("hr");
@@ -678,7 +678,7 @@ public class JdbcTest {
     }
     final Driver driver = new Driver();
     OptiqConnection connection = (OptiqConnection)
-        driver.connect("jdbc:optiq:", new Properties());
+        driver.connect("jdbc:calcite:", new Properties());
     SchemaPlus rootSchema = connection.getRootSchema();
     rootSchema.add("hr", new ReflectiveSchema(new HrSchema()));
     connection.setSchema("hr");
@@ -710,7 +710,7 @@ public class JdbcTest {
    */
   @Test public void testReadme() throws ClassNotFoundException, SQLException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     final SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -734,9 +734,9 @@ public class JdbcTest {
   @Test public void testConnectionProperties() throws ClassNotFoundException,
       SQLException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
-    java.sql.Driver driver = DriverManager.getDriver("jdbc:optiq:");
+    java.sql.Driver driver = DriverManager.getDriver("jdbc:calcite:");
     final DriverPropertyInfo[] propertyInfo =
-        driver.getPropertyInfo("jdbc:optiq:", new Properties());
+        driver.getPropertyInfo("jdbc:calcite:", new Properties());
     final HashSet<String> names = new HashSet<String>();
     for (DriverPropertyInfo info : propertyInfo) {
       names.add(info.name);
@@ -751,11 +751,11 @@ public class JdbcTest {
    */
   @Test public void testVersion() throws ClassNotFoundException, SQLException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     final DatabaseMetaData metaData = optiqConnection.getMetaData();
-    assertEquals("Optiq JDBC Driver", metaData.getDriverName());
+    assertEquals("Calcite JDBC Driver", metaData.getDriverName());
 
     final String driverVersion = metaData.getDriverVersion();
     final int driverMajorVersion = metaData.getDriverMajorVersion();
@@ -763,7 +763,7 @@ public class JdbcTest {
     assertEquals(0, driverMajorVersion);
     assertTrue(driverMinorVersion >= 5); // will work for the next few releases
 
-    assertEquals("Optiq", metaData.getDatabaseProductName());
+    assertEquals("Calcite", metaData.getDatabaseProductName());
     final String databaseProductVersion =
         metaData.getDatabaseProductVersion();
     final int databaseMajorVersion = metaData.getDatabaseMajorVersion();
@@ -1746,7 +1746,7 @@ public class JdbcTest {
         + "}");
 
     Connection optiqConnection = DriverManager.getConnection(
-      "jdbc:optiq:", info);
+      "jdbc:calcite:", info);
 
     Statement optiqStatement = optiqConnection.createStatement();
     ResultSet rs = optiqStatement.executeQuery(
@@ -4023,7 +4023,7 @@ public class JdbcTest {
         .with(OptiqAssert.Config.REGULAR)
         .query(
             // *0 is used to make results predictable.
-            // If using just max(empid) optiq cannot compute the result
+            // If using just max(empid) calcite cannot compute the result
             // properly since it does not support range windows yet :(
             "select max(\"empid\"*0) over (partition by 42\n"
             + "  order by \"empid\") as m\n"
@@ -4043,7 +4043,7 @@ public class JdbcTest {
         .with(OptiqAssert.Config.REGULAR)
         .query(
             // *0 is used to make results predictable.
-            // If using just max(empid) optiq cannot compute the result
+            // If using just max(empid) calcite cannot compute the result
             // properly since it does not support range windows yet :(
             "select max(\"empid\"*0) over (partition by \"deptno\"\n"
             + "  order by 42) as m\n"
@@ -4393,7 +4393,7 @@ public class JdbcTest {
       outFile = new File(path + ".out");
     } else {
       // e.g. path = "sql/outer.oq"
-      // inUrl = "file:/home/fred/optiq/core/target/test-classes/sql/outer.oq"
+      // inUrl = "file:/home/fred/calcite/core/target/test-classes/sql/outer.oq"
       final URL inUrl = JdbcTest.class.getResource("/" + path);
       String x = inUrl.getFile();
       assert x.endsWith(path);
@@ -4911,7 +4911,7 @@ public class JdbcTest {
               public OptiqConnection createConnection() throws Exception {
                 OptiqConnection connection = (OptiqConnection)
                     new AutoTempDriver(objects)
-                        .connect("jdbc:optiq:", new Properties());
+                        .connect("jdbc:calcite:", new Properties());
                 final SchemaPlus rootSchema = connection.getRootSchema();
                 rootSchema.add("hr",
                     new ReflectiveSchema(new HrSchema()));
@@ -5316,11 +5316,11 @@ public class JdbcTest {
   }
 
   /** Test case for bug where if two tables have different element classes
-   * but those classes have identical fields, Optiq would generate code to use
+   * but those classes have identical fields, Calcite would generate code to use
    * the wrong element class; a {@link ClassCastException} would ensue. */
   @Test public void testDifferentTypesSameFields() throws Exception {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     final SchemaPlus rootSchema = optiqConnection.getRootSchema();

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/MultiJdbcSchemaJoinTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/MultiJdbcSchemaJoinTest.java b/core/src/test/java/net/hydromatic/optiq/test/MultiJdbcSchemaJoinTest.java
index 3f17e4b..c46ce79 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/MultiJdbcSchemaJoinTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/MultiJdbcSchemaJoinTest.java
@@ -57,8 +57,8 @@ public class MultiJdbcSchemaJoinTest {
     stmt2.execute("insert into table2 values('a', 'aaaa')");
     c2.close();
 
-    // Connect via optiq to these databases
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    // Connect via calcite to these databases
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection = connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
     final DataSource ds1 =
@@ -95,8 +95,8 @@ public class MultiJdbcSchemaJoinTest {
     stmt1.execute("insert into table1 values(200, 'bar')");
     c1.close();
 
-    // Make an optiq schema with both a jdbc schema and a non-jdbc schema
-    Connection optiqConn = DriverManager.getConnection("jdbc:optiq:");
+    // Make a Calcite schema with both a jdbc schema and a non-jdbc schema
+    Connection optiqConn = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         optiqConn.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -174,8 +174,8 @@ public class MultiJdbcSchemaJoinTest {
         "create table table1(id varchar(10) not null primary key, "
             + "field1 varchar(10))");
 
-    // Connect via optiq to these databases
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    // Connect via calcite to these databases
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection = connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
     final DataSource ds =

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/OptiqAssert.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/OptiqAssert.java b/core/src/test/java/net/hydromatic/optiq/test/OptiqAssert.java
index ad0baf9..54a306d 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/OptiqAssert.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/OptiqAssert.java
@@ -54,7 +54,7 @@ import static org.hamcrest.CoreMatchers.*;
 import static org.junit.Assert.*;
 
 /**
- * Fluid DSL for testing Optiq connections and queries.
+ * Fluid DSL for testing Calcite connections and queries.
  */
 public class OptiqAssert {
   private OptiqAssert() {}
@@ -62,20 +62,21 @@ public class OptiqAssert {
   /** Which database to use for tests that require a JDBC data source. By
    * default the test suite runs against the embedded hsqldb database.
    *
-   * <p>We recommend that casual users use hsqldb, and frequent Optiq developers
-   * use MySQL. The test suite runs faster against the MySQL database (mainly
-   * because of the 0.1s versus 6s startup time). You have to populate MySQL
-   * manually with the foodmart data set, otherwise there will be test failures.
-   * To run against MySQL, specify '-Doptiq.test.db=mysql' on the java command
-   * line.</p> */
+   * <p>We recommend that casual users use hsqldb, and frequent Calcite
+   * developers use MySQL. The test suite runs faster against the MySQL database
+   * (mainly because of the 0.1s versus 6s startup time). You have to populate
+   * MySQL manually with the foodmart data set, otherwise there will be test
+   * failures.  To run against MySQL, specify '-Dcalcite.test.db=mysql' on the
+   * java command line. */
   public static final ConnectionSpec CONNECTION_SPEC =
-      Util.first(System.getProperty("optiq.test.db"), "hsqldb").equals("mysql")
+      Util.first(System.getProperty("calcite.test.db"), "hsqldb")
+          .equals("mysql")
           ? ConnectionSpec.MYSQL
           : ConnectionSpec.HSQLDB;
 
   /** Whether to enable slow tests. Default is false. */
   public static final boolean ENABLE_SLOW =
-      Util.first(Boolean.getBoolean("optiq.test.slow"), false);
+      Util.first(Boolean.getBoolean("calcite.test.slow"), false);
 
   private static final DateFormat UTC_DATE_FORMAT;
   private static final DateFormat UTC_TIME_FORMAT;
@@ -655,7 +656,7 @@ public class OptiqAssert {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     String suffix = schemaList.contains("spark") ? "spark=true" : "";
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:" + suffix);
+        DriverManager.getConnection("jdbc:calcite:" + suffix);
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -692,7 +693,7 @@ public class OptiqAssert {
   static OptiqConnection getConnection(SchemaSpec schemaSpec)
       throws ClassNotFoundException, SQLException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     final SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -749,7 +750,7 @@ public class OptiqAssert {
                 info.setProperty(entry.getKey(), entry.getValue());
               }
               return (OptiqConnection) DriverManager.getConnection(
-                  "jdbc:optiq:", info);
+                  "jdbc:calcite:", info);
             }
           });
     }
@@ -762,7 +763,7 @@ public class OptiqAssert {
             public OptiqConnection createConnection() throws Exception {
               Class.forName("net.hydromatic.optiq.jdbc.Driver");
               Connection connection =
-                  DriverManager.getConnection("jdbc:optiq:");
+                  DriverManager.getConnection("jdbc:calcite:");
               OptiqConnection optiqConnection =
                   connection.unwrap(OptiqConnection.class);
               SchemaPlus rootSchema =
@@ -782,7 +783,7 @@ public class OptiqAssert {
               final Properties info = new Properties();
               info.setProperty("model", "inline:" + model);
               return (OptiqConnection) DriverManager.getConnection(
-                  "jdbc:optiq:", info);
+                  "jdbc:calcite:", info);
             }
           });
     }
@@ -1217,7 +1218,7 @@ public class OptiqAssert {
       return this;
     }
 
-    /** Adds a hook and a handler for that hook. Optiq will create a thread
+    /** Adds a hook and a handler for that hook. Calcite will create a thread
      * hook (by calling {@link Hook#addThread(com.google.common.base.Function)})
      * just before running the query, and remove the hook afterwards. */
     public <T> AssertQuery withHook(Hook hook, Function<T, Void> handler) {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/OptiqSqlOperatorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/OptiqSqlOperatorTest.java b/core/src/test/java/net/hydromatic/optiq/test/OptiqSqlOperatorTest.java
index fe50255..ecdce14 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/OptiqSqlOperatorTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/OptiqSqlOperatorTest.java
@@ -23,7 +23,7 @@ import org.eigenbase.sql.test.SqlTester;
 
 /**
  * Embodiment of {@link org.eigenbase.sql.test.SqlOperatorBaseTest}
- * that generates SQL statements and executes them using Optiq.
+ * that generates SQL statements and executes them using Calcite.
  */
 public class OptiqSqlOperatorTest extends SqlOperatorBaseTest {
   private static final ThreadLocal<OptiqConnection> LOCAL =

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/OptiqSuite.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/OptiqSuite.java b/core/src/test/java/net/hydromatic/optiq/test/OptiqSuite.java
index e2c42e3..0a84bcc 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/OptiqSuite.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/OptiqSuite.java
@@ -40,7 +40,7 @@ import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
 /**
- * Optiq test suite.
+ * Calcite test suite.
  *
  * <p>Tests are sorted by approximate running time. The suite runs the fastest
  * tests first, so that regressions can be discovered as fast as possible.
@@ -114,7 +114,7 @@ import org.junit.runners.Suite;
     PartiallyOrderedSetTest.class,
 
     // system tests and benchmarks (very slow, but usually only run if
-    // '-Doptiq.test.slow=true' is specified)
+    // '-Dcalcite.test.slow=true' is specified)
     FoodmartTest.class
 })
 public class OptiqSuite {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/ReflectiveSchemaTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/ReflectiveSchemaTest.java b/core/src/test/java/net/hydromatic/optiq/test/ReflectiveSchemaTest.java
index 33a1380..9dcc5fc 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/ReflectiveSchemaTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/ReflectiveSchemaTest.java
@@ -138,7 +138,7 @@ public class ReflectiveSchemaTest {
   @Test public void testOperator() throws SQLException, ClassNotFoundException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -163,7 +163,7 @@ public class ReflectiveSchemaTest {
   @Test public void testView() throws SQLException, ClassNotFoundException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -189,7 +189,7 @@ public class ReflectiveSchemaTest {
   @Test public void testViewPath() throws SQLException, ClassNotFoundException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
@@ -319,7 +319,7 @@ public class ReflectiveSchemaTest {
   @Test public void testCompareJavaAndSqlTypes() throws Exception {
     final OptiqAssert.AssertThat with =
         OptiqAssert.that().with("s", new CatchallSchema());
-    // With optiq-119, returned 0 rows. The problem was that when comparing
+    // With OPTIQ-119, returned 0 rows. The problem was that when comparing
     // a Java type (long) and a SQL type (INTEGER), the SQL type was deemed
     // "less restrictive". So, the long value got truncated to an int value.
     with.query(

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/TableInRootSchemaTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/TableInRootSchemaTest.java b/core/src/test/java/net/hydromatic/optiq/test/TableInRootSchemaTest.java
index 0ac93c3..53d0362 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/TableInRootSchemaTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/TableInRootSchemaTest.java
@@ -46,7 +46,7 @@ public class TableInRootSchemaTest {
    * in OptiqPrepareImpl". */
   @Test public void testAddingTableInRootSchema() throws Exception {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection = connection.unwrap(OptiqConnection.class);
 
     optiqConnection.getRootSchema().add("SAMPLE", new SimpleTable());

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/package-info.java b/core/src/test/java/net/hydromatic/optiq/test/package-info.java
index b453656..1834a3e 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/package-info.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/package-info.java
@@ -16,7 +16,7 @@
  */
 
 /**
- * Tests for Optiq.
+ * Tests for Calcite.
  */
 package net.hydromatic.optiq.test;
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/org/eigenbase/rex/RexExecutorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/eigenbase/rex/RexExecutorTest.java b/core/src/test/java/org/eigenbase/rex/RexExecutorTest.java
index 2ba2016..27c36ad 100644
--- a/core/src/test/java/org/eigenbase/rex/RexExecutorTest.java
+++ b/core/src/test/java/org/eigenbase/rex/RexExecutorTest.java
@@ -79,7 +79,7 @@ public class RexExecutorTest {
             SqlTypeName.VARCHAR);
         final RelDataType integer = rexBuilder.getTypeFactory().createSqlType(
             SqlTypeName.INTEGER);
-        // optiq is internally creating the creating the input ref via a
+        // calcite is internally creating the creating the input ref via a
         // RexRangeRef
         // which eventually leads to a RexInputRef. So we are good.
         final RexInputRef input = rexBuilder.makeInputRef(varchar, 0);
@@ -101,10 +101,10 @@ public class RexExecutorTest {
         Object[] result = exec.execute();
         assertTrue(result[0] instanceof String);
         assertThat((String) result[0], equalTo("llo World"));
-        values[0] = "Optiq";
+        values[0] = "Calcite";
         result = exec.execute();
         assertTrue(result[0] instanceof String);
-        assertThat((String) result[0], equalTo("tiq"));
+        assertThat((String) result[0], equalTo("lcite"));
       }
     });
   }

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/org/eigenbase/test/RelOptRulesTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/eigenbase/test/RelOptRulesTest.java b/core/src/test/java/org/eigenbase/test/RelOptRulesTest.java
index a38317d..5c5513e 100644
--- a/core/src/test/java/org/eigenbase/test/RelOptRulesTest.java
+++ b/core/src/test/java/org/eigenbase/test/RelOptRulesTest.java
@@ -635,7 +635,7 @@ public class RelOptRulesTest extends RelOptTestBase {
         + " where a - b < 21");
   }
 
-  @Ignore // Optiq does not support INSERT yet
+  @Ignore // Calcite does not support INSERT yet
   @Test public void testReduceValuesNull() throws Exception {
     // The NULL literal presents pitfalls for value-reduction. Only
     // an INSERT statement contains un-CASTed NULL values.
@@ -773,7 +773,7 @@ public class RelOptRulesTest extends RelOptTestBase {
         + "where cast((empno + (10/2)) as int) = 13");
   }
 
-  @Ignore // Optiq does not support INSERT yet
+  @Ignore // Calcite does not support INSERT yet
   @Test public void testReduceCastsNullable() throws Exception {
     HepProgram program = new HepProgramBuilder()
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/resources/sql/winagg.oq
----------------------------------------------------------------------
diff --git a/core/src/test/resources/sql/winagg.oq b/core/src/test/resources/sql/winagg.oq
index 8fd7d10..7dc2c6a 100644
--- a/core/src/test/resources/sql/winagg.oq
+++ b/core/src/test/resources/sql/winagg.oq
@@ -113,7 +113,7 @@ select *, first_value(ename) over (partition by deptno order by gender range unb
 
 !ok
 !}
-# Optiq does not yet generate tied ranks
+# Calcite does not yet generate tied ranks
 !if (false) {
 select *, count(*) over (order by deptno) as c from emp;
  ENAME | DEPTNO | GENDER | C
@@ -145,7 +145,7 @@ select *, rank() over (order by deptno) as c from emp;
 (9 rows)
 
 !ok
-# Optiq does not yet generate tied ranks
+# Calcite does not yet generate tied ranks
 select *, dense_rank() over (order by deptno) as c from emp;
  ENAME | DEPTNO | GENDER | C
 -------+--------+--------+---

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/doc/HISTORY.md
----------------------------------------------------------------------
diff --git a/doc/HISTORY.md b/doc/HISTORY.md
index 01873fb..09de11c 100644
--- a/doc/HISTORY.md
+++ b/doc/HISTORY.md
@@ -1,4 +1,4 @@
-# Apache Optiq release history
+# Apache Calcite release history
 
 For a full list of releases, see
 <a href="https://github.com/apache/incubator-optiq/releases">github</a>.
@@ -434,7 +434,7 @@ Bug-fixes and internal changes
 * Fix Optiq on Windows. (All tests and checkstyle checks pass.)
 * In checkstyle, support Windows-style file separator, otherwise build fails in
   Windows due to suppressions not used. (Vladimir Sitnikov)
-* Enable MongoDB tests when `-Doptiq.test.mongodb=true`.
+* Enable MongoDB tests when `-Dcalcite.test.mongodb=true`.
 * Cleanup cache exception-handling and an assert.
 * [<a href="https://issues.apache.org/jira/browse/OPTIQ-153">OPTIQ-153</a>]
   Error using MongoDB adapter: Failed to set setXIncludeAware(true)
@@ -649,7 +649,7 @@ Other
 * Add section to <a href="HOWTO.md">HOWTO</a> on implementing adapters.
 * Fix data type conversions when creating a clone table in memory.
 * Fix how strings are escaped in JsonBuilder.
-* Test suite now depends on an embedded hsqldb database, so you can run <code>mvn test</code> right after pulling from git. You can instead use a MySQL database if you specify '-Doptiq.test.db=mysql', but you need to manually populate it.
+* Test suite now depends on an embedded hsqldb database, so you can run <code>mvn test</code> right after pulling from git. You can instead use a MySQL database if you specify '-Dcalcite.test.db=mysql', but you need to manually populate it.
 * Fix a planner issue which occurs when the left and right children of join are the same relational expression, caused by a self-join query.
 * [<a href="https://issues.apache.org/jira/browse/OPTIQ-76">OPTIQ-76</a>]
   Precedence of the item operator, <code>map[index]</code>; remove the space before '[' when converting parse tree to string.

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/doc/HOWTO.md
----------------------------------------------------------------------
diff --git a/doc/HOWTO.md b/doc/HOWTO.md
index d51f606..d37bec0 100644
--- a/doc/HOWTO.md
+++ b/doc/HOWTO.md
@@ -1,6 +1,6 @@
-# Optiq HOWTO
+# Calcite HOWTO
 
-Here's some miscellaneous documentation about using Optiq and its various
+Here's some miscellaneous documentation about using Calcite and its various
 adapters.
 
 ## Building from a source distribution
@@ -13,8 +13,8 @@ Unpack the source distribution `.tar.gz` or `.zip` file,
 then build using maven:
 
 ```bash
-$ tar xvfz optiq-0.9.0-incubating-source.tar.gz
-$ cd optiq-0.9.0-incubating
+$ tar xvfz calcite-0.9.1-incubating-source.tar.gz
+$ cd calcite-0.9.1-incubating
 $ mvn install
 ```
 
@@ -51,22 +51,22 @@ $ mvn -DskipTests clean install
 There are other options that control which tests are run, and in what
 environment, as follows.
 
-* `-Doptiq.test.db=DB` (where db is `hsqldb` or `mysql`) allows you
-  to change the JDBC data source for the test suite. Optiq's test
+* `-Dcalcite.test.db=DB` (where db is `hsqldb` or `mysql`) allows you
+  to change the JDBC data source for the test suite. Calcite's test
   suite requires a JDBC data source populated with the foodmart data
   set.
    * `hsqldb`, the default, uses an in-memory hsqldb database.
    * `mysql` uses a MySQL database in `jdbc:mysql://localhost/foodmart`.
      It is somewhat faster than hsqldb, but you need to populate it
      manually.
-* `-Doptiq.debug` prints extra debugging information to stdout.
-* `-Doptiq.test.slow` enables tests that take longer to execute. For
+* `-Dcalcite.debug` prints extra debugging information to stdout.
+* `-Dcalcite.test.slow` enables tests that take longer to execute. For
   example, there are tests that create virtual TPC-H and TPC-DS schemas
   in-memory and run tests from those benchmarks.
-* `-Doptiq.test.mongodb=true` enables tests that run against
+* `-Dcalcite.test.mongodb=true` enables tests that run against
   MongoDB. MongoDB must be installed, running, and
   [populated with the zips.json data set](HOWTO.md#mongodb-adapter).
-* `-Doptiq.test.splunk=true` enables tests that run against Splunk.
+* `-Dcalcite.test.splunk=true` enables tests that run against Splunk.
   Splunk must be installed and running.
 
 ## Contributing
@@ -104,10 +104,10 @@ changes.
 To enable tracing, add the following flags to the java command line:
 
 ```
--Doptiq.debug=true -Djava.util.logging.config.file=core/src/test/resources/logging.properties
+-Dcalcite.debug=true -Djava.util.logging.config.file=core/src/test/resources/logging.properties
 ```
 
-The first flag causes Optiq to print the Java code it generates
+The first flag causes Calcite to print the Java code it generates
 (to execute queries) to stdout. It is especially useful if you are debugging
 mysterious problems like this:
 
@@ -139,7 +139,7 @@ tutorial</a>.
 
 ## MongoDB adapter
 
-First, download and install Optiq,
+First, download and install Calcite,
 and <a href="http://www.mongodb.org/downloads">install MongoDB</a>.
 
 Import MongoDB's zipcode data set into MongoDB:
@@ -165,13 +165,13 @@ connecting to: test
 bye
 ```
 
-Connect using the <a href="https://github.com/julianhyde/optiq/blob/master/mongodb/src/test/resources/mongo-zips-model.json">mongo-zips-model.json</a> Optiq model:
+Connect using the <a href="https://github.com/julianhyde/optiq/blob/master/mongodb/src/test/resources/mongo-zips-model.json">mongo-zips-model.json</a> Calcite model:
 ```bash
 $ ./sqlline
-sqlline> !connect jdbc:optiq:model=mongodb/target/test-classes/mongo-zips-model.json admin admin
-Connecting to jdbc:optiq:model=mongodb/target/test-classes/mongo-zips-model.json
-Connected to: Optiq (version 0.4.x)
-Driver: Optiq JDBC Driver (version 0.4.x)
+sqlline> !connect jdbc:calcite:model=mongodb/target/test-classes/mongo-zips-model.json admin admin
+Connecting to jdbc:calcite:model=mongodb/target/test-classes/mongo-zips-model.json
+Connected to: Calcite (version 0.9.x)
+Driver: Calcite JDBC Driver (version 0.9.x)
 Autocommit status: true
 Transaction isolation: TRANSACTION_REPEATABLE_READ
 sqlline> !tables
@@ -204,7 +204,7 @@ load Splunk's `tutorialdata.zip` data set as described in
 
 (This step is optional, but it provides some interesting data for the sample
 queries. It is also necessary if you intend to run the test suite, using
-`-Doptiq.test.splunk=true`.)
+`-Dcalcite.test.splunk=true`.)
 
 ## Implementing an adapter
 
@@ -235,7 +235,7 @@ public class AdapterContext implements OptiqPrepare.Context {
 
 The example below shows how SQL query can be submitted to
 `OptiqPrepare` with a custom context (`AdapterContext` in this
-case). Optiq prepares and implements the query execution, using the
+case). Calcite prepares and implements the query execution, using the
 resources provided by the `Context`. `OptiqPrepare.PrepareResult`
 provides access to the underlying enumerable and methods for
 enumeration. The enumerable itself can naturally be some adapter
@@ -264,14 +264,14 @@ public class AdapterContextTest {
 
 ## JavaTypeFactory
 
-When Optiq compares `Type` instances, it requires them to be the same
+When Calcite compares `Type` instances, it requires them to be the same
 object. If there are two distinct `Type` instances that refer to the
-same Java type, Optiq may fail to recognize that they match.  It is
+same Java type, Calcite may fail to recognize that they match.  It is
 recommended to:
--   Use a single instance of `JavaTypeFactory` within the optiq context
+-   Use a single instance of `JavaTypeFactory` within the calcite context
 -   Store the `Type` instances so that the same object is always returned for the same `Type`.
 
-## Set up PGP signing keys (for Optiq committers)
+## Set up PGP signing keys (for Calcite committers)
 
 Follow instructions at http://www.apache.org/dev/release-signing to
 create a key pair. (On Mac OS X, I did `brew install gpg` and `gpg
@@ -280,12 +280,12 @@ create a key pair. (On Mac OS X, I did `brew install gpg` and `gpg
 Add your public key to the `KEYS` file by following instructions in
 the `KEYS` file.
 
-## Making a snapshot (for Optiq committers)
+## Making a snapshot (for Calcite committers)
 
 Before you start:
 * Set up signing keys as described above.
 * Make sure you are using JDK 1.7 (not 1.6 or 1.8).
-* Make sure build and tests succeed with `-Doptiq.test.db=hsqldb` (the default)
+* Make sure build and tests succeed with `-Dcalcite.test.db=hsqldb` (the default)
 
 ```bash
 # set passphrase variable without putting it into shell history
@@ -299,14 +299,14 @@ mvn -Papache-release -Dgpg.passphrase=${GPG_PASSPHRASE} clean install
 
 When the dry-run has succeeded, change `install` to `deploy`.
 
-## Making a release (for Optiq committers)
+## Making a release (for Calcite committers)
 
 Before you start:
 * Set up signing keys as described above.
 * Make sure you are using JDK 1.7 (not 1.6 or 1.8).
 * Make sure build and tests succeed, including with
-  -Doptiq.test.db={mysql,hsqldb}, -Doptiq.test.slow=true,
-  -Doptiq.test.mongodb=true, -Doptiq.test.splunk=true.
+  -Dcalcite.test.db={mysql,hsqldb}, -Dcalcite.test.slow=true,
+  -Dcalcite.test.mongodb=true, -Dcalcite.test.splunk=true.
 * Trigger a
   <a href="https://scan.coverity.com/projects/2966">Coverity scan</a>
   by merging the latest code into the `julianhyde/coverity_scan` branch,
@@ -337,26 +337,26 @@ and start again from the top.
 
 Check the artifacts:
 * In the `target` directory should be these 8 files, among others:
-  * apache-optiq-X.Y.Z-incubating-src.tar.gz
-  * apache-optiq-X.Y.Z-incubating-src.tar.gz.asc
-  * apache-optiq-X.Y.Z-incubating-src.tar.gz.md5
-  * apache-optiq-X.Y.Z-incubating-src.tar.gz.sha1
-  * apache-optiq-X.Y.Z-incubating-src.zip
-  * apache-optiq-X.Y.Z-incubating-src.zip.asc
-  * apache-optiq-X.Y.Z-incubating-src.zip.md5
-  * apache-optiq-X.Y.Z-incubating-src.zip.sha1
-* Note that the file names start `apache-optiq-` and include
+  * apache-calcite-X.Y.Z-incubating-src.tar.gz
+  * apache-calcite-X.Y.Z-incubating-src.tar.gz.asc
+  * apache-calcite-X.Y.Z-incubating-src.tar.gz.md5
+  * apache-calcite-X.Y.Z-incubating-src.tar.gz.sha1
+  * apache-calcite-X.Y.Z-incubating-src.zip
+  * apache-calcite-X.Y.Z-incubating-src.zip.asc
+  * apache-calcite-X.Y.Z-incubating-src.zip.md5
+  * apache-calcite-X.Y.Z-incubating-src.zip.sha1
+* Note that the file names start `apache-calcite-` and include
   `incubating` in the version.
 * In the two source distros `.tar.gz` and `.zip` (currently there is
   no binary distro), check that all files belong to a directory called
-  `apache-optiq-X.Y.Z-incubating-src`.
+  `apache-calcite-X.Y.Z-incubating-src`.
 * That directory must contain files `NOTICE`, `LICENSE`, `README`,
   `README.md`, `git.properties`
   * Check that  the version in `README` is correct
   * Check that `git.properties` is current
 * In each .jar (for example
-  `core/target/optiq-core-X.Y.Z-incubating.jar` and
-  `mongodb/target/optiq-mongodb-X.Y.Z-incubating-sources.jar`), check
+  `core/target/calcite-core-X.Y.Z-incubating.jar` and
+  `mongodb/target/calcite-mongodb-X.Y.Z-incubating-sources.jar`), check
   that the `META-INF` directory contains `DEPENDENCIES`, `LICENSE`,
   `NOTICE` and `git.properties`
 * Check PGP, per https://httpd.apache.org/dev/verification.html
@@ -367,14 +367,14 @@ people.apache.org home directory):
 ```bash
 # Move the files into a directory
 cd target
-mkdir apache-optiq-X.Y.Z-incubating-rcN
-mv apache-optiq-* optiq-X.Y.Z-incubating-rcN
+mkdir apache-calcite-X.Y.Z-incubating-rcN
+mv apache-calcite-* calcite-X.Y.Z-incubating-rcN
 
 # Upload to staging area (your people.apache.org home directory)
-scp -rp apache-optiq-X.Y.Z-incubating-rcN people.apache.org:public_html
+scp -rp apache-calcite-X.Y.Z-incubating-rcN people.apache.org:public_html
 ```
 
-## Cleaning up after a failed release attempt (for Optiq committers)
+## Cleaning up after a failed release attempt (for Calcite committers)
 
 ```
 # Make sure that the tag you are about to generate does not already
@@ -382,8 +382,8 @@ scp -rp apache-optiq-X.Y.Z-incubating-rcN people.apache.org:public_html
 git tag
 
 # If the tag exists, delete it locally and remotely
-git tag -d optiq-X.Y.Z-incubating
-git push origin :refs/tags/optiq-X.Y.Z-incubating
+git tag -d apache-calcite-X.Y.Z-incubating
+git push origin :refs/tags/apache-calcite-X.Y.Z-incubating
 
 # Remove modified files
 mvn release:clean
@@ -401,10 +401,10 @@ git reset --hard HEAD
 gpg --recv-keys key
 
 # Check keys
-curl http://people.apache.org/keys/group/optiq.asc > KEYS
+curl http://people.apache.org/keys/group/calcite.asc > KEYS
 
 # Check keys
-curl -O https://dist.apache.org/repos/dist/release/incubator/optiq/KEYS
+curl -O https://dist.apache.org/repos/dist/release/incubator/calcite/KEYS
 
 # Sign/check md5 and sha1 hashes
 # (Assumes your O/S has 'md5' and 'sha1' commands.)
@@ -436,20 +436,20 @@ function checkHash() {
     fi
   done
 }
-checkHash optiq-X.Y.Z-incubating
+checkHash apache-calcite-X.Y.Z-incubating
 ```
 
-## Get approval for a release via Apache voting process (for Optiq committers)
+## Get approval for a release via Apache voting process (for Calcite committers)
 
 Release vote on dev list
 
 ```
 To: dev@optiq.incubator.apache.org
-Subject: Release Optiq-X.Y.Z-incubating (release candidate N)
+Subject: Release apache-Calcite-X.Y.Z-incubating (release candidate N)
 
 Hi all,
 
-I have created a build for Apache Optiq X.Y.Z-incubating, release candidate N.
+I have created a build for Apache Calcite X.Y.Z-incubating, release candidate N.
 
 Thanks to everyone who has contributed to this release.
 
@@ -457,7 +457,7 @@ The commit to be voted upon:
 http://git-wip-us.apache.org/repos/asf/incubator-optiq/commit/NNNNNN
 
 The artifacts to be voted on are located here:
-http://people.apache.org/~jhyde/optiq-X.Y.Z-incubating-rcN/
+http://people.apache.org/~jhyde/apache-calcite-X.Y.Z-incubating-rcN/
 
 A staged Maven repository is available for review at:
 https://repository.apache.org/content/repositories/orgapacheoptiq-NNNN
@@ -465,12 +465,12 @@ https://repository.apache.org/content/repositories/orgapacheoptiq-NNNN
 Release artifacts are signed with the following key:
 https://people.apache.org/keys/committer/jhyde.asc
 
-Please vote on releasing this package as Apache Optiq X.Y.Z-incubating.
+Please vote on releasing this package as Apache Calcite X.Y.Z-incubating.
 
 The vote is open for the next 72 hours and passes if a majority of
 at least three +1 PPMC votes are cast.
 
-[ ] +1 Release this package as Apache Optiq X.Y.Z-incubating
+[ ] +1 Release this package as Apache Calcite X.Y.Z-incubating
 [ ]  0 I don't feel strongly about it, but I'm okay with the release
 [ ] -1 Do not release this package because...
 
@@ -485,7 +485,7 @@ Julian
 After vote finishes, send out the result:
 
 ```
-Subject: [RESULT] [VOTE] Release Optiq-X.Y.Z-incubating (release candidate N)
+Subject: [RESULT] [VOTE] Release apache-Calcite-X.Y.Z-incubating (release candidate N)
 To: dev@optiq.incubator.apache.org
 
 Thanks to everyone who has tested the release candidate and given
@@ -502,7 +502,7 @@ N non-binding +1s:
 No 0s or -1s.
 
 Therefore I am delighted to announce that the proposal to release
-Apache Optiq X.Y.Z-incubating has passed.
+Apache Calcite X.Y.Z-incubating has passed.
 
 I'll now start a vote on the general list. Those of you in the IPMC,
 please recast your vote on the new thread.
@@ -514,12 +514,12 @@ Propose a vote on the incubator list.
 
 ```
 To: general@incubator.apache.org
-Subject: [VOTE] Release Apache Optiq X.Y.Z (incubating)
+Subject: [VOTE] Release Apache Calcite X.Y.Z (incubating)
 
 Hi all,
 
-The Optiq community has voted on and approved a proposal to release
-Apache Optiq X.Y.Z (incubating).
+The Calcite community has voted on and approved a proposal to release
+Apache Calcite X.Y.Z (incubating).
 
 Pursuant to the Releases section of the Incubation Policy and with
 the endorsement of NNN of our mentors we would now like to request
@@ -527,10 +527,10 @@ the permission of the Incubator PMC to publish the release. The vote
 is open for 72 hours, or until the necessary number of votes (3 +1)
 is reached.
 
-[ ] +1 Release this package as Apache Optiq X.Y.Z incubating
+[ ] +1 Release this package as Apache Calcite X.Y.Z incubating
 [ ] -1 Do not release this package because ...
 
-Apache Optiq PPMC
+Apache Calcite PPMC
 
 
 Proposal:
@@ -543,7 +543,7 @@ No -1 votes
 http://mail-archives.apache.org/mod_mbox/incubator-optiq-dev/201408.mbox/MESSAGE-URI
 
 Artifacts:
-http://people.apache.org/~jhyde/optiq-X.Y.Z-incubating-rcN/
+http://people.apache.org/~jhyde/calcite-X.Y.Z-incubating-rcN/
 
 ```
 
@@ -551,7 +551,7 @@ After vote finishes, send out the result:
 
 ```
 To: general@incubator.apache.org
-Subject: [RESULT] [VOTE] Release Apache Optiq X.Y.Z (incubating)
+Subject: [RESULT] [VOTE] Release Apache Calcite X.Y.Z (incubating)
 
 This vote passes with N +1s and no 0 or -1 votes:
 +1 <name> (mentor)
@@ -564,7 +564,7 @@ Thanks everyone. We’ll now roll the release out to the mirrors.
 Julian
 ```
 
-## Publishing a release (for Optiq committers)
+## Publishing a release (for Calcite committers)
 
 After a successful release vote, we need to push the release
 out to mirrors, and other tasks.
@@ -575,12 +575,12 @@ out to mirrors, and other tasks.
   "Resolved in release X.Y.Z-incubating (YYYY-MM-DD)"
   (fill in release number and date appropriately).
 
-## Publishing the web site (for Optiq committers)
+## Publishing the web site (for Calcite committers)
 
 Get the code:
 
 ```bash
-$ svn co https://svn.apache.org/repos/asf/incubator/optiq/site optiq-site
+$ svn co https://svn.apache.org/repos/asf/incubator/optiq/site calcite-site
 ```
 
 (Note: `https:`, not `http:`.)
@@ -588,7 +588,7 @@ $ svn co https://svn.apache.org/repos/asf/incubator/optiq/site optiq-site
 Build the site:
 
 ```bash
-$ cd optiq-site
+$ cd calcite-site
 $ ./build.sh
 ```
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/doc/MODEL.md
----------------------------------------------------------------------
diff --git a/doc/MODEL.md b/doc/MODEL.md
index e88d8d2..367e66b 100644
--- a/doc/MODEL.md
+++ b/doc/MODEL.md
@@ -1,4 +1,4 @@
-# Optiq JSON model reference
+# Calcite JSON model reference
 
 ## Elements
 
@@ -16,7 +16,7 @@
 
 `defaultSchema` (optional string). If specified, it is
 the name (case-sensitive) of a schema defined in this model, and will
-become the default schema for connections to Optiq that use this model.
+become the default schema for connections to Calcite that use this model.
 
 `schemas` (optional list of <a href="#schema">Schema</a> elements).
 
@@ -57,21 +57,21 @@ string.
 <a href="#materialization">Materialization</a>) defines the tables
 in this schema that are materializations of queries.
 
-`cache` (optional boolean, default true) tells Optiq whether to
+`cache` (optional boolean, default true) tells Calcite whether to
 cache metadata (tables, functions and sub-schemas) generated
 by this schema.
 
-* If `false`, Optiq will go back to the schema each time it needs
+* If `false`, Calcite will go back to the schema each time it needs
   metadata, for example, each time it needs a list of tables in order to
   validate a query against the schema.
 
-* If `true`, Optiq will cache the metadata the first time it reads
+* If `true`, Calcite will cache the metadata the first time it reads
   it. This can lead to better performance, especially if name-matching is
   case-insensitive.
 
 However, it also leads to the problem of cache staleness.
 A particular schema implementation can override the
-`Schema.contentsHaveChangedSince` method to tell Optiq
+`Schema.contentsHaveChangedSince` method to tell Calcite
 when it should consider its cache to be out of date.
 
 Tables, functions and sub-schemas explicitly created in a schema are

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/doc/REFERENCE.md
----------------------------------------------------------------------
diff --git a/doc/REFERENCE.md b/doc/REFERENCE.md
index c1338a4..d6579a4 100644
--- a/doc/REFERENCE.md
+++ b/doc/REFERENCE.md
@@ -1,4 +1,4 @@
-# Optiq SQL language reference
+# Calcite SQL language reference
 
 ## SQL constructs
 
@@ -95,7 +95,7 @@ spaces and other punctuation.  If you wish to include a double quote
 in an identifier, use another double quote to escape it, like this:
 "An employee called ""Fred""."
 
-In Optiq, matching identifiers to the name of the referenced object is
+In Calcite, matching identifiers to the name of the referenced object is
 case-sensitive.  But remember that unquoted identifiers are implicitly
 converted to upper case before matching, and if the object it refers
 to was created using an unquoted identifier for its name, then its

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/mongodb/pom.xml
----------------------------------------------------------------------
diff --git a/mongodb/pom.xml b/mongodb/pom.xml
index 95c3314..85466c0 100644
--- a/mongodb/pom.xml
+++ b/mongodb/pom.xml
@@ -18,32 +18,32 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
-  <artifactId>optiq-mongodb</artifactId>
+  <artifactId>calcite-mongodb</artifactId>
   <packaging>jar</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
-  <name>Optiq MongoDB</name>
-  <description>MongoDB adapter for Optiq.</description>
+  <name>Calcite MongoDB</name>
+  <description>MongoDB adapter for Calcite</description>
 
   <properties>
     <top.dir>${project.basedir}/..</top.dir>
   </properties>
 
   <dependencies>
-    <!-- Sorted by groupId, artifactId; optiq dependencies first. Put versions
+    <!-- Sorted by groupId, artifactId; calcite dependencies first. Put versions
          in dependencyManagement in the root POM, not here. -->
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
       <type>jar</type>
     </dependency>
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
       <type>test-jar</type>
       <scope>test</scope>
     </dependency>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/mongodb/src/test/java/net/hydromatic/optiq/test/MongoAdapterTest.java
----------------------------------------------------------------------
diff --git a/mongodb/src/test/java/net/hydromatic/optiq/test/MongoAdapterTest.java b/mongodb/src/test/java/net/hydromatic/optiq/test/MongoAdapterTest.java
index 5ff81c9..141faf8 100644
--- a/mongodb/src/test/java/net/hydromatic/optiq/test/MongoAdapterTest.java
+++ b/mongodb/src/test/java/net/hydromatic/optiq/test/MongoAdapterTest.java
@@ -112,9 +112,9 @@ public class MongoAdapterTest {
 
   /** Whether to run Mongo tests. Disabled by default, because we do not expect
    * Mongo to be installed and populated with the FoodMart data set. To enable,
-   * specify {@code -Doptiq.test.mongodb=true} on the Java command line. */
+   * specify {@code -Dcalcite.test.mongodb=true} on the Java command line. */
   public static final boolean ENABLED =
-      Boolean.getBoolean("optiq.test.mongodb");
+      Boolean.getBoolean("calcite.test.mongodb");
 
   /** Whether to run this test. */
   protected boolean enabled() {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/plus/pom.xml
----------------------------------------------------------------------
diff --git a/plus/pom.xml b/plus/pom.xml
index 212e949..2fadc12 100644
--- a/plus/pom.xml
+++ b/plus/pom.xml
@@ -18,32 +18,32 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
-  <artifactId>optiq-plus</artifactId>
+  <artifactId>calcite-plus</artifactId>
   <packaging>jar</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
-  <name>Optiq Plus</name>
-  <description>Miscellaneous extras for Optiq.</description>
+  <name>Calcite Plus</name>
+  <description>Miscellaneous extras for Calcite</description>
 
   <properties>
     <top.dir>${project.basedir}/..</top.dir>
   </properties>
 
   <dependencies>
-    <!-- Sorted by groupId, artifactId; optiq dependencies first. Put versions
+    <!-- Sorted by groupId, artifactId; calcite dependencies first. Put versions
          in dependencyManagement in the root POM, not here. -->
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
       <type>jar</type>
     </dependency>
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
       <type>test-jar</type>
       <scope>test</scope>
     </dependency>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/plus/src/test/java/net/hydromatic/optiq/impl/tpcds/TpcdsTest.java
----------------------------------------------------------------------
diff --git a/plus/src/test/java/net/hydromatic/optiq/impl/tpcds/TpcdsTest.java b/plus/src/test/java/net/hydromatic/optiq/impl/tpcds/TpcdsTest.java
index db77db4..f1458ac 100644
--- a/plus/src/test/java/net/hydromatic/optiq/impl/tpcds/TpcdsTest.java
+++ b/plus/src/test/java/net/hydromatic/optiq/impl/tpcds/TpcdsTest.java
@@ -38,7 +38,7 @@ import net.hydromatic.tpcds.query.Query;
 
 /** Unit test for {@link net.hydromatic.optiq.impl.tpcds.TpcdsSchema}.
  *
- * <p>Only runs if {@code -Doptiq.test.slow=true} is specified on the
+ * <p>Only runs if {@code -Dcalcite.test.slow=true} is specified on the
  * command-line.
  * (See {@link net.hydromatic.optiq.test.OptiqAssert#ENABLE_SLOW}.)</p> */
 public class TpcdsTest {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/plus/src/test/java/net/hydromatic/optiq/impl/tpch/TpchTest.java
----------------------------------------------------------------------
diff --git a/plus/src/test/java/net/hydromatic/optiq/impl/tpch/TpchTest.java b/plus/src/test/java/net/hydromatic/optiq/impl/tpch/TpchTest.java
index 222ffe2..d556a1a 100644
--- a/plus/src/test/java/net/hydromatic/optiq/impl/tpch/TpchTest.java
+++ b/plus/src/test/java/net/hydromatic/optiq/impl/tpch/TpchTest.java
@@ -38,7 +38,7 @@ import static org.junit.Assert.assertThat;
  *
  * <p>Because the TPC-H data generator takes time and memory to instantiate,
  * tests that read data (that is, most tests) only run
- * if {@code -Doptiq.test.slow=true} is specified on the command-line.
+ * if {@code -Dcalcite.test.slow=true} is specified on the command-line.
  * (See {@link net.hydromatic.optiq.test.OptiqAssert#ENABLE_SLOW}.)</p> */
 public class TpchTest {
   public static final String JAVA_VERSION =

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/plus/src/test/java/net/hydromatic/optiq/test/PlusSuite.java
----------------------------------------------------------------------
diff --git a/plus/src/test/java/net/hydromatic/optiq/test/PlusSuite.java b/plus/src/test/java/net/hydromatic/optiq/test/PlusSuite.java
index 2b350f9..644c0a8 100644
--- a/plus/src/test/java/net/hydromatic/optiq/test/PlusSuite.java
+++ b/plus/src/test/java/net/hydromatic/optiq/test/PlusSuite.java
@@ -23,7 +23,7 @@ import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
 /**
- * Suite consisting of all tests in the <code>optiq-plus</code> module.
+ * Suite consisting of all tests in the <code>calcite-plus</code> module.
  */
 @RunWith(Suite.class)
 @Suite.SuiteClasses({

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index d8118fe..64b11f2 100644
--- a/pom.xml
+++ b/pom.xml
@@ -24,20 +24,20 @@ limitations under the License.
   </parent>
 
   <!-- The basics. -->
-  <groupId>org.apache.optiq</groupId>
-  <artifactId>optiq</artifactId>
+  <groupId>org.apache.calcite</groupId>
+  <artifactId>calcite</artifactId>
   <packaging>pom</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
 
   <!-- More project information. -->
-  <name>Optiq</name>
-  <description>Optiq is a dynamic data management framework.</description>
-  <url>http://incubator.apache.org/optiq</url>
+  <name>Calcite</name>
+  <description>Calcite is a dynamic data management framework</description>
+  <url>http://optiq.incubator.apache.org</url>
   <inceptionYear>2012</inceptionYear>
 
   <mailingLists>
     <mailingList>
-      <name>Apache Optiq developers list</name>
+      <name>Apache Calcite developers list</name>
       <subscribe>dev-subscribe@optiq.incubator.apache.org</subscribe>
       <unsubscribe>dev-unsubscribe@optiq.incubator.apache.org</unsubscribe>
       <post>dev@optiq.incubator.apache.org</post>
@@ -163,20 +163,20 @@ limitations under the License.
 
   <dependencyManagement>
     <dependencies>
-      <!-- Sorted by groupId, artifactId; optiq dependencies first. -->
+      <!-- Sorted by groupId, artifactId; calcite dependencies first. -->
       <dependency>
-        <groupId>org.apache.optiq</groupId>
-        <artifactId>optiq-avatica</artifactId>
+        <groupId>org.apache.calcite</groupId>
+        <artifactId>calcite-avatica</artifactId>
         <version>${project.version}</version>
       </dependency>
       <dependency>
-        <groupId>org.apache.optiq</groupId>
-        <artifactId>optiq-core</artifactId>
+        <groupId>org.apache.calcite</groupId>
+        <artifactId>calcite-core</artifactId>
         <version>${project.version}</version>
       </dependency>
       <dependency>
-        <groupId>org.apache.optiq</groupId>
-        <artifactId>optiq-core</artifactId>
+        <groupId>org.apache.calcite</groupId>
+        <artifactId>calcite-core</artifactId>
         <type>test-jar</type>
         <version>${project.version}</version>
       </dependency>
@@ -542,7 +542,7 @@ limitations under the License.
                   <runOnlyAtExecutionRoot>true</runOnlyAtExecutionRoot>
                   <appendAssemblyId>false</appendAssemblyId>
                   <descriptor>src/main/config/assemblies/source-assembly.xml</descriptor>
-                  <finalName>apache-optiq-${project.version}-src</finalName>
+                  <finalName>apache-calcite-${project.version}-src</finalName>
                   <tarLongFileMode>gnu</tarLongFileMode>
                 </configuration>
               </execution>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/spark/pom.xml
----------------------------------------------------------------------
diff --git a/spark/pom.xml b/spark/pom.xml
index 9ed406a..2553ebe 100644
--- a/spark/pom.xml
+++ b/spark/pom.xml
@@ -18,30 +18,30 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
-  <artifactId>optiq-spark</artifactId>
+  <artifactId>calcite-spark</artifactId>
   <packaging>jar</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
-  <name>Optiq Spark</name>
+  <name>Calcite Spark</name>
 
   <properties>
     <top.dir>${project.basedir}/..</top.dir>
   </properties>
 
   <dependencies>
-    <!-- Sorted by groupId, artifactId; optiq dependencies first. Put versions
+    <!-- Sorted by groupId, artifactId; calcite dependencies first. Put versions
          in dependencyManagement in the root POM, not here. -->
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
     </dependency>
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
       <type>test-jar</type>
       <scope>test</scope>
     </dependency>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkHandlerImpl.java
----------------------------------------------------------------------
diff --git a/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkHandlerImpl.java b/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkHandlerImpl.java
index b0d78de..6805afc 100644
--- a/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkHandlerImpl.java
+++ b/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkHandlerImpl.java
@@ -37,14 +37,14 @@ import java.util.Calendar;
 import java.util.concurrent.atomic.AtomicInteger;
 
 /**
- * Implementation of {@link OptiqPrepare.SparkHandler}. Gives the core Optiq
+ * Implementation of {@link OptiqPrepare.SparkHandler}. Gives the core Calcite
  * engine access to rules that only exist in the Spark module.
  */
 public class SparkHandlerImpl implements OptiqPrepare.SparkHandler {
   private final HttpServer classServer;
   private final AtomicInteger classId;
   private final JavaSparkContext sparkContext =
-      new JavaSparkContext("local[1]", "optiq");
+      new JavaSparkContext("local[1]", "calcite");
 
   private static SparkHandlerImpl instance;
   private static final File SRC_DIR = new File("/tmp");
@@ -69,7 +69,7 @@ public class SparkHandlerImpl implements OptiqPrepare.SparkHandler {
         + calendar.get(Calendar.SECOND));
   }
 
-  /** Creates a SparkHandlerImpl, initializing on first call. Optiq-core calls
+  /** Creates a SparkHandlerImpl, initializing on first call. Calcite-core calls
    * this via reflection. */
   @SuppressWarnings("UnusedDeclaration")
   public static OptiqPrepare.SparkHandler instance() {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRules.java
----------------------------------------------------------------------
diff --git a/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRules.java b/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRules.java
index 338a695..6b42473 100644
--- a/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRules.java
+++ b/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRules.java
@@ -370,7 +370,7 @@ public abstract class SparkRules {
   // Play area
 
   public static void main(String[] args) {
-    final JavaSparkContext sc = new JavaSparkContext("local[1]", "optiq");
+    final JavaSparkContext sc = new JavaSparkContext("local[1]", "calcite");
     final JavaRDD<String> file = sc.textFile("/usr/share/dict/words");
     System.out.println(
         file.map(

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRuntime.java
----------------------------------------------------------------------
diff --git a/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRuntime.java b/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRuntime.java
index 777d7d5..0168a24 100644
--- a/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRuntime.java
+++ b/spark/src/main/java/net/hydromatic/optiq/impl/spark/SparkRuntime.java
@@ -28,7 +28,7 @@ import org.apache.spark.api.java.function.FlatMapFunction;
 import java.util.*;
 
 /**
- * Runtime utilities for Optiq's Spark adapter. Generated code calls these
+ * Runtime utilities for Calcite's Spark adapter. Generated code calls these
  * methods.
  */
 public abstract class SparkRuntime {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/spark/src/test/java/net/hydromatic/optiq/test/SparkAdapterTest.java
----------------------------------------------------------------------
diff --git a/spark/src/test/java/net/hydromatic/optiq/test/SparkAdapterTest.java b/spark/src/test/java/net/hydromatic/optiq/test/SparkAdapterTest.java
index e16d4ea..74931fb 100644
--- a/spark/src/test/java/net/hydromatic/optiq/test/SparkAdapterTest.java
+++ b/spark/src/test/java/net/hydromatic/optiq/test/SparkAdapterTest.java
@@ -21,7 +21,7 @@ import org.junit.Test;
 import java.sql.*;
 
 /**
- * Tests for using Optiq with Spark as an internal engine, as implemented by
+ * Tests for using Calcite with Spark as an internal engine, as implemented by
  * the {@link net.hydromatic.optiq.impl.spark} package.
  */
 public class SparkAdapterTest {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/splunk/pom.xml
----------------------------------------------------------------------
diff --git a/splunk/pom.xml b/splunk/pom.xml
index a099195..649d4c1 100644
--- a/splunk/pom.xml
+++ b/splunk/pom.xml
@@ -18,31 +18,31 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
-  <artifactId>optiq-splunk</artifactId>
+  <artifactId>calcite-splunk</artifactId>
   <packaging>jar</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
-  <name>Optiq Splunk</name>
-  <description>Splunk adapter for Optiq; also a JDBC driver for Splunk.</description>
+  <name>Calcite Splunk</name>
+  <description>Splunk adapter for Calcite; also a JDBC driver for Splunk</description>
 
   <properties>
     <top.dir>${project.basedir}/..</top.dir>
   </properties>
 
   <dependencies>
-    <!-- Sorted by groupId, artifactId; optiq dependencies first. Put versions
+    <!-- Sorted by groupId, artifactId; calcite dependencies first. Put versions
          in dependencyManagement in the root POM, not here. -->
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
     </dependency>
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
       <type>test-jar</type>
       <scope>test</scope>
     </dependency>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/splunk/src/main/java/net/hydromatic/optiq/impl/splunk/SplunkDriverVersion.java
----------------------------------------------------------------------
diff --git a/splunk/src/main/java/net/hydromatic/optiq/impl/splunk/SplunkDriverVersion.java b/splunk/src/main/java/net/hydromatic/optiq/impl/splunk/SplunkDriverVersion.java
index a1253c5..2dad422 100644
--- a/splunk/src/main/java/net/hydromatic/optiq/impl/splunk/SplunkDriverVersion.java
+++ b/splunk/src/main/java/net/hydromatic/optiq/impl/splunk/SplunkDriverVersion.java
@@ -19,15 +19,15 @@ package net.hydromatic.optiq.impl.splunk;
 import net.hydromatic.avatica.DriverVersion;
 
 /**
- * Version information for Optiq JDBC Driver for Splunk.
+ * Version information for Calcite JDBC Driver for Splunk.
  */
 class SplunkDriverVersion extends DriverVersion {
   /** Creates an OptiqDriverVersion. */
   SplunkDriverVersion() {
     super(
-        "Optiq JDBC Driver for Splunk",
+        "Calcite JDBC Driver for Splunk",
         "0.2",
-        "Optiq-Splunk",
+        "Calcite-Splunk",
         "0.2",
         true,
         0,

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/splunk/src/test/java/net/hydromatic/optiq/test/SplunkAdapterTest.java
----------------------------------------------------------------------
diff --git a/splunk/src/test/java/net/hydromatic/optiq/test/SplunkAdapterTest.java b/splunk/src/test/java/net/hydromatic/optiq/test/SplunkAdapterTest.java
index 2ff2d5b..ae3f949 100644
--- a/splunk/src/test/java/net/hydromatic/optiq/test/SplunkAdapterTest.java
+++ b/splunk/src/test/java/net/hydromatic/optiq/test/SplunkAdapterTest.java
@@ -30,7 +30,7 @@ import static org.hamcrest.CoreMatchers.is;
 import static org.junit.Assert.*;
 
 /**
- * Unit test of the Optiq adapter for Splunk.
+ * Unit test of the Calcite adapter for Splunk.
  */
 public class SplunkAdapterTest {
   public static final String SPLUNK_URL = "https://localhost:8089";
@@ -39,9 +39,9 @@ public class SplunkAdapterTest {
 
   /** Whether to run Splunk tests. Disabled by default, because we do not expect
    * Splunk to be installed and populated data set. To enable,
-   * specify {@code -Doptiq.test.splunk=true} on the Java command line. */
+   * specify {@code -Dcalcite.test.splunk=true} on the Java command line. */
   public static final boolean ENABLED =
-      Boolean.getBoolean("optiq.test.splunk");
+      Boolean.getBoolean("calcite.test.splunk");
 
   /** Whether this test is enabled. Tests are disabled unless we know that
    * Splunk is present and loaded with the requisite data. */

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/sqlline
----------------------------------------------------------------------
diff --git a/sqlline b/sqlline
index baf4067..3c0f4ce 100755
--- a/sqlline
+++ b/sqlline
@@ -18,7 +18,7 @@
 #
 # Example:
 # $ ./sqlline
-# sqlline> !connect jdbc:optiq: admin admin
+# sqlline> !connect jdbc:calcite: admin admin
 
 # Deduce whether we are running cygwin
 case $(uname -s) in

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/sqlline.bat
----------------------------------------------------------------------
diff --git a/sqlline.bat b/sqlline.bat
index 8c3d427..742cbf8 100644
--- a/sqlline.bat
+++ b/sqlline.bat
@@ -18,7 +18,7 @@
 ::
 :: Example:
 :: > sqlline.bat
-:: sqlline> !connect jdbc:optiq: admin admin 
+:: sqlline> !connect jdbc:calcite: admin admin 
 
 :: Copy dependency jars on first call. (To force jar refresh, remove target\dependencies)
 if not exist target\dependencies (call mvn -B dependency:copy-dependencies -DoverWriteReleases=false -DoverWriteSnapshots=false -DoverWriteIfNewer=true -DoutputDirectory=target\dependencies)

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/src/main/config/checkstyle/checker.xml
----------------------------------------------------------------------
diff --git a/src/main/config/checkstyle/checker.xml b/src/main/config/checkstyle/checker.xml
index 7a55a74..c6f24d0 100644
--- a/src/main/config/checkstyle/checker.xml
+++ b/src/main/config/checkstyle/checker.xml
@@ -28,7 +28,7 @@ limitations under the License.
 
 <!DOCTYPE module PUBLIC "-//Puppy Crawl//DTD Check Configuration 1.1//EN" "http://www.puppycrawl.com/dtds/configuration_1_1.dtd">
 
-<!-- Optiq customization of default Checkstyle behavior -->
+<!-- Calcite customization of default Checkstyle behavior -->
 <module name="Checker">
   <property name="localeLanguage" value="en"/>
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/ubenchmark/pom.xml
----------------------------------------------------------------------
diff --git a/ubenchmark/pom.xml b/ubenchmark/pom.xml
index 7ccbecf..e0a5ee5 100644
--- a/ubenchmark/pom.xml
+++ b/ubenchmark/pom.xml
@@ -18,8 +18,8 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
@@ -27,9 +27,9 @@ limitations under the License.
     <top.dir>${project.basedir}/..</top.dir>
   </properties>
 
-  <artifactId>optiq-ubenchmark</artifactId>
-  <name>Optiq Ubenchmark</name>
-  <description>Microbenchmarks for Optiq</description>
+  <artifactId>calcite-ubenchmark</artifactId>
+  <name>Calcite Ubenchmark</name>
+  <description>Microbenchmarks for Calcite</description>
 
   <repositories>
     <repository>
@@ -39,11 +39,11 @@ limitations under the License.
   </repositories>
 
   <dependencies>
-    <!-- Sorted by groupId, artifactId; optiq dependencies first. Put versions
+    <!-- Sorted by groupId, artifactId; calcite dependencies first. Put versions
          in dependencyManagement in the root POM, not here. -->
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-core</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-core</artifactId>
     </dependency>
 
     <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/ubenchmark/src/main/java/net/hydromatic/optiq/StatementTest.java
----------------------------------------------------------------------
diff --git a/ubenchmark/src/main/java/net/hydromatic/optiq/StatementTest.java b/ubenchmark/src/main/java/net/hydromatic/optiq/StatementTest.java
index a642454..37722e6 100644
--- a/ubenchmark/src/main/java/net/hydromatic/optiq/StatementTest.java
+++ b/ubenchmark/src/main/java/net/hydromatic/optiq/StatementTest.java
@@ -27,7 +27,7 @@ import java.util.*;
 /**
  * Compares {@link java.sql.Statement} vs {@link java.sql.PreparedStatement}.
  *
- * <p>This package contains micro-benchmarks to test optiq performance.
+ * <p>This package contains micro-benchmarks to test calcite performance.
  *
  * <p>To run this and other benchmarks:
  *
@@ -67,7 +67,7 @@ public class StatementTest {
         Properties info = new Properties();
         info.put("lex", "JAVA");
         info.put("quoting", "DOUBLE_QUOTE");
-        connection = DriverManager.getConnection("jdbc:optiq:", info);
+        connection = DriverManager.getConnection("jdbc:calcite:", info);
       } catch (SQLException e) {
         throw new IllegalStateException(e);
       }


[3/3] git commit: Add recent presentation to README.md.

Posted by jh...@apache.org.
Add recent presentation to README.md.


Project: http://git-wip-us.apache.org/repos/asf/incubator-optiq/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-optiq/commit/7fc4f6e0
Tree: http://git-wip-us.apache.org/repos/asf/incubator-optiq/tree/7fc4f6e0
Diff: http://git-wip-us.apache.org/repos/asf/incubator-optiq/diff/7fc4f6e0

Branch: refs/heads/master
Commit: 7fc4f6e082955da119b2e34d5a94a8dc0e177ade
Parents: a6f586a
Author: Julian Hyde <jh...@apache.org>
Authored: Tue Sep 30 16:06:22 2014 -0700
Committer: Julian Hyde <jh...@apache.org>
Committed: Tue Sep 30 16:06:22 2014 -0700

----------------------------------------------------------------------
 README.md | 19 ++++++++++++-------
 1 file changed, 12 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/7fc4f6e0/README.md
----------------------------------------------------------------------
diff --git a/README.md b/README.md
index 582dee4..507ede5 100644
--- a/README.md
+++ b/README.md
@@ -4,6 +4,8 @@
 
 Apache Calcite is a dynamic data management framework.
 
+It was formerly called Optiq.
+
 ## Getting Calcite
 
 To run Apache Calcite, you can either
@@ -181,14 +183,16 @@ For more details, see the <a href="doc/REFERENCE.md">Reference guide</a>.
 
 ## More information
 
-* License: Apache License, Version 2.0.
-* Author: Julian Hyde
+* License: Apache License, Version 2.0
 * Blog: http://julianhyde.blogspot.com
+* Project page: http://optiq.incubator.apache.org
 * Incubation status page: http://incubator.apache.org/projects/optiq.html
-* Project page: http://www.hydromatic.net/calcite
 * Source code: http://github.com/apache/incubator-optiq
 * Issues: <a href="https://issues.apache.org/jira/browse/OPTIQ">Apache JIRA</a>
-* Developers list: <a href="mailto:dev@optiq.incubator.apache.org">dev at optiq.incubator.apache.org</a> (<a href="http://mail-archives.apache.org/mod_mbox/incubator-optiq-dev/">archive</a>, <a href="mailto:dev-subscribe@optiq.incubator.apache.org">subscribe</a>)
+* Developers list: <a href="mailto:dev@optiq.incubator.apache.org">dev at optiq.incubator.apache.org</a>
+  (<a href="http://mail-archives.apache.org/mod_mbox/incubator-optiq-dev/">archive</a>,
+  <a href="mailto:dev-subscribe@optiq.incubator.apache.org">subscribe</a>)
+* Twitter: <a href="https://twitter.com/ApacheCalcite">@ApacheCalcite</a>
 * <a href="doc/HOWTO.md">HOWTO</a>
 * <a href="doc/MODEL.md">JSON model</a>
 * <a href="doc/REFERENCE.md">Reference guide</a>
@@ -196,10 +200,10 @@ For more details, see the <a href="doc/REFERENCE.md">Reference guide</a>.
 
 ### Pre-Apache resources
 
-These resources, which we used before Calcite was an Apache incubator
-project, are for reference only.
+These resources, which we used when Calcite was called Optiq and
+before it joined the Apache incubator, are for reference only.
 They may be out of date.
-Please don't post to the mailing list.
+Please don't post or try to subscribe to the mailing list.
 
 * Developers list: <a href="http://groups.google.com/group/optiq-dev">optiq-dev@googlegroups.com</a>
 
@@ -211,6 +215,7 @@ Please don't post to the mailing list.
 * <a href="https://github.com/julianhyde/share/blob/master/slides/optiq-nosql-now-2013.pdf?raw=true">SQL Now!</a> (NoSQL Now! conference, 2013)
 * <a href="https://github.com/julianhyde/share/blob/master/slides/hive-cbo-summit-2014.pdf?raw=true">Cost-based optimization in Hive</a> (<a href="https://www.youtube.com/watch?v=vpG5noIbEFs">video</a>) (Hadoop Summit, 2014)
 * <a href="https://github.com/julianhyde/share/blob/master/slides/dmmq-summit-2014.pdf?raw=true">Discardable, in-memory materialized query for Hadoop</a> (<a href="https://www.youtube.com/watch?v=CziGOa8GXqI">video</a>) (Hadoop Summit, 2014)
+* <a href="https://github.com/julianhyde/share/blob/master/slides/hive-cbo-seattle-2014.pdf?raw=true">Cost-based optimization in Hive 0.14</a> (Seattle, 2014)
 
 ## Disclaimer
 


[2/3] git commit: [OPTIQ-430] Rename project from "Optiq" to "Calcite"

Posted by jh...@apache.org.
[OPTIQ-430] Rename project from "Optiq" to "Calcite"


Project: http://git-wip-us.apache.org/repos/asf/incubator-optiq/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-optiq/commit/a6f586ac
Tree: http://git-wip-us.apache.org/repos/asf/incubator-optiq/tree/a6f586ac
Diff: http://git-wip-us.apache.org/repos/asf/incubator-optiq/diff/a6f586ac

Branch: refs/heads/master
Commit: a6f586ac7764b8ff9ee4b659643fa816e8db42e3
Parents: 356a606
Author: Julian Hyde <jh...@apache.org>
Authored: Tue Sep 30 15:28:27 2014 -0700
Committer: Julian Hyde <jh...@apache.org>
Committed: Tue Sep 30 15:28:27 2014 -0700

----------------------------------------------------------------------
 DISCLAIMER                                      |   2 +-
 NOTICE                                          |   2 +-
 README                                          |  10 +-
 README.md                                       |  60 ++++----
 avatica/pom.xml                                 |   8 +-
 .../hydromatic/avatica/UnregisteredDriver.java  |   2 +-
 core/pom.xml                                    |  18 +--
 core/src/main/codegen/config.fmpp               |   6 +-
 .../main/java/net/hydromatic/optiq/Member.java  |   2 +-
 .../main/java/net/hydromatic/optiq/Schema.java  |  10 +-
 .../java/net/hydromatic/optiq/SchemaPlus.java   |   2 +-
 .../main/java/net/hydromatic/optiq/Schemas.java |   6 +-
 .../main/java/net/hydromatic/optiq/Table.java   |   4 +-
 .../optiq/config/OptiqConnectionConfig.java     |   2 +-
 .../optiq/config/OptiqConnectionProperty.java   |   6 +-
 .../optiq/impl/MaterializedViewTable.java       |   4 +-
 .../optiq/impl/jdbc/JdbcConvention.java         |   2 +-
 .../net/hydromatic/optiq/impl/package-info.java |   2 +-
 .../java/net/hydromatic/optiq/jdbc/Driver.java  |   8 +-
 .../hydromatic/optiq/jdbc/OptiqConnection.java  |   2 +-
 .../optiq/jdbc/OptiqConnectionImpl.java         |   2 +-
 .../net/hydromatic/optiq/jdbc/OptiqFactory.java |   2 +-
 .../optiq/jdbc/OptiqJdbc40Factory.java          |   2 +-
 .../optiq/jdbc/OptiqJdbc41Factory.java          |   2 +-
 .../optiq/jdbc/OptiqPreparedStatement.java      |   2 +-
 .../hydromatic/optiq/jdbc/OptiqResultSet.java   |   2 +-
 .../hydromatic/optiq/jdbc/OptiqStatement.java   |   2 +-
 .../net/hydromatic/optiq/jdbc/package-info.java |   2 +-
 .../optiq/materialize/package-info.java         |   6 +-
 .../net/hydromatic/optiq/model/JsonLattice.java |   2 +-
 .../net/hydromatic/optiq/model/JsonSchema.java  |   6 +-
 .../hydromatic/optiq/model/package-info.java    |   2 +-
 .../java/net/hydromatic/optiq/package-info.java |   2 +-
 .../optiq/prepare/OptiqPrepareImpl.java         |   6 +-
 .../optiq/rules/java/AggImplementor.java        |   4 +-
 .../optiq/rules/java/NotNullImplementor.java    |  11 +-
 .../java/ReflectiveCallNotNullImplementor.java  |   9 +-
 .../optiq/rules/java/RexToLixTranslator.java    |   4 +-
 .../optiq/rules/java/WinAggContext.java         |   5 +-
 .../java/net/hydromatic/optiq/runtime/Hook.java |   2 +-
 .../optiq/server/OptiqServerStatement.java      |   2 +-
 .../hydromatic/optiq/server/package-info.java   |   2 +-
 .../net/hydromatic/optiq/tools/Frameworks.java  |   6 +-
 .../net/hydromatic/optiq/tools/Planner.java     |   2 +-
 .../eigenbase/relopt/SubstitutionVisitor.java   |   2 +-
 .../eigenbase/relopt/volcano/package-info.java  |   2 +-
 .../reltype/RelDataTypeFactoryImpl.java         |   4 +-
 .../main/java/org/eigenbase/sql/SqlDialect.java |   2 +-
 .../org/eigenbase/sql/SqlSelectOperator.java    |   2 +-
 .../eigenbase/sql/SqlUnresolvedFunction.java    |   2 +-
 .../sql/fun/SqlLeadLagAggFunction.java          |   4 +-
 .../eigenbase/sql/fun/SqlNtileAggFunction.java  |   4 +-
 .../org/eigenbase/sql/parser/SqlParser.java     |   2 +-
 .../org/eigenbase/sql/type/SqlTypeName.java     |   6 +-
 .../sql/validate/SqlUserDefinedAggFunction.java |   2 +-
 .../sql/validate/SqlUserDefinedFunction.java    |   2 +-
 .../validate/SqlUserDefinedTableFunction.java   |   2 +-
 .../sql/validate/SqlUserDefinedTableMacro.java  |   2 +-
 .../eigenbase/sql/validate/SqlValidator.java    |   2 +-
 .../net-hydromatic-optiq-jdbc.properties        |   4 +-
 .../examples/foodmart/java/JdbcExample.java     |   4 +-
 .../optiq/impl/generate/RangeTable.java         |   2 +-
 .../optiq/test/ExceptionMessageTest.java        |   2 +-
 .../net/hydromatic/optiq/test/FoodmartTest.java |   2 +-
 .../net/hydromatic/optiq/test/JdbcTest.java     |  42 +++---
 .../optiq/test/MultiJdbcSchemaJoinTest.java     |  12 +-
 .../net/hydromatic/optiq/test/OptiqAssert.java  |  31 +++--
 .../optiq/test/OptiqSqlOperatorTest.java        |   2 +-
 .../net/hydromatic/optiq/test/OptiqSuite.java   |   4 +-
 .../optiq/test/ReflectiveSchemaTest.java        |   8 +-
 .../optiq/test/TableInRootSchemaTest.java       |   2 +-
 .../net/hydromatic/optiq/test/package-info.java |   2 +-
 .../java/org/eigenbase/rex/RexExecutorTest.java |   6 +-
 .../org/eigenbase/test/RelOptRulesTest.java     |   4 +-
 core/src/test/resources/sql/winagg.oq           |   4 +-
 doc/HISTORY.md                                  |   6 +-
 doc/HOWTO.md                                    | 138 +++++++++----------
 doc/MODEL.md                                    |  12 +-
 doc/REFERENCE.md                                |   4 +-
 mongodb/pom.xml                                 |  20 +--
 .../hydromatic/optiq/test/MongoAdapterTest.java |   4 +-
 plus/pom.xml                                    |  20 +--
 .../hydromatic/optiq/impl/tpcds/TpcdsTest.java  |   2 +-
 .../hydromatic/optiq/impl/tpch/TpchTest.java    |   2 +-
 .../net/hydromatic/optiq/test/PlusSuite.java    |   2 +-
 pom.xml                                         |  28 ++--
 spark/pom.xml                                   |  18 +--
 .../optiq/impl/spark/SparkHandlerImpl.java      |   6 +-
 .../hydromatic/optiq/impl/spark/SparkRules.java |   2 +-
 .../optiq/impl/spark/SparkRuntime.java          |   2 +-
 .../hydromatic/optiq/test/SparkAdapterTest.java |   2 +-
 splunk/pom.xml                                  |  20 +--
 .../optiq/impl/splunk/SplunkDriverVersion.java  |   6 +-
 .../optiq/test/SplunkAdapterTest.java           |   6 +-
 sqlline                                         |   2 +-
 sqlline.bat                                     |   2 +-
 src/main/config/checkstyle/checker.xml          |   2 +-
 ubenchmark/pom.xml                              |  16 +--
 .../net/hydromatic/optiq/StatementTest.java     |   4 +-
 99 files changed, 373 insertions(+), 369 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/DISCLAIMER
----------------------------------------------------------------------
diff --git a/DISCLAIMER b/DISCLAIMER
index 50a07ee..09695df 100644
--- a/DISCLAIMER
+++ b/DISCLAIMER
@@ -1,4 +1,4 @@
-Apache Optiq is an effort undergoing incubation at the Apache Software
+Apache Calcite is an effort undergoing incubation at the Apache Software
 Foundation (ASF), sponsored by the Apache Incubator PMC.
 
 Incubation is required of all newly accepted projects until a further

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/NOTICE
----------------------------------------------------------------------
diff --git a/NOTICE b/NOTICE
index fd9f5dc..f41c811 100644
--- a/NOTICE
+++ b/NOTICE
@@ -1,4 +1,4 @@
-Apache Optiq
+Apache Calcite
 Copyright 2012-2014 The Apache Software Foundation
 
 This product includes software developed at

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/README
----------------------------------------------------------------------
diff --git a/README b/README
index bd2e686..9eaef94 100644
--- a/README
+++ b/README
@@ -1,6 +1,6 @@
-Apache Optiq release 0.9.0 (incubating)
+Apache Calcite release 0.9.1 (incubating)
 
-This is a source or binary distribution of Apache Optiq.
+This is a source or binary distribution of Apache Calcite.
 
 Changes since the previous release are described in the doc/HISTORY.md
 file.
@@ -11,14 +11,14 @@ If this is a source distribution, you can find instructions how to
 build the release in the "Building from a source release" section in
 doc/HOWTO.md.
 
-README.md contains examples of running Optiq.
+README.md contains examples of running Calcite.
 
-Further information about Apache Optiq is available at its web site,
+Further information about Apache Calcite is available at its web site,
 http://incubator.apache.org/optiq.
 
 Disclaimer
 
-Apache Optiq is an effort undergoing incubation at The Apache Software
+Apache Calcite is an effort undergoing incubation at The Apache Software
 Foundation (ASF), sponsored by the Apache Incubator. Incubation is
 required of all newly accepted projects until a further review
 indicates that the infrastructure, communications, and decision making

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/README.md
----------------------------------------------------------------------
diff --git a/README.md b/README.md
index 54734c0..582dee4 100644
--- a/README.md
+++ b/README.md
@@ -1,12 +1,12 @@
 [![Build Status](https://travis-ci.org/julianhyde/optiq.svg?branch=master)](https://travis-ci.org/julianhyde/optiq)
 
-# Apache Optiq
+# Apache Calcite
 
-Apache Optiq is a dynamic data management framework.
+Apache Calcite is a dynamic data management framework.
 
-## Getting Optiq
+## Getting Calcite
 
-To run Apache Optiq, you can either
+To run Apache Calcite, you can either
 [download and build from github](doc/HOWTO.md#building-from-git),
 or [download a release](http://www.apache.org/dyn/closer.cgi/incubator/optiq)
 then [build the source code](doc/HOWTO.md#building-from-a-source-distribution).
@@ -17,15 +17,15 @@ with the following Maven coordinates:
 
 ```xml
 <dependency>
-  <groupId>org.apache.optiq</groupId>
-  <artifactId>optiq-core</artifactId>
-  <version>0.9.0-incubating</version>
+  <groupId>org.apache.calcite</groupId>
+  <artifactId>calcite-core</artifactId>
+  <version>0.9.1-incubating</version>
 </dependency>
 ```
 
 ## Example
 
-Optiq makes data anywhere, of any format, look like a database. For
+Calcite makes data anywhere, of any format, look like a database. For
 example, you can execute a complex ANSI-standard SQL statement on
 in-memory collections:
 
@@ -36,7 +36,7 @@ public static class HrSchema {
 }
 
 Class.forName("net.hydromatic.optiq.jdbc.Driver");
-Connection connection = DriverManager.getConnection("jdbc:optiq:");
+Connection connection = DriverManager.getConnection("jdbc:calcite:");
 OptiqConnection optiqConnection =
     connection.unwrap(OptiqConnection.class);
 ReflectiveSchema.create(optiqConnection,
@@ -60,11 +60,11 @@ completely empty until <code>ReflectiveSchema.create</code> registers
 a Java object as a schema and its collection fields <code>emps</code>
 and <code>depts</code> as tables.
 
-Optiq does not want to own data; it does not even have favorite data
+Calcite does not want to own data; it does not even have favorite data
 format. This example used in-memory data sets, and processed them
 using operators such as <code>groupBy</code> and <code>join</code>
 from the linq4j
-library. But Optiq can also process data in other data formats, such
+library. But Calcite can also process data in other data formats, such
 as JDBC. In the first example, replace
 
 ```java
@@ -83,28 +83,28 @@ dataSource.setPassword("");
 JdbcSchema.create(optiqConnection, dataSource, rootSchema, "hr", "");
 ```
 
-and Optiq will execute the same query in JDBC. To the application, the
+and Calcite will execute the same query in JDBC. To the application, the
 data and API are the same, but behind the scenes the implementation is
-very different. Optiq uses optimizer rules
+very different. Calcite uses optimizer rules
 to push the <code>JOIN</code> and <code>GROUP BY</code> operations to
 the source database.
 
-In-memory and JDBC are just two familiar examples. Optiq can handle
+In-memory and JDBC are just two familiar examples. Calcite can handle
 any data source and data format. To add a data source, you need to
-write an adapter that tells Optiq
+write an adapter that tells Calcite
 what collections in the data source it should consider "tables".
 
 For more advanced integration, you can write optimizer
-rules. Optimizer rules allow Optiq to access data of a new format,
+rules. Optimizer rules allow Calcite to access data of a new format,
 allow you to register new operators (such as a better join algorithm),
-and allow Optiq to optimize how queries are translated to
-operators. Optiq will combine your rules and operators with built-in
+and allow Calcite to optimize how queries are translated to
+operators. Calcite will combine your rules and operators with built-in
 rules and operators, apply cost-based optimization, and generate an
 efficient plan.
 
 ### Non-JDBC access
 
-Optiq also allows front-ends other than SQL/JDBC. For example, you can
+Calcite also allows front-ends other than SQL/JDBC. For example, you can
 execute queries in <a href="https://github.com/julianhyde/linq4j">linq4j</a>:
 
 ```java
@@ -125,7 +125,7 @@ for (Customer customer
 ```
 
 Linq4j understands the full query parse tree, and the Linq4j query
-provider for Optiq invokes Optiq as an query optimizer. If the
+provider for Calcite invokes Calcite as an query optimizer. If the
 <code>customer</code> table comes from a JDBC database (based on
 this code fragment, we really can't tell) then the optimal plan
 will be to send the query
@@ -149,7 +149,7 @@ See the <a href="https://github.com/julianhyde/optiq-csv/blob/master/TUTORIAL.md
 for information on using optiq-csv and writing adapters.
 
 See the <a href="doc/HOWTO.md">HOWTO</a> for more information about using other
-adapters, and about using Optiq in general.
+adapters, and about using Calcite in general.
 
 ## Status
 
@@ -166,17 +166,17 @@ For more details, see the <a href="doc/REFERENCE.md">Reference guide</a>.
 
 ### Drivers
 
-* <a href="http://www.hydromatic.net/optiq/optiq-core/apidocs/net/hydromatic/optiq/jdbc/package-summary.html">JDBC driver</a>
+* <a href="http://www.hydromatic.net/calcite/calcite-core/apidocs/net/hydromatic/optiq/jdbc/package-summary.html">JDBC driver</a>
 
 ### Adapters
 
 * <a href="https://github.com/apache/incubator-drill">Apache Drill adapter</a>
 * Cascading adapter (<a href="https://github.com/Cascading/lingual">Lingual</a>)
 * CSV adapter (<a href="https://github.com/julianhyde/optiq-csv">optiq-csv</a>)
-* JDBC adapter (part of <a href="http://www.hydromatic.net/optiq/optiq-core/apidocs/net/hydromatic/optiq/impl/jdbc/package-summary.html">optiq-core</a>)
-* MongoDB adapter (<a href="http://www.hydromatic.net/optiq/optiq-mongodb/apidocs/net/hydromatic/optiq/impl/mongodb/package-summary.html">optiq-mongodb</a>)
-* Spark adapter (<a href="http://www.hydromatic.net/optiq/optiq-spark/apidocs/net/hydromatic/optiq/impl/spark/package-summary.html">optiq-spark</a>)
-* Splunk adapter (<a href="http://www.hydromatic.net/optiq/optiq-splunk/apidocs/net/hydromatic/optiq/impl/splunk/package-summary.html">optiq-splunk</a>)
+* JDBC adapter (part of <a href="http://www.hydromatic.net/calcite/calcite-core/apidocs/net/hydromatic/optiq/impl/jdbc/package-summary.html">calcite-core</a>)
+* MongoDB adapter (<a href="http://www.hydromatic.net/calcite/calcite-mongodb/apidocs/net/hydromatic/optiq/impl/mongodb/package-summary.html">calcite-mongodb</a>)
+* Spark adapter (<a href="http://www.hydromatic.net/calcite/calcite-spark/apidocs/net/hydromatic/optiq/impl/spark/package-summary.html">calcite-spark</a>)
+* Splunk adapter (<a href="http://www.hydromatic.net/calcite/calcite-splunk/apidocs/net/hydromatic/optiq/impl/splunk/package-summary.html">calcite-splunk</a>)
 * Eclipse Memory Analyzer (MAT) adapter (<a href="https://github.com/vlsi/optiq-mat-plugin">optiq-mat-plugin</a>)
 
 ## More information
@@ -185,8 +185,8 @@ For more details, see the <a href="doc/REFERENCE.md">Reference guide</a>.
 * Author: Julian Hyde
 * Blog: http://julianhyde.blogspot.com
 * Incubation status page: http://incubator.apache.org/projects/optiq.html
-* Project page: http://www.hydromatic.net/optiq
-* Source code: http://github.com/julianhyde/optiq
+* Project page: http://www.hydromatic.net/calcite
+* Source code: http://github.com/apache/incubator-optiq
 * Issues: <a href="https://issues.apache.org/jira/browse/OPTIQ">Apache JIRA</a>
 * Developers list: <a href="mailto:dev@optiq.incubator.apache.org">dev at optiq.incubator.apache.org</a> (<a href="http://mail-archives.apache.org/mod_mbox/incubator-optiq-dev/">archive</a>, <a href="mailto:dev-subscribe@optiq.incubator.apache.org">subscribe</a>)
 * <a href="doc/HOWTO.md">HOWTO</a>
@@ -196,7 +196,7 @@ For more details, see the <a href="doc/REFERENCE.md">Reference guide</a>.
 
 ### Pre-Apache resources
 
-These resources, which we used before Optiq was an Apache incubator
+These resources, which we used before Calcite was an Apache incubator
 project, are for reference only.
 They may be out of date.
 Please don't post to the mailing list.
@@ -214,7 +214,7 @@ Please don't post to the mailing list.
 
 ## Disclaimer
 
-Apache Optiq is an effort undergoing incubation at The Apache Software
+Apache Calcite is an effort undergoing incubation at The Apache Software
 Foundation (ASF), sponsored by the Apache Incubator. Incubation is
 required of all newly accepted projects until a further review
 indicates that the infrastructure, communications, and decision making

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/avatica/pom.xml
----------------------------------------------------------------------
diff --git a/avatica/pom.xml b/avatica/pom.xml
index 30d1f47..ea8fb13 100644
--- a/avatica/pom.xml
+++ b/avatica/pom.xml
@@ -18,15 +18,15 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
-  <artifactId>optiq-avatica</artifactId>
+  <artifactId>calcite-avatica</artifactId>
   <packaging>jar</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
-  <name>Optiq Avatica</name>
+  <name>Calcite Avatica</name>
   <description>JDBC driver framework.</description>
 
   <properties>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/avatica/src/main/java/net/hydromatic/avatica/UnregisteredDriver.java
----------------------------------------------------------------------
diff --git a/avatica/src/main/java/net/hydromatic/avatica/UnregisteredDriver.java b/avatica/src/main/java/net/hydromatic/avatica/UnregisteredDriver.java
index cb9c5cd..70e119f 100644
--- a/avatica/src/main/java/net/hydromatic/avatica/UnregisteredDriver.java
+++ b/avatica/src/main/java/net/hydromatic/avatica/UnregisteredDriver.java
@@ -143,7 +143,7 @@ public abstract class UnregisteredDriver implements java.sql.Driver {
   }
 
   /** Returns the prefix of the connect string that this driver will recognize
-   * as its own. For example, "jdbc:optiq:". */
+   * as its own. For example, "jdbc:calcite:". */
   protected abstract String getConnectStringPrefix();
 
   public DriverPropertyInfo[] getPropertyInfo(

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/pom.xml
----------------------------------------------------------------------
diff --git a/core/pom.xml b/core/pom.xml
index 7adf30f..ba22253 100644
--- a/core/pom.xml
+++ b/core/pom.xml
@@ -18,16 +18,16 @@ limitations under the License.
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <parent>
-    <groupId>org.apache.optiq</groupId>
-    <artifactId>optiq</artifactId>
+    <groupId>org.apache.calcite</groupId>
+    <artifactId>calcite</artifactId>
     <version>0.9.1-incubating-SNAPSHOT</version>
   </parent>
 
-  <artifactId>optiq-core</artifactId>
+  <artifactId>calcite-core</artifactId>
   <packaging>jar</packaging>
   <version>0.9.1-incubating-SNAPSHOT</version>
-  <name>Optiq Core</name>
-  <description>Core Optiq APIs and engine.</description>
+  <name>Calcite Core</name>
+  <description>Core Calcite APIs and engine.</description>
 
   <properties>
     <top.dir>${project.basedir}/..</top.dir>
@@ -35,11 +35,11 @@ limitations under the License.
    </properties>
 
   <dependencies>
-    <!-- Sorted by groupId, artifactId; optiq dependencies first. Put versions
+    <!-- Sorted by groupId, artifactId; calcite dependencies first. Put versions
          in dependencyManagement in the root POM, not here. -->
     <dependency>
-      <groupId>org.apache.optiq</groupId>
-      <artifactId>optiq-avatica</artifactId>
+      <groupId>org.apache.calcite</groupId>
+      <artifactId>calcite-avatica</artifactId>
     </dependency>
     <dependency>
       <groupId>org.pentaho</groupId>
@@ -158,7 +158,7 @@ limitations under the License.
       </resource>
       <resource>
         <!-- Copy freemarker template and fmpp configuration files of
-             Optiq's SQL parser to allow clients to extend parser. -->
+             Calcite's SQL parser to allow clients to extend parser. -->
         <directory>${basedir}/src/main/codegen</directory>
         <targetPath>codegen</targetPath>
       </resource>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/codegen/config.fmpp
----------------------------------------------------------------------
diff --git a/core/src/main/codegen/config.fmpp b/core/src/main/codegen/config.fmpp
index b017684..b45cd3a 100644
--- a/core/src/main/codegen/config.fmpp
+++ b/core/src/main/codegen/config.fmpp
@@ -14,10 +14,10 @@
 # limitations under the License.
 
 # This file is an FMPP (http://fmpp.sourceforge.net/) configuration file to
-# allow clients to extend Optiq's SQL parser to support application specific
+# allow clients to extend Calcite's SQL parser to support application specific
 # SQL statements, literals or data types.
 #
-# Optiq's parser grammar file (CombinedParser.jj) is written in javacc
+# Calcite's parser grammar file (CombinedParser.jj) is written in javacc
 # (http://javacc.java.net/) with Freemarker (http://freemarker.org/) variables
 # to allow clients to:
 #   1. have custom parser implementation class and package name.
@@ -30,7 +30,7 @@
 #   4. add import statements needed by inserted custom parser implementations.
 #
 # Parser template file (CombinerParser.jj) along with this file are packaged as
-# part of the optiq-core-<version>.jar under "codegen" directory.
+# part of the calcite-core-<version>.jar under "codegen" directory.
 
 data: {
   parser: {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/Member.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/Member.java b/core/src/main/java/net/hydromatic/optiq/Member.java
index d242985..88984d3 100644
--- a/core/src/main/java/net/hydromatic/optiq/Member.java
+++ b/core/src/main/java/net/hydromatic/optiq/Member.java
@@ -29,7 +29,7 @@ import java.util.List;
  *
  * <p>Several kinds of members crop up in real life. They all implement the
  * {@code Member} interface, but tend to be treated differently by the
- * back-end system if not by Optiq.</p>
+ * back-end system if not by Calcite.</p>
  *
  * <p>A member that has zero arguments and a type that is a collection of
  * records is referred to as a <i>relation</i>. In schemas backed by a

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/Schema.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/Schema.java b/core/src/main/java/net/hydromatic/optiq/Schema.java
index 7b8fd14..1ed8743 100644
--- a/core/src/main/java/net/hydromatic/optiq/Schema.java
+++ b/core/src/main/java/net/hydromatic/optiq/Schema.java
@@ -31,7 +31,7 @@ import java.util.*;
  * <p>There may be multiple overloaded functions with the same name but
  * different numbers or types of parameters.
  * For this reason, {@link #getFunctions} returns a list of all
- * members with the same name. Optiq will call
+ * members with the same name. Calcite will call
  * {@link Schemas#resolve(org.eigenbase.reltype.RelDataTypeFactory, String, java.util.Collection, java.util.List)}
  * to choose the appropriate one.</p>
  *
@@ -102,23 +102,23 @@ public interface Schema {
    * and sub-schemas in this schema, in addition to those returned automatically
    * by methods such as {@link #getTable(String)}.
    *
-   * <p>Even if this method returns true, the maps are not modified. Optiq
+   * <p>Even if this method returns true, the maps are not modified. Calcite
    * stores the defined objects in a wrapper object. */
   boolean isMutable();
 
   /** Returns whether the contents of this schema have changed since a given
    * time. The time is a millisecond value, as returned by
    * {@link System#currentTimeMillis()}. If this method returns true, and
-   * caching is enabled, Optiq will re-build caches.
+   * caching is enabled, Calcite will re-build caches.
    *
    * <p>The default implementation in
    * {@link net.hydromatic.optiq.impl.AbstractSchema} always returns
    * {@code false}.</p>
    *
-   * <p>To control whether Optiq caches the contents of a schema, use the
+   * <p>To control whether Calcite caches the contents of a schema, use the
    * "cache" JSON attribute. The default value is "true".</p>
    *
-   * @param lastCheck The last time that Optiq called this method, or
+   * @param lastCheck The last time that Calcite called this method, or
    *   {@link Long#MIN_VALUE} if this is the first call
    * @param now The current time in millis, as returned by
    *   {@link System#currentTimeMillis()}

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/SchemaPlus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/SchemaPlus.java b/core/src/main/java/net/hydromatic/optiq/SchemaPlus.java
index 91ca5ca..663974b 100644
--- a/core/src/main/java/net/hydromatic/optiq/SchemaPlus.java
+++ b/core/src/main/java/net/hydromatic/optiq/SchemaPlus.java
@@ -24,7 +24,7 @@ import com.google.common.collect.ImmutableList;
  * Extension to the {@link Schema} interface.
  *
  * <p>Given a user-defined schema that implements the {@link Schema} interface,
- * Optiq creates a wrapper that implements the {@code SchemaPlus} interface.
+ * Calcite creates a wrapper that implements the {@code SchemaPlus} interface.
  * This provides extra functionality, such as access to tables that have been
  * added explicitly.</p>
  *

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/Schemas.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/Schemas.java b/core/src/main/java/net/hydromatic/optiq/Schemas.java
index 4c83bef..09167c3 100644
--- a/core/src/main/java/net/hydromatic/optiq/Schemas.java
+++ b/core/src/main/java/net/hydromatic/optiq/Schemas.java
@@ -196,7 +196,7 @@ public final class Schemas {
     return table.asQueryable(root.getQueryProvider(), schema, tableName);
   }
 
-  /** Parses and validates a SQL query. For use within Optiq only. */
+  /** Parses and validates a SQL query. For use within Calcite only. */
   public static OptiqPrepare.ParseResult parse(
       final OptiqConnection connection, final OptiqSchema schema,
       final List<String> schemaPath, final String sql) {
@@ -213,7 +213,7 @@ public final class Schemas {
   }
 
   /** Parses and validates a SQL query and converts to relational algebra. For
-   * use within Optiq only. */
+   * use within Calcite only. */
   public static OptiqPrepare.ConvertResult convert(
       final OptiqConnection connection, final OptiqSchema schema,
       final List<String> schemaPath, final String sql) {
@@ -229,7 +229,7 @@ public final class Schemas {
     }
   }
 
-  /** Prepares a SQL query for execution. For use within Optiq only. */
+  /** Prepares a SQL query for execution. For use within Calcite only. */
   public static OptiqPrepare.PrepareResult<Object> prepare(
       final OptiqConnection connection, final OptiqSchema schema,
       final List<String> schemaPath, final String sql,

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/Table.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/Table.java b/core/src/main/java/net/hydromatic/optiq/Table.java
index e20f477..4e8f76c 100644
--- a/core/src/main/java/net/hydromatic/optiq/Table.java
+++ b/core/src/main/java/net/hydromatic/optiq/Table.java
@@ -22,9 +22,9 @@ import org.eigenbase.reltype.RelDataTypeFactory;
 /**
  * Table.
  *
- * <p>The typical way for a table to be created is when Optiq interrogates
+ * <p>The typical way for a table to be created is when Calcite interrogates
  * a user-defined schema in order to validate names appearing in a SQL query.
- * Optiq finds the schema by calling {@link Schema#getSubSchema(String)} on the
+ * Calcite finds the schema by calling {@link Schema#getSubSchema(String)} on the
  * connection's root schema, then gets a table by calling
  * {@link Schema#getTable(String)}.</p>
  *

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionConfig.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionConfig.java b/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionConfig.java
index 304a3cb..760b0d7 100644
--- a/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionConfig.java
+++ b/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionConfig.java
@@ -20,7 +20,7 @@ import net.hydromatic.avatica.Casing;
 import net.hydromatic.avatica.ConnectionConfig;
 import net.hydromatic.avatica.Quoting;
 
-/** Interface for reading connection properties within Optiq code. There is
+/** Interface for reading connection properties within Calcite code. There is
  * a method for every property. At some point there will be similar config
  * classes for system and statement properties. */
 public interface OptiqConnectionConfig extends ConnectionConfig {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionProperty.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionProperty.java b/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionProperty.java
index 5f2d85c..f1ed97d 100644
--- a/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionProperty.java
+++ b/core/src/main/java/net/hydromatic/optiq/config/OptiqConnectionProperty.java
@@ -31,10 +31,10 @@ public enum OptiqConnectionProperty implements ConnectionProperty {
   /** Whether to store query results in temporary tables. */
   AUTO_TEMP("autoTemp", Type.BOOLEAN, false),
 
-  /** Whether Optiq should use materializations. */
+  /** Whether Calcite should use materializations. */
   MATERIALIZATIONS_ENABLED("materializationsEnabled", Type.BOOLEAN, true),
 
-  /** Whether Optiq should create materializations. */
+  /** Whether Calcite should create materializations. */
   CREATE_MATERIALIZATIONS("createMaterializations", Type.BOOLEAN, true),
 
   /** URI of the model. */
@@ -63,7 +63,7 @@ public enum OptiqConnectionProperty implements ConnectionProperty {
   SCHEMA("schema", Type.STRING, null),
 
   /** Specifies whether Spark should be used as the engine for processing that
-   * cannot be pushed to the source system. If false (the default), Optiq
+   * cannot be pushed to the source system. If false (the default), Calcite
    * generates code that implements the Enumerable interface. */
   SPARK("spark", Type.BOOLEAN, false),
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/impl/MaterializedViewTable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/impl/MaterializedViewTable.java b/core/src/main/java/net/hydromatic/optiq/impl/MaterializedViewTable.java
index 8ba6a13..023dedd 100644
--- a/core/src/main/java/net/hydromatic/optiq/impl/MaterializedViewTable.java
+++ b/core/src/main/java/net/hydromatic/optiq/impl/MaterializedViewTable.java
@@ -50,13 +50,13 @@ public class MaterializedViewTable extends ViewTable {
 
   /**
    * Internal connection, used to execute queries to materialize views.
-   * To be used only by Optiq internals. And sparingly.
+   * To be used only by Calcite internals. And sparingly.
    */
   public static final OptiqConnection MATERIALIZATION_CONNECTION;
 
   static {
     try {
-      MATERIALIZATION_CONNECTION = DriverManager.getConnection("jdbc:optiq:")
+      MATERIALIZATION_CONNECTION = DriverManager.getConnection("jdbc:calcite:")
           .unwrap(OptiqConnection.class);
     } catch (SQLException e) {
       throw new RuntimeException(e);

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/impl/jdbc/JdbcConvention.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/impl/jdbc/JdbcConvention.java b/core/src/main/java/net/hydromatic/optiq/impl/jdbc/JdbcConvention.java
index a3d7607..c28c363 100644
--- a/core/src/main/java/net/hydromatic/optiq/impl/jdbc/JdbcConvention.java
+++ b/core/src/main/java/net/hydromatic/optiq/impl/jdbc/JdbcConvention.java
@@ -34,7 +34,7 @@ import org.eigenbase.sql.SqlDialect;
  * pops out in JDBC.</p>
  *
  * <p>This is the only convention, thus far, that is not a singleton. Each
- * instance contains a JDBC schema (and therefore a data source). If Optiq is
+ * instance contains a JDBC schema (and therefore a data source). If Calcite is
  * working with two different databases, it would even make sense to convert
  * from "JDBC#A" convention to "JDBC#B", even though we don't do it currently.
  * (That would involve asking database B to open a database link to database

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/impl/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/impl/package-info.java b/core/src/main/java/net/hydromatic/optiq/impl/package-info.java
index 6d71f4b..052b587 100644
--- a/core/src/main/java/net/hydromatic/optiq/impl/package-info.java
+++ b/core/src/main/java/net/hydromatic/optiq/impl/package-info.java
@@ -16,7 +16,7 @@
  */
 
 /**
- * Utilities to help implement Optiq's SPIs.
+ * Utilities to help implement Calcite's SPIs.
  */
 package net.hydromatic.optiq.impl;
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/Driver.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/Driver.java b/core/src/main/java/net/hydromatic/optiq/jdbc/Driver.java
index 4b61e72..a6a25b3 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/Driver.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/Driver.java
@@ -29,10 +29,10 @@ import java.sql.SQLException;
 import java.util.*;
 
 /**
- * Optiq JDBC driver.
+ * Calcite JDBC driver.
  */
 public class Driver extends UnregisteredDriver {
-  public static final String CONNECT_STRING_PREFIX = "jdbc:optiq:";
+  public static final String CONNECT_STRING_PREFIX = "jdbc:calcite:";
 
   final Function0<OptiqPrepare> prepareFactory;
 
@@ -71,9 +71,9 @@ public class Driver extends UnregisteredDriver {
     return DriverVersion.load(
         Driver.class,
         "net-hydromatic-optiq-jdbc.properties",
-        "Optiq JDBC Driver",
+        "Calcite JDBC Driver",
         "unknown version",
-        "Optiq",
+        "Calcite",
         "unknown version");
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnection.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnection.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnection.java
index 24ab9f0..402f72d 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnection.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnection.java
@@ -27,7 +27,7 @@ import java.sql.SQLException;
 import java.util.Properties;
 
 /**
- * Extension to Optiq's implementation of
+ * Extension to Calcite's implementation of
  * {@link java.sql.Connection JDBC connection} allows schemas to be defined
  * dynamically.
  *

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnectionImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnectionImpl.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnectionImpl.java
index 9d7ae7a..a1c8f57 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnectionImpl.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqConnectionImpl.java
@@ -52,7 +52,7 @@ import java.util.*;
 
 /**
  * Implementation of JDBC connection
- * in the Optiq engine.
+ * in the Calcite engine.
  *
  * <p>Abstract to allow newer versions of JDBC to add methods.</p>
  */

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqFactory.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqFactory.java
index a1c877c..cac1678 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqFactory.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqFactory.java
@@ -24,7 +24,7 @@ import java.util.Properties;
 
 /**
  * Extension of {@link net.hydromatic.avatica.AvaticaFactory}
- * for Optiq.
+ * for Calcite.
  */
 public abstract class OptiqFactory implements AvaticaFactory {
   protected final int major;

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc40Factory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc40Factory.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc40Factory.java
index 1447a11..a861b07 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc40Factory.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc40Factory.java
@@ -18,7 +18,7 @@ package net.hydromatic.optiq.jdbc;
 
 /**
  * Implementation of {@link net.hydromatic.avatica.AvaticaFactory}
- * for Optiq and JDBC 4.0 (corresponds to JDK 1.6).
+ * for Calcite and JDBC 4.0 (corresponds to JDK 1.6).
  */
 public class OptiqJdbc40Factory extends OptiqJdbc41Factory {
   /** Creates a factory for JDBC version 4.1. */

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc41Factory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc41Factory.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc41Factory.java
index ee0db9c..b55708f 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc41Factory.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqJdbc41Factory.java
@@ -29,7 +29,7 @@ import java.util.TimeZone;
 
 /**
  * Implementation of {@link net.hydromatic.avatica.AvaticaFactory}
- * for Optiq and JDBC 4.1 (corresponds to JDK 1.7).
+ * for Calcite and JDBC 4.1 (corresponds to JDK 1.7).
  */
 @SuppressWarnings("UnusedDeclaration")
 public class OptiqJdbc41Factory extends OptiqFactory {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqPreparedStatement.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqPreparedStatement.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqPreparedStatement.java
index 39b0cdf..3c66e92 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqPreparedStatement.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqPreparedStatement.java
@@ -25,7 +25,7 @@ import java.sql.*;
 
 /**
  * Implementation of {@link java.sql.PreparedStatement}
- * for the Optiq engine.
+ * for the Calcite engine.
  *
  * <p>This class has sub-classes which implement JDBC 3.0 and JDBC 4.0 APIs;
  * it is instantiated using {@link net.hydromatic.avatica.AvaticaFactory#newPreparedStatement}.</p>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqResultSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqResultSet.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqResultSet.java
index 220fc72..347542f 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqResultSet.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqResultSet.java
@@ -30,7 +30,7 @@ import java.util.*;
 
 /**
  * Implementation of {@link ResultSet}
- * for the Optiq engine.
+ * for the Calcite engine.
  */
 public class OptiqResultSet extends AvaticaResultSet {
   OptiqResultSet(

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqStatement.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqStatement.java b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqStatement.java
index 1177a55..eb29453 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqStatement.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/OptiqStatement.java
@@ -24,7 +24,7 @@ import net.hydromatic.optiq.server.OptiqServerStatement;
 
 /**
  * Implementation of {@link java.sql.Statement}
- * for the Optiq engine.
+ * for the Calcite engine.
  */
 public abstract class OptiqStatement
     extends AvaticaStatement

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/jdbc/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/jdbc/package-info.java b/core/src/main/java/net/hydromatic/optiq/jdbc/package-info.java
index 0ef6726..216ddca 100644
--- a/core/src/main/java/net/hydromatic/optiq/jdbc/package-info.java
+++ b/core/src/main/java/net/hydromatic/optiq/jdbc/package-info.java
@@ -16,7 +16,7 @@
  */
 
 /**
- * JDBC driver for Optiq.
+ * JDBC driver for Calcite.
  */
 package net.hydromatic.optiq.jdbc;
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/materialize/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/materialize/package-info.java b/core/src/main/java/net/hydromatic/optiq/materialize/package-info.java
index 6f40dda..ebeda47 100644
--- a/core/src/main/java/net/hydromatic/optiq/materialize/package-info.java
+++ b/core/src/main/java/net/hydromatic/optiq/materialize/package-info.java
@@ -24,9 +24,9 @@
  * ({@link net.hydromatic.optiq.materialize.MaterializationService})
  * for access from other parts of the system.</p>
  *
- * <p>Optimizer rules allow Optiq to rewrite queries using materializations, if
- * they are valid (that is, contain the same result as executing their defining
- * query) and lower cost.
+ * <p>Optimizer rules allow Calcite to rewrite queries using materializations,
+ * if they are valid (that is, contain the same result as executing their
+ * defining query) and lower cost.
  *
  * <p>In future, the actor may manage the process of updating materializations,
  * instantiating materializations from the intermediate results of queries, and

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/model/JsonLattice.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/model/JsonLattice.java b/core/src/main/java/net/hydromatic/optiq/model/JsonLattice.java
index 2a4c62c..a53fd60 100644
--- a/core/src/main/java/net/hydromatic/optiq/model/JsonLattice.java
+++ b/core/src/main/java/net/hydromatic/optiq/model/JsonLattice.java
@@ -43,7 +43,7 @@ public class JsonLattice {
 
   /** Estimated number of rows.
    *
-   * <p>If null, Optiq will a query to find the real value. */
+   * <p>If null, Calcite will a query to find the real value. */
   public Double rowCountEstimate;
 
   /** List of materialized aggregates to create up front. */

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/model/JsonSchema.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/model/JsonSchema.java b/core/src/main/java/net/hydromatic/optiq/model/JsonSchema.java
index f0921dd..0eb2e29 100644
--- a/core/src/main/java/net/hydromatic/optiq/model/JsonSchema.java
+++ b/core/src/main/java/net/hydromatic/optiq/model/JsonSchema.java
@@ -51,18 +51,18 @@ public abstract class JsonSchema {
   /** Whether to cache metadata (tables, functions and sub-schemas) generated
    * by this schema. Default value is {@code true}.
    *
-   * <p>If {@code false}, Optiq will go back to the schema each time it needs
+   * <p>If {@code false}, Calcite will go back to the schema each time it needs
    * metadata, for example, each time it needs a list of tables in order to
    * validate a query against the schema.</p>
    *
-   * <p>If {@code true}, Optiq will cache the metadata the first time it reads
+   * <p>If {@code true}, Calcite will cache the metadata the first time it reads
    * it. This can lead to better performance, especially if name-matching is
    * case-insensitive
    * (see {@link net.hydromatic.optiq.config.Lex#caseSensitive}).
    * However, it also leads to the problem of cache staleness.
    * A particular schema implementation can override the
    * {@link net.hydromatic.optiq.Schema#contentsHaveChangedSince(long, long)}
-   * method to tell Optiq when it should consider its cache to be out of
+   * method to tell Calcite when it should consider its cache to be out of
    * date.</p>
    *
    * <p>Tables, functions and sub-schemas explicitly created in a schema are

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/model/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/model/package-info.java b/core/src/main/java/net/hydromatic/optiq/model/package-info.java
index 53f91fc..c44d6fe 100644
--- a/core/src/main/java/net/hydromatic/optiq/model/package-info.java
+++ b/core/src/main/java/net/hydromatic/optiq/model/package-info.java
@@ -19,7 +19,7 @@
  * Provides model files, in JSON format, defining schemas and other metadata.
  *
  * <p>Models are specified using a <code>model=&lt;uri&gt;</code> parameter on
- * the JDBC connect string. Optiq loads the model while initializing the
+ * the JDBC connect string. Calcite loads the model while initializing the
  * connection. It first parses the JSON, then uses a
  * {@link net.hydromatic.optiq.model.ModelHandler} as visitor over the parse
  * tree.</p>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/package-info.java b/core/src/main/java/net/hydromatic/optiq/package-info.java
index a13e2f5..0afdc3f 100644
--- a/core/src/main/java/net/hydromatic/optiq/package-info.java
+++ b/core/src/main/java/net/hydromatic/optiq/package-info.java
@@ -16,7 +16,7 @@
  */
 
 /**
- * Main package for Optiq, the dynamic data management platform.
+ * Main package for Calcite, the dynamic data management platform.
  */
 package net.hydromatic.optiq;
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/prepare/OptiqPrepareImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/prepare/OptiqPrepareImpl.java b/core/src/main/java/net/hydromatic/optiq/prepare/OptiqPrepareImpl.java
index 9907a5b..1b8cd9e 100644
--- a/core/src/main/java/net/hydromatic/optiq/prepare/OptiqPrepareImpl.java
+++ b/core/src/main/java/net/hydromatic/optiq/prepare/OptiqPrepareImpl.java
@@ -81,11 +81,11 @@ import java.util.*;
 public class OptiqPrepareImpl implements OptiqPrepare {
 
   public static final boolean DEBUG =
-      "true".equals(System.getProperties().getProperty("optiq.debug"));
+      "true".equals(System.getProperties().getProperty("calcite.debug"));
 
   public static final boolean COMMUTE =
       "true".equals(
-          System.getProperties().getProperty("optiq.enable.join.commute"));
+          System.getProperties().getProperty("calcite.enable.join.commute"));
 
   /** Whether to enable the collation trait. Some extra optimizations are
    * possible if enabled, but queries should work either way. At some point
@@ -203,7 +203,7 @@ public class OptiqPrepareImpl implements OptiqPrepare {
   /** Creates a collection of planner factories.
    *
    * <p>The collection must have at least one factory, and each factory must
-   * create a planner. If the collection has more than one planner, Optiq will
+   * create a planner. If the collection has more than one planner, Calcite will
    * try each planner in turn.</p>
    *
    * <p>One of the things you can do with this mechanism is to try a simpler,

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/rules/java/AggImplementor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/rules/java/AggImplementor.java b/core/src/main/java/net/hydromatic/optiq/rules/java/AggImplementor.java
index 361308c..b4e2f17 100644
--- a/core/src/main/java/net/hydromatic/optiq/rules/java/AggImplementor.java
+++ b/core/src/main/java/net/hydromatic/optiq/rules/java/AggImplementor.java
@@ -35,7 +35,7 @@ public interface AggImplementor {
    * Returns the types of the intermediate variables used by the aggregate
    * implementation.
    * For instance, for "concatenate to string" this can be {@link java.lang.StringBuilder}.
-   * Optiq calls this method before all other {@code implement*} methods.
+   * Calcite calls this method before all other {@code implement*} methods.
    * @param info aggregate context
    * @return types of the intermediate variables used by the aggregate
    *   implementation
@@ -66,7 +66,7 @@ public interface AggImplementor {
   /**
    * Calculates the resulting value based on the intermediate variables.
    * Note: this method must NOT destroy the intermediate variables as
-   * optiq might reuse the state when calculating sliding aggregates.
+   * calcite might reuse the state when calculating sliding aggregates.
    * {@link AggResetContext#accumulator()} should be used to reference
    * the state variables.
    * @param info aggregate context

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/rules/java/NotNullImplementor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/rules/java/NotNullImplementor.java b/core/src/main/java/net/hydromatic/optiq/rules/java/NotNullImplementor.java
index b67a38f..8926a4e 100644
--- a/core/src/main/java/net/hydromatic/optiq/rules/java/NotNullImplementor.java
+++ b/core/src/main/java/net/hydromatic/optiq/rules/java/NotNullImplementor.java
@@ -23,18 +23,17 @@ import org.eigenbase.rex.RexCall;
 import java.util.List;
 
 /**
- * Simplified version of {@link net.hydromatic.optiq.rules.java.CallImplementor} that does not know about
- * null semantics.
- * <p>
+ * Simplified version of {@link net.hydromatic.optiq.rules.java.CallImplementor}
+ * that does not know about null semantics.
+ *
  * @see net.hydromatic.optiq.rules.java.RexImpTable
  * @see net.hydromatic.optiq.rules.java.CallImplementor
- *
- **/
+ */
 public interface NotNullImplementor {
   /**
    * Implements a call with assumption that all the null-checking is
    * implemented by caller.
-   * <p>
+   *
    * @param translator translator to implement the code
    * @param call call to implement
    * @param translatedOperands arguments of a call

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/rules/java/ReflectiveCallNotNullImplementor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/rules/java/ReflectiveCallNotNullImplementor.java b/core/src/main/java/net/hydromatic/optiq/rules/java/ReflectiveCallNotNullImplementor.java
index 0a3de79..527facf 100644
--- a/core/src/main/java/net/hydromatic/optiq/rules/java/ReflectiveCallNotNullImplementor.java
+++ b/core/src/main/java/net/hydromatic/optiq/rules/java/ReflectiveCallNotNullImplementor.java
@@ -27,9 +27,12 @@ import java.lang.reflect.Modifier;
 import java.util.List;
 
 /**
- * Implementation of {@link net.hydromatic.optiq.rules.java
- * .NotNullImplementor} that calls given {@link java.lang.reflect.Method}.
- * When method is not static, a new instance of the required class is created.
+ * Implementation of
+ * {@link net.hydromatic.optiq.rules.java.NotNullImplementor}
+ * that calls a given {@link java.lang.reflect.Method}.
+ *
+ * <p>When method is not static, a new instance of the required class is
+ * created.
  */
 public class ReflectiveCallNotNullImplementor implements NotNullImplementor {
   protected final Method method;

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/rules/java/RexToLixTranslator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/rules/java/RexToLixTranslator.java b/core/src/main/java/net/hydromatic/optiq/rules/java/RexToLixTranslator.java
index 4c13cfd..82ee068 100644
--- a/core/src/main/java/net/hydromatic/optiq/rules/java/RexToLixTranslator.java
+++ b/core/src/main/java/net/hydromatic/optiq/rules/java/RexToLixTranslator.java
@@ -550,8 +550,8 @@ public class RexToLixTranslator {
    * Translates the list of {@code RexNode}, using the default output types.
    * This might be suboptimal in terms of additional box-unbox when you use
    * the translation later.
-   * If you know the java class that will be used to store the results,
-   * use {@link net.hydromatic.optiq.rules.java.RexToLixTranslator#translateList(java.util.List, java.util.List)}
+   * If you know the java class that will be used to store the results, use
+   * {@link net.hydromatic.optiq.rules.java.RexToLixTranslator#translateList(java.util.List, java.util.List)}
    * version.
    *
    * @param operandList list of RexNodes to translate

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/rules/java/WinAggContext.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/rules/java/WinAggContext.java b/core/src/main/java/net/hydromatic/optiq/rules/java/WinAggContext.java
index 668074f..c0fc790 100644
--- a/core/src/main/java/net/hydromatic/optiq/rules/java/WinAggContext.java
+++ b/core/src/main/java/net/hydromatic/optiq/rules/java/WinAggContext.java
@@ -17,8 +17,9 @@
 package net.hydromatic.optiq.rules.java;
 
 /**
- * Marker interface to allow {@link net.hydromatic.optiq.rules.java.AggImplementor} to tell if it is used in
- * regular or windowed context.
+ * Marker interface to allow
+ * {@link net.hydromatic.optiq.rules.java.AggImplementor}
+ * to tell if it is used in regular or windowed context.
  */
 public interface WinAggContext extends AggContext {
 }

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/runtime/Hook.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/runtime/Hook.java b/core/src/main/java/net/hydromatic/optiq/runtime/Hook.java
index b82aa3d..f8abae4 100644
--- a/core/src/main/java/net/hydromatic/optiq/runtime/Hook.java
+++ b/core/src/main/java/net/hydromatic/optiq/runtime/Hook.java
@@ -132,7 +132,7 @@ public enum Hook {
   /** Removes a Hook after use.
    *
    * <p>Note: Although it would be convenient, this interface cannot extend
-   * {@code AutoCloseable} while Optiq maintains compatibility with
+   * {@code AutoCloseable} while Calcite maintains compatibility with
    * JDK 1.6.</p>
    */
   public interface Closeable /*extends AutoCloseable*/ {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/server/OptiqServerStatement.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/server/OptiqServerStatement.java b/core/src/main/java/net/hydromatic/optiq/server/OptiqServerStatement.java
index d06b9e3..88654d0 100644
--- a/core/src/main/java/net/hydromatic/optiq/server/OptiqServerStatement.java
+++ b/core/src/main/java/net/hydromatic/optiq/server/OptiqServerStatement.java
@@ -20,7 +20,7 @@ import net.hydromatic.optiq.jdbc.OptiqConnection;
 import net.hydromatic.optiq.jdbc.OptiqPrepare;
 
 /**
- * Statement within an Optiq server.
+ * Statement within a Calcite server.
  */
 public interface OptiqServerStatement {
   /** Creates a context for preparing a statement for execution. */

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/server/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/server/package-info.java b/core/src/main/java/net/hydromatic/optiq/server/package-info.java
index 824ec6e..e8dce01 100644
--- a/core/src/main/java/net/hydromatic/optiq/server/package-info.java
+++ b/core/src/main/java/net/hydromatic/optiq/server/package-info.java
@@ -16,7 +16,7 @@
  */
 
 /**
- * Provides a server for hosting Optiq connections.
+ * Provides a server for hosting Calcite connections.
  */
 package net.hydromatic.optiq.server;
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/tools/Frameworks.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/tools/Frameworks.java b/core/src/main/java/net/hydromatic/optiq/tools/Frameworks.java
index 62b6f3f..7024343 100644
--- a/core/src/main/java/net/hydromatic/optiq/tools/Frameworks.java
+++ b/core/src/main/java/net/hydromatic/optiq/tools/Frameworks.java
@@ -47,7 +47,7 @@ import java.util.List;
 import java.util.Properties;
 
 /**
- * Tools for invoking Optiq functionality without initializing a container /
+ * Tools for invoking Calcite functionality without initializing a container /
  * server first.
  */
 public class Frameworks {
@@ -143,7 +143,7 @@ public class Frameworks {
             action.config.getTypeSystem().getClass().getName());
       }
       Connection connection =
-          DriverManager.getConnection("jdbc:optiq:", info);
+          DriverManager.getConnection("jdbc:calcite:", info);
       OptiqConnection optiqConnection =
           connection.unwrap(OptiqConnection.class);
       final OptiqServerStatement statement =
@@ -268,7 +268,7 @@ public class Frameworks {
   }
 
   /**
-   * An implementation of {@link FrameworkConfig} that uses standard Optiq
+   * An implementation of {@link FrameworkConfig} that uses standard Calcite
    * classes to provide basic planner functionality.
    */
   static class StdFrameworkConfig implements FrameworkConfig {

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/net/hydromatic/optiq/tools/Planner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/net/hydromatic/optiq/tools/Planner.java b/core/src/main/java/net/hydromatic/optiq/tools/Planner.java
index 7d5b181..5b7e776 100644
--- a/core/src/main/java/net/hydromatic/optiq/tools/Planner.java
+++ b/core/src/main/java/net/hydromatic/optiq/tools/Planner.java
@@ -23,7 +23,7 @@ import org.eigenbase.sql.SqlNode;
 import org.eigenbase.sql.parser.SqlParseException;
 
 /**
- * A fa&ccedil;ade that covers Optiq's query planning process: parse SQL,
+ * A fa&ccedil;ade that covers Calcite's query planning process: parse SQL,
  * validate the parse tree, convert the parse tree to a relational expression,
  * and optimize the relational expression.
  *

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/relopt/SubstitutionVisitor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/relopt/SubstitutionVisitor.java b/core/src/main/java/org/eigenbase/relopt/SubstitutionVisitor.java
index 7a08d7a..eefb6d6 100644
--- a/core/src/main/java/org/eigenbase/relopt/SubstitutionVisitor.java
+++ b/core/src/main/java/org/eigenbase/relopt/SubstitutionVisitor.java
@@ -709,7 +709,7 @@ public class SubstitutionVisitor {
     /**
      * <p>Applies this rule to a particular node in a query. The goal is
      * to convert {@code query} into {@code target}. Before the rule is
-     * invoked, Optiq has made sure that query's children are equivalent
+     * invoked, Calcite has made sure that query's children are equivalent
      * to target's children.
      *
      * <p>There are 3 possible outcomes:</p>

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/relopt/volcano/package-info.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/relopt/volcano/package-info.java b/core/src/main/java/org/eigenbase/relopt/volcano/package-info.java
index fb40b21..0e6a0fc 100644
--- a/core/src/main/java/org/eigenbase/relopt/volcano/package-info.java
+++ b/core/src/main/java/org/eigenbase/relopt/volcano/package-info.java
@@ -80,7 +80,7 @@
  *
  * <p>New traits are added to the planner in one of two ways:</p>
  * <ol>
- *     <li>If the new trait is integral to Optiq, then each and every
+ *     <li>If the new trait is integral to Calcite, then each and every
  *         implementation of {@link org.eigenbase.rel.RelNode} should include
  *         its manifestation of the trait as part of the
  *         {@link org.eigenbase.relopt.RelTraitSet} passed to

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/reltype/RelDataTypeFactoryImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/reltype/RelDataTypeFactoryImpl.java b/core/src/main/java/org/eigenbase/reltype/RelDataTypeFactoryImpl.java
index 80d066c..541bd83 100644
--- a/core/src/main/java/org/eigenbase/reltype/RelDataTypeFactoryImpl.java
+++ b/core/src/main/java/org/eigenbase/reltype/RelDataTypeFactoryImpl.java
@@ -94,11 +94,11 @@ public abstract class RelDataTypeFactoryImpl implements RelDataTypeFactory {
 
   /** Creates a type factory with default type system.
    *
-   * @deprecated Will be removed after optiq-0.9.1.
+   * @deprecated Will be removed after calcite-0.9.1.
    */
   protected RelDataTypeFactoryImpl() {
     this(RelDataTypeSystem.DEFAULT);
-    Bug.upgrade("optiq-0.9.1");
+    Bug.upgrade("calcite-0.9.1");
   }
 
   /** Creates a type factory. */

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/SqlDialect.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/SqlDialect.java b/core/src/main/java/org/eigenbase/sql/SqlDialect.java
index 5c4d9fc..0a3102b 100644
--- a/core/src/main/java/org/eigenbase/sql/SqlDialect.java
+++ b/core/src/main/java/org/eigenbase/sql/SqlDialect.java
@@ -483,7 +483,7 @@ public class SqlDialect {
     INFORMIX("Informix", null),
     INGRES("Ingres", null),
     LUCIDDB("LucidDB", "\""),
-    OPTIQ("Apache Optiq", "\""),
+    OPTIQ("Apache Calcite", "\""),
     INTERBASE("Interbase", null),
     PHOENIX("Phoenix", "\""),
     POSTGRESQL("PostgreSQL", "\""),

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/SqlSelectOperator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/SqlSelectOperator.java b/core/src/main/java/org/eigenbase/sql/SqlSelectOperator.java
index 3ef8ce3..6f58867 100644
--- a/core/src/main/java/org/eigenbase/sql/SqlSelectOperator.java
+++ b/core/src/main/java/org/eigenbase/sql/SqlSelectOperator.java
@@ -154,7 +154,7 @@ public class SqlSelectOperator extends SqlOperator {
     writer.endList(selectListFrame);
 
     if (select.from != null) {
-      // Optiq SQL requires FROM but MySQL does not.
+      // Calcite SQL requires FROM but MySQL does not.
       writer.sep("FROM");
 
       // for FROM clause, use precedence just below join operator to make

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/SqlUnresolvedFunction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/SqlUnresolvedFunction.java b/core/src/main/java/org/eigenbase/sql/SqlUnresolvedFunction.java
index a607022..5fdbe78 100644
--- a/core/src/main/java/org/eigenbase/sql/SqlUnresolvedFunction.java
+++ b/core/src/main/java/org/eigenbase/sql/SqlUnresolvedFunction.java
@@ -28,7 +28,7 @@ import org.eigenbase.sql.type.SqlTypeName;
  * Placeholder for an unresolved function.
  *
  * <p>Created by the parser, then it is rewritten to proper SqlFunction by
- * the validator to a function defined in an Optiq schema.</p>
+ * the validator to a function defined in a Calcite schema.</p>
  */
 public class SqlUnresolvedFunction extends SqlFunction {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/fun/SqlLeadLagAggFunction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/fun/SqlLeadLagAggFunction.java b/core/src/main/java/org/eigenbase/sql/fun/SqlLeadLagAggFunction.java
index 6599e09..5f91738 100644
--- a/core/src/main/java/org/eigenbase/sql/fun/SqlLeadLagAggFunction.java
+++ b/core/src/main/java/org/eigenbase/sql/fun/SqlLeadLagAggFunction.java
@@ -82,11 +82,11 @@ public class SqlLeadLagAggFunction extends SqlAggFunction {
   }
 
   public List<RelDataType> getParameterTypes(RelDataTypeFactory typeFactory) {
-    throw new UnsupportedOperationException("remove before optiq-0.9");
+    throw new UnsupportedOperationException("remove before calcite-0.9");
   }
 
   public RelDataType getReturnType(RelDataTypeFactory typeFactory) {
-    throw new UnsupportedOperationException("remove before optiq-0.9");
+    throw new UnsupportedOperationException("remove before calcite-0.9");
   }
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/fun/SqlNtileAggFunction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/fun/SqlNtileAggFunction.java b/core/src/main/java/org/eigenbase/sql/fun/SqlNtileAggFunction.java
index 6c2f4ef..9364e10 100644
--- a/core/src/main/java/org/eigenbase/sql/fun/SqlNtileAggFunction.java
+++ b/core/src/main/java/org/eigenbase/sql/fun/SqlNtileAggFunction.java
@@ -46,11 +46,11 @@ public class SqlNtileAggFunction extends SqlAggFunction {
   }
 
   public List<RelDataType> getParameterTypes(RelDataTypeFactory typeFactory) {
-    throw new UnsupportedOperationException("remove before optiq-0.9");
+    throw new UnsupportedOperationException("remove before calcite-0.9");
   }
 
   public RelDataType getReturnType(RelDataTypeFactory typeFactory) {
-    throw new UnsupportedOperationException("remove before optiq-0.9");
+    throw new UnsupportedOperationException("remove before calcite-0.9");
   }
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/parser/SqlParser.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/parser/SqlParser.java b/core/src/main/java/org/eigenbase/sql/parser/SqlParser.java
index 4976946..29c49dc 100644
--- a/core/src/main/java/org/eigenbase/sql/parser/SqlParser.java
+++ b/core/src/main/java/org/eigenbase/sql/parser/SqlParser.java
@@ -59,7 +59,7 @@ public class SqlParser {
 
   /**
    * Creates a <code>SqlParser</code> to parse the given string using
-   * Optiq's parser implementation.
+   * Calcite's parser implementation.
    *
    * @param s An SQL statement or expression to parse.
    * @return A <code>SqlParser</code> object.

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/type/SqlTypeName.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/type/SqlTypeName.java b/core/src/main/java/org/eigenbase/sql/type/SqlTypeName.java
index 41745f5..fd6603e 100644
--- a/core/src/main/java/org/eigenbase/sql/type/SqlTypeName.java
+++ b/core/src/main/java/org/eigenbase/sql/type/SqlTypeName.java
@@ -303,7 +303,7 @@ public enum SqlTypeName {
    *
    * @deprecated Use
    * {@link org.eigenbase.reltype.RelDataTypeSystem#getDefaultPrecision(SqlTypeName)};
-   * will be removed after optiq-0.9.1.
+   * will be removed after calcite-0.9.1.
    */
   public int getDefaultPrecision() {
     return RelDataTypeSystem.DEFAULT.getDefaultPrecision(this);
@@ -682,7 +682,7 @@ public enum SqlTypeName {
    *
    * @deprecated Use
    * {@link org.eigenbase.reltype.RelDataTypeSystem#getMaxScale(SqlTypeName)};
-   * will be removed after optiq-0.9.1.
+   * will be removed after calcite-0.9.1.
    */
   public int getMaxPrecision() {
     return RelDataTypeSystem.DEFAULT.getMaxPrecision(this);
@@ -697,7 +697,7 @@ public enum SqlTypeName {
    *
    * @deprecated Use
    * {@link org.eigenbase.reltype.RelDataTypeSystem#getMaxScale(SqlTypeName)};
-   * will be removed after optiq-0.9.1.
+   * will be removed after calcite-0.9.1.
    */
   public int getMaxScale() {
     return RelDataTypeSystem.DEFAULT.getMaxScale(this);

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedAggFunction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedAggFunction.java b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedAggFunction.java
index 6088533..acc5836 100644
--- a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedAggFunction.java
+++ b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedAggFunction.java
@@ -33,7 +33,7 @@ import com.google.common.collect.Lists;
  * User-defined aggregate function.
  *
  * <p>Created by the validator, after resolving a function call to a function
- * defined in an Optiq schema.</p>
+ * defined in a Calcite schema.</p>
  */
 public class SqlUserDefinedAggFunction extends SqlAggFunction {
   public final AggregateFunction function;

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedFunction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedFunction.java b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedFunction.java
index 0e1b52a..fc9d771 100644
--- a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedFunction.java
+++ b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedFunction.java
@@ -29,7 +29,7 @@ import net.hydromatic.optiq.Function;
 * User-defined scalar function.
  *
  * <p>Created by the validator, after resolving a function call to a function
- * defined in an Optiq schema.</p>
+ * defined in a Calcite schema.</p>
 */
 public class SqlUserDefinedFunction extends SqlFunction {
   public final Function function;

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableFunction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableFunction.java b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableFunction.java
index 9248c30..14af7dc 100644
--- a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableFunction.java
+++ b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableFunction.java
@@ -33,7 +33,7 @@ import net.hydromatic.optiq.TableFunction;
  * User-defined table function.
  * <p>
  * Created by the validator, after resolving a function call to a function
- * defined in an Optiq schema.
+ * defined in a Calcite schema.
 */
 public class SqlUserDefinedTableFunction extends SqlUserDefinedFunction {
   public SqlUserDefinedTableFunction(SqlIdentifier opName,

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableMacro.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableMacro.java b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableMacro.java
index a9a73cd..5ae9f02 100644
--- a/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableMacro.java
+++ b/core/src/main/java/org/eigenbase/sql/validate/SqlUserDefinedTableMacro.java
@@ -43,7 +43,7 @@ import net.hydromatic.optiq.rules.java.RexToLixTranslator;
  * User-defined table macro.
  * <p>
  * Created by the validator, after resolving a function call to a function
- * defined in an Optiq schema.
+ * defined in a Calcite schema.
 */
 public class SqlUserDefinedTableMacro extends SqlFunction {
   private final TableMacro tableMacro;

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/java/org/eigenbase/sql/validate/SqlValidator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/eigenbase/sql/validate/SqlValidator.java b/core/src/main/java/org/eigenbase/sql/validate/SqlValidator.java
index 503eb5a..842c946 100644
--- a/core/src/main/java/org/eigenbase/sql/validate/SqlValidator.java
+++ b/core/src/main/java/org/eigenbase/sql/validate/SqlValidator.java
@@ -73,7 +73,7 @@ import org.eigenbase.util.*;
  */
 public interface SqlValidator {
   /** Whether to follow the SQL standard strictly. */
-  boolean STRICT = Util.first(Boolean.getBoolean("optiq.strict.sql"), false);
+  boolean STRICT = Util.first(Boolean.getBoolean("calcite.strict.sql"), false);
 
   //~ Methods ----------------------------------------------------------------
 

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/main/resources/version/net-hydromatic-optiq-jdbc.properties
----------------------------------------------------------------------
diff --git a/core/src/main/resources/version/net-hydromatic-optiq-jdbc.properties b/core/src/main/resources/version/net-hydromatic-optiq-jdbc.properties
index 716ca4e..15c5ced 100644
--- a/core/src/main/resources/version/net-hydromatic-optiq-jdbc.properties
+++ b/core/src/main/resources/version/net-hydromatic-optiq-jdbc.properties
@@ -13,9 +13,9 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 #
-driver.name=Optiq JDBC Driver
+driver.name=Calcite JDBC Driver
 driver.version=${pom.version}
-product.name=Optiq
+product.name=Calcite
 product.version=${pom.version}
 jdbc.compliant=true
 driver.version.major=${version.major}

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/examples/foodmart/java/JdbcExample.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/examples/foodmart/java/JdbcExample.java b/core/src/test/java/net/hydromatic/optiq/examples/foodmart/java/JdbcExample.java
index 48ad439..65dbcd5 100644
--- a/core/src/test/java/net/hydromatic/optiq/examples/foodmart/java/JdbcExample.java
+++ b/core/src/test/java/net/hydromatic/optiq/examples/foodmart/java/JdbcExample.java
@@ -23,7 +23,7 @@ import net.hydromatic.optiq.jdbc.OptiqConnection;
 import java.sql.*;
 
 /**
- * Example of using Optiq via JDBC.
+ * Example of using Calcite via JDBC.
  *
  * <p>Schema is specified programmatically.</p>
  */
@@ -35,7 +35,7 @@ public class JdbcExample {
   public void run() throws ClassNotFoundException, SQLException {
     Class.forName("net.hydromatic.optiq.jdbc.Driver");
     Connection connection =
-        DriverManager.getConnection("jdbc:optiq:");
+        DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection =
         connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/impl/generate/RangeTable.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/impl/generate/RangeTable.java b/core/src/test/java/net/hydromatic/optiq/impl/generate/RangeTable.java
index 2ee520f..f06ac4a 100644
--- a/core/src/test/java/net/hydromatic/optiq/impl/generate/RangeTable.java
+++ b/core/src/test/java/net/hydromatic/optiq/impl/generate/RangeTable.java
@@ -97,7 +97,7 @@ public class RangeTable extends AbstractQueryableTable {
   }
 
   /** Implementation of {@link net.hydromatic.optiq.TableFactory} that allows
-   * a {@link RangeTable} to be included as a custom table in an Optiq model
+   * a {@link RangeTable} to be included as a custom table in a Calcite model
    * file. */
   public static class Factory implements TableFactory<RangeTable> {
     public RangeTable create(

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/ExceptionMessageTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/ExceptionMessageTest.java b/core/src/test/java/net/hydromatic/optiq/test/ExceptionMessageTest.java
index 7e4408b..ec2f757 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/ExceptionMessageTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/ExceptionMessageTest.java
@@ -71,7 +71,7 @@ public class ExceptionMessageTest {
 
   @Before
   public void setUp() throws SQLException {
-    Connection connection = DriverManager.getConnection("jdbc:optiq:");
+    Connection connection = DriverManager.getConnection("jdbc:calcite:");
     OptiqConnection optiqConnection = connection.unwrap(OptiqConnection.class);
     SchemaPlus rootSchema = optiqConnection.getRootSchema();
     rootSchema.add("test", new ReflectiveSchema(new TestSchema()));

http://git-wip-us.apache.org/repos/asf/incubator-optiq/blob/a6f586ac/core/src/test/java/net/hydromatic/optiq/test/FoodmartTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/net/hydromatic/optiq/test/FoodmartTest.java b/core/src/test/java/net/hydromatic/optiq/test/FoodmartTest.java
index ca02d54..9535a03 100644
--- a/core/src/test/java/net/hydromatic/optiq/test/FoodmartTest.java
+++ b/core/src/test/java/net/hydromatic/optiq/test/FoodmartTest.java
@@ -105,7 +105,7 @@ public class FoodmartTest {
 
   @Parameterized.Parameters(name = "{index}: foodmart({0})={1}")
   public static List<Object[]> getSqls() throws IOException {
-    String idList = System.getProperty("optiq.ids");
+    String idList = System.getProperty("calcite.ids");
     if (!OptiqAssert.ENABLE_SLOW && idList == null) {
       // Avoid loading the query set in a regular test suite run. It burns too
       // much memory.