You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by jv...@apache.org on 2011/05/08 01:15:01 UTC

svn commit: r1100656 [1/2] - in /hive/trunk: jdbc/src/test/org/apache/hadoop/hive/jdbc/ ql/src/java/org/apache/hadoop/hive/ql/parse/ ql/src/test/queries/clientnegative/ ql/src/test/results/clientnegative/ ql/src/test/results/compiler/errors/

Author: jvs
Date: Sat May  7 23:14:58 2011
New Revision: 1100656

URL: http://svn.apache.org/viewvc?rev=1100656&view=rev
Log:
HIVE-1731. Improve miscellaneous error messages
(Syed Albiz via jvs)


Added:
    hive/trunk/ql/src/test/queries/clientnegative/select_charliteral.q
    hive/trunk/ql/src/test/results/clientnegative/select_charliteral.q.out
Modified:
    hive/trunk/jdbc/src/test/org/apache/hadoop/hive/jdbc/TestJdbcDriver.java
    hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ErrorMsg.java
    hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ParseDriver.java
    hive/trunk/ql/src/test/results/clientnegative/alter_view_failure6.q.out
    hive/trunk/ql/src/test/results/clientnegative/ambiguous_col.q.out
    hive/trunk/ql/src/test/results/clientnegative/bad_sample_clause.q.out
    hive/trunk/ql/src/test/results/clientnegative/clusterbydistributeby.q.out
    hive/trunk/ql/src/test/results/clientnegative/clusterbyorderby.q.out
    hive/trunk/ql/src/test/results/clientnegative/clusterbysortby.q.out
    hive/trunk/ql/src/test/results/clientnegative/clustern3.q.out
    hive/trunk/ql/src/test/results/clientnegative/clustern4.q.out
    hive/trunk/ql/src/test/results/clientnegative/column_rename3.q.out
    hive/trunk/ql/src/test/results/clientnegative/create_view_failure3.q.out
    hive/trunk/ql/src/test/results/clientnegative/drop_function_failure.q.out
    hive/trunk/ql/src/test/results/clientnegative/drop_index_failure.q.out
    hive/trunk/ql/src/test/results/clientnegative/drop_partition_failure.q.out
    hive/trunk/ql/src/test/results/clientnegative/dyn_part2.q.out
    hive/trunk/ql/src/test/results/clientnegative/exim_00_unsupported_schema.q.out
    hive/trunk/ql/src/test/results/clientnegative/fileformat_void_input.q.out
    hive/trunk/ql/src/test/results/clientnegative/groupby2_map_skew_multi_distinct.q.out
    hive/trunk/ql/src/test/results/clientnegative/groupby2_multi_distinct.q.out
    hive/trunk/ql/src/test/results/clientnegative/groupby3_map_skew_multi_distinct.q.out
    hive/trunk/ql/src/test/results/clientnegative/groupby3_multi_distinct.q.out
    hive/trunk/ql/src/test/results/clientnegative/groupby_key.q.out
    hive/trunk/ql/src/test/results/clientnegative/input1.q.out
    hive/trunk/ql/src/test/results/clientnegative/input2.q.out
    hive/trunk/ql/src/test/results/clientnegative/input_part0_neg.q.out
    hive/trunk/ql/src/test/results/clientnegative/invalid_create_tbl2.q.out
    hive/trunk/ql/src/test/results/clientnegative/invalid_select_expression.q.out
    hive/trunk/ql/src/test/results/clientnegative/invalid_tbl_name.q.out
    hive/trunk/ql/src/test/results/clientnegative/invalidate_view1.q.out
    hive/trunk/ql/src/test/results/clientnegative/join2.q.out
    hive/trunk/ql/src/test/results/clientnegative/joinneg.q.out
    hive/trunk/ql/src/test/results/clientnegative/lateral_view_join.q.out
    hive/trunk/ql/src/test/results/clientnegative/load_part_nospec.q.out
    hive/trunk/ql/src/test/results/clientnegative/load_wrong_noof_part.q.out
    hive/trunk/ql/src/test/results/clientnegative/nopart_insert.q.out
    hive/trunk/ql/src/test/results/clientnegative/nopart_load.q.out
    hive/trunk/ql/src/test/results/clientnegative/notable_alias3.q.out
    hive/trunk/ql/src/test/results/clientnegative/orderbysortby.q.out
    hive/trunk/ql/src/test/results/clientnegative/regex_col_1.q.out
    hive/trunk/ql/src/test/results/clientnegative/regex_col_2.q.out
    hive/trunk/ql/src/test/results/clientnegative/regex_col_groupby.q.out
    hive/trunk/ql/src/test/results/clientnegative/sample.q.out
    hive/trunk/ql/src/test/results/clientnegative/select_udtf_alias.q.out
    hive/trunk/ql/src/test/results/clientnegative/semijoin1.q.out
    hive/trunk/ql/src/test/results/clientnegative/semijoin2.q.out
    hive/trunk/ql/src/test/results/clientnegative/semijoin3.q.out
    hive/trunk/ql/src/test/results/clientnegative/semijoin4.q.out
    hive/trunk/ql/src/test/results/clientnegative/show_tables_bad1.q.out
    hive/trunk/ql/src/test/results/clientnegative/show_tables_bad2.q.out
    hive/trunk/ql/src/test/results/clientnegative/smb_bucketmapjoin.q.out
    hive/trunk/ql/src/test/results/clientnegative/strict_orderby.q.out
    hive/trunk/ql/src/test/results/clientnegative/strict_pruning.q.out
    hive/trunk/ql/src/test/results/clientnegative/subq_insert.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong1.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong2.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong2.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong3.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_coalesce.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_args_len.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_type.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_args_len.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_type.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_if_not_bool.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_if_wrong_args_len.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_in.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_args_len.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_type.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_args_len.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_type.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_args_len.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_type.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong2.q.out
    hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong3.q.out
    hive/trunk/ql/src/test/results/clientnegative/union.q.out
    hive/trunk/ql/src/test/results/compiler/errors/ambiguous_table_col.q.out
    hive/trunk/ql/src/test/results/compiler/errors/duplicate_alias.q.out
    hive/trunk/ql/src/test/results/compiler/errors/garbage.q.out
    hive/trunk/ql/src/test/results/compiler/errors/insert_wrong_number_columns.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_create_table.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_dot.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_function_param2.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_index.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_list_index.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_list_index2.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_map_index.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_map_index2.q.out
    hive/trunk/ql/src/test/results/compiler/errors/invalid_select.q.out
    hive/trunk/ql/src/test/results/compiler/errors/missing_overwrite.q.out
    hive/trunk/ql/src/test/results/compiler/errors/nonkey_groupby.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_column1.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_column2.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_column3.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_column4.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_column5.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_column6.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_function1.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_function2.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_function3.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_function4.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_table1.q.out
    hive/trunk/ql/src/test/results/compiler/errors/unknown_table2.q.out
    hive/trunk/ql/src/test/results/compiler/errors/wrong_distinct1.q.out
    hive/trunk/ql/src/test/results/compiler/errors/wrong_distinct2.q.out

Modified: hive/trunk/jdbc/src/test/org/apache/hadoop/hive/jdbc/TestJdbcDriver.java
URL: http://svn.apache.org/viewvc/hive/trunk/jdbc/src/test/org/apache/hadoop/hive/jdbc/TestJdbcDriver.java?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/jdbc/src/test/org/apache/hadoop/hive/jdbc/TestJdbcDriver.java (original)
+++ hive/trunk/jdbc/src/test/org/apache/hadoop/hive/jdbc/TestJdbcDriver.java Sat May  7 23:14:58 2011
@@ -360,16 +360,16 @@ public class TestJdbcDriver extends Test
     // sure
     // how to get around that.
     doTestErrorCase("SELECTT * FROM " + tableName,
-        "cannot recognize input 'SELECTT'", invalidSyntaxSQLState, 11);
+        "cannot recognize input near 'SELECTT' '*' 'FROM'", invalidSyntaxSQLState, 11);
     doTestErrorCase("SELECT * FROM some_table_that_does_not_exist",
-        "Table not found", "42S02", parseErrorCode);
+        "Table not found", "42000", parseErrorCode);
     doTestErrorCase("drop table some_table_that_does_not_exist",
-        "Table not found", "42S02", parseErrorCode);
+        "Table not found", "42000", parseErrorCode);
     doTestErrorCase("SELECT invalid_column FROM " + tableName,
-        "Invalid Table Alias or Column Reference", invalidSyntaxSQLState,
+        "Invalid table alias or column reference", invalidSyntaxSQLState,
         parseErrorCode);
     doTestErrorCase("SELECT invalid_function(key) FROM " + tableName,
-        "Invalid Function", invalidSyntaxSQLState, parseErrorCode);
+        "Invalid function", invalidSyntaxSQLState, parseErrorCode);
 
     // TODO: execute errors like this currently don't return good messages (i.e.
     // 'Table already exists'). This is because the Driver class calls

Modified: hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ErrorMsg.java
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ErrorMsg.java?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ErrorMsg.java (original)
+++ hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ErrorMsg.java Sat May  7 23:14:58 2011
@@ -40,78 +40,78 @@ public enum ErrorMsg {
 
   GENERIC_ERROR("Exception while processing"),
   INVALID_TABLE("Table not found", "42S02"),
-  INVALID_COLUMN("Invalid Column Reference"),
-  INVALID_INDEX("Invalid Index"),
-  INVALID_TABLE_OR_COLUMN("Invalid Table Alias or Column Reference"),
-  AMBIGUOUS_TABLE_OR_COLUMN("Ambiguous Table Alias or Column Reference"),
+  INVALID_COLUMN("Invalid column reference"),
+  INVALID_INDEX("Invalid index"),
+  INVALID_TABLE_OR_COLUMN("Invalid table alias or column reference"),
+  AMBIGUOUS_TABLE_OR_COLUMN("Ambiguous table alias or column reference"),
   INVALID_PARTITION("Partition not found"),
-  AMBIGUOUS_COLUMN("Ambiguous Column Reference"),
-  AMBIGUOUS_TABLE_ALIAS("Ambiguous Table Alias"),
-  INVALID_TABLE_ALIAS("Invalid Table Alias"),
-  NO_TABLE_ALIAS("No Table Alias"),
-  INVALID_FUNCTION("Invalid Function"),
-  INVALID_FUNCTION_SIGNATURE("Function Argument Type Mismatch"),
-  INVALID_OPERATOR_SIGNATURE("Operator Argument Type Mismatch"),
-  INVALID_ARGUMENT("Wrong Arguments"),
-  INVALID_ARGUMENT_LENGTH("Arguments Length Mismatch", "21000"),
-  INVALID_ARGUMENT_TYPE("Argument Type Mismatch"),
-  INVALID_JOIN_CONDITION_1("Both Left and Right Aliases Encountered in Join"),
-  INVALID_JOIN_CONDITION_2("Neither Left nor Right Aliases Encountered in Join"),
-  INVALID_JOIN_CONDITION_3("OR not supported in Join currently"),
-  INVALID_TRANSFORM("TRANSFORM with Other Select Columns not Supported"),
-  DUPLICATE_GROUPBY_KEY("Repeated Key in Group By"),
-  UNSUPPORTED_MULTIPLE_DISTINCTS("DISTINCT on Different Columns not Supported with skew in data"),
-  NO_SUBQUERY_ALIAS("No Alias For Subquery"),
-  NO_INSERT_INSUBQUERY("Cannot insert in a Subquery. Inserting to table "),
-  NON_KEY_EXPR_IN_GROUPBY("Expression Not In Group By Key"),
-  INVALID_XPATH("General . and [] Operators are Not Supported"),
-  INVALID_PATH("Invalid Path"), ILLEGAL_PATH("Path is not legal"),
-  INVALID_NUMERICAL_CONSTANT("Invalid Numerical Constant"),
-  INVALID_ARRAYINDEX_CONSTANT("Non Constant Expressions for Array Indexes not Supported"),
-  INVALID_MAPINDEX_CONSTANT("Non Constant Expression for Map Indexes not Supported"),
-  INVALID_MAPINDEX_TYPE("Map Key Type does not Match Index Expression Type"),
-  NON_COLLECTION_TYPE("[] not Valid on Non Collection Types"),
+  AMBIGUOUS_COLUMN("Ambiguous column reference"),
+  AMBIGUOUS_TABLE_ALIAS("Ambiguous table alias"),
+  INVALID_TABLE_ALIAS("Invalid table alias"),
+  NO_TABLE_ALIAS("No table alias"),
+  INVALID_FUNCTION("Invalid function"),
+  INVALID_FUNCTION_SIGNATURE("Function argument type mismatch"),
+  INVALID_OPERATOR_SIGNATURE("Operator argument type mismatch"),
+  INVALID_ARGUMENT("Wrong arguments"),
+  INVALID_ARGUMENT_LENGTH("Arguments length mismatch", "21000"),
+  INVALID_ARGUMENT_TYPE("Argument type mismatch"),
+  INVALID_JOIN_CONDITION_1("Both left and right aliases encountered in JOIN"),
+  INVALID_JOIN_CONDITION_2("Neither left nor right aliases encountered in JOIN"),
+  INVALID_JOIN_CONDITION_3("OR not supported in JOIN currently"),
+  INVALID_TRANSFORM("TRANSFORM with other SELECT columns not supported"),
+  DUPLICATE_GROUPBY_KEY("Repeated key in GROUP BY"),
+  UNSUPPORTED_MULTIPLE_DISTINCTS("DISTINCT on different columns not supported with skew in data"),
+  NO_SUBQUERY_ALIAS("No alias for subquery"),
+  NO_INSERT_INSUBQUERY("Cannot insert in a subquery. Inserting to table "),
+  NON_KEY_EXPR_IN_GROUPBY("Expression not in GROUP BY key"),
+  INVALID_XPATH("General . and [] operators are not supported"),
+  INVALID_PATH("Invalid path"), ILLEGAL_PATH("Path is not legal"),
+  INVALID_NUMERICAL_CONSTANT("Invalid numerical constant"),
+  INVALID_ARRAYINDEX_CONSTANT("Non-constant expressions for array indexes not supported"),
+  INVALID_MAPINDEX_CONSTANT("Non-constant expression for map indexes not supported"),
+  INVALID_MAPINDEX_TYPE("MAP key type does not match index expression type"),
+  NON_COLLECTION_TYPE("[] not valid on non-collection types"),
   SELECT_DISTINCT_WITH_GROUPBY("SELECT DISTINCT and GROUP BY can not be in the same query"),
   COLUMN_REPEATED_IN_PARTITIONING_COLS("Column repeated in partitioning columns"),
   DUPLICATE_COLUMN_NAMES("Duplicate column name:"),
   INVALID_BUCKET_NUMBER("Bucket number should be bigger than zero"),
-  COLUMN_REPEATED_IN_CLUSTER_SORT("Same column cannot appear in cluster and sort by"),
-  SAMPLE_RESTRICTION("Cannot Sample on More Than Two Columns"),
-  SAMPLE_COLUMN_NOT_FOUND("Sample Column Not Found"),
-  NO_PARTITION_PREDICATE("No Partition Predicate Found"),
-  INVALID_DOT(". operator is only supported on struct or list of struct types"),
+  COLUMN_REPEATED_IN_CLUSTER_SORT("Same column cannot appear in CLUSTER BY and SORT BY"),
+  SAMPLE_RESTRICTION("Cannot SAMPLE on more than two columns"),
+  SAMPLE_COLUMN_NOT_FOUND("SAMPLE column not found"),
+  NO_PARTITION_PREDICATE("No partition predicate found"),
+  INVALID_DOT(". Operator is only supported on struct or list of struct types"),
   INVALID_TBL_DDL_SERDE("Either list of columns or a custom serializer should be specified"),
   TARGET_TABLE_COLUMN_MISMATCH(
       "Cannot insert into target table because column number/types are different"),
-  TABLE_ALIAS_NOT_ALLOWED("Table Alias not Allowed in Sampling Clause"),
-  CLUSTERBY_DISTRIBUTEBY_CONFLICT("Cannot have both Cluster By and Distribute By Clauses"),
-  ORDERBY_DISTRIBUTEBY_CONFLICT("Cannot have both Order By and Distribute By Clauses"),
-  CLUSTERBY_SORTBY_CONFLICT("Cannot have both Cluster By and Sort By Clauses"),
-  ORDERBY_SORTBY_CONFLICT("Cannot have both Order By and Sort By Clauses"),
-  CLUSTERBY_ORDERBY_CONFLICT("Cannot have both Cluster By and Order By Clauses"),
-  NO_LIMIT_WITH_ORDERBY("In strict mode, limit must be specified if ORDER BY is present"),
+  TABLE_ALIAS_NOT_ALLOWED("Table alias not allowed in sampling clause"),
+  CLUSTERBY_DISTRIBUTEBY_CONFLICT("Cannot have both CLUSTER BY and DISTRIBUTE BY clauses"),
+  ORDERBY_DISTRIBUTEBY_CONFLICT("Cannot have both ORDER BY and DISTRIBUTE BY clauses"),
+  CLUSTERBY_SORTBY_CONFLICT("Cannot have both CLUSTER BY and SORT BY clauses"),
+  ORDERBY_SORTBY_CONFLICT("Cannot have both ORDER BY and SORT BY clauses"),
+  CLUSTERBY_ORDERBY_CONFLICT("Cannot have both CLUSTER BY and ORDER BY clauses"),
+  NO_LIMIT_WITH_ORDERBY("In strict mode, if ORDER BY is specified, LIMIT must also be specified"),
   NO_CARTESIAN_PRODUCT("In strict mode, cartesian product is not allowed. "
       + "If you really want to perform the operation, set hive.mapred.mode=nonstrict"),
-  UNION_NOTIN_SUBQ("Top level Union is not supported currently; use a subquery for the union"),
-  INVALID_INPUT_FORMAT_TYPE("Input Format must implement InputFormat"),
+  UNION_NOTIN_SUBQ("Top level UNION is not supported currently; use a subquery for the UNION"),
+  INVALID_INPUT_FORMAT_TYPE("Input format must implement InputFormat"),
   INVALID_OUTPUT_FORMAT_TYPE("Output Format must implement HiveOutputFormat, "
       + "otherwise it should be either IgnoreKeyTextOutputFormat or SequenceFileOutputFormat"),
   NO_VALID_PARTN("The query does not reference any valid partition. "
       + "To run this query, set hive.mapred.mode=nonstrict"),
-  NO_OUTER_MAPJOIN("Map Join cannot be performed with Outer join"),
-  INVALID_MAPJOIN_HINT("neither table specified as map-table"),
-  INVALID_MAPJOIN_TABLE("result of a union cannot be a map table"),
-  NON_BUCKETED_TABLE("Sampling Expression Needed for Non-Bucketed Table"),
+  NO_OUTER_MAPJOIN("MAPJOIN cannot be performed with OUTER JOIN"),
+  INVALID_MAPJOIN_HINT("Neither table specified as map-table"),
+  INVALID_MAPJOIN_TABLE("Result of a union cannot be a map table"),
+  NON_BUCKETED_TABLE("Sampling expression needed for non-bucketed table"),
   BUCKETED_NUMBERATOR_BIGGER_DENOMINATOR("Numberator should not be bigger than "
-      + "denaminator in sample clause for Table"),
-  NEED_PARTITION_ERROR("need to specify partition columns because the destination "
+      + "denaminator in sample clause for table"),
+  NEED_PARTITION_ERROR("Need to specify partition columns because the destination "
       + "table is partitioned."),
   CTAS_CTLT_COEXISTENCE("Create table command does not allow LIKE and AS-SELECT in "
       + "the same command"),
   LINES_TERMINATED_BY_NON_NEWLINE("LINES TERMINATED BY only supports newline '\\n' right now"),
-  CTAS_COLLST_COEXISTENCE("Create table as select command cannot specify the list of columns "
+  CTAS_COLLST_COEXISTENCE("CREATE TABLE AS SELECT command cannot specify the list of columns "
       + "for the target table."),
-  CTLT_COLLST_COEXISTENCE("Create table like command cannot specify the list of columns for "
+  CTLT_COLLST_COEXISTENCE("CREATE TABLE LIKE command cannot specify the list of columns for "
       + "the target table."),
   INVALID_SELECT_SCHEMA("Cannot derive schema from the select-clause."),
   CTAS_PARCOL_COEXISTENCE("CREATE-TABLE-AS-SELECT does not support partitioning in the target "
@@ -132,8 +132,8 @@ public enum ErrorMsg {
   UDTF_ALIAS_MISMATCH("The number of aliases supplied in the AS clause does not match the "
       + "number of columns output by the UDTF"),
   UDF_STATEFUL_INVALID_LOCATION("Stateful UDF's can only be invoked in the SELECT list"),
-  LATERAL_VIEW_WITH_JOIN("Join with a lateral view is not supported"),
-  LATERAL_VIEW_INVALID_CHILD("Lateral view AST with invalid child"),
+  LATERAL_VIEW_WITH_JOIN("JOIN with a LATERAL VIEW is not supported"),
+  LATERAL_VIEW_INVALID_CHILD("LATERAL VIEW AST with invalid child"),
   OUTPUT_SPECIFIED_MULTIPLE_TIMES("The same output cannot be present multiple times: "),
   INVALID_AS("AS clause has an invalid number of aliases"),
   VIEW_COL_MISMATCH("The number of columns produced by the SELECT clause does not match the "
@@ -155,9 +155,9 @@ public enum ErrorMsg {
       + "STRING instead."),
   CREATE_NON_NATIVE_AS("CREATE TABLE AS SELECT cannot be used for a non-native table"),
   LOAD_INTO_NON_NATIVE("A non-native table cannot be used as target for LOAD"),
-  LOCKMGR_NOT_SPECIFIED("lock manager not specified correctly, set hive.lock.manager"),
-  LOCKMGR_NOT_INITIALIZED("lock manager could not be initialized, check hive.lock.manager "),
-  LOCK_CANNOT_BE_ACQUIRED("locks on the underlying objects cannot be acquired. retry after some time"),
+  LOCKMGR_NOT_SPECIFIED("Lock manager not specified correctly, set hive.lock.manager"),
+  LOCKMGR_NOT_INITIALIZED("Lock manager could not be initialized, check hive.lock.manager "),
+  LOCK_CANNOT_BE_ACQUIRED("Locks on the underlying objects cannot be acquired. retry after some time"),
   ZOOKEEPER_CLIENT_COULD_NOT_BE_INITIALIZED("Check hive.zookeeper.quorum and hive.zookeeper.client.port"),
   OVERWRITE_ARCHIVED_PART("Cannot overwrite an archived partition. " +
       "Unarchive before running this command."),
@@ -328,7 +328,7 @@ public enum ErrorMsg {
   }
 
   private static void renderPosition(StringBuilder sb, ASTNode tree) {
-    sb.append("line ");
+    sb.append("Line ");
     sb.append(getLine(tree));
     sb.append(":");
     sb.append(getCharPositionInLine(tree));

Modified: hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ParseDriver.java
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ParseDriver.java?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ParseDriver.java (original)
+++ hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/parse/ParseDriver.java Sat May  7 23:14:58 2011
@@ -25,6 +25,7 @@ import java.util.HashMap;
 import org.antlr.runtime.ANTLRStringStream;
 import org.antlr.runtime.BitSet;
 import org.antlr.runtime.CharStream;
+import org.antlr.runtime.FailedPredicateException;
 import org.antlr.runtime.IntStream;
 import org.antlr.runtime.MismatchedTokenException;
 import org.antlr.runtime.NoViableAltException;
@@ -190,6 +191,7 @@ public class ParseDriver {
     xlateMap.put("TILDE", "~");
     xlateMap.put("BITWISEOR", "|");
     xlateMap.put("BITWISEXOR", "^");
+    xlateMap.put("CharSetLiteral", "\\'");
   }
 
   public static Collection<String> getKeywords() {
@@ -208,7 +210,7 @@ public class ParseDriver {
 
   /**
    * ANTLRNoCaseStringStream.
-   * 
+   *
    */
   //This class provides and implementation for a case insensitive token checker
   //for the lexical analysis part of antlr. By converting the token stream into
@@ -227,6 +229,7 @@ public class ParseDriver {
       super(input);
     }
 
+    @Override
     public int LA(int i) {
 
       int returnChar = super.LA(i);
@@ -258,12 +261,14 @@ public class ParseDriver {
       errors = new ArrayList<ParseError>();
     }
 
+    @Override
     public void displayRecognitionError(String[] tokenNames,
         RecognitionException e) {
 
       errors.add(new ParseError(this, e, tokenNames));
     }
 
+    @Override
     public String getErrorMessage(RecognitionException e, String[] tokenNames) {
       String msg = null;
 
@@ -301,27 +306,45 @@ public class ParseDriver {
       errors = new ArrayList<ParseError>();
     }
 
+    @Override
     protected void mismatch(IntStream input, int ttype, BitSet follow)
         throws RecognitionException {
 
       throw new MismatchedTokenException(ttype, input);
     }
 
+    @Override
     public void recoverFromMismatchedSet(IntStream input,
         RecognitionException re, BitSet follow) throws RecognitionException {
       throw re;
     }
 
+    @Override
     public void displayRecognitionError(String[] tokenNames,
         RecognitionException e) {
 
       errors.add(new ParseError(this, e, tokenNames));
     }
 
+    @Override
+    public String getErrorHeader(RecognitionException e) {
+      String header = null;
+      if (e.charPositionInLine < 0 && input.LT(-1) != null) {
+        Token t = input.LT(-1);
+        header = "line " + t.getLine() + ":" + t.getCharPositionInLine();
+      } else {
+        header = super.getErrorHeader(e);
+      }
+
+      return header;
+    }
+
+
+    @Override
     public String getErrorMessage(RecognitionException e, String[] tokenNames) {
       String msg = null;
 
-      // Transalate the token names to something that the user can understand
+      // Translate the token names to something that the user can understand
       String[] xlateNames = new String[tokenNames.length];
       for (int i = 0; i < tokenNames.length; ++i) {
         xlateNames[i] = ParseDriver.xlate(tokenNames[i]);
@@ -334,7 +357,16 @@ public class ParseDriver {
         // "decision=<<"+nvae.grammarDecisionDescription+">>"
         // and "(decision="+nvae.decisionNumber+") and
         // "state "+nvae.stateNumber
-        msg = "cannot recognize input " + getTokenErrorDisplay(e.token);
+        msg = "cannot recognize input near "
+                + getTokenErrorDisplay(e.token)
+                + (input.LT(2) != null ? " " + getTokenErrorDisplay(input.LT(2)) : "")
+                + (input.LT(3) != null ? " " + getTokenErrorDisplay(input.LT(3)) : "");
+      } else if (e instanceof MismatchedTokenException) {
+        MismatchedTokenException mte = (MismatchedTokenException) e;
+        msg = super.getErrorMessage(e, xlateNames) + (input.LT(-1) == null ? "":" near '" + input.LT(-1).getText()) + "'";
+      } else if (e instanceof FailedPredicateException) {
+        FailedPredicateException fpe = (FailedPredicateException) e;
+        msg = "Failed to recognize predicate '" + fpe.token.getText() + "'. Failed rule: '" + fpe.ruleName + "'";
       } else {
         msg = super.getErrorMessage(e, xlateNames);
       }
@@ -360,7 +392,7 @@ public class ParseDriver {
     /**
      * Creates an ASTNode for the given token. The ASTNode is a wrapper around
      * antlr's CommonTree class that implements the Node interface.
-     * 
+     *
      * @param payload
      *          The token.
      * @return Object (which is actually an ASTNode) for the token.
@@ -378,15 +410,15 @@ public class ParseDriver {
   /**
    * Parses a command, optionally assigning the parser's token stream to the
    * given context.
-   * 
+   *
    * @param command
    *          command to parse
-   * 
+   *
    * @param ctx
    *          context with which to associate this parser's token stream, or
    *          null if either no context is available or the context already has
    *          an existing stream
-   * 
+   *
    * @return parsed AST
    */
   public ASTNode parse(String command, Context ctx) throws ParseException {

Added: hive/trunk/ql/src/test/queries/clientnegative/select_charliteral.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/select_charliteral.q?rev=1100656&view=auto
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/select_charliteral.q (added)
+++ hive/trunk/ql/src/test/queries/clientnegative/select_charliteral.q Sat May  7 23:14:58 2011
@@ -0,0 +1,3 @@
+-- Check that charSetLiteral syntax conformance
+-- Check that a sane error message with correct line/column numbers is emitted with helpful context tokens.
+select _c17, count(1) from tmp_tl_foo group by _c17

Modified: hive/trunk/ql/src/test/results/clientnegative/alter_view_failure6.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/alter_view_failure6.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/alter_view_failure6.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/alter_view_failure6.q.out Sat May  7 23:14:58 2011
@@ -7,13 +7,13 @@ PARTITIONED ON (key)
 AS 
 SELECT hr,key FROM srcpart
 PREHOOK: type: CREATEVIEW
-PREHOOK: Output: file:/var/folders/7P/7PeC14kXFIWq0PIYyexGbmKuXUk/-Tmp-/jsichi/hive_2011-02-08_18-38-11_186_2914437704768475613/-mr-10000
+PREHOOK: Output: file:/var/folders/5V/5V4Zq77qGD4aSK9m8V3frVsFdRU/-Tmp-/salbiz/hive_2011-05-05_20-49-19_135_259619293580272140/-mr-10000
 POSTHOOK: query: CREATE VIEW xxx7
 PARTITIONED ON (key)
 AS 
 SELECT hr,key FROM srcpart
 POSTHOOK: type: CREATEVIEW
 POSTHOOK: Output: default@xxx7
-POSTHOOK: Output: file:/var/folders/7P/7PeC14kXFIWq0PIYyexGbmKuXUk/-Tmp-/jsichi/hive_2011-02-08_18-38-11_186_2914437704768475613/-mr-10000
-FAILED: Error in semantic analysis: No Partition Predicate Found for Alias "xxx7:srcpart" Table "srcpart"
+POSTHOOK: Output: file:/var/folders/5V/5V4Zq77qGD4aSK9m8V3frVsFdRU/-Tmp-/salbiz/hive_2011-05-05_20-49-19_135_259619293580272140/-mr-10000
+FAILED: Error in semantic analysis: No partition predicate found for Alias "xxx7:srcpart" Table "srcpart"
 FAILED: Error in semantic analysis: The query does not reference any valid partition. To run this query, set hive.mapred.mode=nonstrict

Modified: hive/trunk/ql/src/test/results/clientnegative/ambiguous_col.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/ambiguous_col.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/ambiguous_col.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/ambiguous_col.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: Ambiguous Column Reference key
+FAILED: Error in semantic analysis: Ambiguous column reference key

Modified: hive/trunk/ql/src/test/results/clientnegative/bad_sample_clause.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/bad_sample_clause.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/bad_sample_clause.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/bad_sample_clause.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(key INT, value STRING, dt STRING, hr STRING) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: Sampling Expression Needed for Non-Bucketed Table srcpart
+FAILED: Error in semantic analysis: Sampling expression needed for non-bucketed table srcpart

Modified: hive/trunk/ql/src/test/results/clientnegative/clusterbydistributeby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/clusterbydistributeby.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/clusterbydistributeby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/clusterbydistributeby.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(key INT, ten INT, one INT, value STRING) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: line 8:14 Cannot have both Cluster By and Distribute By Clauses tkey
+FAILED: Error in semantic analysis: Line 8:14 Cannot have both CLUSTER BY and DISTRIBUTE BY clauses tkey

Modified: hive/trunk/ql/src/test/results/clientnegative/clusterbyorderby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/clusterbyorderby.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/clusterbyorderby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/clusterbyorderby.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 5:0 mismatched input 'ORDER' expecting EOF
+FAILED: Parse Error: line 5:0 mismatched input 'ORDER' expecting EOF near 'tkey'
 

Modified: hive/trunk/ql/src/test/results/clientnegative/clusterbysortby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/clusterbysortby.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/clusterbysortby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/clusterbysortby.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(key INT, ten INT, one INT, value STRING) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: line 8:8 Cannot have both Cluster By and Sort By Clauses one
+FAILED: Error in semantic analysis: Line 8:8 Cannot have both CLUSTER BY and SORT BY clauses one

Modified: hive/trunk/ql/src/test/results/clientnegative/clustern3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/clustern3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/clustern3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/clustern3.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:52 Invalid Column Reference key
+FAILED: Error in semantic analysis: Line 2:52 Invalid column reference key

Modified: hive/trunk/ql/src/test/results/clientnegative/clustern4.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/clustern4.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/clustern4.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/clustern4.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:50 Invalid Table Alias or Column Reference key
+FAILED: Error in semantic analysis: Line 2:50 Invalid table alias or column reference key

Modified: hive/trunk/ql/src/test/results/clientnegative/column_rename3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/column_rename3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/column_rename3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/column_rename3.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 0:-1 cannot recognize input '<EOF>' in column type
+FAILED: Parse Error: line 1:27 cannot recognize input near '<EOF>' '<EOF>' '<EOF>' in column type
 

Modified: hive/trunk/ql/src/test/results/clientnegative/create_view_failure3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/create_view_failure3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/create_view_failure3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/create_view_failure3.q.out Sat May  7 23:14:58 2011
@@ -2,4 +2,4 @@ PREHOOK: query: DROP VIEW xxx13
 PREHOOK: type: DROPVIEW
 POSTHOOK: query: DROP VIEW xxx13
 POSTHOOK: type: DROPVIEW
-FAILED: Error in semantic analysis: line 5:16 The number of columns produced by the SELECT clause does not match the number of column names specified by CREATE VIEW key
+FAILED: Error in semantic analysis: Line 5:16 The number of columns produced by the SELECT clause does not match the number of column names specified by CREATE VIEW key

Modified: hive/trunk/ql/src/test/results/clientnegative/drop_function_failure.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/drop_function_failure.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/drop_function_failure.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/drop_function_failure.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: Invalid Function UnknownFunction
+FAILED: Error in semantic analysis: Invalid function UnknownFunction

Modified: hive/trunk/ql/src/test/results/clientnegative/drop_index_failure.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/drop_index_failure.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/drop_index_failure.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/drop_index_failure.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: Invalid Index UnknownIndex
+FAILED: Error in semantic analysis: Invalid index UnknownIndex

Modified: hive/trunk/ql/src/test/results/clientnegative/drop_partition_failure.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/drop_partition_failure.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/drop_partition_failure.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/drop_partition_failure.q.out Sat May  7 23:14:58 2011
@@ -31,4 +31,4 @@ POSTHOOK: type: SHOWPARTITIONS
 b=1/c=1
 b=1/c=2
 b=2/c=2
-FAILED: Error in semantic analysis: line 3:31 Partition not found '3'
+FAILED: Error in semantic analysis: Line 3:31 Partition not found '3'

Modified: hive/trunk/ql/src/test/results/clientnegative/dyn_part2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/dyn_part2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/dyn_part2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/dyn_part2.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: create table nzhang_part1 (key string, value string) partitioned by (ds string, hr string)
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@nzhang_part1
-FAILED: Error in semantic analysis: line 3:23 Cannot insert into target table because column number/types are different hr: Table insclause-0 has 3 columns, but query has 2 columns.
+FAILED: Error in semantic analysis: Line 3:23 Cannot insert into target table because column number/types are different hr: Table insclause-0 has 3 columns, but query has 2 columns.

Modified: hive/trunk/ql/src/test/results/clientnegative/exim_00_unsupported_schema.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/exim_00_unsupported_schema.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/exim_00_unsupported_schema.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/exim_00_unsupported_schema.q.out Sat May  7 23:14:58 2011
@@ -13,4 +13,4 @@ PREHOOK: Output: default@exim_department
 POSTHOOK: query: load data local inpath "../data/files/test.dat" into table exim_department
 POSTHOOK: type: LOAD
 POSTHOOK: Output: default@exim_department
-FAILED: Error in semantic analysis: Invalid Path only the following file systems accepted for export/import : hdfs,pfile
+FAILED: Error in semantic analysis: Invalid path only the following file systems accepted for export/import : hdfs,pfile

Modified: hive/trunk/ql/src/test/results/clientnegative/fileformat_void_input.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/fileformat_void_input.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/fileformat_void_input.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/fileformat_void_input.q.out Sat May  7 23:14:58 2011
@@ -19,4 +19,4 @@ POSTHOOK: Input: default@src
 POSTHOOK: Output: default@dest1
 POSTHOOK: Lineage: dest1.key EXPRESSION [(src)src.FieldSchema(name:key, type:string, comment:default), ]
 POSTHOOK: Lineage: dest1.value SIMPLE [(src)src.FieldSchema(name:value, type:string, comment:default), ]
-FAILED: Error in semantic analysis: line 3:20 Input Format must implement InputFormat dest1
+FAILED: Error in semantic analysis: Line 3:20 Input format must implement InputFormat dest1

Modified: hive/trunk/ql/src/test/results/clientnegative/groupby2_map_skew_multi_distinct.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/groupby2_map_skew_multi_distinct.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/groupby2_map_skew_multi_distinct.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/groupby2_map_skew_multi_distinct.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(key STRING, c1 INT, c2 STRING, c3 INT, c4 INT) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: DISTINCT on Different Columns not Supported with skew in data
+FAILED: Error in semantic analysis: DISTINCT on different columns not supported with skew in data

Modified: hive/trunk/ql/src/test/results/clientnegative/groupby2_multi_distinct.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/groupby2_multi_distinct.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/groupby2_multi_distinct.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/groupby2_multi_distinct.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest_g2(key STRING, c1 INT, c2 STRING, c3 INT, c4 INT) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest_g2
-FAILED: Error in semantic analysis: DISTINCT on Different Columns not Supported with skew in data
+FAILED: Error in semantic analysis: DISTINCT on different columns not supported with skew in data

Modified: hive/trunk/ql/src/test/results/clientnegative/groupby3_map_skew_multi_distinct.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/groupby3_map_skew_multi_distinct.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/groupby3_map_skew_multi_distinct.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/groupby3_map_skew_multi_distinct.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(c1 DOUBLE, c2 DOUBLE, c3 DOUBLE, c4 DOUBLE, c5 DOUBLE, c6 DOUBLE, c7 DOUBLE, c8 DOUBLE, c9 DOUBLE, c10 DOUBLE, c11 DOUBLE) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: DISTINCT on Different Columns not Supported with skew in data
+FAILED: Error in semantic analysis: DISTINCT on different columns not supported with skew in data

Modified: hive/trunk/ql/src/test/results/clientnegative/groupby3_multi_distinct.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/groupby3_multi_distinct.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/groupby3_multi_distinct.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/groupby3_multi_distinct.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(c1 DOUBLE, c2 DOUBLE, c3 DOUBLE, c4 DOUBLE, c5 DOUBLE, c6 DOUBLE, c7 DOUBLE, c8 DOUBLE, c9 DOUBLE, c10 DOUBLE, c11 DOUBLE) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: DISTINCT on Different Columns not Supported with skew in data
+FAILED: Error in semantic analysis: DISTINCT on different columns not supported with skew in data

Modified: hive/trunk/ql/src/test/results/clientnegative/groupby_key.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/groupby_key.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/groupby_key.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/groupby_key.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:14 Expression Not In Group By Key value
+FAILED: Error in semantic analysis: Line 1:14 Expression not in GROUP BY key value

Modified: hive/trunk/ql/src/test/results/clientnegative/input1.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/input1.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/input1.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/input1.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Invalid Table Alias a
+FAILED: Error in semantic analysis: Line 1:7 Invalid table alias a

Modified: hive/trunk/ql/src/test/results/clientnegative/input2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/input2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/input2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/input2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Invalid Table Alias or Column Reference a
+FAILED: Error in semantic analysis: Line 1:7 Invalid table alias or column reference a

Modified: hive/trunk/ql/src/test/results/clientnegative/input_part0_neg.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/input_part0_neg.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/input_part0_neg.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/input_part0_neg.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: No Partition Predicate Found for Alias "x" Table "srcpart"
+FAILED: Error in semantic analysis: No partition predicate found for Alias "x" Table "srcpart"

Modified: hive/trunk/ql/src/test/results/clientnegative/invalid_create_tbl2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/invalid_create_tbl2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/invalid_create_tbl2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/invalid_create_tbl2.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 1:7 rule kwRole failed predicate: {input.LT(1).getText().equalsIgnoreCase("role")}? in create role
+FAILED: Parse Error: line 1:7 Failed to recognize predicate 'tabl'. Failed rule: 'kwRole' in create role
 

Modified: hive/trunk/ql/src/test/results/clientnegative/invalid_select_expression.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/invalid_select_expression.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/invalid_select_expression.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/invalid_select_expression.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 1:32 cannot recognize input '.' in expression specification
+FAILED: Parse Error: line 1:32 cannot recognize input near '.' 'foo' '<EOF>' in expression specification
 

Modified: hive/trunk/ql/src/test/results/clientnegative/invalid_tbl_name.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/invalid_tbl_name.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/invalid_tbl_name.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/invalid_tbl_name.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 1:20 cannot recognize input '-' in create table statement
+FAILED: Parse Error: line 1:20 cannot recognize input near '-' 'name' '(' in create table statement
 

Modified: hive/trunk/ql/src/test/results/clientnegative/invalidate_view1.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/invalidate_view1.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/invalidate_view1.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/invalidate_view1.q.out Sat May  7 23:14:58 2011
@@ -19,18 +19,18 @@ POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@xxx10
 PREHOOK: query: CREATE VIEW xxx9 AS SELECT * FROM xxx10
 PREHOOK: type: CREATEVIEW
-PREHOOK: Output: file:/tmp/njain/hive_2010-08-16_23-08-55_315_6053999460183300682/-mr-10000
+PREHOOK: Output: file:/var/folders/5V/5V4Zq77qGD4aSK9m8V3frVsFdRU/-Tmp-/salbiz/hive_2011-05-05_20-52-14_588_3232160525939411769/-mr-10000
 POSTHOOK: query: CREATE VIEW xxx9 AS SELECT * FROM xxx10
 POSTHOOK: type: CREATEVIEW
-POSTHOOK: Output: file:/tmp/njain/hive_2010-08-16_23-08-55_315_6053999460183300682/-mr-10000
 POSTHOOK: Output: default@xxx9
+POSTHOOK: Output: file:/var/folders/5V/5V4Zq77qGD4aSK9m8V3frVsFdRU/-Tmp-/salbiz/hive_2011-05-05_20-52-14_588_3232160525939411769/-mr-10000
 PREHOOK: query: CREATE VIEW xxx8 AS SELECT * FROM xxx9 xxx
 PREHOOK: type: CREATEVIEW
-PREHOOK: Output: file:/tmp/njain/hive_2010-08-16_23-08-55_367_8780672183290065174/-mr-10000
+PREHOOK: Output: file:/var/folders/5V/5V4Zq77qGD4aSK9m8V3frVsFdRU/-Tmp-/salbiz/hive_2011-05-05_20-52-14_617_9002044296975800480/-mr-10000
 POSTHOOK: query: CREATE VIEW xxx8 AS SELECT * FROM xxx9 xxx
 POSTHOOK: type: CREATEVIEW
-POSTHOOK: Output: file:/tmp/njain/hive_2010-08-16_23-08-55_367_8780672183290065174/-mr-10000
 POSTHOOK: Output: default@xxx8
+POSTHOOK: Output: file:/var/folders/5V/5V4Zq77qGD4aSK9m8V3frVsFdRU/-Tmp-/salbiz/hive_2011-05-05_20-52-14_617_9002044296975800480/-mr-10000
 PREHOOK: query: ALTER TABLE xxx10 REPLACE COLUMNS (key int)
 PREHOOK: type: ALTERTABLE_REPLACECOLS
 PREHOOK: Input: default@xxx10
@@ -39,8 +39,8 @@ POSTHOOK: query: ALTER TABLE xxx10 REPLA
 POSTHOOK: type: ALTERTABLE_REPLACECOLS
 POSTHOOK: Input: default@xxx10
 POSTHOOK: Output: default@xxx10
-FAILED: Error in semantic analysis: line 1:30 Invalid Column Reference `value` in definition of VIEW xxx9 [
+FAILED: Error in semantic analysis: Line 1:30 Invalid column reference `value` in definition of VIEW xxx9 [
 SELECT `xxx10`.`key`, `xxx10`.`value` FROM `xxx10`
-] used as xxx at line 1:39 in definition of VIEW xxx8 [
+] used as xxx at Line 1:39 in definition of VIEW xxx8 [
 SELECT `xxx`.`key`, `xxx`.`value` FROM `xxx9` `xxx`
-] used as yyy at line 2:14
+] used as yyy at Line 2:14

Modified: hive/trunk/ql/src/test/results/clientnegative/join2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/join2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/join2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/join2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: Map Join cannot be performed with Outer join
+FAILED: Error in semantic analysis: MAPJOIN cannot be performed with OUTER JOIN

Modified: hive/trunk/ql/src/test/results/clientnegative/joinneg.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/joinneg.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/joinneg.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/joinneg.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 5:12 Invalid Table Alias b
+FAILED: Error in semantic analysis: Line 5:12 Invalid table alias b

Modified: hive/trunk/ql/src/test/results/clientnegative/lateral_view_join.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/lateral_view_join.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/lateral_view_join.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/lateral_view_join.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 1:59 mismatched input 'AS' expecting Identifier in table alias
+FAILED: Parse Error: line 1:59 mismatched input 'AS' expecting Identifier near ')' in table alias
 

Modified: hive/trunk/ql/src/test/results/clientnegative/load_part_nospec.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/load_part_nospec.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/load_part_nospec.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/load_part_nospec.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: create table hive_test_src ( col1 string ) partitioned by (pcol1 string) stored as textfile
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@hive_test_src
-FAILED: Error in semantic analysis: need to specify partition columns because the destination table is partitioned.
+FAILED: Error in semantic analysis: Need to specify partition columns because the destination table is partitioned.

Modified: hive/trunk/ql/src/test/results/clientnegative/load_wrong_noof_part.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/load_wrong_noof_part.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/load_wrong_noof_part.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/load_wrong_noof_part.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE loadpart1(a STRING, b STRING) PARTITIONED BY (ds STRING,ds1 STRING)
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@loadpart1
-FAILED: Error in semantic analysis: line 2:79 Partition not found '2009-05-05'
+FAILED: Error in semantic analysis: Line 2:79 Partition not found '2009-05-05'

Modified: hive/trunk/ql/src/test/results/clientnegative/nopart_insert.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/nopart_insert.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/nopart_insert.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/nopart_insert.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE nopart_insert(a STRING, b STRING) PARTITIONED BY (ds STRING)
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@nopart_insert
-FAILED: Error in semantic analysis: need to specify partition columns because the destination table is partitioned.
+FAILED: Error in semantic analysis: Need to specify partition columns because the destination table is partitioned.

Modified: hive/trunk/ql/src/test/results/clientnegative/nopart_load.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/nopart_load.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/nopart_load.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/nopart_load.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE nopart_load(a STRING, b STRING) PARTITIONED BY (ds STRING)
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@nopart_load
-FAILED: Error in semantic analysis: need to specify partition columns because the destination table is partitioned.
+FAILED: Error in semantic analysis: Need to specify partition columns because the destination table is partitioned.

Modified: hive/trunk/ql/src/test/results/clientnegative/notable_alias3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/notable_alias3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/notable_alias3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/notable_alias3.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(key INT, value DOUBLE) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: line 4:44 Expression Not In Group By Key src
+FAILED: Error in semantic analysis: Line 4:44 Expression not in GROUP BY key src

Modified: hive/trunk/ql/src/test/results/clientnegative/orderbysortby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/orderbysortby.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/orderbysortby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/orderbysortby.q.out Sat May  7 23:14:58 2011
@@ -3,4 +3,4 @@ PREHOOK: type: CREATETABLE
 POSTHOOK: query: CREATE TABLE dest1(key INT, ten INT, one INT, value STRING) STORED AS TEXTFILE
 POSTHOOK: type: CREATETABLE
 POSTHOOK: Output: default@dest1
-FAILED: Error in semantic analysis: line 8:8 Cannot have both Order By and Sort By Clauses one
+FAILED: Error in semantic analysis: Line 8:8 Cannot have both ORDER BY and SORT BY clauses one

Modified: hive/trunk/ql/src/test/results/clientnegative/regex_col_1.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/regex_col_1.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/regex_col_1.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/regex_col_1.q.out Sat May  7 23:14:58 2011
@@ -1,3 +1,3 @@
-FAILED: Error in semantic analysis: line 2:7 Invalid Column Reference `+++`: Dangling meta character '+' near index 0
+FAILED: Error in semantic analysis: Line 2:7 Invalid column reference `+++`: Dangling meta character '+' near index 0
 +++
 ^

Modified: hive/trunk/ql/src/test/results/clientnegative/regex_col_2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/regex_col_2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/regex_col_2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/regex_col_2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:7 Invalid Column Reference `.a.`
+FAILED: Error in semantic analysis: Line 2:7 Invalid column reference `.a.`

Modified: hive/trunk/ql/src/test/results/clientnegative/regex_col_groupby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/regex_col_groupby.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/regex_col_groupby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/regex_col_groupby.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:44 Invalid Table Alias or Column Reference `..`
+FAILED: Error in semantic analysis: Line 2:44 Invalid table alias or column reference `..`

Modified: hive/trunk/ql/src/test/results/clientnegative/sample.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/sample.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/sample.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/sample.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: Numberator should not be bigger than denaminator in sample clause for Table srcbucket
+FAILED: Error in semantic analysis: Numberator should not be bigger than denaminator in sample clause for table srcbucket

Added: hive/trunk/ql/src/test/results/clientnegative/select_charliteral.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/select_charliteral.q.out?rev=1100656&view=auto
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/select_charliteral.q.out (added)
+++ hive/trunk/ql/src/test/results/clientnegative/select_charliteral.q.out Sat May  7 23:14:58 2011
@@ -0,0 +1,2 @@
+FAILED: Parse Error: line 3:11 mismatched input ',' expecting \' near '_c17' in character string literal
+

Modified: hive/trunk/ql/src/test/results/clientnegative/select_udtf_alias.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/select_udtf_alias.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/select_udtf_alias.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/select_udtf_alias.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 3:49 mismatched input 'LIMIT' expecting FROM in from clause
+FAILED: Parse Error: line 3:49 mismatched input 'LIMIT' expecting FROM near ')' in from clause
 

Modified: hive/trunk/ql/src/test/results/clientnegative/semijoin1.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/semijoin1.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/semijoin1.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/semijoin1.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:7 Invalid Table Alias or Column Reference b
+FAILED: Error in semantic analysis: Line 2:7 Invalid table alias or column reference b

Modified: hive/trunk/ql/src/test/results/clientnegative/semijoin2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/semijoin2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/semijoin2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/semijoin2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:70 Invalid Table Alias or Column Reference b
+FAILED: Error in semantic analysis: Line 2:70 Invalid table alias or column reference b

Modified: hive/trunk/ql/src/test/results/clientnegative/semijoin3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/semijoin3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/semijoin3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/semijoin3.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:67 Invalid Table Alias or Column Reference b
+FAILED: Error in semantic analysis: Line 2:67 Invalid table alias or column reference b

Modified: hive/trunk/ql/src/test/results/clientnegative/semijoin4.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/semijoin4.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/semijoin4.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/semijoin4.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:112 Invalid Table Alias or Column Reference b
+FAILED: Error in semantic analysis: Line 2:112 Invalid table alias or column reference b

Modified: hive/trunk/ql/src/test/results/clientnegative/show_tables_bad1.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/show_tables_bad1.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/show_tables_bad1.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/show_tables_bad1.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 0:-1 mismatched input '<EOF>' expecting set null in Identifier for show statement
+FAILED: Parse Error: line 1:12 mismatched input '<EOF>' expecting set null in Identifier for show statement
 

Modified: hive/trunk/ql/src/test/results/clientnegative/show_tables_bad2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/show_tables_bad2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/show_tables_bad2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/show_tables_bad2.q.out Sat May  7 23:14:58 2011
@@ -1,2 +1,2 @@
-FAILED: Parse Error: line 0:-1 mismatched input '<EOF>' expecting set null in Identifier for show statement
+FAILED: Parse Error: line 1:25 mismatched input '<EOF>' expecting set null in Identifier for show statement
 

Modified: hive/trunk/ql/src/test/results/clientnegative/smb_bucketmapjoin.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/smb_bucketmapjoin.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/smb_bucketmapjoin.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/smb_bucketmapjoin.q.out Sat May  7 23:14:58 2011
@@ -34,4 +34,4 @@ POSTHOOK: Lineage: smb_bucket4_1.key EXP
 POSTHOOK: Lineage: smb_bucket4_1.value SIMPLE [(src)src.FieldSchema(name:value, type:string, comment:default), ]
 POSTHOOK: Lineage: smb_bucket4_2.key EXPRESSION [(src)src.FieldSchema(name:key, type:string, comment:default), ]
 POSTHOOK: Lineage: smb_bucket4_2.value SIMPLE [(src)src.FieldSchema(name:value, type:string, comment:default), ]
-FAILED: Error in semantic analysis: Map Join cannot be performed with Outer join
+FAILED: Error in semantic analysis: MAPJOIN cannot be performed with OUTER JOIN

Modified: hive/trunk/ql/src/test/results/clientnegative/strict_orderby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/strict_orderby.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/strict_orderby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/strict_orderby.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 4:44 In strict mode, limit must be specified if ORDER BY is present key
+FAILED: Error in semantic analysis: Line 4:44 In strict mode, if ORDER BY is specified, LIMIT must also be specified key

Modified: hive/trunk/ql/src/test/results/clientnegative/strict_pruning.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/strict_pruning.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/strict_pruning.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/strict_pruning.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: No Partition Predicate Found for Alias "srcpart" Table "srcpart"
+FAILED: Error in semantic analysis: No partition predicate found for Alias "srcpart" Table "srcpart"

Modified: hive/trunk/ql/src/test/results/clientnegative/subq_insert.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/subq_insert.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/subq_insert.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/subq_insert.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:38 Cannot insert in a Subquery. Inserting to table  src1
+FAILED: Error in semantic analysis: Line 2:38 Cannot insert in a subquery. Inserting to table  src1

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong1.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong1.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong1.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong1.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:22 Argument Type Mismatch 1: "array" expected at function ARRAY_CONTAINS, but "int" is found
+FAILED: Error in semantic analysis: Line 2:22 Argument type mismatch 1: "array" expected at function ARRAY_CONTAINS, but "int" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_array_contains_wrong2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:38 Argument Type Mismatch '2': "int" expected at function ARRAY_CONTAINS, but "string" is found
+FAILED: Error in semantic analysis: Line 2:38 Argument type mismatch '2': "int" expected at function ARRAY_CONTAINS, but "string" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:13 Argument Type Mismatch 1: The expressions after WHEN should have the same type with that after CASE: "string" is expected but "int" is found
+FAILED: Error in semantic analysis: Line 2:13 Argument type mismatch 1: The expressions after WHEN should have the same type with that after CASE: "string" is expected but "int" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 3:20 Argument Type Mismatch 4: The expressions after THEN should have the same type: "string" is expected but "int" is found
+FAILED: Error in semantic analysis: Line 3:20 Argument type mismatch 4: The expressions after THEN should have the same type: "string" is expected but "int" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_case_type_wrong3.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 4:13 Argument Type Mismatch 7: The expression after ELSE should have the same type as those after THEN: "string" is expected but "int" is found
+FAILED: Error in semantic analysis: Line 4:13 Argument type mismatch 7: The expression after ELSE should have the same type as those after THEN: "string" is expected but "int" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_coalesce.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_coalesce.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_coalesce.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_coalesce.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:19 Argument Type Mismatch 2.0: The expressions after COALESCE should all have the same type: "int" is expected but "double" is found
+FAILED: Error in semantic analysis: Line 1:19 Argument type mismatch 2.0: The expressions after COALESCE should all have the same type: "int" is expected but "double" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_args_len.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_args_len.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_args_len.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_args_len.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Arguments Length Mismatch 3: The function ELT(N,str1,str2,str3,...) needs at least two arguments.
+FAILED: Error in semantic analysis: Line 1:7 Arguments length mismatch 3: The function ELT(N,str1,str2,str3,...) needs at least two arguments.

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_type.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_type.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_type.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_elt_wrong_type.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:14 Argument Type Mismatch lintstring: The 2nd argument of function ELT is expected to a primitive type, but list is found
+FAILED: Error in semantic analysis: Line 2:14 Argument type mismatch lintstring: The 2nd argument of function ELT is expected to a primitive type, but list is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_args_len.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_args_len.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_args_len.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_args_len.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Wrong Arguments 3: The function FIELD(str, str1, str2, ...) needs at least two arguments.
+FAILED: Error in semantic analysis: Line 1:7 Wrong arguments 3: The function FIELD(str, str1, str2, ...) needs at least two arguments.

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_type.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_type.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_type.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_field_wrong_type.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:16 Argument Type Mismatch lintstring: The 2nd argument of function FIELD is expected to a primitive type, but list is found
+FAILED: Error in semantic analysis: Line 2:16 Argument type mismatch lintstring: The 2nd argument of function FIELD is expected to a primitive type, but list is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_if_not_bool.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_if_not_bool.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_if_not_bool.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_if_not_bool.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:10 Argument Type Mismatch 'STRING': The first argument of function IF should be "boolean", but "string" is found
+FAILED: Error in semantic analysis: Line 1:10 Argument type mismatch 'STRING': The first argument of function IF should be "boolean", but "string" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_if_wrong_args_len.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_if_wrong_args_len.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_if_wrong_args_len.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_if_wrong_args_len.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Arguments Length Mismatch 1: The function IF(expr1,expr2,expr3) accepts exactly 3 arguments.
+FAILED: Error in semantic analysis: Line 1:7 Arguments length mismatch 1: The function IF(expr1,expr2,expr3) accepts exactly 3 arguments.

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_in.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_in.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_in.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_in.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:9 Wrong Arguments 3: The arguments for IN should be the same type! Types are: {int IN (array<int>)}
+FAILED: Error in semantic analysis: Line 1:9 Wrong arguments 3: The arguments for IN should be the same type! Types are: {int IN (array<int>)}

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_args_len.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_args_len.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_args_len.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_args_len.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Arguments Length Mismatch 'abcd': The function INSTR accepts exactly 2 arguments.
+FAILED: Error in semantic analysis: Line 1:7 Arguments length mismatch 'abcd': The function INSTR accepts exactly 2 arguments.

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_type.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_type.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_type.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_instr_wrong_type.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:21 Argument Type Mismatch lintstring: The 2nd argument of function INSTR is expected to a primitive type, but list is found
+FAILED: Error in semantic analysis: Line 2:21 Argument type mismatch lintstring: The 2nd argument of function INSTR is expected to a primitive type, but list is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_args_len.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_args_len.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_args_len.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_args_len.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:7 Arguments Length Mismatch 2: The function LOCATE accepts exactly 2 or 3 arguments.
+FAILED: Error in semantic analysis: Line 1:7 Arguments length mismatch 2: The function LOCATE accepts exactly 2 or 3 arguments.

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_type.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_type.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_type.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_locate_wrong_type.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:22 Argument Type Mismatch lintstring: The 2nd argument of function LOCATE is expected to a primitive type, but list is found
+FAILED: Error in semantic analysis: Line 2:22 Argument type mismatch lintstring: The 2nd argument of function LOCATE is expected to a primitive type, but list is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_args_len.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_args_len.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_args_len.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_args_len.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 2:7 Arguments Length Mismatch lintstring: The function SIZE only accepts 1 argument.
+FAILED: Error in semantic analysis: Line 2:7 Arguments length mismatch lintstring: The function SIZE only accepts 1 argument.

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_type.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_type.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_type.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_size_wrong_type.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 1:12 Argument Type Mismatch 'wrong type: string': "map" or "list" is expected at function SIZE, but "string" is found
+FAILED: Error in semantic analysis: Line 1:12 Argument type mismatch 'wrong type: string': "map" or "list" is expected at function SIZE, but "string" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 3:13 Argument Type Mismatch '1': "boolean" is expected after WHEN, but "string" is found
+FAILED: Error in semantic analysis: Line 3:13 Argument type mismatch '1': "boolean" is expected after WHEN, but "string" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong2.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong2.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 3:22 Argument Type Mismatch 4: The expressions after THEN should have the same type: "string" is expected but "int" is found
+FAILED: Error in semantic analysis: Line 3:22 Argument type mismatch 4: The expressions after THEN should have the same type: "string" is expected but "int" is found

Modified: hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong3.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong3.q.out?rev=1100656&r1=1100655&r2=1100656&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong3.q.out (original)
+++ hive/trunk/ql/src/test/results/clientnegative/udf_when_type_wrong3.q.out Sat May  7 23:14:58 2011
@@ -1 +1 @@
-FAILED: Error in semantic analysis: line 4:13 Argument Type Mismatch 5.3: The expression after ELSE should have the same type as those after THEN: "string" is expected but "double" is found
+FAILED: Error in semantic analysis: Line 4:13 Argument type mismatch 5.3: The expression after ELSE should have the same type as those after THEN: "string" is expected but "double" is found