You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@asterixdb.apache.org by im...@apache.org on 2016/04/07 17:00:08 UTC

[33/50] [abbrv] incubator-asterixdb git commit: Merge branch 'master' into hyracks-merge2

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/distinct_aggregate.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/distinct_aggregate.sqlpp
index 877bb0f,0000000..6b95c9c
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/distinct_aggregate.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/distinct_aggregate.sqlpp
@@@ -1,62 -1,0 +1,62 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
- create  nodegroup group1 if not exists  on 
++create  nodegroup group1 if not exists  on
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table LineItems_q1(LineItemType) primary key l_orderkey,l_linenumber on group1;
 +
 +write output to asterix_nc1:"rttest/tpch_q1_pricing_summary_report_nt.adm"
- select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'count_suppkey':tpch.count(g)}
++select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'count_suppkey':count(g)}
 +from  (
 +    select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'l_suppkey':l_suppkey}
 +    from  LineItems_q1 as l
 +    where (l.l_shipdate <= '1998-09-02')
 +    group by l.l_returnflag as l_returnflag,l.l_linestatus as l_linestatus,l.l_suppkey as l_suppkey
 +) as g
 +group by g.l_returnflag as l_returnflag,g.l_linestatus as l_linestatus
 +order by l_returnflag,l_linestatus
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase1.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase1.sqlpp
index 4e274e5,0000000..f1d5086
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase1.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase1.sqlpp
@@@ -1,65 -1,0 +1,65 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database rares03 if exists;
 +create  database rares03;
 +
 +use rares03;
 +
 +
 +create type rares03.UserType as
 +{
 +  uid : int32,
 +  name : string,
 +  lottery_numbers : {{int32}}
 +}
 +
 +create type rares03.VisitorType as
 +{
 +  vid : int32,
 +  name : string,
 +  lottery_numbers : {{int32}}
 +}
 +
 +create  nodegroup group1 if not exists  on 
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table Users(UserType) primary key uid on group1;
 +
 +create  table Visitors(VisitorType) primary key vid on group1;
 +
 +write output to asterix_nc1:"/tmp/rares03.adm"
 +select element {'uid':user.uid,'tokens':tokens}
 +from  Users as user
 +with  tokens as (
 +      select element i
 +      from  user.lottery_numbers as lottery_number,
 +            (
 +          select element item
 +          from  Users as user,
 +                user.lottery_numbers as lottery_number
 +          group by lottery_number as item
-           with  count as rares03.count(user)
++          with  count as count(user)
 +          order by count desc
 +      ) as token at i
 +      where (lottery_number = token)
 +      order by token
 +  )
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase2-with-hints.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase2-with-hints.sqlpp
index 7850337,0000000..c82f62c
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase2-with-hints.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/fj-phase2-with-hints.sqlpp
@@@ -1,60 -1,0 +1,60 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database fuzzyjoin_078 if exists;
 +create  database fuzzyjoin_078;
 +
 +use fuzzyjoin_078;
 +
 +
 +create type fuzzyjoin_078.DBLPType as
 +{
 +  id : int32,
 +  dblpid : string,
 +  title : string,
 +  authors : string,
 +  misc : string
 +}
 +
 +create  nodegroup group1 if not exists  on 
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table DBLP_fuzzyjoin_078(DBLPType) primary key id on group1;
 +
 +write output to asterix_nc1:"rttest/fuzzyjoin_078.adm"
 +select element {'id':paperDBLP.id,'tokens':tokensDBLP}
 +from  DBLP_fuzzyjoin_078 as paperDBLP
 +with  unrankedTokensDBLP as fuzzyjoin_078."counthashed-word-tokens"(paperDBLP.title),
 +      tokensDBLP as (
 +      select element i
 +      from  unrankedTokensDBLP as token,
 +            (
 +          select element tokenGroupped
 +          from  DBLP_fuzzyjoin_078 as paper,
 +                fuzzyjoin_078."counthashed-word-tokens"(paper.title) as token
 +          /* +hash */
 +          group by token as tokenGroupped
-           order by fuzzyjoin_078.count(paper),tokenGroupped
++          order by count(paper),tokenGroupped
 +      ) as tokenRanked at i
 +      where (token = tokenRanked)
 +      order by i
 +  )
 +order by paperDBLP.id
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/inlined_q18_large_volume_customer.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/inlined_q18_large_volume_customer.sqlpp
index 10bf154,0000000..91680fe
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/inlined_q18_large_volume_customer.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/inlined_q18_large_volume_customer.sqlpp
@@@ -1,101 -1,0 +1,101 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database inlined_q18_large_volume_customer if exists;
 +create  database inlined_q18_large_volume_customer;
 +
 +use inlined_q18_large_volume_customer;
 +
 +
 +create type inlined_q18_large_volume_customer.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create type inlined_q18_large_volume_customer.OrderType as
 + closed {
 +  o_orderkey : int32,
 +  o_custkey : int32,
 +  o_orderstatus : string,
 +  o_totalprice : double,
 +  o_orderdate : string,
 +  o_orderpriority : string,
 +  o_clerk : string,
 +  o_shippriority : int32,
 +  o_comment : string
 +}
 +
 +create type inlined_q18_large_volume_customer.CustomerType as
 + closed {
 +  c_custkey : int32,
 +  c_name : string,
 +  c_address : string,
 +  c_nationkey : int32,
 +  c_phone : string,
 +  c_acctbal : double,
 +  c_mktsegment : string,
 +  c_comment : string
 +}
 +
 +create  nodegroup group1 if not exists  on 
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table LineItems(LineItemType) primary key l_orderkey,l_linenumber on group1;
 +
 +create  table Orders(OrderType) primary key o_orderkey on group1;
 +
 +create  table Customers(CustomerType) primary key c_custkey on group1;
 +
 +write output to asterix_nc1:"/tmp/inlined_q18_large_volume_customer.adm"
- select element {'c_name':c_name,'c_custkey':c_custkey,'o_orderkey':o_orderkey,'o_orderdate':o_orderdate,'o_totalprice':o_totalprice,'sum_quantity':inlined_q18_large_volume_customer.sum((
++select element {'c_name':c_name,'c_custkey':c_custkey,'o_orderkey':o_orderkey,'o_orderdate':o_orderdate,'o_totalprice':o_totalprice,'sum_quantity':inlined_q18_large_volume_customer.coll_sum((
 +        select element j.l_quantity
 +        from  l as j
 +    ))}
 +from  Customers as c,
 +      Orders as o,
 +      (
-     select element {'l_orderkey':l_orderkey,'t_sum_quantity':inlined_q18_large_volume_customer.sum((
++    select element {'l_orderkey':l_orderkey,'t_sum_quantity':inlined_q18_large_volume_customer.coll_sum((
 +            select element i.l_quantity
 +            from  l as i
 +        ))}
 +    from  LineItems as l
 +    group by l.l_orderkey as l_orderkey
 +) as t,
 +      LineItems as l
 +where ((c.c_custkey = o.o_custkey) and ((o.o_orderkey = t.l_orderkey) and (t.t_sum_quantity > 300)) and (l.l_orderkey = o.o_orderkey))
 +group by c.c_name as c_name,c.c_custkey as c_custkey,o.o_orderkey as o_orderkey,o.o_orderdate as o_orderdate,o.o_totalprice as o_totalprice
 +order by o_totalprice desc,o_orderdate
 +limit 100
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/nest_aggregate.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/nest_aggregate.sqlpp
index 2b67f09,0000000..80fb9bc
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/nest_aggregate.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/nest_aggregate.sqlpp
@@@ -1,137 -1,0 +1,137 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description  : This test case is to verify the fix for issue782
 + * https://code.google.com/p/asterixdb/issues/detail?id=782
 + * Expected Res : SUCCESS
 + * Date         : 2nd Jun 2014
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.OrderType as
 + closed {
 +  o_orderkey : int32,
 +  o_custkey : int32,
 +  o_orderstatus : string,
 +  o_totalprice : double,
 +  o_orderdate : string,
 +  o_orderpriority : string,
 +  o_clerk : string,
 +  o_shippriority : int32,
 +  o_comment : string
 +}
 +
 +create type tpch.CustomerType as
 + closed {
 +  c_custkey : int32,
 +  c_name : string,
 +  c_address : string,
 +  c_nationkey : int32,
 +  c_phone : string,
 +  c_acctbal : double,
 +  c_mktsegment : string,
 +  c_comment : string
 +}
 +
 +create type tpch.SupplierType as
 + closed {
 +  s_suppkey : int32,
 +  s_name : string,
 +  s_address : string,
 +  s_nationkey : int32,
 +  s_phone : string,
 +  s_acctbal : double,
 +  s_comment : string
 +}
 +
 +create type tpch.NationType as
 + closed {
 +  n_nationkey : int32,
 +  n_name : string,
 +  n_regionkey : int32,
 +  n_comment : string
 +}
 +
 +create type tpch.RegionType as
 + closed {
 +  r_regionkey : int32,
 +  r_name : string,
 +  r_comment : string
 +}
 +
 +create type tpch.PartType as
 + closed {
 +  p_partkey : int32,
 +  p_name : string,
 +  p_mfgr : string,
 +  p_brand : string,
 +  p_type : string,
 +  p_size : int32,
 +  p_container : string,
 +  p_retailprice : double,
 +  p_comment : string
 +}
 +
 +create type tpch.PartSuppType as
 + closed {
 +  ps_partkey : int32,
 +  ps_suppkey : int32,
 +  ps_availqty : int32,
 +  ps_supplycost : double,
 +  ps_comment : string
 +}
 +
 +create  table Orders(OrderType) primary key o_orderkey;
 +
 +create  table Supplier(SupplierType) primary key s_suppkey;
 +
 +create  table Region(RegionType) primary key r_regionkey;
 +
 +create  table Nation(NationType) primary key n_nationkey;
 +
 +create  table Part(PartType) primary key p_partkey;
 +
 +create  table Partsupp(PartSuppType) primary key ps_partkey,ps_suppkey;
 +
 +create  table Customer(CustomerType) primary key c_custkey;
 +
 +create  table SelectedNation(NationType) primary key n_nationkey;
 +
 +select element {'nation_key':nation.n_nationkey,'name':nation.n_name,'aggregates':(
 +        select element {'order_date':orderdate,'sum_price':sum}
 +        from  Orders as orders,
 +              Customer as customer
 +        where ((orders.o_custkey = customer.c_custkey) and (customer.c_nationkey = nation.n_nationkey))
 +        group by orders.o_orderdate as orderdate
-         with  sum as tpch.sum((
++        with  sum as tpch.coll_sum((
 +              select element o.o_totalprice
 +              from  orders as o
 +          ))
 +        order by sum
 +        limit 3
 +    )}
 +from  Nation as nation,
 +      SelectedNation as sn
 +where (nation.n_nationkey = sn.n_nationkey)
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/orders-aggreg.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/orders-aggreg.sqlpp
index 4a6203a,0000000..c216c66
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/orders-aggreg.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/orders-aggreg.sqlpp
@@@ -1,52 -1,0 +1,52 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database "orders-aggreg" if exists;
 +create  database "orders-aggreg";
 +
 +use "orders-aggreg";
 +
 +
 +create type "orders-aggreg".OrderType as
 + closed {
 +  oid : int32,
 +  cid : int32,
 +  orderstatus : string,
 +  orderpriority : string,
 +  clerk : string,
 +  total : float
 +}
 +
- create  nodegroup group1 if not exists  on 
++create  nodegroup group1 if not exists  on
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table Orders(OrderType) primary key oid on group1;
 +
 +write output to asterix_nc1:"/tmp/orders-aggreg.adm"
- select element {'cid':cid,'ordpercust':"orders-aggreg".count(o),'totalcust':"orders-aggreg".sum((
++select element {'cid':cid,'ordpercust':"orders-aggreg".coll_count(o),'totalcust':"orders-aggreg".coll_sum((
 +        select element i.total
 +        from  o as i
-     )),'avgcust':"orders-aggreg".avg((
++    )),'avgcust':"orders-aggreg".coll_avg((
 +        select element i.total
 +        from  o as i
 +    ))}
 +from  Orders as o
 +group by o.cid as cid
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q01_pricing_summary_report_nt.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q01_pricing_summary_report_nt.sqlpp
index c6c79b9,0000000..9642265
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q01_pricing_summary_report_nt.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q01_pricing_summary_report_nt.sqlpp
@@@ -1,78 -1,0 +1,78 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create  table LineItem(LineItemType) primary key l_orderkey,l_linenumber;
 +
 +load  table LineItem using localfs (("path"="asterix_nc1://data/tpch0.001/lineitem.tbl"),("format"="delimited-text"),("delimiter"="|")) pre-sorted;
 +
 +write output to asterix_nc1:"rttest/tpch_q1_pricing_summary_report_nt.adm"
- select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'sum_qty':tpch.sum((
++select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'sum_qty':tpch.coll_sum((
 +        select element i.l_quantity
 +        from  l as i
-     )),'sum_base_price':tpch.sum((
++    )),'sum_base_price':tpch.coll_sum((
 +        select element i.l_extendedprice
 +        from  l as i
-     )),'sum_disc_price':tpch.sum((
++    )),'sum_disc_price':tpch.coll_sum((
 +        select element (i.l_extendedprice * (1 - i.l_discount))
 +        from  l as i
-     )),'sum_charge':tpch.sum((
++    )),'sum_charge':tpch.coll_sum((
 +        select element (i.l_extendedprice * (1 - i.l_discount) * (1 + i.l_tax))
 +        from  l as i
-     )),'ave_qty':tpch.avg((
++    )),'ave_qty':tpch.coll_avg((
 +        select element i.l_quantity
 +        from  l as i
-     )),'ave_price':tpch.avg((
++    )),'ave_price':tpch.coll_avg((
 +        select element i.l_extendedprice
 +        from  l as i
-     )),'ave_disc':tpch.avg((
++    )),'ave_disc':tpch.coll_avg((
 +        select element i.l_discount
 +        from  l as i
-     )),'count_order':tpch.count(l)}
++    )),'count_order':tpch.coll_count(l)}
 +from  LineItem as l
 +where (l.l_shipdate <= '1998-09-02')
 +/* +hash */
 +group by l.l_returnflag as l_returnflag,l.l_linestatus as l_linestatus
 +order by l_returnflag,l_linestatus
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q03_shipping_priority.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q03_shipping_priority.sqlpp
index 7c05feb,0000000..6980bdd
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q03_shipping_priority.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q03_shipping_priority.sqlpp
@@@ -1,95 -1,0 +1,95 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database q3_shipping_priority if exists;
 +create  database q3_shipping_priority;
 +
 +use q3_shipping_priority;
 +
 +
 +create type q3_shipping_priority.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create type q3_shipping_priority.OrderType as
 + closed {
 +  o_orderkey : int32,
 +  o_custkey : int32,
 +  o_orderstatus : string,
 +  o_totalprice : double,
 +  o_orderdate : string,
 +  o_orderpriority : string,
 +  o_clerk : string,
 +  o_shippriority : int32,
 +  o_comment : string
 +}
 +
 +create type q3_shipping_priority.CustomerType as
 + closed {
 +  c_custkey : int32,
 +  c_name : string,
 +  c_address : string,
 +  c_nationkey : int32,
 +  c_phone : string,
 +  c_acctbal : double,
 +  c_mktsegment : string,
 +  c_comment : string
 +}
 +
 +create  nodegroup group1 if not exists  on 
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table LineItems(LineItemType) primary key l_orderkey,l_linenumber on group1;
 +
 +create  table Orders(OrderType) primary key o_orderkey on group1;
 +
 +create  table Customers(CustomerType) primary key c_custkey on group1;
 +
 +write output to asterix_nc1:"/tmp/q3_shipping_priority.adm"
 +select element {'l_orderkey':l_orderkey,'revenue':revenue,'o_orderdate':o_orderdate,'o_shippriority':o_shippriority}
 +from  Customers as c,
 +      Orders as o,
 +      LineItems as l
 +where (((c.c_mktsegment = 'BUILDING') and (c.c_custkey = o.o_custkey)) and ((l.l_orderkey = o.o_orderkey) and (o.o_orderdate < '1995-03-15') and (l.l_shipdate > '1995-03-15')))
 +/* +hash */
 +group by l.l_orderkey as l_orderkey,o.o_orderdate as o_orderdate,o.o_shippriority as o_shippriority
- with  revenue as q3_shipping_priority.sum((
++with  revenue as q3_shipping_priority.coll_sum((
 +      select element (i.l_extendedprice * (1 - i.l_discount))
 +      from  l as i
 +  ))
 +order by revenue desc,o_orderdate
 +limit 10
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q05_local_supplier_volume.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q05_local_supplier_volume.sqlpp
index 58093e0,0000000..df9b375
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q05_local_supplier_volume.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q05_local_supplier_volume.sqlpp
@@@ -1,145 -1,0 +1,145 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database q5_local_supplier if exists;
 +create  database q5_local_supplier;
 +
 +use q5_local_supplier;
 +
 +
 +create type q5_local_supplier.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create type q5_local_supplier.OrderType as
 + closed {
 +  o_orderkey : int32,
 +  o_custkey : int32,
 +  o_orderstatus : string,
 +  o_totalprice : double,
 +  o_orderdate : string,
 +  o_orderpriority : string,
 +  o_clerk : string,
 +  o_shippriority : int32,
 +  o_comment : string
 +}
 +
 +create type q5_local_supplier.CustomerType as
 + closed {
 +  c_custkey : int32,
 +  c_name : string,
 +  c_address : string,
 +  c_nationkey : int32,
 +  c_phone : string,
 +  c_acctbal : double,
 +  c_mktsegment : string,
 +  c_comment : string
 +}
 +
 +create type q5_local_supplier.SupplierType as
 + closed {
 +  s_suppkey : int32,
 +  s_name : string,
 +  s_address : string,
 +  s_nationkey : int32,
 +  s_phone : string,
 +  s_acctbal : double,
 +  s_comment : string
 +}
 +
 +create type q5_local_supplier.NationType as
 + closed {
 +  n_nationkey : int32,
 +  n_name : string,
 +  n_regionkey : int32,
 +  n_comment : string
 +}
 +
 +create type q5_local_supplier.RegionType as
 + closed {
 +  r_regionkey : int32,
 +  r_name : string,
 +  r_comment : string
 +}
 +
 +create  nodegroup group1 if not exists  on 
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table LineItems(LineItemType) primary key l_orderkey,l_linenumber on group1;
 +
 +create  table Orders(OrderType) primary key o_orderkey on group1;
 +
 +create  table Customers(CustomerType) primary key c_custkey on group1;
 +
 +create  table Suppliers(SupplierType) primary key s_suppkey on group1;
 +
 +create  table Nations(NationType) primary key n_nationkey on group1;
 +
 +create  table Regions(RegionType) primary key r_regionkey on group1;
 +
 +write output to asterix_nc1:"/tmp/q5_local_supplier.adm"
 +select element {'n_name':n_name,'revenue':revenue}
 +from  Customers as c,
 +      (
 +    select element {'n_name':l1.n_name,'l_extendedprice':l1.l_extendedprice,'l_discount':l1.l_discount,'s_nationkey':l1.s_nationkey,'o_custkey':o.o_custkey}
 +    from  Orders as o,
 +          (
 +        select element {'n_name':s1.n_name,'l_extendedprice':l.l_extendedprice,'l_discount':l.l_discount,'l_orderkey':l.l_orderkey,'s_nationkey':s1.s_nationkey}
 +        from  LineItems as l,
 +              (
 +            select element {'n_name':n1.n_name,'s_suppkey':s.s_suppkey,'s_nationkey':s.s_nationkey}
 +            from  Suppliers as s,
 +                  (
 +                select element {'n_name':n.n_name,'n_nationkey':n.n_nationkey}
 +                from  Nations as n,
 +                      Regions as r
 +                where ((n.n_regionkey = r.r_regionkey) and (r.r_name = 'ASIA'))
 +            ) as n1
 +            where (s.s_nationkey = n1.n_nationkey)
 +        ) as s1
 +        where (l.l_suppkey = s1.s_suppkey)
 +    ) as l1
 +    where ((l1.l_orderkey = o.o_orderkey) and (o.o_orderdate >= '1994-01-01') and (o.o_orderdate < '1995-01-01'))
 +) as o1
 +where ((c.c_nationkey = o1.s_nationkey) and (c.c_custkey = o1.o_custkey))
 +/* +hash */
 +group by o1.n_name as n_name
- with  revenue as q5_local_supplier.sum((
++with  revenue as q5_local_supplier.coll_sum((
 +      select element (i.l_extendedprice * (1 - i.l_discount))
 +      from  o1 as i
 +  ))
 +order by revenue desc
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q2.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q2.sqlpp
index 74a8f59,0000000..5472ad0
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q2.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/q2.sqlpp
@@@ -1,73 -1,0 +1,73 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database events if exists;
 +create  database events;
 +
 +use events;
 +
 +
 +create type events.AddressType as
 + closed {
 +  street : string,
 +  city : string,
 +  zip : string
 +}
 +
 +create type events.EventType as
 + closed {
 +  name : string,
 +  location : AddressType?,
 +  organizers : {{{
 +          name : string,
 +          role : string
 +      }
 +}},
 +  sponsoring_sigs : [{
 +          sig_name : string,
 +          chapter_name : string
 +      }
 +],
 +  interest_keywords : {{string}},
 +  price : double?,
 +  start_time : datetime,
 +  end_time : datetime
 +}
 +
 +create  nodegroup group1 if not exists  on 
 +    asterix_nc1,
 +    asterix_nc2
 +;
 +create  table Event(EventType) primary key name on group1;
 +
 +write output to asterix_nc1:"/tmp/q2.adm"
 +select element {'sig_name':sig_name,'total_count':sig_sponsorship_count,'chapter_breakdown':by_chapter}
 +from  Event as event,
 +      event.sponsoring_sigs as sponsor
 +with  es as {'event':event,'sponsor':sponsor}
 +group by sponsor.sig_name as sig_name
- with  sig_sponsorship_count as events.count(es),
++with  sig_sponsorship_count as count(es),
 +      by_chapter as (
-       select element {'chapter_name':chapter_name,'escount':events.count(e)}
++      select element {'chapter_name':chapter_name,'escount':count(e)}
 +      from  es as e
 +      group by e.sponsor.chapter_name as chapter_name
 +  )
 +order by sig_sponsorship_count desc
 +limit 5
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue562.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue562.sqlpp
index 5fb9440,0000000..c87d0d0
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue562.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue562.sqlpp
@@@ -1,107 -1,0 +1,107 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description  : This test case is to verify the fix for issue562
 + * https://code.google.com/p/asterixdb/issues/detail?id=562
 + * Expected Res : SUCCESS
 + * Date         : 15th Jan. 2015
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : int32,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create type tpch.OrderType as
 + closed {
 +  o_orderkey : int32,
 +  o_custkey : int32,
 +  o_orderstatus : string,
 +  o_totalprice : double,
 +  o_orderdate : string,
 +  o_orderpriority : string,
 +  o_clerk : string,
 +  o_shippriority : int32,
 +  o_comment : string
 +}
 +
 +create type tpch.CustomerType as
 + closed {
 +  c_custkey : int32,
 +  c_name : string,
 +  c_address : string,
 +  c_nationkey : int32,
 +  c_phone : string,
 +  c_acctbal : double,
 +  c_mktsegment : string,
 +  c_comment : string
 +}
 +
 +create  table Orders(OrderType) primary key o_orderkey;
 +
 +create  table Customer(CustomerType) primary key c_custkey;
 +
 +declare function q22_customer_tmp() {
 +(
 +    select element {'c_acctbal':c.c_acctbal,'c_custkey':c.c_custkey,'cntrycode':phone_substr}
 +    from  Customer as c
 +    with  phone_substr as tpch.substring(c.c_phone,1,2)
 +    where ((phone_substr = '13') or (phone_substr = '31') or (phone_substr = '23') or (phone_substr = '29') or (phone_substr = '30') or (phone_substr = '18') or (phone_substr = '17'))
 +)
 +};
- with  avg as tpch.avg((
++with  avg as tpch.coll_avg((
 +      select element c.c_acctbal
 +      from  Customer as c
 +      with  phone_substr as tpch.substring(c.c_phone,1,2)
 +      where ((c.c_acctbal > 0.0) and ((phone_substr = '13') or (phone_substr = '31') or (phone_substr = '23') or (phone_substr = '29') or (phone_substr = '30') or (phone_substr = '18') or (phone_substr = '17')))
 +  ))
- select element {'cntrycode':cntrycode,'numcust':tpch.count(ct),'totacctbal':tpch.sum((
++select element {'cntrycode':cntrycode,'numcust':tpch.coll_count(ct),'totacctbal':tpch.coll_sum((
 +        select element i.c_acctbal
 +        from  ct as i
 +    ))}
 +from  tpch.q22_customer_tmp() as ct
- where (tpch.count((
++where (tpch.coll_count((
 +    select element o
 +    from  Orders as o
 +    where (ct.c_custkey = o.o_custkey)
 +)) = 0)
 +group by ct.cntrycode as cntrycode
 +order by cntrycode
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue601.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue601.sqlpp
index 5f60eb0,0000000..1c68428
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue601.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue601.sqlpp
@@@ -1,57 -1,0 +1,57 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description  : This test case is to verify the fix for issue601
 + * https://code.google.com/p/asterixdb/issues/detail?id=601
 + * Expected Res : SUCCESS
 + * Date         : 10th Oct 2014
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create  table LineItem(LineItemType) primary key l_orderkey,l_linenumber;
 +
- select element {'l_linenumber':l_linenumber,'count_order':tpch.count(l)}
++select element {'l_linenumber':l_linenumber,'count_order':count(l)}
 +from  LineItem as l
 +group by l.l_linenumber as l_linenumber
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue697.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue697.sqlpp
index 5d23126,0000000..813109a
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue697.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue697.sqlpp
@@@ -1,47 -1,0 +1,47 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description     : This test case is to verify the fix for issue697
 + * https://code.google.com/p/asterixdb/issues/detail?id=697
 + * Expected Result : Success
 + * Date            : 16th Nov. 2014
 + */
 +
 +drop  database test if exists;
 +create  database test;
 +
 +use test;
 +
 +
 +create type test.TestType as
 + closed {
 +  key1 : int32,
 +  "value" : int32
 +}
 +
 +create  table test(TestType) primary key key1;
 +
- select element {'gid':aid,'avg':test.avg((
++select element {'gid':aid,'avg':test.coll_avg((
 +        select element j."value"
 +        from  i as j
 +        where test.not(test."is-null"(j."value"))
 +    ))}
 +from  test as i
 +group by i.key1 as aid
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue785.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue785.sqlpp
index aecafb4,0000000..09bd754
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue785.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue785.sqlpp
@@@ -1,121 -1,0 +1,121 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description  : This test case is to verify the fix for issue785
 + * https://code.google.com/p/asterixdb/issues/detail?id=785
 + * Expected Res : SUCCESS
 + * Date         : 2nd Oct. 2014
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.OrderType as
 + closed {
 +  o_orderkey : int32,
 +  o_custkey : int32,
 +  o_orderstatus : string,
 +  o_totalprice : double,
 +  o_orderdate : string,
 +  o_orderpriority : string,
 +  o_clerk : string,
 +  o_shippriority : int32,
 +  o_comment : string
 +}
 +
 +create type tpch.CustomerType as
 + closed {
 +  c_custkey : int32,
 +  c_name : string,
 +  c_address : string,
 +  c_nationkey : int32,
 +  c_phone : string,
 +  c_acctbal : double,
 +  c_mktsegment : string,
 +  c_comment : string
 +}
 +
 +create type tpch.SupplierType as
 + closed {
 +  s_suppkey : int32,
 +  s_name : string,
 +  s_address : string,
 +  s_nationkey : int32,
 +  s_phone : string,
 +  s_acctbal : double,
 +  s_comment : string
 +}
 +
 +create type tpch.NationType as
 + closed {
 +  n_nationkey : int32,
 +  n_name : string,
 +  n_regionkey : int32,
 +  n_comment : string
 +}
 +
 +create type tpch.RegionType as
 + closed {
 +  r_regionkey : int32,
 +  r_name : string,
 +  r_comment : string
 +}
 +
 +create  table Orders(OrderType) primary key o_orderkey;
 +
 +create  table Supplier(SupplierType) primary key s_suppkey;
 +
 +create  table Region(RegionType) primary key r_regionkey;
 +
 +create  table Nation(NationType) primary key n_nationkey;
 +
 +create  table Customer(CustomerType) primary key c_custkey;
 +
 +create  table SelectedNation(NationType) primary key n_nationkey;
 +
 +with  t as (
 +      select element {'n_nationkey':nation.n_nationkey,'n_name':nation.n_name}
 +      from  Nation as nation,
 +            SelectedNation as sn
 +      where (nation.n_nationkey = sn.n_nationkey)
 +  ),
 +      X as (
 +      select element {'nation_key':nation_key,'order_date':orderdate,'sum_price':sum}
 +      from  t as n,
 +            Customer as customer,
 +            Orders as orders
 +      where ((orders.o_custkey = customer.c_custkey) and (customer.c_nationkey = n.n_nationkey))
 +      group by orders.o_orderdate as orderdate,n.n_nationkey as nation_key
-       with  sum as tpch.sum((
++      with  sum as tpch.coll_sum((
 +            select element o.o_totalprice
 +            from  orders as o
 +        ))
 +  )
 +select element {'nation_key':nation_key,'sum_price':(
 +        select element {'orderdate':y.order_date,'sum_price':y.sum_price}
 +        from  x as y
 +        order by y.sum_price desc
 +        limit 3
 +    )}
 +from  X as x
 +group by x.nation_key as nation_key
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810-2.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810-2.sqlpp
index b2e4121,0000000..16655ff
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810-2.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810-2.sqlpp
@@@ -1,78 -1,0 +1,78 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description  : This test case is to verify the fix for issue810
 + * https://code.google.com/p/asterixdb/issues/detail?id=810
 + * Expected Res : SUCCESS
 + * Date         : 24th Nov. 2014
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create  table LineItem(LineItemType) primary key l_orderkey,l_linenumber;
 +
- select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'count_cheaps':tpch.count(cheaps),'avg_expensive_discounts':tpch.avg(expensives),'sum_disc_prices':tpch.sum(disc_prices),'total_charges':tpch.sum(charges)}
++select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'count_cheaps':tpch.coll_count(cheaps),'avg_expensive_discounts':tpch.coll_avg(expensives),'sum_disc_prices':tpch.coll_sum(disc_prices),'total_charges':tpch.coll_sum(charges)}
 +from  LineItem as l
 +where (l.l_shipdate <= '1998-09-02')
 +/* +hash */
 +group by l.l_returnflag as l_returnflag,l.l_linestatus as l_linestatus
 +with  expensives as (
 +      select element i.l_discount
 +      from  l as i
 +      where (i.l_discount <= 0.05)
 +  ),
 +      cheaps as (
 +      select element i
 +      from  l as i
 +      where (i.l_discount > 0.05)
 +  ),
 +      charges as (
 +      select element (i.l_extendedprice * (1 - i.l_discount) * (1 + i.l_tax))
 +      from  l as i
 +  ),
 +      disc_prices as (
 +      select element (i.l_extendedprice * (1 - i.l_discount))
 +      from  l as i
 +  )
 +order by l_returnflag,l_linestatus
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810.sqlpp
index da41e12,0000000..50760dc
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue810.sqlpp
@@@ -1,70 -1,0 +1,70 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description     : This test case is to verify the fix for issue810
 + * https://code.google.com/p/asterixdb/issues/detail?id=810
 + * Expected Result : Success
 + * Date            : 16th Nov. 2014
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create  table LineItem(LineItemType) primary key l_orderkey,l_linenumber;
 +
- select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'count_cheaps':tpch.count(cheap),'count_expensives':tpch.count(expensive)}
++select element {'l_returnflag':l_returnflag,'l_linestatus':l_linestatus,'count_cheaps':tpch.coll_count(cheap),'count_expensives':tpch.coll_count(expensive)}
 +from  LineItem as l
 +where (l.l_shipdate <= '1998-09-02')
 +/* +hash */
 +group by l.l_returnflag as l_returnflag,l.l_linestatus as l_linestatus
 +with  cheap as (
 +      select element m
 +      from  l as m
 +      where (m.l_discount > 0.05)
 +  ),
 +      expensive as (
 +      select element a
 +      from  l as a
 +      where (a.l_discount <= 0.05)
 +  )
 +order by l_returnflag,l_linestatus
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue827-2.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue827-2.sqlpp
index c5ad063,0000000..f7c8ddf
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue827-2.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/query-issue827-2.sqlpp
@@@ -1,80 -1,0 +1,80 @@@
 +/*
 + * 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.
 + */
 +/*
 + * Description  : This test case is to verify the fix for issue827
 + * https://code.google.com/p/asterixdb/issues/detail?id=827
 + * Expected Res : SUCCESS
 + * Date         : 3rd Dec. 2014
 + */
 +
 +drop  database tpch if exists;
 +create  database tpch;
 +
 +use tpch;
 +
 +
 +create type tpch.LineItemType as
 + closed {
 +  l_orderkey : int32,
 +  l_partkey : int32,
 +  l_suppkey : int32,
 +  l_linenumber : int32,
 +  l_quantity : double,
 +  l_extendedprice : double,
 +  l_discount : double,
 +  l_tax : double,
 +  l_returnflag : string,
 +  l_linestatus : string,
 +  l_shipdate : string,
 +  l_commitdate : string,
 +  l_receiptdate : string,
 +  l_shipinstruct : string,
 +  l_shipmode : string,
 +  l_comment : string
 +}
 +
 +create  table LineItem(LineItemType) primary key l_orderkey,l_linenumber;
 +
- {'sum_qty_partial':tpch.sum((
++{'sum_qty_partial':tpch.coll_sum((
 +    select element i.l_quantity
 +    from  LineItem as i
 +    where (i.l_shipdate <= '1998-09-02')
- )),'sum_base_price':tpch.sum((
++)),'sum_base_price':tpch.coll_sum((
 +    select element i.l_extendedprice
 +    from  LineItem as i
- )),'sum_disc_price':tpch.sum((
++)),'sum_disc_price':tpch.coll_sum((
 +    select element (i.l_extendedprice * (1 - i.l_discount))
 +    from  LineItem as i
- )),'sum_charge':tpch.sum((
++)),'sum_charge':tpch.coll_sum((
 +    select element (i.l_extendedprice * (1 - i.l_discount) * (1 + i.l_tax))
 +    from  LineItem as i
- )),'ave_qty':tpch.avg((
++)),'ave_qty':tpch.coll_avg((
 +    select element i.l_quantity
 +    from  LineItem as i
 +    where (i.l_shipdate <= '1998-09-02')
- )),'ave_price':tpch.avg((
++)),'ave_price':tpch.coll_avg((
 +    select element i.l_extendedprice
 +    from  LineItem as i
- )),'ave_disc':tpch.avg((
++)),'ave_disc':tpch.coll_avg((
 +    select element i.l_discount
 +    from  LineItem as i
- )),'count_order':tpch.count((
++)),'count_order':tpch.coll_count((
 +    select element l
 +    from  LineItem as l
 +))};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization-above-join.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization-above-join.sqlpp
index 07ccedc,0000000..94bcbf1
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization-above-join.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization-above-join.sqlpp
@@@ -1,82 -1,0 +1,82 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database fuzzyjoin if exists;
 +create  database fuzzyjoin;
 +
 +use fuzzyjoin;
 +
 +
 +create type fuzzyjoin.DBLPType as
 +{
 +  id : int32,
 +  dblpid : string,
 +  title : string,
 +  authors : string,
 +  misc : string
 +}
 +
 +create  table DBLP(DBLPType) primary key id;
 +
 +set "import-private-functions" "true";
 +
 +select element {'left':paperLeft,'right':paperRight,'sim':ridpair.sim}
 +from  DBLP as paperLeft,
 +      DBLP as paperRight,
 +      (
 +    select element {'idLeft':idLeft,'idRight':idRight,'sim':sim[0]}
 +    from  DBLP as paperLeft,
 +          fuzzyjoin."subset-collection"(tokensLeft,0,fuzzyjoin."prefix-len-jaccard"(lenLeft,0.500000f)) as prefixTokenLeft,
 +          DBLP as paperRight,
 +          fuzzyjoin."subset-collection"(tokensRight,0,fuzzyjoin."prefix-len-jaccard"(lenRight,0.500000f)) as prefixTokenRight
 +    with  lenLeft as fuzzyjoin.len(fuzzyjoin."counthashed-word-tokens"(paperLeft.title)),
 +          tokensLeft as (
 +          select element i
 +          from  fuzzyjoin."counthashed-word-tokens"(paperLeft.title) as tokenUnranked,
 +                (
 +              select element tokenGroupped
 +              from  DBLP as paper,
 +                    fuzzyjoin."counthashed-word-tokens"(paper.title) as token
 +              group by token as tokenGroupped
-               order by fuzzyjoin.count(paper),tokenGroupped
++              order by count(paper),tokenGroupped
 +          ) as tokenRanked at i
 +          where (tokenUnranked = tokenRanked)
 +          order by i
 +      ),
 +          lenRight as fuzzyjoin.len(fuzzyjoin."counthashed-word-tokens"(paperRight.title)),
 +          tokensRight as (
 +          select element i
 +          from  fuzzyjoin."counthashed-word-tokens"(paperRight.title) as tokenUnranked,
 +                (
 +              select element tokenGroupped
 +              from  DBLP as paper,
 +                    fuzzyjoin."counthashed-word-tokens"(paper.title) as token
 +              group by token as tokenGroupped
-               order by fuzzyjoin.count(paper),tokenGroupped
++              order by count(paper),tokenGroupped
 +          ) as tokenRanked at i
 +          where (tokenUnranked = tokenRanked)
 +          order by i
 +      ),
 +          sim as fuzzyjoin."similarity-jaccard-prefix"(lenLeft,tokensLeft,lenRight,tokensRight,prefixTokenLeft,0.500000f)
 +    where ((prefixTokenLeft = prefixTokenRight) and ((sim >= 0.500000f) and (paperLeft.id < paperRight.id)))
 +    group by paperLeft.id as idLeft,paperRight.id as idRight
 +) as ridpair
 +where ((ridpair.idLeft = paperLeft.id) and (ridpair.idRight = paperRight.id))
 +order by paperLeft.id,paperRight.id
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization.sqlpp
index 9f9d609,0000000..0cd244c
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/optimizerts/queries_sqlpp/split-materialization.sqlpp
@@@ -1,60 -1,0 +1,60 @@@
 +/*
 + * 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.
 + */
 +
 +drop  database TinySocial if exists;
 +create  database TinySocial;
 +
 +use TinySocial;
 +
 +
 +create type TinySocial.EmploymentType as
 +{
 +  "organization-name" : string,
 +  "start-date" : date,
 +  "end-date" : date?
 +}
 +
 +create type TinySocial.FacebookUserType as
 + closed {
 +  id : int32,
 +  alias : string,
 +  name : string,
 +  "user-since" : datetime,
 +  "friend-ids" : {{int32}},
 +  employment : [EmploymentType]
 +}
 +
 +create  table FacebookUsers(FacebookUserType) primary key id;
 +
 +with  lonelyusers as (
 +      select element d
 +      from  FacebookUsers as d
-       where (TinySocial.count(d."friend-ids") < 2)
++      where (TinySocial.coll_count(d."friend-ids") < 2)
 +  ),
 +      lonelyusers2 as (
 +      select element d
 +      from  FacebookUsers as d
-       where (TinySocial.count(d."friend-ids") < 2)
++      where (TinySocial.coll_count(d."friend-ids") < 2)
 +  )
 +select element {'user1':{'id':l1.id,'name':l1.name},'user2':{'id':l2.id,'name':l2.name}}
 +from  lonelyusers as l1,
 +      lonelyusers2 as l2
 +where (l1.id < l2.id)
 +order by l1.id,l2.id
 +;

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries/external-indexing/rc-format/rc-format.1.ddl.aql
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries/external-indexing/rc-format/rc-format.1.ddl.aql
index 5a7294c,0000000..4ffc5a7
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries/external-indexing/rc-format/rc-format.1.ddl.aql
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries/external-indexing/rc-format/rc-format.1.ddl.aql
@@@ -1,41 -1,0 +1,46 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Create an external dataset that contains records stored with rc hdfs file format.
 +                 Build an index over the external dataset age attribute
 +                 Perform a query over the dataset using the index.
 +* Expected Res : Success
 +* Date         : 3rd Jan 2014
 +*/
 +drop dataverse test if exists;
 +create dataverse test;
 +
 +use dataverse test;
 +
 +create type EmployeeType as closed {
 + id: int64,
 + name: string,
 + age: int64
 +};
 +
 +create external dataset EmployeeDataset(EmployeeType)
 +using hdfs
- (("hdfs"="hdfs://127.0.0.1:31888"),("path"="/asterix/external-indexing-test.rc"),("input-format"="rc-input-format"),("format"="binary"),("parser"="hive-parser"),("hive-serde"="org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe"));
++(("hdfs"="hdfs://127.0.0.1:31888"),
++("path"="/asterix/external-indexing-test.rc"),
++("input-format"="rc-input-format"),
++("format"="hdfs-writable"),
++("parser"="hive-parser"),
++("hive-serde"="org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe"));
 +
 +create index EmployeeAgeIdx on EmployeeDataset(age);

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries/hdfs/large-record/large-record.1.ddl.aql
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries/hdfs/large-record/large-record.1.ddl.aql
index 000ef5b,0000000..4e306b3
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries/hdfs/large-record/large-record.1.ddl.aql
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries/hdfs/large-record/large-record.1.ddl.aql
@@@ -1,45 -1,0 +1,45 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Create an external dataset that contains a very large record
 +                 stored with text hdfs file format.
 +                 Perform a query over the dataset.
 +* Expected Res : Success
 +* Date         : 3rd Jan 2016
 +*/
 +drop dataverse test if exists;
 +create dataverse test;
 +
 +use dataverse test;
 +
 +create type EmployeeType as closed {
 + id: int64,
 + name: string,
 + age: int64
 +};
 +
 +create external dataset EmployeeDataset(EmployeeType)
 +using adapter
 +(("reader"="hdfs"),
- ("parser"="delimited-text"),
++("format"="delimited-text"),
 +("hdfs"="hdfs://127.0.0.1:31888"),
 +("path"="/asterix/large-record.txt"),
 +("input-format"="text-input-format"),
 +("delimiter"="|"));
 +

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null/agg_null.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null/agg_null.3.query.sqlpp
index 4529b3c,0000000..68c00f0
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null/agg_null.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null/agg_null.3.query.sqlpp
@@@ -1,25 -1,0 +1,25 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Run aggregates over both ordered list and unordered list with only null items.
 +* Expected Res : Success
 +* Date         : Feb 7th 2014
 +*/
 +
- {'sql-count1':"sql-count"([null]),'average1':"sql-avg"([null]),'sql-sum1':"sql-sum"([null]),'sql-min1':"sql-min"([null]),'sql-max1':"sql-max"([null]),'sql-count2':"sql-count"({{null,null}}),'average2':"sql-avg"({{null,null}}),'sql-sum2':"sql-sum"({{null,null}}),'sql-min2':"sql-min"({{null,null}}),'sql-max2':"sql-max"({{null,null}})};
++{'sql-count1':"coll_sql-count"([null]),'average1':"coll_sql-avg"([null]),'sql-sum1':"coll_sql-sum"([null]),'sql-min1':"coll_sql-min"([null]),'sql-max1':"coll_sql-max"([null]),'sql-count2':"coll_sql-count"({{null,null}}),'average2':"coll_sql-avg"({{null,null}}),'sql-sum2':"coll_sql-sum"({{null,null}}),'sql-min2':"coll_sql-min"({{null,null}}),'sql-max2':"coll_sql-max"({{null,null}})};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec/agg_null_rec.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec/agg_null_rec.3.query.sqlpp
index f720a2c,0000000..83037b7
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec/agg_null_rec.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec/agg_null_rec.3.query.sqlpp
@@@ -1,43 -1,0 +1,43 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Run aggregates over records, with only null items for the aggregating fields.
 +* Expected Res : Success
 +* Date         : Feb 7th 2014
 +*/
 +
 +use test;
 +
 +
- {'sql-count':test."sql-count"((
++{'sql-count':test."coll_sql-count"((
 +    select element t.valplus
 +    from  Test as t
- )),'average':test."sql-avg"((
++)),'average':test."coll_sql-avg"((
 +    select element t.valplus
 +    from  Test as t
- )),'sql-sum':test."sql-sum"((
++)),'sql-sum':test."coll_sql-sum"((
 +    select element t.valplus
 +    from  Test as t
- )),'sql-min':test."sql-min"((
++)),'sql-min':test."coll_sql-min"((
 +    select element t.valplus
 +    from  Test as t
- )),'sql-max':test."sql-max"((
++)),'sql-max':test."coll_sql-max"((
 +    select element t.valplus
 +    from  Test as t
 +))};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec_1/agg_null_rec_1.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec_1/agg_null_rec_1.3.query.sqlpp
index bec4d87,0000000..0f32271
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec_1/agg_null_rec_1.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_null_rec_1/agg_null_rec_1.3.query.sqlpp
@@@ -1,55 -1,0 +1,55 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Run aggregates over records, with only null items for the aggregating fields.
 +* Expected Res : Success
 +* Date         : Feb 7th 2014
 +*/
 +
 +use test;
 +
 +
- {'sql-count':test."sql-count"((
++{'sql-count':test."coll_sql-count"((
 +    select element t
 +    from  Test as t
- )),'average':test."sql-avg"((
++)),'average':test."coll_sql-avg"((
 +    select element i.val
 +    from  (
 +        select element t
 +        from  Test as t
 +    ) as i
- )),'sql-sum':test."sql-sum"((
++)),'sql-sum':test."coll_sql-sum"((
 +    select element i.val
 +    from  (
 +        select element t
 +        from  Test as t
 +    ) as i
- )),'sql-min':test."sql-min"((
++)),'sql-min':test."coll_sql-min"((
 +    select element i.valplus
 +    from  (
 +        select element t
 +        from  Test as t
 +    ) as i
- )),'sql-max':test."sql-max"((
++)),'sql-max':test."coll_sql-max"((
 +    select element i.valplus
 +    from  (
 +        select element t
 +        from  Test as t
 +    ) as i
 +))};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number/agg_number.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number/agg_number.3.query.sqlpp
index dc464a5,0000000..4f13bd4
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number/agg_number.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number/agg_number.3.query.sqlpp
@@@ -1,25 -1,0 +1,25 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Run aggregates over an ordered list with numbers of different types
 +* Expected Res : Success
 +* Date         : Feb 7th 2014
 +*/
 +
- {'sql-count1':"sql-count"([float('2.0'),double('3.0'),93847382783847382,1]),'average1':"sql-avg"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-sum1':"sql-sum"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-min1':"sql-min"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-max1':"sql-max"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-count2':"sql-count"({{float('2.0'),double('3.0'),93847382783847382,1}}),'average2':"sql-avg"({{float('2.0'),double('3.0'),93847382783847382,1}}),'sql-sum2':"sql-sum"({{float('2.0'),double('3.0'),93847382783847382,1}}),'sql-min2':"sql-min"({{float('2.0'),double('3.0'),93847382783847382,1}}),'sql-max2':"sql-max"({{float('2.0'),double('3.0'),93847382783847382,1}})};
++{'sql-count1':"coll_sql-count"([float('2.0'),double('3.0'),93847382783847382,1]),'average1':"coll_sql-avg"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-sum1':"coll_sql-sum"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-min1':"coll_sql-min"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-max1':"coll_sql-max"([float('2.0'),double('3.0'),93847382783847382,1]),'sql-count2':"coll_sql-count"({{float('2.0'),double('3.0'),93847382783847382,1}}),'average2':"coll_sql-avg"({{float('2.0'),double('3.0'),93847382783847382,1}}),'sql-sum2':"coll_sql-sum"({{float('2.0'),double('3.0'),93847382783847382,1}}),'sql-min2':"coll_sql-min"({{float('2.0'),double('3.0'),93847382783847382,1}}),'sql-max2':"coll_sql-max"({{float('2.0'),double('3.0'),93847382783847382,1}})};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number_rec/agg_number_rec.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number_rec/agg_number_rec.3.query.sqlpp
index f57bba5,0000000..e93edc6
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number_rec/agg_number_rec.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/agg_number_rec/agg_number_rec.3.query.sqlpp
@@@ -1,43 -1,0 +1,43 @@@
 +/*
 + * 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.
 + */
 +/*
 +* Description  : Run aggregates over records, with different numeric typed items for the aggregating fields.
 +* Expected Res : Success
 +* Date         : Feb 7th 2014
 +*/
 +
 +use test;
 +
 +
- {'sql-count':test."sql-count"((
++{'sql-count':test."coll_sql-count"((
 +    select element t.valplus
 +    from  Test as t
- )),'average':test."sql-avg"((
++)),'average':test."coll_sql-avg"((
 +    select element t.valplus
 +    from  Test as t
- )),'sql-sum':test."sql-sum"((
++)),'sql-sum':test."coll_sql-sum"((
 +    select element t.valplus
 +    from  Test as t
- )),'sql-min':test."sql-min"((
++)),'sql-min':test."coll_sql-min"((
 +    select element t.valplus
 +    from  Test as t
- )),'sql-max':test."sql-max"((
++)),'sql-max':test."coll_sql-max"((
 +    select element t.valplus
 +    from  Test as t
 +))};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double/avg_double.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double/avg_double.3.query.sqlpp
index f6db917,0000000..0971e7d
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double/avg_double.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double/avg_double.3.query.sqlpp
@@@ -1,23 -1,0 +1,23 @@@
 +/*
 + * 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.
 + */
 +
- select element "sql-avg"((
++select element "coll_sql-avg"((
 +    select element x
 +    from  [1.0,2.0,double('3.0')] as x
 +));

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double_null/avg_double_null.3.query.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double_null/avg_double_null.3.query.sqlpp
index 9f70bcb,0000000..192c5c4
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double_null/avg_double_null.3.query.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_double_null/avg_double_null.3.query.sqlpp
@@@ -1,26 -1,0 +1,26 @@@
 +/*
 + * 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.
 + */
 +
 +use test;
 +
 +
- {'average':test."sql-avg"((
++{'average':test."coll_sql-avg"((
 +    select element x.doubleField
 +    from  Numeric as x
 +))};

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.1.ddl.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.1.ddl.sqlpp
index a71e263,0000000..dd878f9
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.1.ddl.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.1.ddl.sqlpp
@@@ -1,27 -1,0 +1,27 @@@
 +/*
 + * 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.
 + */
 +/*
-  * Description    : Tests that sql-avg aggregation correctly returns null for an empty stream,
++ * Description    : Tests that coll_sql-avg aggregation correctly returns null for an empty stream,
 + *                  without an aggregate combiner.
 + * Success        : Yes
 + */
 +
 +drop  database test if exists;
 +create  database test;
 +

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/8516517e/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.2.update.sqlpp
----------------------------------------------------------------------
diff --cc asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.2.update.sqlpp
index ddc1233,0000000..d5b1944
mode 100644,000000..100644
--- a/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.2.update.sqlpp
+++ b/asterixdb/asterix-app/src/test/resources/runtimets/queries_sqlpp/aggregate-sql/avg_empty_01/avg_empty_01.2.update.sqlpp
@@@ -1,24 -1,0 +1,24 @@@
 +/*
 + * 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.
 + */
 +/*
-  * Description    : Tests that sql-avg aggregation correctly returns null for an empty stream,
++ * Description    : Tests that coll_sql-avg aggregation correctly returns null for an empty stream,
 + *                  without an aggregate combiner.
 + * Success        : Yes
 + */
 +