You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by su...@apache.org on 2015/05/15 00:55:16 UTC

[1/2] hive git commit: Add RELEASE_NOTES for previous releases

Repository: hive
Updated Branches:
  refs/heads/branch-1.1.1 984637541 -> 3e8d832a1


http://git-wip-us.apache.org/repos/asf/hive/blob/3e8d832a/RELEASE_NOTES.txt
----------------------------------------------------------------------
diff --git a/RELEASE_NOTES.txt b/RELEASE_NOTES.txt
index e526979..3f7f368 100644
--- a/RELEASE_NOTES.txt
+++ b/RELEASE_NOTES.txt
@@ -2,3 +2,4995 @@ Release Notes - Hive - Version 1.1.1
 
 ** Bug
     * [HIVE-10573] - Improve Hive service for connection
+
+
+
+Release Notes - Hive - Version 1.1.0
+
+** Sub-task
+    * [HIVE-7073] - Implement Binary in ParquetSerDe
+    * [HIVE-8121] - Create micro-benchmarks for ParquetSerde and evaluate performance
+    * [HIVE-8122] - Make use of SearchArgument classes for Parquet SERDE
+    * [HIVE-8130] - Support Date in Avro
+    * [HIVE-8131] - Support timestamp in Avro
+    * [HIVE-8362] - Investigate flaky test parallel.q
+    * [HIVE-8651] - CBO: sort column changed in infer_bucket_sort test
+    * [HIVE-8707] - Fix ordering differences due to Java 8 HashMap function
+    * [HIVE-8718] - Refactoring: move mapLocalWork field from MapWork to BaseWork
+    * [HIVE-8773] - Fix TestWebHCatE2e#getStatus for Java8
+    * [HIVE-8862] - Fix ordering diferences on TestParse tests due to Java8
+    * [HIVE-8922] - CBO: assorted date and timestamp issues
+    * [HIVE-8923] - HIVE-8512 needs to be fixed also for CBO
+    * [HIVE-8936] - Add SORT_QUERY_RESULTS for join tests that do not guarantee order
+    * [HIVE-8962] - Add SORT_QUERY_RESULTS for join tests that do not guarantee order #2
+    * [HIVE-9030] - CBO: Plans with comparison of values with different types
+    * [HIVE-9033] - Fix ordering differences due to Java8 (part 2)
+    * [HIVE-9034] - CBO: type change in literal_ints.q
+    * [HIVE-9035] - CBO: Disable PPD when functions are non-deterministic (ppd_random.q  - non-deterministic udf rand() pushed above join)
+    * [HIVE-9043] - HiveException: Conflict on row inspector for {table}
+    * [HIVE-9066] - temporarily disable CBO for non-deterministic functions
+    * [HIVE-9104] - windowing.q failed when mapred.reduce.tasks is set to larger than one
+    * [HIVE-9109] - Add support for Java 8 specific q-test out files
+    * [HIVE-9127] - Improve CombineHiveInputFormat.getSplit performance
+    * [HIVE-9133] - CBO (Calcite Return Path): Refactor Semantic Analyzer to Move CBO code out 
+    * [HIVE-9153] - Perf enhancement on CombineHiveInputFormat and HiveInputFormat
+    * [HIVE-9161] - Fix ordering differences on UDF functions due to Java8
+    * [HIVE-9181] - Fix SkewJoinOptimizer related Java 8 ordering differences
+    * [HIVE-9193] - Fix ordering differences due to Java 8 (Part 3)
+    * [HIVE-9194] - Support select distinct *
+    * [HIVE-9200] - CBO (Calcite Return Path): Inline Join, Properties
+    * [HIVE-9206] - Fix Desc Formatted related Java 8 ordering differences
+    * [HIVE-9222] - Fix ordering differences due to Java 8 (Part 4)
+    * [HIVE-9224] - CBO (Calcite Return Path): Inline Table, Properties
+    * [HIVE-9239] - Fix ordering differences due to Java 8 (Part 5)
+    * [HIVE-9241] - Fix TestCliDriver.testCliDriver_subquery_multiinsert
+    * [HIVE-9257] - Merge from spark to trunk January 2015
+    * [HIVE-9259] - Fix ClassCastException when CBO is enabled for HOS [Spark Branch]
+    * [HIVE-9264] - Merge encryption branch to trunk
+    * [HIVE-9292] - CBO (Calcite Return Path): Inline GroupBy, Properties
+    * [HIVE-9315] - CBO (Calcite Return Path): Inline FileSinkOperator, Properties
+    * [HIVE-9352] - Merge from spark to trunk (follow-up of HIVE-9257)
+    * [HIVE-9409] - Avoid ser/de loggers as logging framework can be incompatible on driver and workers
+    * [HIVE-9410] - ClassNotFoundException occurs during hive query case execution with UDF defined [Spark Branch]
+    * [HIVE-9428] - LocalSparkJobStatus may return failed job as successful [Spark Branch]
+    * [HIVE-9431] - CBO (Calcite Return Path): Removing AST from ParseContext
+    * [HIVE-9434] - Shim the method Path.getPathWithoutSchemeAndAuthority
+    * [HIVE-9444] - CBO (Calcite Return Path): Rewrite GlobalLimitOptimizer
+    * [HIVE-9449] - Push YARN configuration to Spark while deply Spark on YARN[Spark Branch]
+    * [HIVE-9450] - [Parquet] Check all data types work for Parquet in Group By operator
+    * [HIVE-9477] - No error thrown when global limit optimization failed to find enough number of rows [Spark Branch]
+    * [HIVE-9487] - Make Remote Spark Context secure [Spark Branch]
+    * [HIVE-9493] - Failed job may not throw exceptions [Spark Branch]
+
+** Bug
+    * [HIVE-9705] - All curator deps should be listed in dependency management section
+    * [HIVE-9707] - ExecDriver does not get token from environment
+    * [HIVE-9701] - JMH module does not compile under hadoop-1 profile
+    * [HIVE-9686] - HiveMetastore.logAuditEvent can be used before sasl server is started
+    * [HIVE-9685] - CLIService should create SessionState after logging into kerberos
+    * [HIVE-9425] - Add jar/file doesn't work with yarn-cluster mode [Spark Branch]
+    * [HIVE-9684] - Incorrect disk range computation in ORC because of optional stream kind
+    * [HIVE-1344] - error in select disinct
+    * [HIVE-1654] - select distinct should allow column name regex
+    * [HIVE-1869] - TestMTQueries failing on jenkins
+    * [HIVE-3781] - Index related events should be delivered to metastore event listener
+    * [HIVE-4009] - CLI Tests fail randomly due to MapReduce LocalJobRunner race condition
+    * [HIVE-5536] - Incorrect Operation Name is passed to hookcontext
+    * [HIVE-5631] - Index creation on a skew table fails
+    * [HIVE-5664] - Drop cascade database fails when the db has any tables with indexes
+    * [HIVE-5865] - AvroDeserializer incorrectly assumes keys to Maps will always be of type 'org.apache.avro.util.Utf8'
+    * [HIVE-6165] - Unify HivePreparedStatement from jdbc:hive and jdbc:hive2
+    * [HIVE-6198] - ORC file and struct column names are case sensitive
+    * [HIVE-6308] - COLUMNS_V2 Metastore table not populated for tables created without an explicit column list.
+    * [HIVE-6421] - abs() should preserve precision/scale of decimal input
+    * [HIVE-6468] - HS2 & Metastore using SASL out of memory error when curl sends a get request
+    * [HIVE-6623] - Add "owner" tag to ptest2 created instances
+    * [HIVE-6679] - HiveServer2 should support configurable the server side socket timeout and keepalive for various transports types where applicable
+    * [HIVE-6683] - Beeline does not accept comments at end of line
+    * [HIVE-6914] - parquet-hive cannot write nested map (map value is map)
+    * [HIVE-7024] - Escape control characters for explain result
+    * [HIVE-7069] - Zookeeper connection leak
+    * [HIVE-7270] - SerDe Properties are not considered by show create table Command
+    * [HIVE-7932] - It may cause NP exception when add accessed columns to ReadEntity
+    * [HIVE-7951] - InputFormats implementing (Job)Configurable should not be cached
+    * [HIVE-7997] - Potential null pointer reference in ObjectInspectorUtils#compareTypes()
+    * [HIVE-8099] - IN operator for partition column fails when the partition column type is DATE
+    * [HIVE-8182] - beeline fails when executing multiple-line queries with trailing spaces
+    * [HIVE-8257] - Accumulo introduces old hadoop-client dependency
+    * [HIVE-8266] - create function using <resource> statement compilation should include resource URI entity
+    * [HIVE-8284] - Equality comparison is done between two floating point variables in HiveRelMdUniqueKeys#getUniqueKeys()
+    * [HIVE-8295] - Add batch retrieve partition objects for metastore direct sql 
+    * [HIVE-8308] - Acid related table properties should be defined in one place and should be case insensitive
+    * [HIVE-8317] - WebHCat pom should explicitly depend on jersey-core
+    * [HIVE-8326] - Using DbTxnManager with concurrency off results in run time error
+    * [HIVE-8330] - HiveResultSet.findColumn() parameters are case sensitive
+    * [HIVE-8338] - Add ip and command to semantic analyzer hook context
+    * [HIVE-8345] - q-test for Avro date support
+    * [HIVE-8359] - Map containing null values are not correctly written in Parquet files
+    * [HIVE-8374] - schematool fails on Postgres versions < 9.2
+    * [HIVE-8381] - Update hive version on trunk to 0.15
+    * [HIVE-8387] - add retry logic to ZooKeeperStorage in WebHCat
+    * [HIVE-8448] - Union All might not work due to the type conversion issue
+    * [HIVE-8450] - Create table like does not copy over table properties
+    * [HIVE-8485] - HMS on Oracle incompatibility
+    * [HIVE-8491] - Fix build name in ptest pre-commit message
+    * [HIVE-8500] - beeline does not need to set hive.aux.jars.path
+    * [HIVE-8512] - queries with star and gby produce incorrect results
+    * [HIVE-8518] - Compile time skew join optimization returns duplicated results
+    * [HIVE-8523] - Potential null dereference in DDLSemanticAnalyzer#addInputsOutputsAlterTable()
+    * [HIVE-8532] - return code of "source xxx" clause is missing
+    * [HIVE-8556] - introduce overflow control and sanity check to BytesBytesMapJoin
+    * [HIVE-8564] - DROP TABLE IF EXISTS throws exception if the table does not exist.  
+    * [HIVE-8565] - beeline may go into an infinite loop when using EOF
+    * [HIVE-8576] - Guaranteed NPE in StatsRulesProcFactory
+    * [HIVE-8594] - Wrong condition in SettableConfigUpdater#setHiveConfWhiteList()
+    * [HIVE-8600] - Add option to log explain output for query
+    * [HIVE-8610] - Compile time skew join optimization doesn't work with auto map join
+    * [HIVE-8611] - grant/revoke syntax should support additional objects for authorization plugins
+    * [HIVE-8612] - Support metadata result filter hooks
+    * [HIVE-8613] - percentile_approx raise a comparator error
+    * [HIVE-8627] - Compute stats on a table from impala caused the table to be corrupted
+    * [HIVE-8634] - HiveServer2 fair scheduler queue mapping doesn't handle the secondary groups rules correctly
+    * [HIVE-8636] - CBO: split cbo_correctness test
+    * [HIVE-8666] - hive.metastore.server.max.threads default is too high
+    * [HIVE-8680] - Set Max Message for Binary Thrift endpoints
+    * [HIVE-8693] - Separate out fair scheduler dependency from hadoop 0.23 shim
+    * [HIVE-8706] - Table statistic collection on counter failed due to table name character case.
+    * [HIVE-8708] - Add query id to explain log option
+    * [HIVE-8715] - Hive 14 upgrade scripts can fail for statistics if database was created using auto-create
+    * [HIVE-8720] - Update orc_merge tests to make it consistent across OS'es
+    * [HIVE-8728] - Fix ptf.q determinism
+    * [HIVE-8730] - schemaTool failure when date partition has non-date value
+    * [HIVE-8736] - add ordering to cbo_correctness to make result consistent
+    * [HIVE-8739] - handle Derby and Oracle errors with joins and filters in Direct SQL in a invalid-DB-specific path
+    * [HIVE-8757] - YARN dep in scheduler shim should be optional
+    * [HIVE-8762] - HiveMetaStore.BooleanPointer should be replaced with an AtomicBoolean
+    * [HIVE-8784] - Querying partition does not work with JDO enabled against PostgreSQL
+    * [HIVE-8791] - Hive permission inheritance throws exception S3
+    * [HIVE-8796] - TestCliDriver acid tests with decimal needs benchmark to be updated
+    * [HIVE-8797] - Simultaneous dynamic inserts can result in "partition already exists" error
+    * [HIVE-8803] - DESC SCHEMA <DATABASE-NAME> is not working
+    * [HIVE-8805] - CBO skipped due to SemanticException: Line 0:-1 Both left and right aliases encountered in JOIN 'avg_cs_ext_discount_amt'
+    * [HIVE-8808] - HiveInputFormat caching cannot work with all input formats
+    * [HIVE-8811] - Dynamic partition pruning can result in NPE during query compilation
+    * [HIVE-8812] - TestMinimrCliDriver failure if run in the same command as TestHBaseNegativeCliDriver
+    * [HIVE-8825] - SQLCompletor catches Throwable and ignores it
+    * [HIVE-8827] - Remove SSLv2Hello from list of disabled protocols
+    * [HIVE-8830] - hcatalog process don't exit because of non daemon thread
+    * [HIVE-8845] - Switch to Tez 0.5.2
+    * [HIVE-8847] - Fix bugs in jenkins scripts
+    * [HIVE-8848] - data loading from text files or text file processing doesn't handle nulls correctly
+    * [HIVE-8850] - ObjectStore:: rollbackTransaction() needs to be looked into further.
+    * [HIVE-8863] - Cannot drop table with uppercase name after "compute statistics for columns"
+    * [HIVE-8866] - Vectorization on partitioned table throws ArrayIndexOutOfBoundsException when partitions are not of same #of columns
+    * [HIVE-8869] - RowSchema not updated for some ops when columns are pruned
+    * [HIVE-8870] - errors when selecting a struct field within an array from ORC based tables
+    * [HIVE-8872] - Hive view of HBase range scan intermittently returns incorrect data.
+    * [HIVE-8873] - Switch to calcite 0.9.2
+    * [HIVE-8874] - Error Accessing HBase from Hive via Oozie on Kerberos 5.0.1 cluster
+    * [HIVE-8875] - hive.optimize.sort.dynamic.partition should be turned off for ACID
+    * [HIVE-8876] - incorrect upgrade script for Oracle (13->14)
+    * [HIVE-8877] - improve context logging during job submission via WebHCat
+    * [HIVE-8879] - Upgrade derby version to address race candition
+    * [HIVE-8880] - non-synchronized access to split list in OrcInputFormat
+    * [HIVE-8881] - Receiving json "{"error":"Could not find job job_1415748506143_0002"}" when web client tries to fetch all jobs from webhcat where HDFS does not have the data.
+    * [HIVE-8886] - Some Vectorized String CONCAT expressions result in runtime error Vectorization: Unsuported vector output type: StringGroup
+    * [HIVE-8888] - Mapjoin with LateralViewJoin generates wrong plan in Tez
+    * [HIVE-8889] - JDBC Driver ResultSet.getXXXXXX(String columnLabel) methods Broken
+    * [HIVE-8890] - HiveServer2 dynamic service discovery: use persistent ephemeral nodes curator recipe
+    * [HIVE-8891] - Another possible cause to NucleusObjectNotFoundException from drops/rollback
+    * [HIVE-8893] - Implement whitelist for builtin UDFs to avoid untrused code execution in multiuser mode
+    * [HIVE-8901] - increase retry attempt, interval on metastore database errors
+    * [HIVE-8909] - Hive doesn't correctly read Parquet nested types
+    * [HIVE-8914] - HDFSCleanup thread holds reference to FileSystem
+    * [HIVE-8916] - Handle user@domain username under LDAP authentication
+    * [HIVE-8917] - HIVE-5679 adds two thread safety problems
+    * [HIVE-8926] - Projections that only swap input columns are identified incorrectly as identity projections
+    * [HIVE-8938] - Compiler should save the transform URI as input entity
+    * [HIVE-8944] - TestCompactor fails with IncompatibleClassChangeError
+    * [HIVE-8947] - HIVE-8876 also affects Postgres < 9.2
+    * [HIVE-8948] - TestStreaming is flaky
+    * [HIVE-8964] - Some TestMiniTezCliDriver tests taking two hours
+    * [HIVE-8965] - Enhance PTest to kill all processes between tests and to report when a TEST*.xml file is not generated
+    * [HIVE-8967] - Fix bucketmapjoin7.q determinism
+    * [HIVE-8975] - Possible performance regression on bucket_map_join_tez2.q
+    * [HIVE-8978] - Fix test determinism issue for qfile: smb_mapjoin_1.q etc
+    * [HIVE-8990] - mapjoin_mapjoin.q is failing on Tez (missed golden file update)
+    * [HIVE-9001] - Ship with log4j.properties file that has a reliable time based rolling policy
+    * [HIVE-9003] - Vectorized IF expr broken for the scalar and scalar case
+    * [HIVE-9006] - hiveserver thrift api version is still 6
+    * [HIVE-9011] - Fix parquet_join.q determinism
+    * [HIVE-9024] - NullPointerException when starting webhcat server if templeton.hive.properties is not set
+    * [HIVE-9025] - join38.q (without map join) produces incorrect result when testing with multiple reducers
+    * [HIVE-9032] - Help for orcfiledump script does not reflect new options
+    * [HIVE-9048] - Hive build failed on hadoop-1 after HIVE-8828.
+    * [HIVE-9051] - TezJobMonitor in-place updates logs too often to logfile
+    * [HIVE-9053] - select constant in union all followed by group by gives wrong result
+    * [HIVE-9055] - Tez: union all followed by group by followed by another union all gives error
+    * [HIVE-9060] - Fix child operator references after NonBlockingOpDeDupProc
+    * [HIVE-9067] - OrcFileMergeOperator may create merge file that does not match properties of input files
+    * [HIVE-9077] - Set completer in CliDriver is not working
+    * [HIVE-9090] - Rename "Tez File Merge Work" to smaller name
+    * [HIVE-9096] - GenericUDF may be left unclosed in PartitionPrune#visitCall()
+    * [HIVE-9108] - Fix for HIVE-8735 is incorrect (stats with long paths)
+    * [HIVE-9111] - Potential NPE in OrcStruct for list and map types
+    * [HIVE-9112] - Query may generate different results depending on the number of reducers
+    * [HIVE-9113] - Explain on query failed with NPE
+    * [HIVE-9114] - union all query in cbo test has undefined ordering
+    * [HIVE-9120] - Hive Query log does not work when hive.exec.parallel is true
+    * [HIVE-9122] - Need to remove additional references to hive-shims-common-secure, hive-shims-0.20
+    * [HIVE-9126] - Backport HIVE-8827 (Remove SSLv2Hello from list of disabled protocols) to 0.14 branch
+    * [HIVE-9129] - Migrate to newer Calcite snapshot, where ByteString is now in org.apache.calcite.avatica.util
+    * [HIVE-9130] -  vector_partition_diff_num_cols result is not updated after CBO upgrade
+    * [HIVE-9131] - MiniTez optimize_nullscan test is unstable
+    * [HIVE-9141] - HiveOnTez: mix of union all, distinct, group by generates error
+    * [HIVE-9149] - Add unit test to test implicit conversion during dynamic partitioning/distribute by
+    * [HIVE-9150] - Unrelated types are compared in GenTezWork#getFollowingWorkIndex()
+    * [HIVE-9154] - Cache pathToPartitionInfo in context aware record reader
+    * [HIVE-9155] - HIVE_LOCKS uses int instead of bigint hive-txn-schema-0.14.0.mssql.sql
+    * [HIVE-9162] - stats19 test is environment-dependant
+    * [HIVE-9166] - Place an upper bound for SARG CNF conversion
+    * [HIVE-9168] - Vectorized Coalesce for strings is broken
+    * [HIVE-9177] - Fix child operator references after NonBlockingOpDeDupProc (II)
+    * [HIVE-9195] - CBO changes constant to column type
+    * [HIVE-9197] - fix lvj_mapjoin.q diff in trunk
+    * [HIVE-9199] - Excessive exclusive lock used in some DDLs with DummyTxnManager
+    * [HIVE-9203] - CREATE TEMPORARY FUNCTION hangs trying to acquire lock
+    * [HIVE-9205] - Change default tez install directory to use /tmp instead of /user and create the directory if it does not exist
+    * [HIVE-9215] - Some mapjoin queries broken with IdentityProjectRemover with PPD
+    * [HIVE-9221] - Remove deprecation warning for hive.metastore.local
+    * [HIVE-9234] - HiveServer2 leaks FileSystem objects in FileSystem.CACHE
+    * [HIVE-9242] - Many places in CBO code eat exceptions
+    * [HIVE-9243] - Static Map in IOContext is not thread safe
+    * [HIVE-9249] - java.lang.ClassCastException: org.apache.hadoop.hive.serde2.io.HiveVarcharWritable cannot be cast to org.apache.hadoop.hive.common.type.HiveVarchar when joining tables
+    * [HIVE-9255] - Fastpath for limited fetches from unpartitioned tables
+    * [HIVE-9296] - Need to add schema upgrade changes for queueing events in the database
+    * [HIVE-9299] - Reuse Configuration in AvroSerdeUtils
+    * [HIVE-9300] - Make TCompactProtocol configurable
+    * [HIVE-9301] - Potential null dereference in MoveTask#createTargetPath()
+    * [HIVE-9309] - schematool fails on Postgres 8.1
+    * [HIVE-9310] - CLI JLine does not flush history back to ~/.hivehistory
+    * [HIVE-9316] - TestSqoop tests in WebHCat testsuite hardcode libdir path to hdfs
+    * [HIVE-9317] - move Microsoft copyright to NOTICE file
+    * [HIVE-9321] - Notification message size can be arbitrarily long, DbNotificationListener limits to 1024
+    * [HIVE-9330] - DummyTxnManager will throw NPE if WriteEntity writeType has not been set
+    * [HIVE-9331] - get rid of pre-optimized-hashtable memory optimizations
+    * [HIVE-9344] - Fix flaky test optimize_nullscan
+    * [HIVE-9347] - Bug with max() together with rank() and grouping sets
+    * [HIVE-9351] - Running Hive Jobs with Tez cause templeton to never report percent complete
+    * [HIVE-9353] - make TABLE keyword optional in INSERT INTO TABLE foo...
+    * [HIVE-9359] - Export of a large table causes OOM in Metastore and Client
+    * [HIVE-9361] - Intermittent NPE in SessionHiveMetaStoreClient.alterTempTable
+    * [HIVE-9366] - wrong date in description annotation in date_add() and date_sub() udf
+    * [HIVE-9369] - fix arguments length checking in Upper and Lower UDF
+    * [HIVE-9377] - UDF in_file() in WHERE predicate causes NPE.
+    * [HIVE-9381] - HCatalog hardcodes maximum append limit to 1000.
+    * [HIVE-9382] - Query got rerun with Global Limit optimization on and Fetch optimization off
+    * [HIVE-9386] - FileNotFoundException when using in_file()
+    * [HIVE-9390] - Enhance retry logic wrt DB access in TxnHandler
+    * [HIVE-9393] - reduce noisy log level of ColumnarSerDe.java:116 from INFO to DEBUG
+    * [HIVE-9396] - date_add()/date_sub() should allow tinyint/smallint/bigint arguments in addition to int
+    * [HIVE-9401] - Backport: Fastpath for limited fetches from unpartitioned tables
+    * [HIVE-9404] - NPE in org.apache.hadoop.hive.metastore.txn.TxnHandler.determineDatabaseProduct()
+    * [HIVE-9414] - Fixup post HIVE-9264 - Merge encryption branch to trunk
+    * [HIVE-9437] - Beeline does not add any existing HADOOP_CLASSPATH
+    * [HIVE-9440] - Folders may not be pruned for Hadoop 2
+    * [HIVE-9441] - Remove call to deprecated Calcite method
+    * [HIVE-9443] - ORC PPD - fix fuzzy case evaluation of IS_NULL
+    * [HIVE-9445] - Revert HIVE-5700 - enforce single date format for partition column storage
+    * [HIVE-9446] - JDBC DatabaseMetadata.getColumns() does not work for temporary tables
+    * [HIVE-9448] - Merge spark to trunk 1/23/15
+    * [HIVE-9454] - Test failures due to new Calcite version
+    * [HIVE-9462] - HIVE-8577 - breaks type evolution
+    * [HIVE-9473] - sql std auth should disallow built-in udfs that allow any java methods to be called
+    * [HIVE-9475] - HiveMetastoreClient.tableExists does not work
+    * [HIVE-9476] - Beeline fails to start on trunk
+    * [HIVE-9502] - Parquet cannot read Map types from files written with Hive <= 0.12
+    * [HIVE-9514] - schematool is broken in hive 1.0.0
+    * [HIVE-9519] - Bump up spark client connection timeout
+    * [HIVE-9593] - ORC Reader should ignore unknown metadata streams 
+    * [HIVE-9610] - Continuation of HIVE-9438 - The standalone-jdbc jar missing some classes
+    * [HIVE-9611] - Allow SPARK_HOME as well as spark.home to define sparks location
+    * [HIVE-9621] - HiveServer2 http mode - embedded jetty should use SynchronousQueue
+    * [HIVE-9646] - Beeline doesn't show Spark job progress info [Spark Branch]
+    * [HIVE-9651] - FileSinkOperator does not pass in conf to serde.initialize
+
+** Improvement
+    * [HIVE-9708] - Remove testlibs directory
+    * [HIVE-9211] - Research on build mini HoS cluster on YARN for unit test
+    * [HIVE-9515] - Check hive.vectorized.execution.reduce.enabled
+    * [HIVE-9691] - Include a few more files include the source tarball
+    * [HIVE-2828] - make timestamp accessible in the hbase KeyValue 
+    * [HIVE-3187] - support ISO-2012 timestamp literals
+    * [HIVE-3280] - Make HiveMetaStoreClient a public API
+    * [HIVE-4639] - Add has null flag to ORC internal index
+    * [HIVE-4766] - Support HS2 client login timeout when the thrift thread max# is reached
+    * [HIVE-4809] - ReduceSinkOperator of PTFOperator can have redundant key columns
+    * [HIVE-5718] - Support direct fetch for lateral views, sub queries, etc.
+    * [HIVE-6148] - Support arbitrary structs stored in HBase
+    * [HIVE-7032] - Remove Triple Negative in Error 10129
+    * [HIVE-7313] - Allow in-memory/ssd session-level temp-tables
+    * [HIVE-7408] - HCatPartition needs getPartCols method
+    * [HIVE-7550] - Extend cached evaluation to multiple expressions
+    * [HIVE-7605] - add more javadoc to HivePrivilegeObject
+    * [HIVE-7685] - Parquet memory manager
+    * [HIVE-7858] - Parquet compression should be configurable via table property
+    * [HIVE-7868] - AvroSerDe error handling could be improved
+    * [HIVE-7896] - orcfiledump should be able to dump data
+    * [HIVE-7977] - Avoid creating serde for partitions if possible in FetchTask
+    * [HIVE-8094] - add LIKE keyword support for SHOW FUNCTIONS
+    * [HIVE-8155] -  In select statement after * any random characters are allowed in hive but in RDBMS its not allowed
+    * [HIVE-8337] - Change default of hive.warehouse.subdir.inherit.perms to true
+    * [HIVE-8347] - Use base-64 encoding instead of custom encoding for serialized objects
+    * [HIVE-8357] - Path type entities should use qualified path rather than string
+    * [HIVE-8395] - CBO: enable by default
+    * [HIVE-8424] - Support fair scheduler user queue mapping in non-impersonation mode
+    * [HIVE-8449] - webhcat startup does not create the log directory
+    * [HIVE-8469] - Add parquet.compression as a Serde Property
+    * [HIVE-8552] - Remove hard code of offline and make addHost api public
+    * [HIVE-8642] - Hive stack() UDTF Doesn't Support NULL Insert Values
+    * [HIVE-8661] - JDBC MinimizeJAR should be configurable in pom.xml
+    * [HIVE-8710] - Add more tests for transactional inserts
+    * [HIVE-8813] - Allow tests to be excluded based on pattern/regex
+    * [HIVE-8823] - Add additional serde properties for parquet
+    * [HIVE-8829] - Upgrade to Thrift 0.9.2
+    * [HIVE-8839] - Support "alter table .. add/replace columns cascade"
+    * [HIVE-8910] - Refactoring of PassThroughOutputFormat 
+    * [HIVE-8933] - Check release builds for SNAPSHOT dependencies
+    * [HIVE-8971] - HIVE-8965 exposed some classes which start with Test but are not tests
+    * [HIVE-8976] - Make nine additional tests deterministic
+    * [HIVE-8977] - TestParquetDirect should be abstract
+    * [HIVE-8983] - PTest Backup spark.log in addition to hive.log
+    * [HIVE-8988] - Support advanced aggregation in Hive to Calcite path 
+    * [HIVE-8996] - Rename getUGIForConf
+    * [HIVE-9037] - Improve explain plan to show joining keys for shuffle join
+    * [HIVE-9049] - Metastore should use TCompactProtocol as opposed to TBinaryProtocol
+    * [HIVE-9062] - Explain plan doesn't print join keys for Tez shuffle join
+    * [HIVE-9106] - improve the performance of null scan optimizer when several table scans share a physical path
+    * [HIVE-9119] - ZooKeeperHiveLockManager does not use zookeeper in the proper way
+    * [HIVE-9140] - Add Calcite's ReduceExpressionRules to Hive
+    * [HIVE-9158] - Multiple LDAP server URLs in hive.server2.authentication.ldap.url
+    * [HIVE-9176] - Delegation token interval should be configurable in HadoopThriftAuthBridge
+    * [HIVE-9189] - Add ProjectRemove rule on CBO path
+    * [HIVE-9226] - Beeline interweaves the query result and query log sometimes
+    * [HIVE-9244] - Upgrade 0.23 hadoop-shims to latest stable hadoop-2.6.0
+    * [HIVE-9314] - Writable object inspector should use Writable classes from Hadoop for get
+    * [HIVE-9318] - Add UnionMerge rule on cbo path
+    * [HIVE-9341] - Apply ColumnPrunning for noop PTFs
+    * [HIVE-9357] - Create ADD_MONTHS UDF
+    * [HIVE-9358] - Create LAST_DAY UDF
+    * [HIVE-9367] - CombineFileInputFormatShim#getDirIndices is expensive
+    * [HIVE-9372] - Parallel checking non-combinable paths in CombineHiveInputFormat
+    * [HIVE-9383] - Improve schema verification error message
+    * [HIVE-9538] - Exclude thirdparty directory from tarballs
+    * [HIVE-9549] - Include missing directories in source tarball
+    * [HIVE-9586] - Too verbose log can hurt performance, we should always check log level first
+    * [HIVE-9608] - Define SPARK_HOME if not defined automagically
+
+** New Feature
+    * [HIVE-3405] - UDF initcap to obtain a string with the first letter of each word in uppercase other letters in lowercase
+    * [HIVE-7122] - Storage format for create like table
+    * [HIVE-8435] - Add identity project remover optimization
+    * [HIVE-9174] - Enable queuing of HCatalog notification events in metastore DB
+    * [HIVE-9175] - Add alters to list of events handled by NotificationListener
+    * [HIVE-9184] - Modify HCatClient to support new notification methods in HiveMetaStoreClient
+
+** Task
+    * [HIVE-6977] - Delete Hiveserver1
+    * [HIVE-7111] - Extend join transitivity PPD to non-column expressions
+    * [HIVE-8351] - Allow testing of both hadoop-1 and hadoop-2 for precommits
+    * [HIVE-8370] - Fix tabs in DefaultHBaseValueFactory
+    * [HIVE-8465] - Fix some minor test fails on trunk
+    * [HIVE-8608] - Move jenkins scripts to source control
+    * [HIVE-8609] - Move beeline to jline2
+    * [HIVE-8826] - Remove jdbm from top level license file
+    * [HIVE-8828] - Remove hadoop 20 shims
+    * [HIVE-8894] - Move calcite.version to root pom
+    * [HIVE-8935] - Add debug logging around token stores
+    * [HIVE-8974] - Upgrade to Calcite 1.0.0-SNAPSHOT (with lots of renames)
+    * [HIVE-8979] - Merge shims/common-secure into shims/common
+    * [HIVE-8989] - Make groupby_multi_single_reducer.q and smb_mapjoin_3.q deterministic
+    * [HIVE-9183] - Compilation against HBase 1.0.0 fails due to missing dependency on high_scale_lib.Counter
+    * [HIVE-9304] - [Refactor] remove unused method in SemAly
+    * [HIVE-9345] - Add encryption branch to pre-commit script
+    * [HIVE-9402] - Create GREATEST and LEAST udf
+    * [HIVE-9407] - Fix spacing in pom
+    * [HIVE-9408] - Add hook interface so queries can be redacted before being placed in job.xml
+    * [HIVE-9527] - Include dot files in tarball
+    * [HIVE-9554] - Rename 0.15 upgrade scripts to 1.1
+    * [HIVE-9672] - Update RELEASE_NOTES on trunk to reflect the 1.0.0 release
+
+** Test
+    * [HIVE-7924] - auto_sortmerge_join_8 sometimes fails with OOM
+    * [HIVE-8256] - Add SORT_QUERY_RESULTS for test that doesn't guarantee order #2
+    * [HIVE-8327] - mvn site -Pfindbugs
+    * [HIVE-8573] - Fix some non-deterministic vectorization tests
+    * [HIVE-8601] - Fix auto_sortmerge_join_16 determinism
+    * [HIVE-8602] - Add SORT_QUERY_RESULTS for skewjoinopt2
+    * [HIVE-8753] - TestMiniTezCliDriver.testCliDriver_vector_mapjoin_reduce failing on trunk
+    * [HIVE-8801] - Make orc_merge_incompat1.q deterministic across platforms
+    * [HIVE-8929] - incorrect error message for cbo path
+    * [HIVE-9091] - Add additional unit tests for HiveSQLException
+    * [HIVE-9173] - Fix auto_join29.q, auto_join_without_localtask.q determinism
+    * [HIVE-9290] - Make some test results deterministic
+    * [HIVE-9360] - TestSparkClient throws Timeoutexception
+    * [HIVE-9403] - File tests determinism with multiple reducers
+    * [HIVE-9417] - Fix failing test groupby_grouping_window.q on trunk
+    * [HIVE-9435] - Fix auto_join21.q for Tez
+
+
+
+Release Notes - Hive - Version 1.0.0
+
+** Bug
+    * [HIVE-5631] - Index creation on a skew table fails
+    * [HIVE-5664] - Drop cascade database fails when the db has any tables with indexes
+    * [HIVE-6198] - ORC file and struct column names are case sensitive
+    * [HIVE-6468] - HS2 & Metastore using SASL out of memory error when curl sends a get request
+    * [HIVE-7270] - SerDe Properties are not considered by show create table Command
+    * [HIVE-8099] - IN operator for partition column fails when the partition column type is DATE
+    * [HIVE-8295] - Add batch retrieve partition objects for metastore direct sql 
+    * [HIVE-8374] - schematool fails on Postgres versions < 9.2
+    * [HIVE-8485] - HMS on Oracle incompatibility
+    * [HIVE-8706] - Table statistic collection on counter failed due to table name character case.
+    * [HIVE-8715] - Hive 14 upgrade scripts can fail for statistics if database was created using auto-create
+    * [HIVE-8739] - handle Derby and Oracle errors with joins and filters in Direct SQL in a invalid-DB-specific path
+    * [HIVE-8784] - Querying partition does not work with JDO enabled against PostgreSQL
+    * [HIVE-8805] - CBO skipped due to SemanticException: Line 0:-1 Both left and right aliases encountered in JOIN 'avg_cs_ext_discount_amt'
+    * [HIVE-8807] - Obsolete default values in webhcat-default.xml
+    * [HIVE-8811] - Dynamic partition pruning can result in NPE during query compilation
+    * [HIVE-8827] - Remove SSLv2Hello from list of disabled protocols
+    * [HIVE-8830] - hcatalog process don't exit because of non daemon thread
+    * [HIVE-8845] - Switch to Tez 0.5.2
+    * [HIVE-8866] - Vectorization on partitioned table throws ArrayIndexOutOfBoundsException when partitions are not of same #of columns
+    * [HIVE-8870] - errors when selecting a struct field within an array from ORC based tables
+    * [HIVE-8873] - Switch to calcite 0.9.2
+    * [HIVE-8876] - incorrect upgrade script for Oracle (13->14)
+    * [HIVE-8880] - non-synchronized access to split list in OrcInputFormat
+    * [HIVE-8886] - Some Vectorized String CONCAT expressions result in runtime error Vectorization: Unsuported vector output type: StringGroup
+    * [HIVE-8888] - Mapjoin with LateralViewJoin generates wrong plan in Tez
+    * [HIVE-8947] - HIVE-8876 also affects Postgres < 9.2
+    * [HIVE-8966] - Delta files created by hive hcatalog streaming cannot be compacted
+    * [HIVE-9003] - Vectorized IF expr broken for the scalar and scalar case
+    * [HIVE-9025] - join38.q (without map join) produces incorrect result when testing with multiple reducers
+    * [HIVE-9038] - Join tests fail on Tez
+    * [HIVE-9051] - TezJobMonitor in-place updates logs too often to logfile
+    * [HIVE-9053] - select constant in union all followed by group by gives wrong result
+    * [HIVE-9067] - OrcFileMergeOperator may create merge file that does not match properties of input files
+    * [HIVE-9090] - Rename "Tez File Merge Work" to smaller name
+    * [HIVE-9108] - Fix for HIVE-8735 is incorrect (stats with long paths)
+    * [HIVE-9111] - Potential NPE in OrcStruct for list and map types
+    * [HIVE-9112] - Query may generate different results depending on the number of reducers
+    * [HIVE-9114] - union all query in cbo test has undefined ordering
+    * [HIVE-9126] - Backport HIVE-8827 (Remove SSLv2Hello from list of disabled protocols) to 0.14 branch
+    * [HIVE-9141] - HiveOnTez: mix of union all, distinct, group by generates error
+    * [HIVE-9155] - HIVE_LOCKS uses int instead of bigint hive-txn-schema-0.14.0.mssql.sql
+    * [HIVE-9162] - stats19 test is environment-dependant
+    * [HIVE-9166] - Place an upper bound for SARG CNF conversion
+    * [HIVE-9168] - Vectorized Coalesce for strings is broken
+    * [HIVE-9205] - Change default tez install directory to use /tmp instead of /user and create the directory if it does not exist
+    * [HIVE-9234] - HiveServer2 leaks FileSystem objects in FileSystem.CACHE
+    * [HIVE-9249] - java.lang.ClassCastException: org.apache.hadoop.hive.serde2.io.HiveVarcharWritable cannot be cast to org.apache.hadoop.hive.common.type.HiveVarchar when joining tables
+    * [HIVE-9278] - Cached expression feature broken in one case
+    * [HIVE-9317] - move Microsoft copyright to NOTICE file
+    * [HIVE-9359] - Export of a large table causes OOM in Metastore and Client
+    * [HIVE-9361] - Intermittent NPE in SessionHiveMetaStoreClient.alterTempTable
+    * [HIVE-9390] - Enhance retry logic wrt DB access in TxnHandler
+    * [HIVE-9401] - Backport: Fastpath for limited fetches from unpartitioned tables
+    * [HIVE-9404] - NPE in org.apache.hadoop.hive.metastore.txn.TxnHandler.determineDatabaseProduct()
+    * [HIVE-9436] - RetryingMetaStoreClient does not retry JDOExceptions
+    * [HIVE-9473] - sql std auth should disallow built-in udfs that allow any java methods to be called
+    * [HIVE-9514] - schematool is broken in hive 1.0.0
+
+
+** Improvement
+    * [HIVE-3280] - Make HiveMetaStoreClient a public API
+    * [HIVE-8933] - Check release builds for SNAPSHOT dependencies
+
+
+** Task
+    * [HIVE-6977] - Delete Hiveserver1
+
+
+
+
+Release Notes - Hive - Version 0.14.0
+
+** Sub-task
+    * [HIVE-4629] - HS2 should support an API to retrieve query logs
+    * [HIVE-5176] - Wincompat : Changes for allowing various path compatibilities with Windows
+    * [HIVE-5179] - Wincompat : change script tests from bash to sh
+    * [HIVE-5579] - Update statistics rules for different types of joins
+    * [HIVE-5760] - Add vectorized support for CHAR/VARCHAR data types
+    * [HIVE-5804] - Support column statistics for expressions in GBY attributes, JOIN condition etc. when annotating operator tree with statistics
+    * [HIVE-5805] - Support for operators like PTF, Script, Extract etc. in statistics annotation.
+    * [HIVE-5868] - Add statistics rule for Union operator
+    * [HIVE-5949] - In statistics annotation add flag to say if statistics is estimated or accurate
+    * [HIVE-5998] - Add vectorized reader for Parquet files
+    * [HIVE-6031] - explain subquery rewrite for where clause predicates 
+    * [HIVE-6123] - Implement checkstyle in maven
+    * [HIVE-6252] - sql std auth - support 'with admin option' in revoke role metastore api
+    * [HIVE-6290] - Add support for hbase filters for composite keys
+    * [HIVE-6367] - Implement Decimal in ParquetSerde
+    * [HIVE-6394] - Implement Timestmap in ParquetSerde
+    * [HIVE-6445] - Add qop support for kerberos over http in HiveServer2
+    * [HIVE-6626] - Hive does not expand the DOWNLOADED_RESOURCES_DIR path
+    * [HIVE-6627] - HiveServer2 should handle scratch dir permissions / errors in a better way
+    * [HIVE-6714] - Fix getMapSize() of LazyMap
+    * [HIVE-6735] - Make scalable dynamic partitioning work in vectorized mode
+    * [HIVE-6760] - Scalable dynamic partitioning should bail out properly for list bucketing
+    * [HIVE-6761] - Hashcode computation does not use maximum parallelism for scalable dynamic partitioning
+    * [HIVE-6798] - Update column stats based on filter expression in stats annotation
+    * [HIVE-6815] - Version of the HIVE-6374 for Hive 0.13
+    * [HIVE-6982] - Export all .sh equivalent for windows (.cmd files) in bin, bin/ext
+    * [HIVE-6993] - Update hive for Tez VertexLocationHint and getAVailableResource API changes
+    * [HIVE-7029] - Vectorize ReduceWork
+    * [HIVE-7078] - Need file sink operators that work with ACID
+    * [HIVE-7094] - Separate out static/dynamic partitioning code in FileRecordWriterContainer
+    * [HIVE-7156] - Group-By operator stat-annotation only uses distinct approx to generate rollups
+    * [HIVE-7184] - TestHadoop20SAuthBridge no longer compiles after HADOOP-10448
+    * [HIVE-7204] - Use NULL vertex location hint for Prewarm DAG vertices
+    * [HIVE-7262] - Partitioned Table Function (PTF) query fails on ORC table when attempting to vectorize
+    * [HIVE-7286] - Parameterize HCatMapReduceTest for testing against all Hive storage formats
+    * [HIVE-7291] - Refactor TestParser to understand test-property file
+    * [HIVE-7350] - Changes related to TEZ-692, TEZ-1169, TEZ-1234
+    * [HIVE-7357] - Add vectorized support for BINARY data type
+    * [HIVE-7398] - Parent GBY of MUX is removed even it's not for semijoin
+    * [HIVE-7404] - Revoke privilege should support revoking of grant option
+    * [HIVE-7405] - Vectorize GROUP BY on the Reduce-Side (Part 1 – Basic)
+    * [HIVE-7420] - Parameterize tests for HCatalog Pig interfaces for testing against all storage formats
+    * [HIVE-7427] - Changes for EdgeConfigurations
+    * [HIVE-7457] - Minor HCatalog Pig Adapter test clean up
+    * [HIVE-7491] - Stats annotation fails to evaluate constant expressions in filter operator
+    * [HIVE-7513] - Add ROW__ID VirtualColumn
+    * [HIVE-7535] - Make use of number of nulls column statistics in filter rule
+    * [HIVE-7536] - Make use of decimal column statistics in statistics annotation
+    * [HIVE-7544] - Changes related to TEZ-1288 (FastTezSerialization)
+    * [HIVE-7548] - Precondition checks should not fail the merge task in case of automatic trigger
+    * [HIVE-7571] - RecordUpdater should read virtual columns from row
+    * [HIVE-7589] - Some fixes and improvements to statistics annotation rules
+    * [HIVE-7601] - Bring up tez-branch upto the API changes from TEZ-1058, TEZ-1303, TEZ-1346, TEZ-1041
+    * [HIVE-7639] - Bring tez-branch upto api changes in TEZ-1379, TEZ-1057, TEZ-1382
+    * [HIVE-7646] - Modify parser to support new grammar for Insert,Update,Delete
+    * [HIVE-7655] - CBO: Reading of partitioned table stats slows down explain
+    * [HIVE-7656] - Bring tez-branch up-to the API changes made by TEZ-1372
+    * [HIVE-7663] - OrcRecordUpdater needs to implement getStats
+    * [HIVE-7679] - JOIN operator should update the column stats when number of rows changes
+    * [HIVE-7734] - Join stats annotation rule is not updating columns statistics correctly
+    * [HIVE-7735] - Implement Char, Varchar in ParquetSerDe
+    * [HIVE-7788] - Generate plans for insert, update, and delete
+    * [HIVE-7790] - Update privileges to check for update and delete
+    * [HIVE-7808] - Changes to work against Tez-0.5 RC
+    * [HIVE-7809] - Fix ObjectRegistry to work with Tez 0.5
+    * [HIVE-7820] - union_null.q is not deterministic 
+    * [HIVE-7825] - Bring tez-branch up-to the API changes made by TEZ-1472, TEZ-1469
+    * [HIVE-7836] - Ease-out denominator for multi-attribute join case in statistics annotation
+    * [HIVE-7864] - [CBO] Query fails if it refers only partitioning column
+    * [HIVE-7869] - Build long running HS2 test framework
+    * [HIVE-7904] - Missing null check cause NPE when updating join column stats in statistics annotation
+    * [HIVE-7905] - CBO: more cost model changes
+    * [HIVE-7907] - Bring up tez branch to changes in TEZ-1038, TEZ-1500
+    * [HIVE-7935] - Support dynamic service discovery for HiveServer2
+    * [HIVE-7979] - Fix testconfiguration.property file in Tez branch
+    * [HIVE-7990] - With fetch column stats disabled number of elements in grouping set is not taken into account
+    * [HIVE-7991] - Incorrect calculation of number of rows in JoinStatsRule.process results in overflow
+    * [HIVE-7992] - StatsRulesProcFactory should gracefully handle overflows
+    * [HIVE-7994] - BMJ test fails on tez
+    * [HIVE-7995] - Column statistics from expression does not handle fields within complex types
+    * [HIVE-8006] - CBO Trunk Merge: Test fail that includes Table Sample, rows(), query hints
+    * [HIVE-8016] - CBO: PPD to honor hive Join Cond, Casting fixes, Add annotations for IF, Code cleanup
+    * [HIVE-8021] - CBO: support CTAS and insert ... select
+    * [HIVE-8046] - CBO: fix issues with Windowing queries
+    * [HIVE-8069] - CBO: RowResolver after SubQuery predicate handling should be reset to outer query block RR
+    * [HIVE-8111] - CBO trunk merge: duplicated casts for arithmetic expressions in Hive and CBO
+    * [HIVE-8125] - CBO Trunk Merge: On Failure Fall Back to Non CBO
+    * [HIVE-8144] - CBO: HiveProjectRel factory should create RelSubSets
+    * [HIVE-8145] - CBO: bail from Optiq planning if a Select list contains multiple references to the same name
+    * [HIVE-8159] - CBO: bail from Optiq planning if a Select list contains multiple references to the same name
+    * [HIVE-8168] - With dynamic partition enabled fact table selectivity is not taken into account when generating the physical plan (Use CBO cardinality using physical plan generation)
+    * [HIVE-8172] - HiveServer2 dynamic service discovery should let the JDBC client use default ZooKeeper namespace
+    * [HIVE-8173] - HiveServer2 dynamic service discovery: figure out best ZooKeeper ACLs for security
+    * [HIVE-8186] - Self join may fail if one side have virtual column(s) and other doesn't
+    * [HIVE-8193] - Hook HiveServer2 dynamic service discovery with session time out
+    * [HIVE-8194] - CBO: bail for having clause referring select expr aliases
+    * [HIVE-8199] - CBO Trunk Merge: quote2 test fails due to incorrect literal translation
+    * [HIVE-8223] - CBO Trunk Merge: partition_wise_fileformat2 select result depends on ordering
+    * [HIVE-8228] - CBO: fix couple of issues with partition pruning
+    * [HIVE-8237] - CBO: Use Fully qualified table name (db.tablename in ReloptHiveTable)
+    * [HIVE-8288] - HiveServer2 dynamic discovery should create znodes organized by version number & add support for removing server uri's of a particular version from the server script.
+    * [HIVE-8309] - CBO: Fix OB by removing constraining DT, Use external names for col Aliases, Remove unnecessary Selects, Make DT Name counter query specific
+    * [HIVE-8377] - Enable Kerberized SSL for HiveServer2 in http mode
+    * [HIVE-8454] - Select Operator does not rename column stats properly in case of select star
+    * [HIVE-8522] - CBO: Update Calcite Version to 0.9.2-incubating-SNAPSHOT
+    * [HIVE-8530] - CBO: Preserve types of literals
+    * [HIVE-8549] - NPE in PK-FK inference when one side of join is complex tree
+    * [HIVE-8580] - Support LateralViewJoinOperator and LateralViewForwardOperator in stats annotation
+    * [HIVE-8582] - CBO: Outer Join Simplification is broken
+    * [HIVE-8653] - CBO: Push Semi Join through, Project/Filter/Join
+    * [HIVE-8654] - CBO: parquet_ctas test returns incorrect results
+    * [HIVE-8655] - CBO: ppr_pushdown, udf_substr produces incorrect results due to broken tablesample handling
+    * [HIVE-8656] - CBO: auto_join_filters fails
+    * [HIVE-8657] - CBO: inputddl5, udf_reverse tests fail
+    * [HIVE-8662] - CBO: tez_dml fails
+    * [HIVE-8768] - CBO: Fix filter selectivity for "in clause" & "<>" 
+
+
+
+** Bug
+    * [HIVE-1363] - 'SHOW TABLE EXTENDED LIKE' command does not strip single/double quotes
+    * [HIVE-1608] - use sequencefile as the default for storing intermediate results
+    * [HIVE-1879] - Remove hive.metastore.metadb.dir property from hive-default.xml and HiveConf
+    * [HIVE-2137] - JDBC driver doesn't encode string properly.
+    * [HIVE-2390] - Add UNIONTYPE serialization support to LazyBinarySerDe
+    * [HIVE-2597] - Repeated key in GROUP BY is erroneously displayed when using DISTINCT
+    * [HIVE-3392] - Hive unnecessarily validates table SerDes when dropping a table
+    * [HIVE-3685] - TestCliDriver (script_pipe.q) failed with IBM JDK
+    * [HIVE-3925] - dependencies of fetch task are not shown by explain
+    * [HIVE-4064] - Handle db qualified names consistently across all HiveQL statements
+    * [HIVE-4118] - ANALYZE TABLE ... COMPUTE STATISTICS FOR COLUMNS fails when using fully qualified table name
+    * [HIVE-4274] - Table created using HCatalog java client doesn't set the owner
+    * [HIVE-4561] - Column stats :  LOW_VALUE (or HIGH_VALUE) will always be 0.0000 ,if all the column values larger than 0.0 (or if all column values smaller than 0.0)
+    * [HIVE-4576] - templeton.hive.properties does not allow values with commas
+    * [HIVE-4577] - hive CLI can't handle hadoop dfs command  with space and quotes.
+    * [HIVE-4723] - DDLSemanticAnalyzer.addTablePartsOutputs eats several exceptions
+    * [HIVE-4795] - Delete/Alter/Describe actions fail when SerDe is not on class path
+    * [HIVE-4965] - Add support so that PTFs can stream their output; Windowing PTF should do this
+    * [HIVE-5077] - Provide an option to run local task in process
+    * [HIVE-5092] - Fix hiveserver2 mapreduce local job on Windows
+    * [HIVE-5150] - UnsatisfiedLinkError when running hive unit tests on Windows
+    * [HIVE-5268] - HiveServer2 accumulates orphaned OperationHandle objects when a client fails while executing query
+    * [HIVE-5315] - Cannot attach debugger to Hiveserver2 
+    * [HIVE-5336] - HCatSchema.remove(HCatFieldSchema hcatFieldSchema) should renumber the  fieldPositionMap and the fieldPositionMap should not be cached by the end user
+    * [HIVE-5376] - Hive does not honor type for partition columns when altering column type
+    * [HIVE-5434] - Creating a new HiveConnection does not handle the case when properties are supplied separately from connection string 
+    * [HIVE-5456] - Queries fail on avro backed table with empty partition 
+    * [HIVE-5607] - Hive fails to parse the "%" (mod) sign after brackets.
+    * [HIVE-5631] - Index creation on a skew table fails
+    * [HIVE-5664] - Drop cascade database fails when the db has any tables with indexes
+    * [HIVE-5677] - Beeline warns about unavailable files if HIVE_OPTS is set
+    * [HIVE-5789] - WebHCat E2E tests do not launch on Windows
+    * [HIVE-5847] - DatabaseMetadata.getColumns() doesn't show correct column size for char/varchar/decimal
+    * [HIVE-5870] - Move TestJDBCDriver2.testNewConnectionConfiguration to TestJDBCWithMiniHS2
+    * [HIVE-6035] - Windows: percentComplete returned by job status from WebHCat is null
+    * [HIVE-6093] - table creation should fail when user does not have permissions on db
+    * [HIVE-6149] - TestJdbcDriver2 is unable to drop a database created from previous runs ("hbasedb")
+    * [HIVE-6176] - Beeline gives bogus error message if an unaccepted command line option is given
+    * [HIVE-6187] - Add test to verify that DESCRIBE TABLE works with quoted table names
+    * [HIVE-6195] - Create unit tests to exercise behaviour when creating a HBase Table in Hive
+    * [HIVE-6200] - Hive custom SerDe cannot load DLL added by "ADD FILE" command
+    * [HIVE-6245] - HS2 creates DBs/Tables with wrong ownership when HMS setugi is true
+    * [HIVE-6305] - test use of quoted identifiers in user/role names
+    * [HIVE-6313] - Minimr tests in hadoop-1 hangs on shutdown
+    * [HIVE-6321] - hiveserver2 --help says Unrecognized option: -h
+    * [HIVE-6322] - Fix file_with_header_footer_negative.q
+    * [HIVE-6331] - HIVE-5279 deprecated UDAF class without explanation/documentation/alternative
+    * [HIVE-6374] - Hive job submitted with non-default name node (fs.default.name) doesn't process locations properly 
+    * [HIVE-6437] - DefaultHiveAuthorizationProvider should not initialize a new HiveConf
+    * [HIVE-6446] - Ability to specify hadoop.bin.path from command line -D
+    * [HIVE-6447] - Bucket map joins in hive-tez
+    * [HIVE-6480] - Metastore server startup script ignores ENV settings
+    * [HIVE-6487] - PTest2 do not copy failed source directories
+    * [HIVE-6508] - Mismatched results between vector and non-vector mode with decimal field
+    * [HIVE-6511] - casting from decimal to tinyint,smallint, int and bigint generates different result when vectorization is on
+    * [HIVE-6515] - Custom vertex in hive-tez should be able to accept multiple MR-inputs
+    * [HIVE-6521] - WebHCat cannot fetch correct percentComplete for Hive jobs
+    * [HIVE-6531] - Runtime errors in vectorized execution.
+    * [HIVE-6538] - yet another annoying exception in test logs
+    * [HIVE-6549] - remove templeton.jar from webhcat-default.xml, remove hcatalog/bin/hive-config.sh
+    * [HIVE-6550] - SemanticAnalyzer.reset() doesn't clear all the state
+    * [HIVE-6555] - TestSchemaTool is failing on trunk after branching
+    * [HIVE-6560] - varchar and char types cannot be cast to binary
+    * [HIVE-6563] - hdfs jar being pulled in when creating a hadoop-2 based hive tar ball
+    * [HIVE-6564] - WebHCat E2E tests that launch MR jobs fail on check job completion timeout
+    * [HIVE-6569] - HCatalog still has references to deprecated property hive.metastore.local
+    * [HIVE-6570] - Hive variable substitution does not work with the "source" command
+    * [HIVE-6571] - query id should be available for logging during query compilation
+    * [HIVE-6583] - wrong sql comments : ----... instead of -- ---...
+    * [HIVE-6586] - Update parameters in HiveConf.java after commit HIVE-6037
+    * [HIVE-6592] - WebHCat E2E test abort when pointing to https url of webhdfs
+    * [HIVE-6594] - UnsignedInt128 addition does not increase internal int array count resulting in corrupted values during serialization
+    * [HIVE-6597] - WebHCat E2E tests doAsTests_6 and doAsTests_7 need to be updated
+    * [HIVE-6598] - Importing the project into eclipse as maven project have some issues
+    * [HIVE-6601] - alter database commands should support schema synonym keyword
+    * [HIVE-6602] - Multi-user HiveServer2 throws error
+    * [HIVE-6612] - Misspelling "schemaTool completeted" 
+    * [HIVE-6620] - UDF printf doesn't take either CHAR or VARCHAR as the first argument
+    * [HIVE-6622] - UDF translate doesn't take either CHAR or VARCHAR as any of its arguments
+    * [HIVE-6637] - UDF in_file() doesn't take CHAR or VARCHAR as input
+    * [HIVE-6648] - Permissions are not inherited correctly when tables have multiple partition columns
+    * [HIVE-6652] - Beeline gives evasive error message for any unrecognized command line arguement
+    * [HIVE-6669] - sourcing txn-script from schema script results in failure for mysql & oracle
+    * [HIVE-6683] - Beeline does not accept comments at end of line
+    * [HIVE-6684] - Beeline does not accept comments that are preceded by spaces
+    * [HIVE-6695] - bin/hcat should include hbase jar and dependencies in the classpath [followup/clone of HCATALOG-621]
+    * [HIVE-6698] - hcat.py script does not correctly load the hbase storage handler jars
+    * [HIVE-6707] - Lazy maps are broken (LazyMap and LazyBinaryMap)
+    * [HIVE-6709] - HiveServer2 help command is not recognizing properly.
+    * [HIVE-6711] - ORC maps uses getMapSize() from MapOI which is unreliable
+    * [HIVE-6715] - Hive JDBC should include username into open session request for non-sasl connection
+    * [HIVE-6724] - HCatStorer throws ClassCastException while storing tinyint/smallint data
+    * [HIVE-6726] - Hcat cli does not close SessionState
+    * [HIVE-6727] - Table level stats for external tables are set incorrectly
+    * [HIVE-6741] - HiveServer2 startup fails in secure (kerberos) mode due to backward incompatible hadoop change
+    * [HIVE-6745] - HCat MultiOutputFormat hardcodes DistributedCache keynames
+    * [HIVE-6756] - alter table set fileformat should set serde too
+    * [HIVE-6768] - remove hcatalog/webhcat/svr/src/main/config/override-container-log4j.properties
+    * [HIVE-6773] - Update readme for ptest2 framework
+    * [HIVE-6782] - HiveServer2Concurrency issue when running with tez intermittently, throwing "org.apache.tez.dag.api.SessionNotRunning: Application not running" error
+    * [HIVE-6783] - Incompatible schema for maps between parquet-hive and parquet-pig
+    * [HIVE-6784] - parquet-hive should allow column type change
+    * [HIVE-6785] - query fails when partitioned table's table level serde is ParquetHiveSerDe and partition level serde is of different SerDe
+    * [HIVE-6788] - Abandoned opened transactions not being timed out
+    * [HIVE-6792] - hive.warehouse.subdir.inherit.perms doesn't work correctly in CTAS
+    * [HIVE-6793] - DDLSemanticAnalyzer.analyzeShowRoles() should use HiveAuthorizationTaskFactory
+    * [HIVE-6807] - add HCatStorer ORC test to test missing columns
+    * [HIVE-6811] - LOAD command does not work with relative paths on Windows
+    * [HIVE-6817] - Some hadoop2-only tests need diffs to be updated
+    * [HIVE-6820] - HiveServer(2) ignores HIVE_OPTS
+    * [HIVE-6822] - TestAvroSerdeUtils fails with -Phadoop-2
+    * [HIVE-6824] - Hive HBase query fails on Tez due to missing jars - part 2
+    * [HIVE-6826] - Hive-tez has issues when different partitions work off of different input types
+    * [HIVE-6828] - Hive tez bucket map join conversion interferes with map join conversion
+    * [HIVE-6835] - Reading of partitioned Avro data fails if partition schema does not match table schema
+    * [HIVE-6843] - INSTR for UTF-8 returns incorrect position
+    * [HIVE-6847] - Improve / fix bugs in Hive scratch dir setup
+    * [HIVE-6853] - show create table for hbase tables should exclude LOCATION 
+    * [HIVE-6858] - Unit tests decimal_udf.q, vectorization_div0.q fail with jdk-7.
+    * [HIVE-6861] - more hadoop2 only golden files to fix
+    * [HIVE-6862] - add DB schema DDL and upgrade 12to13 scripts for MS SQL Server
+    * [HIVE-6868] - Create table in HCatalog sets different SerDe defaults than what is set through the CLI
+    * [HIVE-6870] - Fix maven.repo.local setting in Hive build
+    * [HIVE-6871] - Build fixes to allow Windows to run TestCliDriver
+    * [HIVE-6877] - TestOrcRawRecordMerger is deleting test.tmp.dir
+    * [HIVE-6880] - TestHWISessionManager fails with -Phadoop-2
+    * [HIVE-6883] - Dynamic partitioning optimization does not honor sort order or order by
+    * [HIVE-6884] - HiveLockObject and enclosed HiveLockObjectData override equal() method but didn't do so for hashcode()
+    * [HIVE-6888] - Hive leaks MapWork objects via Utilities::gWorkMap
+    * [HIVE-6890] - Bug in HiveStreaming API causes problems if hive-site.xml is missing on streaming client side
+    * [HIVE-6891] - Alter rename partition Perm inheritance and general partition/table group inheritance
+    * [HIVE-6893] - out of sequence error in HiveMetastore server
+    * [HIVE-6898] - Functions in hive are failing with java.lang.ClassNotFoundException on Tez
+    * [HIVE-6900] - HostUtil.getTaskLogUrl signature change causes compilation to fail
+    * [HIVE-6901] - Explain plan doesn't show operator tree for the fetch operator
+    * [HIVE-6908] - TestThriftBinaryCLIService.testExecuteStatementAsync has intermittent failures
+    * [HIVE-6910] - Invalid column access info for partitioned table
+    * [HIVE-6913] - Hive unable to find the hashtable file during complex multi-staged map join
+    * [HIVE-6915] - Hive Hbase queries fail on secure Tez cluster
+    * [HIVE-6916] - Export/import inherit permissions from parent directory
+    * [HIVE-6919] - hive sql std auth select query fails on partitioned tables
+    * [HIVE-6921] - index creation fails with sql std auth turned on 
+    * [HIVE-6922] - NullPointerException in collect_set() UDAF
+    * [HIVE-6927] - Add support for MSSQL in schematool
+    * [HIVE-6928] - Beeline should not chop off "describe extended" results by default
+    * [HIVE-6931] - Windows unit test fixes
+    * [HIVE-6932] - hive README needs update
+    * [HIVE-6934] - PartitionPruner doesn't handle top level constant expression correctly
+    * [HIVE-6936] - Provide table properties to InputFormats
+    * [HIVE-6937] - Fix test reporting url's after jenkins move from bigtop
+    * [HIVE-6939] - TestExecDriver.testMapRedPlan3 fails on hadoop-2
+    * [HIVE-6944] - WebHCat e2e tests broken by HIVE-6432
+    * [HIVE-6945] - issues with dropping partitions on Oracle
+    * [HIVE-6946] - Make it easier to run WebHCat e2e tests
+    * [HIVE-6947] - More fixes for tests on hadoop-2 
+    * [HIVE-6952] - Hive 0.13 HiveOutputFormat breaks backwards compatibility
+    * [HIVE-6954] - After ALTER FILEFORMAT, DESCRIBE throwing exception
+    * [HIVE-6955] - ExprNodeColDesc isSame doesn't account for tabAlias: this affects trait Propagation in Joins
+    * [HIVE-6956] - Duplicate partitioning column for union when dynamic partition sort optimization is enabled
+    * [HIVE-6957] - SQL authorization does not work with HS2 binary mode and Kerberos auth
+    * [HIVE-6959] - Enable Constant propagation optimizer for Hive Vectorization
+    * [HIVE-6960] - Set Hive pom to use Hadoop-2.4
+    * [HIVE-6961] - Drop partitions treats partition columns as strings
+    * [HIVE-6965] - Transaction manager should use RDBMS time instead of machine time
+    * [HIVE-6966] - More fixes for TestCliDriver on Windows
+    * [HIVE-6967] - Hive transaction manager fails when SQLServer is used as an RDBMS
+    * [HIVE-6968] - list bucketing feature does not update the location map for unpartitioned tables
+    * [HIVE-6972] - jdbc HTTP configuration options should be part of sessionConf part of connection string
+    * [HIVE-6976] - Show query id only when there's jobs on the cluster
+    * [HIVE-6978] - beeline always exits with 0 status, should exit with non-zero status on error
+    * [HIVE-6979] - Hadoop-2 test failures related to quick stats not being populated correctly
+    * [HIVE-6984] - Analyzing partitioned table with NULL values for the partition column failed with NPE
+    * [HIVE-6985] - sql std auth - privileges grants to public role not being honored
+    * [HIVE-6986] - MatchPath fails with small resultExprString
+    * [HIVE-6987] - Metastore qop settings won't work with Hadoop-2.4
+    * [HIVE-6989] - Error with arithmetic operators with javaXML serialization
+    * [HIVE-6990] - Direct SQL fails when the explicit schema setting is different from the default one
+    * [HIVE-6994] - parquet-hive createArray strips null elements
+    * [HIVE-6995] - GenericUDFBridge should log exception when it is unable to instantiate UDF object
+    * [HIVE-6996] - FS based stats broken with indexed tables
+    * [HIVE-7001] - fs.permissions.umask-mode is getting unset when Session is started
+    * [HIVE-7003] - Fix typo in README
+    * [HIVE-7004] - Fix more unit test failures on hadoop-2
+    * [HIVE-7005] - MiniTez tests have non-deterministic explain plans
+    * [HIVE-7006] - Fix ql_rewrite_gbtoidx.q output file
+    * [HIVE-7009] - HIVE_USER_INSTALL_DIR could not bet set to non-HDFS filesystem
+    * [HIVE-7011] - HiveInputFormat's split generation isn't thread safe
+    * [HIVE-7012] - Wrong RS de-duplication in the ReduceSinkDeDuplication Optimizer
+    * [HIVE-7015] - Failing to inherit group/permission should not fail the operation
+    * [HIVE-7016] - Hive returns wrong results when execute UDF on top of DISTINCT column
+    * [HIVE-7017] - Insertion into Parquet tables fails under Tez
+    * [HIVE-7021] - HiveServer2 memory leak on failed queries
+    * [HIVE-7023] - Bucket mapjoin is broken when the number of small aliases is two or more
+    * [HIVE-7027] - Hive job fails when referencing a view that explodes an array
+    * [HIVE-7030] - Remove hive.hadoop.classpath from hiveserver2.cmd
+    * [HIVE-7031] - Utiltites.createEmptyFile uses File.Separator instead of Path.Separator to create an empty file in HDFS
+    * [HIVE-7033] - grant statements should check if the role exists
+    * [HIVE-7035] - Templeton returns 500 for user errors - when job cannot be found
+    * [HIVE-7037] - Add additional tests for transform clauses with Tez
+    * [HIVE-7041] - DoubleWritable/ByteWritable should extend their hadoop counterparts
+    * [HIVE-7042] - Fix stats_partscan_1_23.q and orc_createas1.q for hadoop-2
+    * [HIVE-7043] - When using the tez session pool via hive, once sessions time out, all queries go to the default queue
+    * [HIVE-7045] - Wrong results in multi-table insert aggregating without group by clause
+    * [HIVE-7050] - Display table level column stats in DESCRIBE FORMATTED TABLE
+    * [HIVE-7051] - Display partition level column stats in DESCRIBE FORMATTED PARTITION
+    * [HIVE-7052] - Optimize split calculation time
+    * [HIVE-7053] - Unable to fetch column stats from decimal columns
+    * [HIVE-7055] - config not propagating for PTFOperator
+    * [HIVE-7057] - webhcat e2e deployment scripts don't have x bit set
+    * [HIVE-7060] - Column stats give incorrect min and distinct_count
+    * [HIVE-7061] - sql std auth - insert queries without overwrite should not require delete privileges
+    * [HIVE-7062] - Support Streaming mode in Windowing
+    * [HIVE-7063] - Optimize for the Top N within a Group use case
+    * [HIVE-7065] - Hive jobs in webhcat run in default mr mode even in Hive on Tez setup
+    * [HIVE-7066] - hive-exec jar is missing avro core
+    * [HIVE-7067] - Min() and Max() on Timestamp and Date columns for ORC returns wrong results
+    * [HIVE-7071] - Use custom Tez split generator to support schema evolution
+    * [HIVE-7072] - HCatLoader only loads first region of hbase table
+    * [HIVE-7075] - JsonSerde raises NullPointerException when object key is not lower case
+    * [HIVE-7076] - Plugin (exec hook) to log to application timeline data to Yarn
+    * [HIVE-7077] - Hive contrib compilation maybe broken with removal of org.apache.hadoop.record
+    * [HIVE-7079] - Hive logs errors about missing tables when parsing CTE expressions
+    * [HIVE-7080] - In PTest framework, Add logs URL to the JIRA comment
+    * [HIVE-7082] - Vectorized parquet reader should create assigners only for the columns it assigns, not for scratch columns
+    * [HIVE-7083] - Fix test failures on trunk
+    * [HIVE-7087] - Remove lineage information after query completion
+    * [HIVE-7092] - Insert overwrite should not delete the original directory
+    * [HIVE-7096] - Support grouped splits in Tez partitioned broadcast join
+    * [HIVE-7099] - Add Decimal datatype support for Windowing
+    * [HIVE-7104] - Unit tests are disabled
+    * [HIVE-7105] - Enable ReduceRecordProcessor to generate VectorizedRowBatches
+    * [HIVE-7107] - Fix HiveServer1 JDBC Driver spec compliancy issue
+    * [HIVE-7109] - Resource leak in HBaseStorageHandler
+    * [HIVE-7112] - Tez processor swallows errors
+    * [HIVE-7114] - Extra Tez session is started during HiveServer2 startup
+    * [HIVE-7116] - HDFS FileSystem object cache causes permission issues in creating tmp directories
+    * [HIVE-7117] - Partitions not inheriting table permissions after alter rename partition
+    * [HIVE-7118] - Oracle upgrade schema scripts do not map Java long datatype columns correctly for transaction related tables
+    * [HIVE-7119] - Extended ACL's should be inherited if warehouse perm inheritance enabled
+    * [HIVE-7123] - Follow-up of HIVE-6367
+    * [HIVE-7130] - schematool is broken for minor version upgrades (eg 0.13.x)
+    * [HIVE-7131] - Dependencies of fetch task for tez are not shown properly
+    * [HIVE-7135] - Fix test fail of TestTezTask.testSubmit
+    * [HIVE-7143] - Add Streaming support in Windowing mode for more UDAFs (min/max, lead/lag, fval/lval)
+    * [HIVE-7144] - GC pressure during ORC StringDictionary writes 
+    * [HIVE-7146] - posexplode() UDTF fails with a NullPointerException on NULL columns
+    * [HIVE-7147] - ORC PPD should handle CHAR/VARCHAR types
+    * [HIVE-7149] - Parquet not able to handle negative decimal numbers
+    * [HIVE-7154] - TestMetrics fails intermittently on the trunk
+    * [HIVE-7155] - WebHCat controller job exceeds container memory limit
+    * [HIVE-7159] - For inner joins push a 'is not null predicate' to the join sources for every non nullSafe join condition
+    * [HIVE-7161] - TestMetastoreVersion fails intermittently on trunk
+    * [HIVE-7162] - hadoop-1 build broken by HIVE-7071
+    * [HIVE-7165] - Fix hive-default.xml.template errors & omissions
+    * [HIVE-7167] - Hive Metastore fails to start with SQLServerException
+    * [HIVE-7169] - HiveServer2 in Http Mode should have a configurable IdleMaxTime timeout
+    * [HIVE-7170] - Fix display_colstats_tbllvl.q in trunk
+    * [HIVE-7173] - Support HIVE-4867 on mapjoin of MR Tasks
+    * [HIVE-7174] - Do not accept string as scale and precision when reading Avro schema
+    * [HIVE-7176] - FileInputStream is not closed in Commands#properties()
+    * [HIVE-7182] - ResultSet is not closed in JDBCStatsPublisher#init()
+    * [HIVE-7183] - Size of partColumnGrants should be checked in ObjectStore#removeRole()
+    * [HIVE-7187] - Reconcile jetty versions in hive
+    * [HIVE-7188] - sum(if()) returns wrong results with vectorization
+    * [HIVE-7190] - WebHCat launcher task failure can cause two concurent user jobs to run
+    * [HIVE-7191] - optimized map join hash table has a bug when it reaches 2Gb
+    * [HIVE-7192] - Hive Streaming - Some required settings are not mentioned in the documentation
+    * [HIVE-7199] - Cannot alter table to parquet
+    * [HIVE-7200] - Beeline output displays column heading even if --showHeader=false is set
+    * [HIVE-7201] - Fix TestHiveConf#testConfProperties test case
+    * [HIVE-7202] - DbTxnManager deadlocks in hcatalog.cli.TestSematicAnalysis.testAlterTblFFpart()
+    * [HIVE-7209] - allow metastore authorization api calls to be restricted to certain invokers
+    * [HIVE-7210] - NPE with "No plan file found" when running Driver instances on multiple threads
+    * [HIVE-7213] - COUNT(*) returns out-dated count value after TRUNCATE
+    * [HIVE-7220] - Empty dir in external table causes issue (root_dir_external_table.q failure)
+    * [HIVE-7225] - Unclosed Statement's in TxnHandler
+    * [HIVE-7226] - Windowing Streaming mode causes NPE for empty partitions
+    * [HIVE-7228] - StreamPrinter should be joined to calling thread 
+    * [HIVE-7229] - String is compared using equal in HiveMetaStore#HMSHandler#init()
+    * [HIVE-7232] - VectorReduceSink is emitting incorrect JOIN keys
+    * [HIVE-7234] - Select on decimal column throws NPE
+    * [HIVE-7235] - TABLESAMPLE on join table is regarded as alias
+    * [HIVE-7236] - Tez progress monitor should indicate running/failed tasks
+    * [HIVE-7237] - hive.exec.parallel=true w/ Hive 0.13/Tez causes application to linger forever
+    * [HIVE-7241] - Wrong lock acquired for alter table rename partition
+    * [HIVE-7242] - alter table drop partition is acquiring the wrong type of lock
+    * [HIVE-7245] - Fix parquet_columnar
+    * [HIVE-7246] - Hive transaction manager hardwires bonecp as the JDBC pooling implementation
+    * [HIVE-7247] - Fix itests using hadoop-1 profile 
+    * [HIVE-7249] - HiveTxnManager.closeTxnManger() throws if called after commitTxn()
+    * [HIVE-7251] - Fix StorageDescriptor usage in unit tests 
+    * [HIVE-7257] - UDF format_number() does not work on FLOAT types
+    * [HIVE-7263] - Missing fixes from review of parquet-timestamp
+    * [HIVE-7265] - BINARY columns use BytesWritable::getBytes() without ::getLength()
+    * [HIVE-7268] - On Windows Hive jobs in Webhcat always run on default MR mode
+    * [HIVE-7271] - Speed up unit tests
+    * [HIVE-7274] - Update PTest2 to JClouds 1.7.3
+    * [HIVE-7279] - UDF format_number() does not work on DECIMAL types
+    * [HIVE-7281] - DbTxnManager acquiring wrong level of lock for dynamic partitioning
+    * [HIVE-7282] - HCatLoader fail to load Orc map with null key
+    * [HIVE-7287] - hive --rcfilecat command is broken on Windows
+    * [HIVE-7294] - sql std auth - authorize show grant statements
+    * [HIVE-7298] - desc database extended does not show properties of the database
+    * [HIVE-7302] - Allow Auto-reducer parallelism to be turned off by a logical optimizer
+    * [HIVE-7303] - IllegalMonitorStateException when stmtHandle is null in HiveStatement
+    * [HIVE-7304] - Transitive Predicate Propagation doesn't happen properly after HIVE-7159
+    * [HIVE-7314] - Wrong results of UDF when hive.cache.expr.evaluation is set
+    * [HIVE-7317] - authorization_explain.q fails when run in sequence
+    * [HIVE-7323] - Date type stats in ORC sometimes go stale
+    * [HIVE-7325] - Support non-constant expressions for ARRAY/MAP type indices.
+    * [HIVE-7326] - Hive complains invalid column reference with 'having' aggregate predicates
+    * [HIVE-7339] - hive --orcfiledump command is not supported on Windows
+    * [HIVE-7342] - support hiveserver2,metastore specific config files
+    * [HIVE-7344] - Add streaming support in Windowing mode for FirstVal, LastVal
+    * [HIVE-7345] - Beeline changes its prompt to reflect successful database connection even after failing to connect
+    * [HIVE-7346] - Wrong results caused by hive ppd under specific join condition
+    * [HIVE-7352] - Queries without tables fail under Tez
+    * [HIVE-7353] - HiveServer2 using embedded MetaStore leaks JDOPersistanceManager
+    * [HIVE-7354] - windows:Need to set hbase jars in hadoop classpath explicitly
+    * [HIVE-7356] - Table level stats collection fail for partitioned tables
+    * [HIVE-7359] - Stats based compute query replies fail to do simple column transforms
+    * [HIVE-7363] - VectorExpressionWriterDecimal is missing null check in setValue()
+    * [HIVE-7366] - getDatabase using direct sql
+    * [HIVE-7373] - Hive should not remove trailing zeros for decimal numbers
+    * [HIVE-7374] - SHOW COMPACTIONS fail with remote metastore when there are no compations
+    * [HIVE-7376] - add minimizeJar to jdbc/pom.xml
+    * [HIVE-7385] - Optimize for empty relation scans
+    * [HIVE-7389] - Reduce number of metastore calls in MoveTask (when loading dynamic partitions)
+    * [HIVE-7393] - Tez jobs sometimes fail with NPE processing input splits
+    * [HIVE-7394] - ORC writer logging fails when the padding is < 0.01
+    * [HIVE-7396] - BucketingSortingReduceSinkOptimizer throws NullPointException during ETL
+    * [HIVE-7397] - Set the default threshold for fetch task conversion to 1Gb
+    * [HIVE-7399] - Timestamp type is not copied by ObjectInspectorUtils.copyToStandardObject
+    * [HIVE-7409] - Add workaround for a deadlock issue of Class.getAnnotation() 
+    * [HIVE-7412] - column stats collection throws exception if all values for a column is null
+    * [HIVE-7414] - Update golden file for MiniTez temp_table.q
+    * [HIVE-7415] - Test TestMinimrCliDriver.testCliDriver_ql_rewrite_gbtoidx failing
+    * [HIVE-7417] - select count(1) from ... where true; fails in optimizer
+    * [HIVE-7419] - Missing break in SemanticAnalyzer#getTableDescFromSerDe()
+    * [HIVE-7421] - Make VectorUDFDateString use the same date parsing and formatting as GenericUDFDate
+    * [HIVE-7422] - Array out of bounds exception involving ql.exec.vector.expressions.aggregates.gen.VectorUDAFAvgDouble
+    * [HIVE-7423] - produce hive-exec-core.jar from ql module
+    * [HIVE-7424] - HiveException: Error evaluating concat(concat('      ', str2), '      ') in ql.exec.vector.VectorSelectOperator.processOp
+    * [HIVE-7426] - ClassCastException: ...IntWritable cannot be cast to ...Text involving ql.udf.generic.GenericUDFBasePad.evaluate
+    * [HIVE-7429] - Set replication for archive called before file exists
+    * [HIVE-7433] - ColumnMappins.ColumnMapping should expose public accessors for its fields
+    * [HIVE-7441] - Custom partition scheme gets rewritten with hive scheme upon concatenate
+    * [HIVE-7450] - Database should inherit perms of warehouse dir
+    * [HIVE-7451] - pass function name in create/drop function to authorization api
+    * [HIVE-7452] - Boolean comparison is done through reference equality rather than using equals
+    * [HIVE-7459] - Fix NPE when an empty file is included in a Hive query that uses CombineHiveInputFormat
+    * [HIVE-7470] - Wrong Thrift declaration for {{ShowCompactResponseElement}}
+    * [HIVE-7472] - CLONE - Import fails for tables created with default text, sequence and orc file formats using HCatalog API
+    * [HIVE-7473] - Null values in DECIMAL columns cause serialization issues with HCatalog
+    * [HIVE-7475] - Beeline requires newline at the end of each query in a file
+    * [HIVE-7481] - The planning side changes for SMB join on hive-tez
+    * [HIVE-7482] - The execution side changes for SMB join in hive-tez
+    * [HIVE-7486] - Delete jar should close current classloader
+    * [HIVE-7488] - pass column names being used for inputs to authorization api
+    * [HIVE-7490] - Revert ORC stripe size
+    * [HIVE-7494] - ORC returns empty rows for constant folded date queries
+    * [HIVE-7508] - Kerberos support for streaming
+    * [HIVE-7514] - Vectorization does not handle constant expression whose value is NULL
+    * [HIVE-7521] - Reference equality is used on Boolean in NullScanOptimizer#WhereFalseProcessor#process()
+    * [HIVE-7522] - Update .q.out for cluster_tasklog_retrieval.q test
+    * [HIVE-7529] - load data query fails on hdfs federation + viewfs
+    * [HIVE-7531] - auxpath parameter does not handle paths relative to current working directory. 
+    * [HIVE-7533] - sql std auth - set authorization privileges for tables when created from hive cli
+    * [HIVE-7538] - Fix eclipse:eclipse after HIVE-7496
+    * [HIVE-7539] - streaming windowing UDAF seems to be broken without Partition Spec
+    * [HIVE-7553] - avoid the scheduling maintenance window for every jar change
+    * [HIVE-7557] - When reduce is vectorized, dynpart_sort_opt_vectorization.q under Tez fails
+    * [HIVE-7558] - HCatLoader reuses credentials across jobs
+    * [HIVE-7563] - ClassLoader should be released from LogFactory
+    * [HIVE-7574] - CommonJoinOperator.checkAndGenObject calls LOG.Trace per row from probe side in a HashMap join consuming 4% of the CPU
+    * [HIVE-7576] - Add PartitionSpec support in HCatClient API
+    * [HIVE-7579] - error message for 'drop admin role' in sql std auth mode is not informative
+    * [HIVE-7583] - Use FileSystem.access() if available to check file access for user
+    * [HIVE-7592] - List Jars or Files are not supported by Beeline
+    * [HIVE-7595] - isKerberosMode() does a case sensitive comparison
+    * [HIVE-7599] - NPE in MergeTask#main() when -format is absent
+    * [HIVE-7600] - ConstantPropagateProcFactory uses reference equality on Boolean
+    * [HIVE-7618] - TestDDLWithRemoteMetastoreSecondNamenode unit test failure
+    * [HIVE-7620] - Hive metastore fails to start in secure mode due to "java.lang.NoSuchFieldError: SASL_PROPS" error
+    * [HIVE-7623] - hive partition rename fails if filesystem cache is disabled
+    * [HIVE-7629] - Problem in SMB Joins between two Parquet tables
+    * [HIVE-7634] - Use Configuration.getPassword() if available to eliminate passwords from hive-site.xml
+    * [HIVE-7635] - Query having same aggregate functions but different case throws IndexOutOfBoundsException
+    * [HIVE-7637] - Change throws clause for Hadoop23Shims.ProxyFileSystem23.access()
+    * [HIVE-7638] - Disallow CREATE VIEW when created with a temporary table
+    * [HIVE-7645] - Hive CompactorMR job set NUM_BUCKETS mistake
+    * [HIVE-7647] - Beeline does not honor --headerInterval and --color when executing with "-e"
+    * [HIVE-7648] - authorization check api should provide table for create table,drop/create index, and db for create/switch db
+    * [HIVE-7649] - Support column stats with temporary tables
+    * [HIVE-7658] - Hive search order for hive-site.xml when using --config option
+    * [HIVE-7664] - VectorizedBatchUtil.addRowToBatchFrom is not optimized for Vectorized execution and takes 25% CPU
+    * [HIVE-7666] - Join selectivity calculation should use exponential back-off for conjunction predicates 
+    * [HIVE-7667] - handle cast for long in get_aggr_stats() api for metastore for mysql
+    * [HIVE-7669] - parallel order by clause on a string column fails with IOException: Split points are out of order
+    * [HIVE-7673] - Authorization api: missing privilege objects in create table/view
+    * [HIVE-7676] - JDBC: Support more DatabaseMetaData, ResultSetMetaData methods
+    * [HIVE-7678] - add more test cases for tables qualified with database/schema name
+    * [HIVE-7680] - Do not throw SQLException for HiveStatement getMoreResults and setEscapeProcessing(false)
+    * [HIVE-7681] - qualified tablenames usage does not work with several alter-table commands
+    * [HIVE-7682] - HadoopThriftAuthBridge20S should not reset configuration unless required
+    * [HIVE-7683] - Test TestMinimrCliDriver.testCliDriver_ql_rewrite_gbtoidx is still failing
+    * [HIVE-7694] - SMB join on tables differing by number of sorted by columns with same join prefix fails
+    * [HIVE-7695] - hive stats issue when insert query is appending data into table
+    * [HIVE-7700] - authorization api - HivePrivilegeObject for permanent function should have database name set
+    * [HIVE-7701] - Upgrading tez to 0.4.1 causes metadata only query to fail.
+    * [HIVE-7704] - Create tez task for fast file merging
+    * [HIVE-7710] - Rename table across database might fail
+    * [HIVE-7712] - hive-exec-0.13.0.2.1.2.0-402.jar contains avro classes compiled against hadoop-v1 
+    * [HIVE-7722] - TestJdbcDriver2.testDatabaseMetaData fails after HIVE-7676
+    * [HIVE-7723] - Explain plan for complex query with lots of partitions is slow due to in-efficient collection used to find a matching ReadEntity
+    * [HIVE-7730] - Extend ReadEntity to add accessed columns from query
+    * [HIVE-7733] - Ambiguous column reference error on query
+    * [HIVE-7738] - tez select sum(decimal) from union all of decimal and null throws NPE
+    * [HIVE-7741] - Don't synchronize WriterImpl.addRow() when dynamic.partition is enabled
+    * [HIVE-7744] - In Windowing Streaming mode Avg and Sum give incorrect results when Wdw size is same as partition size
+    * [HIVE-7753] - Same operand appears on both sides of > in DataType#compareByteArray()
+    * [HIVE-7759] - document hive cli authorization behavior when SQL std auth is enabled
+    * [HIVE-7760] - Constants in VirtualColumn should be final
+    * [HIVE-7764] - Support all JDBC-HiveServer2 authentication modes on a secure cluster
+    * [HIVE-7769] - add --SORT_BEFORE_DIFF to union all .q tests
+    * [HIVE-7770] - Undo backward-incompatible behaviour change introduced by HIVE-7341
+    * [HIVE-7771] - ORC PPD fails for some decimal predicates
+    * [HIVE-7774] - Issues with location path for temporary external tables
+    * [HIVE-7777] - Add CSV Serde based on OpenCSV
+    * [HIVE-7784] - Created the needed indexes on Hive.PART_COL_STATS for CBO 
+    * [HIVE-7786] - add --SORT_BEFORE_DIFF to union all tez .q.out files
+    * [HIVE-7787] - Reading Parquet file with enum in Thrift Encoding throws NoSuchFieldError
+    * [HIVE-7800] - Parquet Column Index Access Schema Size Checking
+    * [HIVE-7807] - Refer to umask property using FsPermission.UMASK_LABEL.
+    * [HIVE-7812] - Disable CombineHiveInputFormat when ACID format is used
+    * [HIVE-7813] - Hive join key not null shouldn't be generated for partition column
+    * [HIVE-7823] - HIVE-6185 removed Partition.getPartition
+    * [HIVE-7824] - CLIServer.getOperationStatus eats ExceutionException
+    * [HIVE-7828] - TestCLIDriver.parquet_join.q is failing on trunk
+    * [HIVE-7829] - Entity.getLocation can throw an NPE
+    * [HIVE-7834] - Use min, max and NDV from the stats to better estimate many to many vs one to many inner joins
+    * [HIVE-7840] - Generated hive-default.xml.template mistakenly refers to property "name"s as "key"s
+    * [HIVE-7841] - Case, When, Lead, Lag UDF is missing annotation
+    * [HIVE-7846] - authorization api should support group, not assume case insensitive role names
+    * [HIVE-7847] - query orc partitioned table fail when table column type change
+    * [HIVE-7851] - Fix NPE in split generation on Tez 0.5
+    * [HIVE-7857] - Hive query fails after Tez session times out
+    * [HIVE-7859] - Tune zlib compression in ORC to account for the encoding strategy
+    * [HIVE-7863] - Potential null reference in TxnDbUtil#prepareDb()
+    * [HIVE-7865] - Extend TestFileDump test case to printout ORC row index information
+    * [HIVE-7878] - add -- SORT_BEFORE_DIFF to optimize_nullscan.q test
+    * [HIVE-7883] - DBTxnManager trying to close already closed metastore client connection
+    * [HIVE-7887] - VectorFileSinkOp does not publish the stats correctly
+    * [HIVE-7889] - Query fails with char partition column
+    * [HIVE-7890] - SessionState creates HMS Client while not impersonating
+    * [HIVE-7891] - Table-creation fails through HCatClient for Oracle-based metastore.
+    * [HIVE-7892] - Thrift Set type not working with Hive
+    * [HIVE-7895] - Storage based authorization should consider sticky bit for drop actions
+    * [HIVE-7897] - ObjectStore not using getPassword() for JDO connection string
+    * [HIVE-7899] - txnMgr should be session specific
+    * [HIVE-7901] - CLONE - pig -useHCatalog with embedded metastore fails to pass command line args to metastore (org.apache.hive.hcatalog version)
+    * [HIVE-7902] - Cleanup hbase-handler/pom.xml dependency list
+    * [HIVE-7911] - Guaranteed ClassCastException in AccumuloRangeGenerator
+    * [HIVE-7913] - Simplify filter predicates for CBO
+    * [HIVE-7914] - Simplify join predicates for CBO to avoid cross products
+    * [HIVE-7915] - Expose High and Low value in plan.ColStatistics
+    * [HIVE-7919] - sql std auth: user with 'admin option' for role should be able to list all users in the role
+    * [HIVE-7927] - Checking sticky bit needs shim
+    * [HIVE-7936] - Support for handling Thrift Union types 
+    * [HIVE-7943] - hive.security.authorization.createtable.owner.grants is ineffective with Default Authorization
+    * [HIVE-7944] - current update stats for columns of a partition of a table is not correct
+    * [HIVE-7946] - CBO: Merge CBO changes to Trunk
+    * [HIVE-7949] - Create table LIKE command doesn't set new owner
+    * [HIVE-7950] - StorageHandler resources aren't added to Tez Session if already Session is already Open
+    * [HIVE-7957] - Revisit event version handling in dynamic partition pruning on Tez
+    * [HIVE-7971] - Support alter table change/replace/add columns for existing partitions
+    * [HIVE-7972] - hiveserver2 specific configuration file is not getting used
+    * [HIVE-7976] - Merge tez branch into trunk (tez 0.5.0)
+    * [HIVE-7982] - Regression in explain with CBO enabled due to issuing query per K,V for the stats
+    * [HIVE-7984] - AccumuloOutputFormat Configuration items from StorageHandler not re-set in Configuration in Tez
+    * [HIVE-7985] - With CBO enabled cross product is generated when a subquery is present
+    * [HIVE-7987] - Storage based authorization  - NPE for drop view
+    * [HIVE-7993] - With CBO enabled Q75 fails with RuntimeException: cannot find field _col69 from [0:_col18,...]
+    * [HIVE-8002] - Deprecate the use of JDBC client only parameters from the map used to transfer HiveConf configs to the server.
+    * [HIVE-8008] - NPE while reading null decimal value
+    * [HIVE-8012] - TestHiveServer2Concurrency is not implemented
+    * [HIVE-8018] - Fix typo in config var name for dynamic partition pruning
+    * [HIVE-8019] - Missing hive 0.13.1 commit in trunk : export/import statement authorization - CVE-2014-0228
+    * [HIVE-8022] - Recursive root scratch directory creation is not using hdfs umask properly 
+    * [HIVE-8023] - Code in HIVE-6380 eats exceptions
+    * [HIVE-8031] - CBO needs to scale down NDV with selectivity to avoid underestimating 
+    * [HIVE-8034] - Don't add colon when no port is specified
+    * [HIVE-8041] - Hadoop-2 build is broken with JDK6
+    * [HIVE-8044] - Container size and hash table size should be taken into account before deciding to do a MapJoin
+    * [HIVE-8045] - SQL standard auth with cli - Errors and configuration issues
+    * [HIVE-8047] - Lazy char/varchar are not using escape char defined in serde params
+    * [HIVE-8051] - Some union queries fail with dynamic partition pruning on tez
+    * [HIVE-8052] - Vectorization: min() on TimeStamp datatype fails with error "Vector aggregate not implemented: min for type: TIMESTAMP"
+    * [HIVE-8056] - SessionState.dropSessionPaths should use FileSystem.getLocal(conf) to delete local files
+    * [HIVE-8062] - Stats collection for columns fails on a partitioned table with null values in partitioning column
+    * [HIVE-8071] - hive shell tries to write hive-exec.jar for each run
+    * [HIVE-8078] - ORC Delta encoding corrupts data when delta overflows long
+    * [HIVE-8081] - "drop index if exists" fails if table specified does not exist
+    * [HIVE-8082] - generateErrorMessage doesn't handle null ast properly
+    * [HIVE-8083] - Authorization DDLs should not enforce hive identifier syntax for user or group
+    * [HIVE-8085] - stats optimizer should not use Description annotation to figure out function mapping (because FunctionRegistry doesn't)
+    * [HIVE-8090] - Potential null pointer reference in WriterImpl#StreamFactory#createStream()
+    * [HIVE-8092] - Vectorized Tez count(*) returns NULL instead of 0 when result is empty
+    * [HIVE-8095] - Tez and Vectorized GROUP BY: ClassCastException: ...HiveDecimal cannot be cast to ...HiveDecimalWritable
+    * [HIVE-8099] - IN operator for partition column fails when the partition column type is DATE
+    * [HIVE-8101] - Hive on spark Issue during compiling hive source
+    * [HIVE-8102] - Partitions of type 'date' behave incorrectly with daylight saving time.
+    * [HIVE-8103] - Read ACID tables with FetchOperator returns no rows
+    * [HIVE-8104] - Insert statements against ACID tables NPE when vectorization is on
+    * [HIVE-8105] - booleans and nulls not handled properly in insert/values
+    * [HIVE-8107] - Bad error m

<TRUNCATED>

[2/2] hive git commit: Add RELEASE_NOTES for previous releases

Posted by su...@apache.org.
Add RELEASE_NOTES for previous releases


Project: http://git-wip-us.apache.org/repos/asf/hive/repo
Commit: http://git-wip-us.apache.org/repos/asf/hive/commit/3e8d832a
Tree: http://git-wip-us.apache.org/repos/asf/hive/tree/3e8d832a
Diff: http://git-wip-us.apache.org/repos/asf/hive/diff/3e8d832a

Branch: refs/heads/branch-1.1.1
Commit: 3e8d832a1a8e2b12029adcb55862cf040098ef0f
Parents: 9846375
Author: Chao Sun <su...@apache.org>
Authored: Thu May 14 15:09:06 2015 -0700
Committer: Chao Sun <su...@apache.org>
Committed: Thu May 14 15:09:06 2015 -0700

----------------------------------------------------------------------
 RELEASE_NOTES.txt | 4992 ++++++++++++++++++++++++++++++++++++++++++++++++
 1 file changed, 4992 insertions(+)
----------------------------------------------------------------------