You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@calcite.apache.org by fr...@apache.org on 2019/07/09 22:43:26 UTC

[calcite] branch test-site updated (e21aadb -> bc4b7e8)

This is an automated email from the ASF dual-hosted git repository.

francischuang pushed a change to branch test-site
in repository https://gitbox.apache.org/repos/asf/calcite.git.


 discard e21aadb  Site: Change timezone offsets for posts to UTC (+0)
 discard 6fe3ae8  Add Jenkinsfile for automated site build
 discard 614bdcf  Site: Add Danny Chan as committer
 discard 2126ee2  Site: Improve contribution guidelines for JIRA
 discard 4851b23  Site: Add new committers and PMC (Chunwei Lei, Ruben Quesada Lopez, Zhiwei Peng and Stamatis Zampetakis)
 discard ffe62fc  Site: Add guidelines for JIRA's fix version field
 discard aa025d2  Site: Improve documentation for MySQL-specific JSON operators (does not include JSON_LENGTH)
 discard f971492  Update instructions for publishing site; we previously used subversion, now we use git
 discard 42dce09  Site: Add Alibaba MaxCompute to powered-by page
 discard 1939f9c  Suppress deprecation warning, and remove unicode character from Java source file
 discard 8197225  Site: Add new committers (Haisheng Yuan, Hongze Zhang and Stamatis Zampetakis)
 discard a5530e5  [CALCITE-2952] Add JDK 12 as tested to 1.19.0 history
     add 25ffeb4  [CALCITE-2908] Implement SQL LAST_DAY function (Chunwei Lei)
     add 81143c8  [CALCITE-589] Extend unifyAggregates method to work with Grouping Sets
     add 1b43072  [CALCITE-574] Remove org.apache.calcite.util.Bug.CALCITE_461_FIXED
     add 35ab6c7  [CALCITE-2952] Add JDK 12 as tested to 1.19.0 history
     add 11c067f  Site: Add new committers (Haisheng Yuan, Hongze Zhang and Stamatis Zampetakis)
     add 90e69d4  [CALCITE-2953] LatticeTest.testTileAlgorithm2 and LatticeTest.testTileAlgorithm3 fail intermittently
     add 4fdf241  In RelFieldCollation, add a "withX" copy method for each attribute "X", and deprecate "copy"
     add 1f4b619  [CALCITE-2796] JDBC adapter should convert 'GROUP BY ROLLUP(x, y)' to 'GROUP BY x, y WITH ROLLUP' for MySQL 5
     add ddbcd39  Suppress deprecation warning, and remove unicode character from Java source file
     add 650d24b  Site: Add Alibaba MaxCompute to powered-by page
     add a9687de  [CALCITE-2958] Upgrade SQLLine to 1.7.0
     add 62fc0e6  [CALCITE-2877] Make GeodeSchema constructor public to pass client cache object (Sandeep Chada)
     add 7887465  Update instructions for publishing site; we previously used subversion, now we use git
     add 8d81495  [CALCITE-2903] Exception thrown when decorrelating query with TEMPORAL TABLE
     add 2d33c57  [CALCITE-2808] Add the JSON_LENGTH function (xuqianjin)
     add aafdc52  [CALCITE-2729] Introducing WindowReduceExpressionsRule (Chunwei Lei)
     add 3124a85  [CALCITE-2927] The Javadoc and implement of RuleQueue.computeImportance() is inconsistent (Meng Wang)
     add a619cae  Oops!
     add 0537f27  [CALCITE-2658] Add ExchangeRemoveConstantKeysRule that removes constant keys from Exchange or SortExchange (Chunwei Lei)
     add 5cdf856  [CALCITE-2961] Enable Travis to test against JDK 13
     add 59aa115  [CALCITE-2909] Optimize Enumerable SemiJoin with lazy computation of innerLookup (Ruben Quesada Lopez)
     add 382f62c  [CALCITE-2941] EnumerableLimitRule on Sort with no collation creates EnumerableLimit with wrong traitSet and cluster (Ruben Quesada Lopez)
     add 1018d25  [CALCITE-2900] RelStructuredTypeFlattener generates wrong types on nested columns (Will Yu)
     add a3c0abd  [CALCITE-1515] In RelBuilder, add functionScan method to create TableFunctionScan (Chunwei Lei)
     add 22fd34f  [CALCITE-2920] In RelBuilder, add antiJoin method (Ruben Quesada Lopez)
     add 136c9c5  [CALCITE-2928] When resolving user-defined functions (UDFs), use the case-sensitivity of the current connection (Danny Chan)
     add 9bce62c  Site: Improve documentation for MySQL-specific JSON operators
     add b6d663c  Site: Update content of "Not implemented" since JSON_LENGH has already been added
     add 81fa531  Site: Add guidelines for JIRA's fix version field
     add 42f5761  Cosmetic changes
     add d7946a9  [CALCITE-883] Support RESPECT NULLS, IGNORE NULLS option for LEAD, LAG, FIRST_VALUE, LAST_VALUE, NTH_VALUE functions (Chunwei Lei)
     add a75a689  [CALCITE-2820] Avoid reducing certain aggregate functions when it is not necessary (Siddharth Teotia)
     add e043640  [CALCITE-2004] Push join predicate down into inner relation for lateral join
     add 43ba147  [CALCITE-2930] IllegalStateException when FilterCorrelateRule matches a SEMI or ANTI Correlate (Ruben Quesada Lopez)
     add 80dc5bc  [CALCITE-2892] Add the JSON_KEYS function (xuqianjin)
     add 463ab84  [CALCITE-1172] Add rule to flatten two Aggregate operators into one
     add bb4a063  [CALCITE-2754] Implement LISTAGG function (Sergey Nuyanzin, Chunwei Lei)
     add 6d57ff9  [CALCITE-2954] SubQueryJoinRemoveRule and SubQueryProjectRemoveRule passing on empty set instead of set of correlation id (Vineet Garg)
     add 906183a  [CALCITE-2914] Add a new statistic provider, to improve how LatticeSuggester deduces foreign keys
     add 7bc9258  [CALCITE-2976] Improve materialized view rewriting coverage with disjunctive predicates
     add 16f518b  [CALCITE-2847] Optimize global LOOKAHEAD for SQL parsers
     add a8e71f9  Remove calls to deprecated Guava API
     add 72e952d  [CALCITE-2456] VolcanoRuleCall doesn't match unordered child operand when the operand is not the first operand. PruneEmptyRules UNION and MINUS with empty inputs cause infinite cycle. (Zuozhi Wang)
     add af97f55  [CALCITE-2990] Fix document misspelling in RelInput (Shuming Li)
     add f596539  [CALCITE-2427] Allow sub-queries in DML statements (Pressenna Sockalingasamy)
     add 3ed7637  [CALCITE-896] Remove Aggregate if grouping columns are unique and all functions are splittable
     add f2869e9  [CALCITE-2739] NPE is thrown if the DEFINE statement contains IN in MATCH_RECOGNIZE
     add 38e3c30  [CALCITE-2977] Exception is not thrown when there are ambiguous field in select list
     add 53561d2  [CALCITE-1338] JoinProjectTransposeRule should not pull a literal up through the null-generating side of a join (Chunwei Lei)
     add 9538374  [CALCITE-2991] getMaxRowCount should return 1 for an Aggregate with constant keys (Vineet Garg)
     add 395aa85  [CALCITE-2994] Least restrictive type among structs does not consider nullability
     add b03cdc4  [CALCITE-2343] PushProjector with OVER expression causes infinite loop (Chunwei Lei)
     add 41df09c  [CALCITE-3006] Example code on site cannot compile (Chunwei Lei)
     add 8982925  [CALCITE-2865] FilterProjectTransposeRule generates wrong traitSet when copyFilter/Project is true (Ruben Quesada Lopez)
     add ceb3674  [CALCITE-3007] Type mismatch for ANY subquery in project (Vineet Garg)
     add a51a187  [CALCITE-2962] RelStructuredTypeFlattener generates wrong types for nested column when flattenProjection (Will Yu)
     add cd96973  [CALCITE-2986] Wrong results with =ANY subquery (Vineet Garg)
     add ee83efd  [CALCITE-3009] DiffRepository should ensure that XML resource file does not contain duplicate test names
     add 02eb106  [CALCITE-3010] In SQL parser, move JsonValueExpression into Expression
     add 577e72c  [CALCITE-2993] ParseException may be thrown for legal SQL queries due to incorrect "LOOKAHEAD(1)" hints
     add 79df7f9  Following [CALCITE-3010], remove redundant non-reserved keyword definitions
     add 898ddbd  [CALCITE-3001] Upgrade to Apache Druid 0.14.0-incubating
     add ecb469b  [CALCITE-3011] Support left and right outer joins with AggregateJoinTransposeRule (Vineet Garg)
     add f26d92f  [CALCITE-3004] RexOver is incorrectly pushed down in ProjectSetOpTransposeRule and ProjectCorrelateTransposeRule (Chunwei Lei)
     add 986a2d5  [CALCITE-2453] Parse list of SQL statements separated with a semicolon (Chunwei Lei, charbel yazbeck)
     add 758ce8b  [CALCITE-3021] ArrayEqualityComparer should use Arrays#deepEquals/deepHashCode instead of Arrays#equals/hashCode (Ruben Quesada Lopez)
     add b722612  Revert "[CALCITE-3021] ArrayEqualityComparer should use Arrays#deepEquals/deepHashCode instead of Arrays#equals/hashCode (Ruben Quesada Lopez)"
     add eed664d  [CALCITE-2982] SqlItemOperator should throw understandable exception message for incorrect operand type (pengzhiwei)
     add a3f81bb  [CALCITE-2998] RexCopier should support all rex types (Chunwei Lei, Alexander Shilov)
     add 9aebcfc  Site: Add new committers and PMC (Chunwei Lei, Ruben Quesada Lopez, Zhiwei Peng and Stamatis Zampetakis)
     add 20dbd23  [CALCITE-2292] Query result is wrong when table is implemented with FilterableTable and the sql has multiple where conditions
     add 37002c1  [CALCITE-3029] Java-oriented field type is wrongly forced to be NOT NULL after being converted to SQL-oriented
     add e3a6970  [CALCITE-3030] SqlParseException when using component identifier for setting in merge statements (Danny Chan)
     add a8f4623  [CALCITE-3045] NullPointerException when casting null literal to composite user defined type
     add 9ece70f  [CALCITE-3012] Column uniqueness metadata provider may return wrong result for FULL OUTER JOIN operator (Vineet Garg)
     add 603f93d  [CALCITE-3003] AssertionError when GROUP BY nested field (Will Yu)
     add 0d504d2  Oops, remove a println
     add 247c7d4  [CALCITE-3049] When simplifying "IS NULL" and "IS NOT NULL", simplify the operand first
     add da4970e  [CALCITE-3039] In Interpreter, min() incorrectly returns maximum double value (dijkspicy)
     add f536347  [CALCITE-3054] Elasticsearch adapter. Avoid scripting for simple projections
     add c0523d3  [CALCITE-2846] Document Oracle-specific functions, such as NVL and LTRIM, in the SQL reference
     add 735fc06  [CALCITE-3053] Add a test to ensure that all functions are documented in the SQL reference
     add b8bdfb0  [CALCITE-3046] CompileException when inserting casted value of composited user defined type into table
     add b727f3b  [CALCITE-3056] Elasticsearch adapter. Invalid result with cast function on raw queries
     add b15c8c9  Mongo adapter. Mongo checker validates only first line of the Bson query in tests
     add 6afa38b  Site: Improve contribution guidelines for JIRA
     add 9a4eab5  [CALCITE-3017] Re-organize how we represent built-in operators that are not in the standard operator table
     add d0a06f7  [CALCITE-3061] Query with WITH clause fails when alias is the same as the table with rolled up column
     add c25b29c  [CALCITE-2803] ProjectTransposeJoinRule messes INDF expressions
     add 2a2140f  Site: Add Danny Chan as committer
     add b039a36  [CALCITE-3034] CSV test case description does not match it's code logic (FaxianZhao)
     add 3f24710  [CALCITE-2936] Simplify EXISTS or NOT EXISTS sub-query that has "GROUP BY ()"
     add e98c779  [CALCITE-3017] Improve null handling of JsonValueExpressionOperator
     add a5b382a  [CALCITE-3028] Support FULL OUTER JOIN with AggregateJoinTransposeRule (Vineet Garg)
     add d689620  [CALCITE-3066] RelToSqlConverter may incorrectly throw an AssertionError for some decimal literals
     add 046bb81  [CALCITE-3052] Error while applying rule MaterializedViewAggregateRule(Project-Aggregate): ArrayIndexOutOfBoundsException
     add 051058b  [CALCITE-2282] Remove sql operator table from parser
     add 7df0678  [CALCITE-2933] Add timestamp extract for casts from timestamp type to other types
     add 999c41d  [CALCITE-2975] Implement JSON_REMOVE function (xuqianjin)
     add c6b6800  [CALCITE-3062] Do not populate provenanceMap if not debug
     add ca92ce2  [CALCITE-3074] Move MySQL's JSON operators to SqlLibraryOperators
     add 4d04773  [CALCITE-2965] Implement string functions: REPEAT, SPACE, SOUNDEX, DIFFERENCE
     add 996579a  [CALCITE-2712] Add rule to remove null-generating side of a Join
     add 7fa13bf  [CALCITE-3072] Generate right SQL for FLOOR&SUBSTRING functions in SparkSqlDialect (DonnyZone)
     add 1a5fca0  [CALCITE-3068] testSubprogram() does not test whether subprogram gets re-executed
     add 50cd134  [CALCITE-3076] AggregateJoinTransposeRule throws error for unique under aggregate keys when generating merged calls
     add 2e01ce1  [CALCITE-2601] Add REVERSE function (pingle wang)
     add 2765791  [CALCITE-3067] Splunk adapter cannot parse right session keys from Splunk 7.2 (Shawn Chen)
     add 61b858d  [CALCITE-3023] Upgrade elastic search to 7.x (Takako Shimamoto)
     add 170d522  [CALCITE-3050] Integrate SqlDialect and SqlParser.Config
     add 82e7d4e  [CALCITE-2807] Fix `IS NOT DISTINCT FROM` expression identification in RelOptUtil#pushDownJoinConditions()
     add 2cbdb6d  Oops, broke a test on Windows
     add b42029f  [CALCITE-2985] Implement JSON_STORAGE_SIZE function (xuqianjin)
     add 6120ff0  [CALCITE-3084] Implement JDBC string functions: ASCII, REPEAT, SPACE, SOUNDEX, DIFFERENC (pingle wang)
     add 1310295  [CALCITE-3090] Use https for maven central
     add ca6dc99  [CALCITE-2913] Adapter for Apache Kafka (Mingmin Xu) Expose an Apache Kafka topic as a stream table.
     add b318997  Revert "[CALCITE-3090] Use https for maven central"
     add 3fffb54  [CALCITE-3090] Remove Central configuration
     add e0cbcd8  Improve display of reproducer code in RexFuzzerTest for SqlStdOperatorTable.MULTIPLY
     add 2037831  Add system properties to RexProgramFuzzyTest to simplify git bisect
     add 4e1b68e  [CALCITE-3077] Rewrite CUBE&ROLLUP queries in SparkSqlDialect (DonnyZone)
     add ee14e01  [CALCITE-35] More test cases to guard against providing a broken fix for parenthesized join (Muhammad Gelbana)
     add 769fa6d  Make field JdbcTableScan.jdbcTable public
     add 80e09c0  Remove call to Class.newInstance(), which is deprecated as of JDK 9
     add b5b036d  Cosmetic changes
     add ab40586  [CALCITE-3021] Equality of nested ROWs returns false for identical values
     add 98d0dce  [CALCITE-2952] Document JDK 12 support
     add ac40d69  [CALCITE-3055] Use pair of relNode's rowType and digest as unique key for cache in RelOptPlanner (KazydubB)
     add aabcb2e  [CALCITE-3096] In RelBuilder, make alias method idempotent
     add fc5704e  Javadoc typos (Wenhui Tang, Muhammad Gelbana)
     add 7429c25  [CALCITE-3048] Improve how JDBC adapter deduces current schema on Redshift
     add 5c477f0  [CALCITE-3047] In JDBC adapter, expose multiple schemas of the back-end database
     add f1cad57  [CALCITE-3022] Babel: Various SQL parsing issues
     add 21ada17  [CALCITE-3097] GROUPING SETS breaks on sets of size > 1 due to precedence issues (Steven Talbot)
     add 73e6d05  [CALCITE-2812] Add algebraic operators to allow expressing recursive queries
     add 00f8b5f  RelOptUtilTest concurrency fixup
     add 4809393  [CALCITE-2696] Improve design of join-like relational expressions
     add 5650beb  [CALCITE-3095] Add several system properties to control enabling/disabling of rules and traits
     add 037250b  [CALCITE-3093] Remove JDBC connection calls from PlannerImpl
     add d8768f9  [CALCITE-3082] Fix NPE in SqlUtil#getSelectListItem
     add a09fa1e  [CALCITE-2742] Read values of USER and SYSTEM_USER variables from DataContext (Siddharth Teotia, Jacques Nadeau)
     add 6c96d15  [CALCITE-3098] Upgrade SQLLine to 1.8.0
     add 682dd8f  [CALCITE-3102] Remove deprecation warnings following CALCITE-2969
     add 8a25787  [CALCITE-2944] Deprecate Aggregate indicator and remove fields where possible
     add ef0c4c6  Complete [CALCITE-2969] and [CALCITE-3102] by restoring APIs that use SemiJoin but mask deprecation warnings
     add b0e83c4  Following [CALCITE-2944] remove internal uses of Aggregate.indicator
     add c08ea8b  Cosmetic changes
     add 674c123  [CALCITE-3106] Upgrade commons-pool2 from 2.6.0 to 2.6.2 (Fokko Driesprong)
     add c4e61bd  [CALCITE-3107] Upgrade commons-dbcp2 from 2.5.0 to 2.6.0 (Fokko Driesprong)
     add 7f33215  [CALCITE-3005] Implement string functions: LEFT, RIGHT (xuqianjin)
     add 9a617d5  Following [CALCITE-2812] Disable parallel execution of parameterized test to avoid hanging
     add e0774db  [CALCITE-2804] Fix casting to timestamps in Druid
     add d8f4cc4  [CALCITE-2744] RelDecorrelator use wrong output map for LogicalAggregate decorrelate (godfreyhe and Danny Chan)
     add 614b435  [CALCITE-3116] Upgrade to Avatica 1.15
     add 4513a72  [CALCITE-2721] Support parsing record-type [DOT] member-functions
     add be2b979  [CALCITE-2968] New AntiJoin relational expression
     add 0cb51c6  [CALCITE-2822] Allow MultiJoin rules with any project/filter (Siddharth Teotia)
     add 941cd4e  Following [CALCITE-2822] simplify test and related classes/rules
     add e01ba5a  [CALCITE-3123] In RelBuilder, eliminate duplicate aggregate calls
     add 90a4316  Following [CALCITE-3005], remove conflict warning in SQL parser
     add 340e21a  Following [CALCITE-2744] Remove usage of deprecated api in MockSqlOperatorTable
     add 2b91eb2  Fix test exception caused by slightly different error message from regex in JDK 13
     add a3c56be  [CALCITE-3087] AggregateOnProjectToAggregateUnifyRule ignores Project incorrectly when its Mapping breaks ordering (DonnyZone)
     add 4e89fdd  [CALCITE-3119] Deprecate Linq4j CorrelateJoinType (in favor of JoinType)
     add b1c1491  Bump version number for 1.20.0
     add 55e4328  Release notes for 1.20.0
     add 3979b46  Bump version for sanity check of properties
     add 31a3321  [maven-release-plugin] prepare release calcite-1.20.0
     add 8b5fae5  [maven-release-plugin] prepare for next development iteration
     add 3530daa  Add 1.20.0 release announcement
     add 34758b3  Add 1.20.0 release date
     add 69c8053  Add committer names to 1.20.0 release notes
     add 1cc7c35  Update example announcement
     add 6375e24  [CALCITE-3148] Validator throws IndexOutOfBoundsException for SqlInsert when source and sink have non-equal fields number
     add 135daf3  [CALCITE-3156] Mongo adapter. Replace fongo with Mongo Java Server for tests
     add 3301a32  [CALCITE-3157] Mongo java driver upgrade: 3.5.0 -> 3.10.2
     add bd42d29  [CALCITE-3060] MutableProject should be generated based on INVERSE_SURJECTION mapping (DonnyZone)
     add ccbacf6  [CALCITE-3149] RelDataType CACHE in RelDataTypeFactoryImpl can't be garbage collected
     add 78251a1  [CALCITE-2801] Check input type in AggregateUnionAggregateRule when remove the bottom Aggregate (Hequn Cheng)
     add 914e212  [CALCITE-3151] RexCall's Monotonicity is not considered in determining a Calc's collation
     add 8dd4fed  [CALCITE-3155] Empty LogicalValues can not be converted to UNION_ALL without operands which can not be unparsed(Musbah EL FIL)
     add eb47b37  [CALCITE-3146] Support the detection of nested aggregations for JdbcAggregate in SqlImplementor.(Wenhui Tang)
     add 79a4ec6  [CALCITE-3126] Remove deprecated SemiJoin usage completely
     add ceb13a1  [CALCITE-3133] Remove completely SemiJoinType
     add 64a61cd  [CALCITE-3125] Remove completely CorrelateJoinType
     add d9d79ba  [CALCITE-3152] Unify throws in sql parser
     add adf4cc4  [CALCITE-3063] Parse and process PostgreSQL posix regular expressions
     add 021fabe  [CALCITE-3168] Add test for invalid literal of sql parser
     add 0ed54bd  [CALCITE-3121] VolcanoPlanner hangs due to subquery with dynamic star
     add 1748f05  [CALCITE-2460] [CALCITE-2459] Add TO_BASE64 / FROM_BASE64 SQL functions (Wenhui Tang)
     add 046f9f4  [CALCITE-3172] RelBuilder#empty does not keep aliases
     add e1875e3  [CALCITE-3171] SemiJoin on conditions push down throws IndexOutOfBoundsException
     add e723ee9  [CALCITE-3169] decorrelateRel method should return when meeting SEMI/ANTI join in RelDecorrelator
     add 4d4fe4c  [CALCITE-3179] Bump Jackson from 2.9.8 to 2.9.9 (Fokko Driesprong)
     add cb364ce  [CALCITE-3170] ANTI join on conditions push down generates wrong plan
     add 6abf37a  [CALCITE-3160] Failed to materialize when the aggregate function uses group key (DonnyZone)
     new 3ee40c3  Add Jenkinsfile for automated site build
     new bc4b7e8  Site: Change timezone offsets for posts to UTC (+0)

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (e21aadb)
            \
             N -- N -- N   refs/heads/test-site (bc4b7e8)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

The 2 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .travis.yml                                        |    1 +
 README                                             |    2 +-
 babel/pom.xml                                      |    4 +-
 babel/src/main/codegen/config.fmpp                 |  136 +-
 babel/src/main/codegen/includes/parserImpls.ftl    |   28 +
 .../org/apache/calcite/test/BabelParserTest.java   |   87 +-
 cassandra/pom.xml                                  |    4 +-
 .../apache/calcite/test/CassandraAdapterTest.java  |    9 +-
 core/pom.xml                                       |   12 +-
 core/src/main/codegen/config.fmpp                  |   12 +-
 core/src/main/codegen/templates/Parser.jj          |  592 +--
 .../main/java/org/apache/calcite/DataContext.java  |   13 +-
 .../calcite/adapter/enumerable/EnumUtils.java      |   35 +-
 .../adapter/enumerable/EnumerableAggregate.java    |   21 +-
 .../enumerable/EnumerableAggregateRule.java        |    1 -
 .../adapter/enumerable/EnumerableCorrelate.java    |   14 +-
 ...EnumerableJoin.java => EnumerableHashJoin.java} |  136 +-
 .../adapter/enumerable/EnumerableJoinRule.java     |   39 +-
 .../adapter/enumerable/EnumerableLimitRule.java    |   12 +-
 .../adapter/enumerable/EnumerableMergeJoin.java    |   27 +-
 .../enumerable/EnumerableMergeJoinRule.java        |   10 +-
 ...hetaJoin.java => EnumerableNestedLoopJoin.java} |   53 +-
 .../enumerable/EnumerableRelImplementor.java       |   36 +-
 .../adapter/enumerable/EnumerableRepeatUnion.java  |   89 +
 ...ectRule.java => EnumerableRepeatUnionRule.java} |   41 +-
 .../adapter/enumerable/EnumerableRules.java        |   45 +-
 .../adapter/enumerable/EnumerableSemiJoin.java     |  145 -
 .../adapter/enumerable/EnumerableSemiJoinRule.java |   52 -
 .../adapter/enumerable/EnumerableTableSpool.java   |  113 +
 ...sectRule.java => EnumerableTableSpoolRule.java} |   43 +-
 .../adapter/enumerable/EnumerableWindow.java       |    3 +
 .../calcite/adapter/enumerable/NullPolicy.java     |    2 +
 .../calcite/adapter/enumerable/RexImpTable.java    |  135 +-
 .../adapter/enumerable/RexToLixTranslator.java     |    2 +-
 .../calcite/adapter/jdbc/JdbcCatalogSchema.java    |  147 +
 .../org/apache/calcite/adapter/jdbc/JdbcRules.java |  148 +-
 .../apache/calcite/adapter/jdbc/JdbcSchema.java    |  112 +-
 .../org/apache/calcite/adapter/jdbc/JdbcTable.java |   31 +-
 .../apache/calcite/adapter/jdbc/JdbcTableScan.java |    6 +-
 .../adapter/jdbc/JdbcToEnumerableConverter.java    |   14 +-
 .../config/CalciteConnectionConfigImpl.java        |   42 +-
 .../calcite/config/CalciteConnectionProperty.java  |    4 +-
 .../calcite/config/CalciteSystemProperty.java      |   16 +
 .../apache/calcite/interpreter/AggregateNode.java  |    6 +-
 .../org/apache/calcite/interpreter/Bindables.java  |   18 +-
 .../apache/calcite/jdbc/CalciteConnectionImpl.java |    4 +
 .../org/apache/calcite/jdbc/CalciteSchema.java     |   19 +-
 .../apache/calcite/jdbc/JavaTypeFactoryImpl.java   |   32 +-
 .../org/apache/calcite/materialize/Lattice.java    |    6 +-
 .../materialize/MapSqlStatisticProvider.java       |   88 -
 .../calcite/materialize/SqlStatisticProvider.java  |   36 +-
 .../java/org/apache/calcite/materialize/Step.java  |   37 +-
 .../java/org/apache/calcite/plan/RelOptNode.java   |    4 +-
 .../apache/calcite/plan/RelOptPredicateList.java   |    2 +-
 .../org/apache/calcite/plan/RelOptRuleCall.java    |    2 +
 .../java/org/apache/calcite/plan/RelOptRules.java  |  195 +
 .../java/org/apache/calcite/plan/RelOptUtil.java   |  354 +-
 .../main/java/org/apache/calcite/plan/Strong.java  |   32 +
 .../apache/calcite/plan/SubstitutionVisitor.java   |   57 +-
 .../org/apache/calcite/plan/hep/HepPlanner.java    |   27 +-
 .../org/apache/calcite/plan/hep/HepProgram.java    |    2 +-
 .../apache/calcite/plan/hep/HepProgramBuilder.java |    2 +-
 .../org/apache/calcite/plan/volcano/RuleQueue.java |    4 +-
 .../calcite/plan/volcano/VolcanoPlanner.java       |   83 +-
 .../calcite/plan/volcano/VolcanoRuleCall.java      |   41 +-
 .../calcite/prepare/CalciteCatalogReader.java      |    6 +-
 .../apache/calcite/prepare/CalcitePrepareImpl.java |  180 +-
 .../org/apache/calcite/prepare/PlannerImpl.java    |   84 +-
 .../apache/calcite/prepare/RelOptTableImpl.java    |    5 +-
 .../java/org/apache/calcite/rel/RelCollations.java |    4 +-
 .../org/apache/calcite/rel/RelFieldCollation.java  |   29 +-
 .../main/java/org/apache/calcite/rel/RelInput.java |    2 +-
 .../org/apache/calcite/rel/core/Aggregate.java     |  182 +-
 .../org/apache/calcite/rel/core/AggregateCall.java |   68 +-
 .../org/apache/calcite/rel/core/Correlate.java     |   26 +-
 .../java/org/apache/calcite/rel/core/EquiJoin.java |   25 +-
 .../java/org/apache/calcite/rel/core/Join.java     |   24 +-
 .../org/apache/calcite/rel/core/JoinRelType.java   |   60 +-
 .../org/apache/calcite/rel/core/RelFactories.java  |  155 +-
 .../org/apache/calcite/rel/core/RepeatUnion.java   |  117 +
 .../java/org/apache/calcite/rel/core/SemiJoin.java |  127 -
 .../java/org/apache/calcite/rel/core/Spool.java    |   95 +
 .../apache/calcite/rel/core/TableFunctionScan.java |    5 +-
 .../rel/{stream/Chi.java => core/TableSpool.java}  |   38 +-
 .../java/org/apache/calcite/rel/core/Window.java   |   23 +-
 .../apache/calcite/rel/externalize/RelJson.java    |    4 +-
 .../calcite/rel/externalize/RelJsonReader.java     |    2 +-
 .../calcite/rel/logical/LogicalAggregate.java      |   44 +-
 .../calcite/rel/logical/LogicalCorrelate.java      |   18 +-
 .../calcite/rel/logical/LogicalRepeatUnion.java    |   69 +
 .../rel/logical/LogicalTableFunctionScan.java      |    9 +-
 .../calcite/rel/logical/LogicalTableSpool.java     |   69 +
 .../apache/calcite/rel/logical/LogicalWindow.java  |    3 +-
 .../rel/metadata/JaninoRelMetadataProvider.java    |    4 +-
 .../calcite/rel/metadata/RelMdAllPredicates.java   |   16 +-
 .../calcite/rel/metadata/RelMdCollation.java       |   53 +-
 .../calcite/rel/metadata/RelMdColumnOrigins.java   |   11 +-
 .../rel/metadata/RelMdColumnUniqueness.java        |   21 +-
 .../rel/metadata/RelMdDistinctRowCount.java        |   29 -
 .../rel/metadata/RelMdExpressionLineage.java       |   13 +-
 .../calcite/rel/metadata/RelMdMaxRowCount.java     |   24 +
 .../calcite/rel/metadata/RelMdNodeTypes.java       |    6 -
 .../calcite/rel/metadata/RelMdPopulationSize.java  |    6 -
 .../calcite/rel/metadata/RelMdPredicates.java      |   42 +-
 .../apache/calcite/rel/metadata/RelMdRowCount.java |   15 +-
 .../calcite/rel/metadata/RelMdSelectivity.java     |    8 +-
 .../org/apache/calcite/rel/metadata/RelMdSize.java |   13 +-
 .../calcite/rel/metadata/RelMdUniqueKeys.java      |   14 +-
 .../org/apache/calcite/rel/metadata/RelMdUtil.java |  113 +-
 .../calcite/rel/mutable/MutableAggregate.java      |    8 +-
 .../calcite/rel/mutable/MutableCorrelate.java      |    8 +-
 .../apache/calcite/rel/mutable/MutableRelType.java |    1 -
 .../apache/calcite/rel/mutable/MutableRels.java    |   27 +-
 .../calcite/rel/mutable/MutableSemiJoin.java       |   88 -
 .../calcite/rel/rel2sql/RelToSqlConverter.java     |  206 +-
 .../apache/calcite/rel/rel2sql/SqlImplementor.java |   18 +-
 .../rel/rules/AbstractMaterializedViewRule.java    |  125 +-
 .../AggregateExpandDistinctAggregatesRule.java     |   60 +-
 .../rel/rules/AggregateFilterTransposeRule.java    |    9 +-
 .../rel/rules/AggregateJoinJoinRemoveRule.java     |  158 +
 .../calcite/rel/rules/AggregateJoinRemoveRule.java |  126 +
 .../rel/rules/AggregateJoinTransposeRule.java      |   25 +-
 .../calcite/rel/rules/AggregateMergeRule.java      |  151 +
 .../rel/rules/AggregateProjectMergeRule.java       |   24 +-
 .../rules/AggregateProjectPullUpConstantsRule.java |    1 -
 .../rel/rules/AggregateReduceFunctionsRule.java    |   89 +-
 .../calcite/rel/rules/AggregateRemoveRule.java     |   77 +-
 .../calcite/rel/rules/AggregateStarTableRule.java  |   10 +-
 .../rel/rules/AggregateUnionAggregateRule.java     |   23 +-
 .../rel/rules/AggregateUnionTransposeRule.java     |   12 +-
 .../apache/calcite/rel/rules/CalcMergeRule.java    |    3 +-
 .../rel/rules/ExchangeRemoveConstantKeysRule.java  |  201 +
 .../calcite/rel/rules/FilterCorrelateRule.java     |    7 +-
 .../apache/calcite/rel/rules/FilterJoinRule.java   |   30 +-
 .../rel/rules/FilterMultiJoinMergeRule.java        |   27 +-
 .../rel/rules/FilterProjectTransposeRule.java      |   15 +-
 .../rel/rules/JoinAddRedundantSemiJoinRule.java    |    9 +-
 .../rel/rules/JoinProjectTransposeRule.java        |   17 +-
 .../calcite/rel/rules/JoinToCorrelateRule.java     |   54 +-
 .../apache/calcite/rel/rules/LoptMultiJoin.java    |   12 +-
 .../calcite/rel/rules/LoptOptimizeJoinRule.java    |   10 +-
 .../calcite/rel/rules/LoptSemiJoinOptimizer.java   |   44 +-
 .../org/apache/calcite/rel/rules/MultiJoin.java    |    2 +-
 .../rel/rules/MultiJoinProjectTransposeRule.java   |   15 +-
 .../rel/rules/ProjectCorrelateTransposeRule.java   |    5 +-
 .../rel/rules/ProjectFilterTransposeRule.java      |   21 +
 .../rel/rules/ProjectJoinJoinRemoveRule.java       |  142 +
 .../calcite/rel/rules/ProjectJoinRemoveRule.java   |  127 +
 .../rel/rules/ProjectJoinTransposeRule.java        |   32 +-
 .../rel/rules/ProjectMultiJoinMergeRule.java       |   22 +-
 .../rel/rules/ProjectSetOpTransposeRule.java       |   45 +-
 .../rel/rules/ProjectWindowTransposeRule.java      |   11 +-
 .../apache/calcite/rel/rules/PruneEmptyRules.java  |   85 +-
 .../apache/calcite/rel/rules/PushProjector.java    |   18 +-
 .../calcite/rel/rules/ReduceExpressionsRule.java   |   89 +-
 .../rel/rules/SemiJoinFilterTransposeRule.java     |   19 +-
 .../rel/rules/SemiJoinJoinTransposeRule.java       |   27 +-
 .../rel/rules/SemiJoinProjectTransposeRule.java    |   31 +-
 .../calcite/rel/rules/SemiJoinRemoveRule.java      |    9 +-
 .../org/apache/calcite/rel/rules/SemiJoinRule.java |   29 +-
 .../calcite/rel/rules/SubQueryRemoveRule.java      |   53 +-
 .../org/apache/calcite/rel/stream/StreamRules.java |    2 +-
 .../calcite/rel/type/RelDataTypeFactoryImpl.java   |   31 +-
 .../java/org/apache/calcite/rex/RexBuilder.java    |   63 +-
 .../java/org/apache/calcite/rex/RexCopier.java     |   22 +-
 .../main/java/org/apache/calcite/rex/RexOver.java  |   12 +-
 .../java/org/apache/calcite/rex/RexProgram.java    |    3 +-
 .../java/org/apache/calcite/rex/RexShuttle.java    |    3 +-
 .../java/org/apache/calcite/rex/RexSimplify.java   |   18 +-
 .../calcite/rex/RexSqlStandardConvertletTable.java |    8 +-
 .../java/org/apache/calcite/rex/RexSubQuery.java   |    8 +-
 .../main/java/org/apache/calcite/rex/RexUtil.java  |    2 +-
 .../apache/calcite/runtime/CalciteResource.java    |   31 +-
 .../java/org/apache/calcite/runtime/FlatLists.java |    9 +-
 .../org/apache/calcite/runtime/JsonFunctions.java  |  796 ++++
 .../org/apache/calcite/runtime/SqlFunctions.java   |  690 +--
 .../TransientTable.java}                           |   18 +-
 .../calcite/schema/impl/ListTransientTable.java    |  150 +
 .../java/org/apache/calcite/sql/SemiJoinType.java  |  116 -
 .../org/apache/calcite/sql/SqlAggFunction.java     |    6 +
 .../java/org/apache/calcite/sql/SqlBasicCall.java  |    2 +-
 .../main/java/org/apache/calcite/sql/SqlCall.java  |    9 +-
 .../java/org/apache/calcite/sql/SqlCollation.java  |    6 +-
 .../org/apache/calcite/sql/SqlDataTypeSpec.java    |    2 +-
 .../java/org/apache/calcite/sql/SqlDialect.java    |  263 +-
 .../apache/calcite/sql/SqlDialectFactoryImpl.java  |   53 +
 .../org/apache/calcite/sql/SqlFilterOperator.java  |    2 +-
 .../java/org/apache/calcite/sql/SqlFunction.java   |    7 +-
 .../java/org/apache/calcite/sql/SqlIdentifier.java |   26 +-
 .../apache/calcite/sql/SqlJdbcFunctionCall.java    |   56 +-
 .../main/java/org/apache/calcite/sql/SqlKind.java  |   42 +-
 .../main/java/org/apache/calcite/sql/SqlNode.java  |    3 +-
 .../calcite/sql/SqlNullTreatmentOperator.java      |   67 +
 .../java/org/apache/calcite/sql/SqlOperator.java   |    7 +-
 .../org/apache/calcite/sql/SqlOperatorTable.java   |    6 +-
 .../org/apache/calcite/sql/SqlOverOperator.java    |    6 +
 .../calcite/sql/SqlSplittableAggFunction.java      |   80 +-
 .../main/java/org/apache/calcite/sql/SqlUtil.java  |  137 +-
 .../java/org/apache/calcite/sql/SqlWriter.java     |    7 +-
 .../calcite/sql/dialect/MssqlSqlDialect.java       |    3 +-
 .../calcite/sql/dialect/MysqlSqlDialect.java       |   13 +
 .../calcite/sql/dialect/OracleSqlDialect.java      |    4 +-
 .../calcite/sql/dialect/PostgresqlSqlDialect.java  |    2 +
 .../calcite/sql/dialect/RedshiftSqlDialect.java    |    6 +-
 ...aseSqlDialect.java => SnowflakeSqlDialect.java} |   17 +-
 .../calcite/sql/dialect/SparkSqlDialect.java       |   48 +
 .../calcite/sql/dialect/VerticaSqlDialect.java     |    4 +-
 .../apache/calcite/sql/fun/LibraryOperator.java    |   25 +-
 .../calcite/sql/fun/OracleSqlOperatorTable.java    |  100 +-
 .../sql/fun/SqlFirstLastValueAggFunction.java      |    4 +
 .../apache/calcite/sql/fun/SqlItemOperator.java    |    8 +-
 .../sql/fun/SqlJsonApiCommonSyntaxOperator.java    |   67 -
 .../sql/fun/SqlJsonArrayAggAggFunction.java        |    7 +-
 .../calcite/sql/fun/SqlJsonArrayFunction.java      |    5 +-
 .../calcite/sql/fun/SqlJsonDepthFunction.java      |   10 +-
 .../calcite/sql/fun/SqlJsonExistsFunction.java     |   18 +-
 ...leAggFunction.java => SqlJsonKeysFunction.java} |   32 +-
 ...AggFunction.java => SqlJsonLengthFunction.java} |   31 +-
 .../sql/fun/SqlJsonObjectAggAggFunction.java       |   12 +-
 .../calcite/sql/fun/SqlJsonObjectFunction.java     |   16 +-
 .../calcite/sql/fun/SqlJsonPrettyFunction.java     |    9 +-
 .../calcite/sql/fun/SqlJsonQueryFunction.java      |   20 +-
 ...ttyFunction.java => SqlJsonRemoveFunction.java} |   57 +-
 ...nction.java => SqlJsonStorageSizeFunction.java} |   31 +-
 .../calcite/sql/fun/SqlJsonTypeFunction.java       |   11 +-
 .../sql/fun/SqlJsonValueExpressionOperator.java    |   39 +-
 .../calcite/sql/fun/SqlJsonValueFunction.java      |   88 +-
 .../calcite/sql/fun/SqlLeadLagAggFunction.java     |    4 +
 .../org/apache/calcite/sql/fun/SqlLibrary.java     |   96 +
 .../sql/fun/SqlLibraryOperatorTableFactory.java    |  166 +
 .../calcite/sql/fun/SqlLibraryOperators.java       |  242 ++
 .../calcite/sql/fun/SqlLiteralChainOperator.java   |    2 +-
 .../calcite/sql/fun/SqlNthValueAggFunction.java    |    4 +
 .../calcite/sql/fun/SqlPosixRegexOperator.java     |  136 +
 .../apache/calcite/sql/fun/SqlRollupOperator.java  |   33 +-
 .../calcite/sql/fun/SqlStdOperatorTable.java       |   93 +-
 .../calcite/sql/parser/SqlAbstractParserImpl.java  |   40 +-
 .../org/apache/calcite/sql/parser/SqlParser.java   |   36 +-
 .../apache/calcite/sql/parser/SqlParserPos.java    |    3 +
 .../apache/calcite/sql/parser/SqlParserUtil.java   |   15 +-
 .../apache/calcite/sql/pretty/SqlPrettyWriter.java |    7 +-
 .../org/apache/calcite/sql/type/InferTypes.java    |   14 +
 .../org/apache/calcite/sql/type/OperandTypes.java  |   10 +
 .../org/apache/calcite/sql/type/ReturnTypes.java   |   29 +
 .../calcite/sql/type/SqlTypeAssignmentRules.java   |    6 +-
 .../calcite/sql/util/ChainedSqlOperatorTable.java  |    6 +-
 .../calcite/sql/util/ListSqlOperatorTable.java     |    6 +-
 .../sql/util/ReflectiveSqlOperatorTable.java       |   71 +-
 .../apache/calcite/sql/validate/AggChecker.java    |   16 +-
 .../org/apache/calcite/sql/validate/AggFinder.java |   11 +-
 .../apache/calcite/sql/validate/AggVisitor.java    |   21 +-
 .../calcite/sql/validate/DelegatingScope.java      |   24 +-
 .../apache/calcite/sql/validate/SqlValidator.java  |    8 +
 .../calcite/sql/validate/SqlValidatorImpl.java     |  149 +-
 .../calcite/sql/validate/SqlValidatorUtil.java     |   34 +-
 .../apache/calcite/sql2rel/AuxiliaryConverter.java |    2 +-
 .../apache/calcite/sql2rel/RelDecorrelator.java    |   68 +-
 .../apache/calcite/sql2rel/RelFieldTrimmer.java    |   33 +-
 .../sql2rel/RelStructuredTypeFlattener.java        |   26 +-
 .../apache/calcite/sql2rel/SqlToRelConverter.java  |  128 +-
 .../calcite/sql2rel/StandardConvertletTable.java   |   41 +-
 .../statistic/CachingSqlStatisticProvider.java     |   90 +
 .../calcite/statistic/MapSqlStatisticProvider.java |  168 +
 .../statistic/QuerySqlStatisticProvider.java       |  222 +
 .../apache/calcite/statistic}/package-info.java    |    5 +-
 .../java/org/apache/calcite/tools/Frameworks.java  |    6 +-
 .../java/org/apache/calcite/tools/Programs.java    |   40 +-
 .../java/org/apache/calcite/tools/RelBuilder.java  |  433 +-
 .../java/org/apache/calcite/util/BlackholeMap.java |  116 +
 .../src/main/java/org/apache/calcite/util/Bug.java |   21 +-
 .../org/apache/calcite/util/BuiltInMethod.java     |   77 +-
 .../main/java/org/apache/calcite/util/Util.java    |   31 +
 .../org/apache/calcite/util/mapping/Mappings.java  |   23 +-
 .../calcite/runtime/CalciteResource.properties     |   13 +-
 core/src/test/codegen/config.fmpp                  |   12 +-
 .../calcite/adapter/enumerable/TypeFinderTest.java |  132 +
 .../apache/calcite/jdbc/JavaTypeFactoryTest.java   |   16 +
 .../calcite/materialize/LatticeSuggesterTest.java  |   25 +-
 .../org/apache/calcite/plan/RelOptUtilTest.java    |  330 +-
 .../org/apache/calcite/plan/RelWriterTest.java     |    8 +-
 .../calcite/plan/volcano/TraitPropagationTest.java |   17 +-
 .../calcite/plan/volcano/VolcanoPlannerTest.java   |    1 -
 .../prepare/LookupOperatorOverloadsTest.java       |   20 +-
 .../calcite/rel/rel2sql/RelToSqlConverterTest.java |  424 +-
 .../calcite/rel/rules/EnumerableLimitRuleTest.java |  103 +
 .../calcite/rel/rules/SortRemoveRuleTest.java      |   24 +-
 .../org/apache/calcite/rex/RexBuilderTest.java     |  155 +
 .../org/apache/calcite/rex/RexExecutorTest.java    |   95 +-
 .../apache/calcite/runtime/EnumerablesTest.java    |   29 +-
 .../apache/calcite/sql/parser/SqlParserTest.java   |  877 +++-
 .../apache/calcite/sql/test/AbstractSqlTester.java |   19 +-
 .../apache/calcite/sql/test/DocumentationTest.java |  203 +
 .../apache/calcite/sql/test/SqlAdvisorTest.java    |   18 +-
 .../calcite/sql/test/SqlOperatorBaseTest.java      |  686 ++-
 .../calcite/sql/type/SqlTypeFactoryTest.java       |   12 +
 .../apache/calcite/sql/type/SqlTypeFixture.java    |   10 +
 .../org/apache/calcite/test/CalciteAssert.java     |   28 +-
 .../java/org/apache/calcite/test/CalciteSuite.java |   10 +-
 .../org/apache/calcite/test/DiffRepository.java    |   29 +-
 .../org/apache/calcite/test/HepPlannerTest.java    |   15 +-
 .../org/apache/calcite/test/HierarchySchema.java   |   91 +
 .../calcite/test/InduceGroupingTypeTest.java       |   74 +-
 .../org/apache/calcite/test/JdbcAdapterTest.java   |    4 +-
 .../test/JdbcFrontJdbcBackLinqMiddleTest.java      |    4 +-
 .../java/org/apache/calcite/test/JdbcTest.java     |  157 +-
 .../java/org/apache/calcite/test/LatticeTest.java  |   26 +-
 .../java/org/apache/calcite/test/Matchers.java     |   17 +
 .../apache/calcite/test/MaterializationTest.java   |  174 +-
 .../apache/calcite/test/MockSqlOperatorTable.java  |   42 +
 .../calcite/test/MultiJdbcSchemaJoinTest.java      |   36 +-
 .../org/apache/calcite/test/MutableRelTest.java    |    2 +-
 .../java/org/apache/calcite/test/QuidemTest.java   |    2 -
 .../org/apache/calcite/test/RelBuilderTest.java    |  246 +-
 .../test/RelMdPercentageOriginalRowsTest.java      |    2 +-
 .../org/apache/calcite/test/RelMetadataTest.java   |   31 +-
 .../org/apache/calcite/test/RelOptRulesTest.java   | 1909 ++++++++-
 .../org/apache/calcite/test/RexProgramTest.java    |   16 +
 .../org/apache/calcite/test/SqlFunctionsTest.java  |   58 +
 .../apache/calcite/test/SqlJsonFunctionsTest.java  |  454 +-
 .../calcite/test/SqlStatisticProviderTest.java     |  135 +
 .../apache/calcite/test/SqlToRelConverterTest.java |  348 +-
 .../org/apache/calcite/test/SqlToRelTestBase.java  |   37 +-
 .../apache/calcite/test/SqlValidatorMatchTest.java |    2 +-
 .../org/apache/calcite/test/SqlValidatorTest.java  |  325 +-
 .../java/org/apache/calcite/test/StreamTest.java   |    2 +-
 .../org/apache/calcite/test/TableFunctionTest.java |   14 +
 .../test/java/org/apache/calcite/test/UdtTest.java |    9 +
 .../org/apache/calcite/test/catalog/Fixture.java   |    1 +
 .../calcite/test/catalog/MockCatalogReader.java    |  116 +-
 .../test/catalog/MockCatalogReaderDynamic.java     |   36 +-
 .../test/enumerable/EnumerableCorrelateTest.java   |  171 +-
 .../test/enumerable/EnumerableJoinTest.java        |  170 +
 .../EnumerableRepeatUnionHierarchyTest.java        |  156 +
 .../test/enumerable/EnumerableRepeatUnionTest.java |  149 +
 .../calcite/test/fuzzer/RexProgramFuzzyTest.java   |   17 +-
 .../calcite/test/fuzzer/RexToTestCodeShuttle.java  |    1 +
 .../java/org/apache/calcite/tools/PlannerTest.java |  211 +-
 .../java/org/apache/calcite/util/UtilTest.java     |   55 +
 .../org/apache/calcite/test/HepPlannerTest.xml     |   21 +-
 .../org/apache/calcite/test/RelOptRulesTest.xml    | 4384 +++++++++++++++-----
 .../apache/calcite/test/SqlToRelConverterTest.xml  |  495 ++-
 core/src/test/resources/sql/agg.iq                 |  205 +-
 core/src/test/resources/sql/blank.iq               |    4 +-
 core/src/test/resources/sql/join.iq                |   20 +-
 core/src/test/resources/sql/lateral.iq             |   30 +-
 core/src/test/resources/sql/misc.iq                |   57 +-
 core/src/test/resources/sql/outer.iq               |    4 +-
 core/src/test/resources/sql/some.iq                |   27 +-
 core/src/test/resources/sql/struct.iq              |   17 +-
 core/src/test/resources/sql/sub-query.iq           |   99 +-
 druid/pom.xml                                      |    4 +-
 .../apache/calcite/adapter/druid/DruidQuery.java   |   35 +-
 .../apache/calcite/adapter/druid/DruidRules.java   |    9 +-
 .../adapter/druid/DruidSqlCastConverter.java       |   11 +-
 .../org/apache/calcite/test/DruidAdapterIT.java    |  138 +-
 .../org/apache/calcite/test/DruidAdapterIT2.java   |   26 +-
 druid/src/test/resources/druid-wiki-model.json     |    2 +-
 .../resources/druid-wiki-no-columns-model.json     |    2 +-
 elasticsearch/pom.xml                              |    4 +-
 .../elasticsearch/ElasticsearchAggregate.java      |   21 +-
 .../elasticsearch/ElasticsearchEnumerators.java    |    4 +-
 .../adapter/elasticsearch/ElasticsearchJson.java   |   55 +-
 .../elasticsearch/ElasticsearchMapping.java        |   15 +-
 .../elasticsearch/ElasticsearchProject.java        |   18 +-
 .../adapter/elasticsearch/ElasticsearchRules.java  |   29 +-
 .../adapter/elasticsearch/ElasticsearchSchema.java |   66 +-
 .../elasticsearch/ElasticsearchSchemaFactory.java  |    2 +-
 .../adapter/elasticsearch/ElasticsearchTable.java  |   23 +-
 .../elasticsearch/ElasticsearchTransport.java      |   20 +-
 .../elasticsearch/ElasticsearchVersion.java        |   20 +-
 .../calcite/adapter/elasticsearch/Scrolling.java   |    4 +-
 .../adapter/elasticsearch/AggregationTest.java     |   28 +-
 .../elasticsearch/ElasticSearchAdapterTest.java    |    5 +-
 .../elasticsearch/EmbeddedElasticsearchNode.java   |    9 +-
 .../elasticsearch/EmbeddedElasticsearchPolicy.java |   27 +-
 .../adapter/elasticsearch/Projection2Test.java     |   23 +
 .../adapter/elasticsearch/ScrollingTest.java       |    5 +-
 example/csv/pom.xml                                |    4 +-
 .../calcite/adapter/csv/CsvFilterableTable.java    |    6 +-
 .../test/java/org/apache/calcite/test/CsvTest.java |   32 +
 example/function/pom.xml                           |    4 +-
 example/pom.xml                                    |    4 +-
 file/pom.xml                                       |    4 +-
 geode/pom.xml                                      |    4 +-
 .../calcite/adapter/geode/rel/GeodeAggregate.java  |   21 +-
 .../calcite/adapter/geode/rel/GeodeRules.java      |   15 +-
 .../calcite/adapter/geode/rel/GeodeSchema.java     |   10 +-
 .../adapter/geode/rel/GeodeSchemaFactory.java      |    7 +-
 .../calcite/adapter/geode/util/GeodeUtils.java     |    6 +-
 .../calcite/adapter/geode/rel/GeodeZipsTest.java   |    2 +-
 {file => kafka}/pom.xml                            |   46 +-
 .../adapter/kafka/KafkaMessageEnumerator.java      |   92 +
 .../calcite/adapter/kafka/KafkaRowConverter.java   |   53 +
 .../adapter/kafka/KafkaRowConverterImpl.java       |   69 +
 .../calcite/adapter/kafka/KafkaStreamTable.java    |  116 +
 .../calcite/adapter/kafka/KafkaTableConstants.java |   15 +-
 .../calcite/adapter/kafka/KafkaTableFactory.java   |   97 +
 .../calcite/adapter/kafka/KafkaTableOptions.java   |   81 +
 .../calcite/adapter/kafka}/package-info.java       |    5 +-
 .../calcite/adapter/kafka/KafkaAdapterTest.java    |  113 +
 .../calcite/adapter/kafka/KafkaMockConsumer.java   |   49 +
 .../adapter/kafka/KafkaRowConverterTest.java       |   64 +
 .../src/test/resources/kafka.model.json            |   28 +-
 linq4j/pom.xml                                     |    4 +-
 .../apache/calcite/linq4j/CorrelateJoinType.java   |   50 -
 .../apache/calcite/linq4j/DefaultEnumerable.java   |   14 +-
 .../apache/calcite/linq4j/EnumerableDefaults.java  |  247 +-
 .../apache/calcite/linq4j/EnumerableQueryable.java |    4 +-
 .../apache/calcite/linq4j/ExtendedEnumerable.java  |    8 +-
 .../java/org/apache/calcite/linq4j}/JoinType.java  |   74 +-
 .../apache/calcite/linq4j/function/Functions.java  |    4 +-
 .../calcite/linq4j/test/CorrelateJoinTest.java     |   16 +-
 .../calcite/linq4j/test/JoinPreserveOrderTest.java |   52 +-
 .../org/apache/calcite/linq4j/test/Linq4jTest.java |   10 +-
 mongodb/pom.xml                                    |   15 +-
 .../calcite/adapter/mongodb/MongoAggregate.java    |   22 +-
 .../apache/calcite/adapter/mongodb/MongoRules.java |    1 -
 .../calcite/adapter/mongodb/MongoAdapterTest.java  |   40 +-
 .../adapter/mongodb/MongoDatabasePolicy.java       |   38 +-
 .../org/apache/calcite/test/MongoAssertions.java   |    7 +-
 pig/pom.xml                                        |    4 +-
 .../apache/calcite/adapter/pig/PigAggregate.java   |   24 +-
 .../calcite/adapter/pig/PigRelFactories.java       |    6 +-
 .../org/apache/calcite/adapter/pig/PigRules.java   |    2 +-
 .../apache/calcite/adapter/pig/PigTableScan.java   |    2 +-
 piglet/pom.xml                                     |    6 +-
 piglet/src/main/javacc/PigletParser.jj             |    7 +-
 plus/pom.xml                                       |    4 +-
 .../apache/calcite/adapter/tpcds/TpcdsTest.java    |   14 +-
 pom.xml                                            |   86 +-
 server/pom.xml                                     |    6 +-
 server/src/main/codegen/config.fmpp                |   12 +-
 server/src/main/codegen/includes/parserImpls.ftl   |    2 +-
 .../calcite/sql/ddl/SqlAttributeDefinition.java    |    2 +-
 .../org/apache/calcite/test/ServerParserTest.java  |    4 -
 .../java/org/apache/calcite/test/ServerTest.java   |   17 +
 server/src/test/resources/sql/schema.iq            |    4 +-
 site/_docs/adapter.md                              |    3 +-
 site/_docs/algebra.md                              |   55 +-
 site/_docs/elasticsearch_adapter.md                |   34 +-
 site/_docs/history.md                              |  190 +
 site/_docs/howto.md                                |   10 +-
 site/_docs/index.md                                |    8 +-
 site/_docs/kafka_adapter.md                        |  105 +
 site/_docs/reference.md                            |  295 +-
 ...ease-1.10.0.md => 2019-03-26-release-1.20.0.md} |   18 +-
 spark/pom.xml                                      |    4 +-
 .../org/apache/calcite/test/SparkAdapterTest.java  |    4 +-
 splunk/pom.xml                                     |    4 +-
 .../splunk/search/SplunkConnectionImpl.java        |    2 +-
 sqlline                                            |    2 +-
 sqlline.bat                                        |    2 +-
 ubenchmark/pom.xml                                 |    2 +-
 .../AbstractRelNodeGetRelTypeNameBenchmark.java    |    4 +-
 454 files changed, 24051 insertions(+), 7136 deletions(-)
 rename core/src/main/java/org/apache/calcite/adapter/enumerable/{EnumerableJoin.java => EnumerableHashJoin.java} (65%)
 rename core/src/main/java/org/apache/calcite/adapter/enumerable/{EnumerableThetaJoin.java => EnumerableNestedLoopJoin.java} (82%)
 create mode 100644 core/src/main/java/org/apache/calcite/adapter/enumerable/EnumerableRepeatUnion.java
 copy core/src/main/java/org/apache/calcite/adapter/enumerable/{EnumerableCollectRule.java => EnumerableRepeatUnionRule.java} (53%)
 delete mode 100644 core/src/main/java/org/apache/calcite/adapter/enumerable/EnumerableSemiJoin.java
 delete mode 100644 core/src/main/java/org/apache/calcite/adapter/enumerable/EnumerableSemiJoinRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/adapter/enumerable/EnumerableTableSpool.java
 copy core/src/main/java/org/apache/calcite/adapter/enumerable/{EnumerableIntersectRule.java => EnumerableTableSpoolRule.java} (52%)
 create mode 100644 core/src/main/java/org/apache/calcite/adapter/jdbc/JdbcCatalogSchema.java
 delete mode 100644 core/src/main/java/org/apache/calcite/materialize/MapSqlStatisticProvider.java
 create mode 100644 core/src/main/java/org/apache/calcite/plan/RelOptRules.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/core/RepeatUnion.java
 delete mode 100644 core/src/main/java/org/apache/calcite/rel/core/SemiJoin.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/core/Spool.java
 copy core/src/main/java/org/apache/calcite/rel/{stream/Chi.java => core/TableSpool.java} (52%)
 create mode 100644 core/src/main/java/org/apache/calcite/rel/logical/LogicalRepeatUnion.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/logical/LogicalTableSpool.java
 delete mode 100644 core/src/main/java/org/apache/calcite/rel/mutable/MutableSemiJoin.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/rules/AggregateJoinJoinRemoveRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/rules/AggregateJoinRemoveRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/rules/AggregateMergeRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/rules/ExchangeRemoveConstantKeysRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/rules/ProjectJoinJoinRemoveRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/rel/rules/ProjectJoinRemoveRule.java
 create mode 100644 core/src/main/java/org/apache/calcite/runtime/JsonFunctions.java
 copy core/src/main/java/org/apache/calcite/{sql/SqlExecutableStatement.java => schema/TransientTable.java} (59%)
 create mode 100644 core/src/main/java/org/apache/calcite/schema/impl/ListTransientTable.java
 delete mode 100644 core/src/main/java/org/apache/calcite/sql/SemiJoinType.java
 create mode 100644 core/src/main/java/org/apache/calcite/sql/SqlNullTreatmentOperator.java
 copy core/src/main/java/org/apache/calcite/sql/dialect/{InterbaseSqlDialect.java => SnowflakeSqlDialect.java} (66%)
 copy linq4j/src/main/java/org/apache/calcite/linq4j/function/NonDeterministic.java => core/src/main/java/org/apache/calcite/sql/fun/LibraryOperator.java (55%)
 delete mode 100644 core/src/main/java/org/apache/calcite/sql/fun/SqlJsonApiCommonSyntaxOperator.java
 copy core/src/main/java/org/apache/calcite/sql/fun/{SqlNtileAggFunction.java => SqlJsonKeysFunction.java} (62%)
 copy core/src/main/java/org/apache/calcite/sql/fun/{SqlNtileAggFunction.java => SqlJsonLengthFunction.java} (63%)
 copy core/src/main/java/org/apache/calcite/sql/fun/{SqlJsonPrettyFunction.java => SqlJsonRemoveFunction.java} (52%)
 copy core/src/main/java/org/apache/calcite/sql/fun/{SqlNtileAggFunction.java => SqlJsonStorageSizeFunction.java} (65%)
 create mode 100644 core/src/main/java/org/apache/calcite/sql/fun/SqlLibrary.java
 create mode 100644 core/src/main/java/org/apache/calcite/sql/fun/SqlLibraryOperatorTableFactory.java
 create mode 100644 core/src/main/java/org/apache/calcite/sql/fun/SqlLibraryOperators.java
 create mode 100644 core/src/main/java/org/apache/calcite/sql/fun/SqlPosixRegexOperator.java
 create mode 100644 core/src/main/java/org/apache/calcite/statistic/CachingSqlStatisticProvider.java
 create mode 100644 core/src/main/java/org/apache/calcite/statistic/MapSqlStatisticProvider.java
 create mode 100644 core/src/main/java/org/apache/calcite/statistic/QuerySqlStatisticProvider.java
 copy {pig/src/main/java/org/apache/calcite/adapter/pig => core/src/main/java/org/apache/calcite/statistic}/package-info.java (86%)
 create mode 100644 core/src/main/java/org/apache/calcite/util/BlackholeMap.java
 create mode 100644 core/src/test/java/org/apache/calcite/adapter/enumerable/TypeFinderTest.java
 create mode 100644 core/src/test/java/org/apache/calcite/rel/rules/EnumerableLimitRuleTest.java
 create mode 100644 core/src/test/java/org/apache/calcite/sql/test/DocumentationTest.java
 create mode 100644 core/src/test/java/org/apache/calcite/test/HierarchySchema.java
 create mode 100644 core/src/test/java/org/apache/calcite/test/SqlStatisticProviderTest.java
 create mode 100644 core/src/test/java/org/apache/calcite/test/enumerable/EnumerableJoinTest.java
 create mode 100644 core/src/test/java/org/apache/calcite/test/enumerable/EnumerableRepeatUnionHierarchyTest.java
 create mode 100644 core/src/test/java/org/apache/calcite/test/enumerable/EnumerableRepeatUnionTest.java
 copy {file => kafka}/pom.xml (72%)
 create mode 100644 kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaMessageEnumerator.java
 create mode 100644 kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaRowConverter.java
 create mode 100644 kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaRowConverterImpl.java
 create mode 100644 kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaStreamTable.java
 copy core/src/main/java/org/apache/calcite/adapter/enumerable/WinAggContext.java => kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaTableConstants.java (66%)
 create mode 100644 kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaTableFactory.java
 create mode 100644 kafka/src/main/java/org/apache/calcite/adapter/kafka/KafkaTableOptions.java
 copy {pig/src/main/java/org/apache/calcite/adapter/pig => kafka/src/main/java/org/apache/calcite/adapter/kafka}/package-info.java (87%)
 create mode 100644 kafka/src/test/java/org/apache/calcite/adapter/kafka/KafkaAdapterTest.java
 create mode 100644 kafka/src/test/java/org/apache/calcite/adapter/kafka/KafkaMockConsumer.java
 create mode 100644 kafka/src/test/java/org/apache/calcite/adapter/kafka/KafkaRowConverterTest.java
 copy pig/src/test/resources/model.json => kafka/src/test/resources/kafka.model.json (56%)
 delete mode 100644 linq4j/src/main/java/org/apache/calcite/linq4j/CorrelateJoinType.java
 copy {core/src/main/java/org/apache/calcite/sql => linq4j/src/main/java/org/apache/calcite/linq4j}/JoinType.java (55%)
 create mode 100644 site/_docs/kafka_adapter.md
 copy site/_posts/{2016-10-12-release-1.10.0.md => 2019-03-26-release-1.20.0.md} (63%)


[calcite] 01/02: Add Jenkinsfile for automated site build

Posted by fr...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

francischuang pushed a commit to branch test-site
in repository https://gitbox.apache.org/repos/asf/calcite.git

commit 3ee40c37dbbc527cba3c23fb2157ed692a2e4209
Author: Francis Chuang <fr...@apache.org>
AuthorDate: Sun Jun 9 15:40:40 2019 +1000

    Add Jenkinsfile for automated site build
---
 Jenkinsfile             | 129 ++++++++++++++++++++++++++++++++++++++++++++++++
 site/_config.yml        |   2 +
 site/docker-compose.yml |   6 ++-
 3 files changed, 136 insertions(+), 1 deletion(-)

diff --git a/Jenkinsfile b/Jenkinsfile
new file mode 100644
index 0000000..17d9b1f
--- /dev/null
+++ b/Jenkinsfile
@@ -0,0 +1,129 @@
+/*
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements.  See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to you under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License.  You may obtain a copy of the License at
+*
+* http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
+pipeline {
+    agent {
+        node {
+            label 'git-websites'
+        }
+    }
+
+    environment {
+        COMPOSE_PROJECT_NAME = "${env.JOB_NAME}-${env.BUILD_ID}"
+    }
+
+    options {
+        timeout(time: 40, unit: 'MINUTES')
+    }
+
+    stages {
+        stage('Build Site') {
+            when {
+                branch 'test-site'
+            }
+            steps {
+                dir ("site") {
+                    sh '''docker-compose run -d -e JEKYLL_UID=$(id -u) -e JEKYLL_GID=$(id -g) build-site
+                        containerID=$(docker-compose ps -q build-site)
+
+                        while $(docker inspect -f '{{.State.Running}}' $containerID) != "false"; do
+                            sleep 1
+                        done
+
+                        docker logs $containerID
+                        exit $(docker inspect -f '{{.State.ExitCode}}' $containerID)
+                    '''
+                }
+                echo "Website assets built."
+            }
+        }
+
+        stage('Build Javadoc') {
+            when {
+                tag pattern: "^calcite-[\d\.]+$", comparator: "REGEXP"
+            }
+            steps {
+                dir ("site") {
+                    sh '''docker-compose run -d -u $(id -u):$(id -g) generate-javadoc
+                        containerID=$(docker-compose ps -q generate-javadoc)
+
+                        while $(docker inspect -f '{{.State.Running}}' $containerID) != "false"; do
+                            sleep 1
+                        done
+
+                        docker logs $containerID
+                        exit $(docker inspect -f '{{.State.ExitCode}}' $containerID)
+                    '''
+                }
+                echo "Javadoc built."
+            }
+        }
+
+        stage('Deploy Site') {
+            when {
+                branch 'test-site'
+            }
+            steps {
+                echo 'Deploying to git repository'
+                dir ("site") {
+                    sh '''
+                        shopt -s extglob
+
+                        git clone --depth 1 --branch asf-site https://gitbox.apache.org/repos/asf/calcite-site.git deploy
+                        cd deploy/
+
+                        rm -rf !(apidocs|avatica|testapidocs)
+                        cp -r ../target/* .
+
+                        git add .
+                        git commit -m "Automatic site deployment at $GIT_COMMIT"
+                        git push origin HEAD:asf-site
+                    '''
+                }
+                echo "Deployment completed."
+            }
+        }
+
+        stage('Deploy Javadoc') {
+            when {
+                tag pattern: "^calcite-[\d\.]+$", comparator: "REGEXP"
+            }
+            steps {
+                echo 'Deploying to git repository'
+                dir ("site") {
+                    sh '''
+                        git clone --depth 1 --branch asf-site https://gitbox.apache.org/repos/asf/calcite-site.git deploy
+                        cd deploy/
+
+                        rm -rf apidocs/ testapidocs/
+
+                        cp -r ../target/* .
+
+                        git add .
+                        git commit -m "Automatic site deployment at $GIT_COMMIT"
+                        git push origin HEAD:asf-site
+                    '''
+                }
+                echo "Deployment completed."
+            }
+        }
+    }
+    post {
+        always {
+            sh 'docker system prune --force --all'
+        }
+    }
+}
\ No newline at end of file
diff --git a/site/_config.yml b/site/_config.yml
index 08427ff..f79761b 100644
--- a/site/_config.yml
+++ b/site/_config.yml
@@ -53,4 +53,6 @@ avaticaBaseurl: /avatica
 plugins:
     - jekyll-redirect-from
 
+future: true
+
 # End _config.yml
diff --git a/site/docker-compose.yml b/site/docker-compose.yml
index 13b808c..f975655 100644
--- a/site/docker-compose.yml
+++ b/site/docker-compose.yml
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-version: '3'
+version: '3.7'
 services:
   dev:
     image: jekyll/jekyll:3
@@ -22,11 +22,15 @@ services:
       - 4000:4000
     volumes:
       - .:/srv/jekyll
+    environment:
+      TZ: "UTC"
   build-site:
     image: jekyll/jekyll:3
     command: jekyll build
     volumes:
       - .:/srv/jekyll
+    environment:
+      TZ: "UTC"
   generate-javadoc:
     image: maven
     working_dir: /usr/src/calcite


[calcite] 02/02: Site: Change timezone offsets for posts to UTC (+0)

Posted by fr...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

francischuang pushed a commit to branch test-site
in repository https://gitbox.apache.org/repos/asf/calcite.git

commit bc4b7e870b09b47d3b928464200122e4b228ad8a
Author: Francis Chuang <fr...@apache.org>
AuthorDate: Mon Jun 17 10:51:29 2019 +1000

    Site: Change timezone offsets for posts to UTC (+0)
---
 site/_config.yml                                   | 2 ++
 site/_posts/2014-06-27-release-0.8.0-incubating.md | 2 +-
 site/_posts/2014-08-19-release-0.9.0-incubating.md | 2 +-
 site/_posts/2014-10-02-release-0.9.1-incubating.md | 2 +-
 site/_posts/2014-11-05-release-0.9.2-incubating.md | 2 +-
 site/_posts/2015-01-31-release-1.0.0-incubating.md | 2 +-
 site/_posts/2015-03-13-release-1.1.0-incubating.md | 2 +-
 site/_posts/2015-04-07-release-1.2.0-incubating.md | 2 +-
 site/_posts/2015-04-24-new-committers.md           | 2 +-
 site/_posts/2015-06-05-algebra-builder.md          | 2 +-
 site/_posts/2015-07-31-xldb-best-lightning-talk.md | 2 +-
 site/_posts/2015-11-08-new-committers.md           | 2 +-
 site/_posts/2016-02-17-elser-pmc.md                | 2 +-
 site/_posts/2016-02-17-streaming-sql-talk.md       | 2 +-
 14 files changed, 15 insertions(+), 13 deletions(-)

diff --git a/site/_config.yml b/site/_config.yml
index f79761b..26cc781 100644
--- a/site/_config.yml
+++ b/site/_config.yml
@@ -55,4 +55,6 @@ plugins:
 
 future: true
 
+timezone: UTC
+
 # End _config.yml
diff --git a/site/_posts/2014-06-27-release-0.8.0-incubating.md b/site/_posts/2014-06-27-release-0.8.0-incubating.md
index 83f975d..bfb01da 100644
--- a/site/_posts/2014-06-27-release-0.8.0-incubating.md
+++ b/site/_posts/2014-06-27-release-0.8.0-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2014-06-27 00:00:00 -0800"
+date: "2014-06-27 00:00:00 +0000"
 author: jhyde
 version: 0.8
 tag: v0-8
diff --git a/site/_posts/2014-08-19-release-0.9.0-incubating.md b/site/_posts/2014-08-19-release-0.9.0-incubating.md
index 7ca65ac..356f6e5 100644
--- a/site/_posts/2014-08-19-release-0.9.0-incubating.md
+++ b/site/_posts/2014-08-19-release-0.9.0-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2014-08-19 00:00:00 -0800"
+date: "2014-08-19 00:00:00 +0000"
 author: jhyde
 version: 0.9.0-incubating
 fullVersion: apache-optiq-0.9.0-incubating
diff --git a/site/_posts/2014-10-02-release-0.9.1-incubating.md b/site/_posts/2014-10-02-release-0.9.1-incubating.md
index bca9113..38e1843 100644
--- a/site/_posts/2014-10-02-release-0.9.1-incubating.md
+++ b/site/_posts/2014-10-02-release-0.9.1-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2014-10-02 00:00:00 -0800"
+date: "2014-10-02 00:00:00 +0000"
 author: jhyde
 version: 0.9.1-incubating
 tag: v0-9-1
diff --git a/site/_posts/2014-11-05-release-0.9.2-incubating.md b/site/_posts/2014-11-05-release-0.9.2-incubating.md
index 47741c0..69045a3 100644
--- a/site/_posts/2014-11-05-release-0.9.2-incubating.md
+++ b/site/_posts/2014-11-05-release-0.9.2-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2014-11-05 00:00:00 -0800"
+date: "2014-11-05 00:00:00 +0000"
 author: jhyde
 version: 0.9.2-incubating
 tag: v0-9-2
diff --git a/site/_posts/2015-01-31-release-1.0.0-incubating.md b/site/_posts/2015-01-31-release-1.0.0-incubating.md
index ad60205..a5f480f 100644
--- a/site/_posts/2015-01-31-release-1.0.0-incubating.md
+++ b/site/_posts/2015-01-31-release-1.0.0-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2015-01-31 19:03:07 -0800"
+date: "2015-01-31 19:03:07 +0000"
 author: jhyde
 version: 1.0.0-incubating
 tag: v1-0-0
diff --git a/site/_posts/2015-03-13-release-1.1.0-incubating.md b/site/_posts/2015-03-13-release-1.1.0-incubating.md
index 327b023..543f763 100644
--- a/site/_posts/2015-03-13-release-1.1.0-incubating.md
+++ b/site/_posts/2015-03-13-release-1.1.0-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2015-03-13 19:03:07 -0800"
+date: "2015-03-13 19:03:07 +0000"
 author: jhyde
 version: 1.1.0-incubating
 tag: v1-1-0
diff --git a/site/_posts/2015-04-07-release-1.2.0-incubating.md b/site/_posts/2015-04-07-release-1.2.0-incubating.md
index 8332063..348175d 100644
--- a/site/_posts/2015-04-07-release-1.2.0-incubating.md
+++ b/site/_posts/2015-04-07-release-1.2.0-incubating.md
@@ -1,6 +1,6 @@
 ---
 layout: news_item
-date: "2015-04-07 19:03:07 -0800"
+date: "2015-04-07 19:03:07 +0000"
 author: jhyde
 version: 1.2.0-incubating
 tag: v1-2-0
diff --git a/site/_posts/2015-04-24-new-committers.md b/site/_posts/2015-04-24-new-committers.md
index 92a2466..51198fa 100644
--- a/site/_posts/2015-04-24-new-committers.md
+++ b/site/_posts/2015-04-24-new-committers.md
@@ -1,7 +1,7 @@
 ---
 layout: news_item
 title: "Calcite adds 5 committers"
-date: "2015-04-24 19:03:07 -0800"
+date: "2015-04-24 19:03:07 +0000"
 author: jhyde
 categories: [team]
 ---
diff --git a/site/_posts/2015-06-05-algebra-builder.md b/site/_posts/2015-06-05-algebra-builder.md
index ddf3377..797b1c9 100644
--- a/site/_posts/2015-06-05-algebra-builder.md
+++ b/site/_posts/2015-06-05-algebra-builder.md
@@ -1,7 +1,7 @@
 ---
 layout: news_item
 title: "Algebra builder"
-date: "2015-06-05 19:29:07 -0800"
+date: "2015-06-05 19:29:07 +0000"
 author: jhyde
 categories: ["new features"]
 ---
diff --git a/site/_posts/2015-07-31-xldb-best-lightning-talk.md b/site/_posts/2015-07-31-xldb-best-lightning-talk.md
index b0e1f46..6d4aa34 100644
--- a/site/_posts/2015-07-31-xldb-best-lightning-talk.md
+++ b/site/_posts/2015-07-31-xldb-best-lightning-talk.md
@@ -1,7 +1,7 @@
 ---
 layout: news_item
 title: "XLDB 2015 best lightning talk"
-date: "2015-07-31 11:53:00 -0800"
+date: "2015-07-31 11:53:00 +0000"
 author: jhyde
 categories: ["talks"]
 ---
diff --git a/site/_posts/2015-11-08-new-committers.md b/site/_posts/2015-11-08-new-committers.md
index 8946fc5..10fc61b 100644
--- a/site/_posts/2015-11-08-new-committers.md
+++ b/site/_posts/2015-11-08-new-committers.md
@@ -1,7 +1,7 @@
 ---
 layout: news_item
 title: "Calcite adds 2 committers"
-date: "2015-11-08 19:03:07 -0800"
+date: "2015-11-08 19:03:07 +0000"
 author: jhyde
 categories: [team]
 ---
diff --git a/site/_posts/2016-02-17-elser-pmc.md b/site/_posts/2016-02-17-elser-pmc.md
index 960fe79..27631b8 100644
--- a/site/_posts/2016-02-17-elser-pmc.md
+++ b/site/_posts/2016-02-17-elser-pmc.md
@@ -1,7 +1,7 @@
 ---
 layout: news_item
 title: "Calcite appoints Josh Elser to PMC"
-date: "2016-02-17 10:30:00 -0800"
+date: "2016-02-17 10:30:00 +0000"
 author: jhyde
 categories: [team]
 ---
diff --git a/site/_posts/2016-02-17-streaming-sql-talk.md b/site/_posts/2016-02-17-streaming-sql-talk.md
index 9c5d55a..5760427 100644
--- a/site/_posts/2016-02-17-streaming-sql-talk.md
+++ b/site/_posts/2016-02-17-streaming-sql-talk.md
@@ -1,7 +1,7 @@
 ---
 layout: news_item
 title: "Streaming SQL in Samza"
-date: "2016-02-17 11:53:00 -0800"
+date: "2016-02-17 11:53:00 +0000"
 author: jhyde
 categories: ["talks"]
 ---