Apache Hive Changelog

What's new in Apache Hive 2.1.0

Jun 27, 2016
  • Sub-task:
  • [HIVE-9774] - Print yarn application id to console [Spark Branch]
  • [HIVE-10280] - LLAP: Handle errors while sending source state updates to the daemons
  • [HIVE-11107] - Support for Performance regression test suite with TPCDS
  • [HIVE-11417] - Create shims for the row by row read path that is backed by VectorizedRowBatch
  • [HIVE-11526] - LLAP: implement LLAP UI as a separate service - part 1
  • [HIVE-11766] - LLAP: Remove MiniLlapCluster from shim layer after hadoop-1 removal
  • [HIVE-11927] - Implement/Enable constant related optimization rules in Calcite: enable HiveReduceExpressionsRule to fold constants
  • [HIVE-12049] - HiveServer2: Provide an option to write serialized thrift objects in final tasks
  • [HIVE-12159] - Create vectorized readers for the complex types
  • [HIVE-12442] - HiveServer2: Refactor/repackage HiveServer2's Thrift code so that it can be used in the tasks
  • [HIVE-12499] - Add HMS metrics for number of tables and partitions
  • [HIVE-12543] - Disable Hive ConstantPropagate optimizer when CBO has optimized the plan
  • [HIVE-12550] - Cache and display last N completed queries in HS2 WebUI
  • [HIVE-12709] - further improve user level explain
  • [HIVE-12733] - UX improvements for HIVE-12499
  • [HIVE-12781] - Temporarily disable authorization tests that always fail on Jenkins
  • [HIVE-12782] - update the golden files for some tests that fail
  • [HIVE-12793] - Address TestSparkCliDriver.testCliDriver_order2 failure due to HIVE-12782
  • [HIVE-12802] - CBO: Calcite Operator To Hive Operator (Calcite Return Path): MiniTezCliDriver.vector_join_filters.q failure
  • [HIVE-12805] - CBO: Calcite Operator To Hive Operator (Calcite Return Path): MiniTezCliDriver skewjoin.q failure
  • [HIVE-12853] - LLAP: localize permanent UDF jars to daemon and add them to classloader
  • [HIVE-12855] - LLAP: add checks when resolving UDFs to enforce whitelist
  • [HIVE-12857] - LLAP: modify the decider to allow using LLAP with whitelisted UDFs
  • [HIVE-12868] - Fix empty operation-pool metrics
  • [HIVE-12889] - Support COUNT(DISTINCT) for partitioning query.
  • [HIVE-12910] - HBaseStore: initial null value of aggregateData can not call compareTo
  • [HIVE-12918] - LLAP should never create embedded metastore when localizing functions
  • [HIVE-12944] - Support SUM(DISTINCT) for partitioning query.
  • [HIVE-12952] - Show query sub-pages on webui
  • [HIVE-12960] - Migrate Column Stats Extrapolation and UniformDistribution to HBaseStore
  • [HIVE-12961] - Migrate Column Stats UniformDistribution to HBaseStore
  • [HIVE-13005] - CBO: Calcite Operator To Hive Operator (Calcite Return Path): RexNode convert(ExprNodeConstantDesc literal) decimal support bug
  • [HIVE-13068] - Disable Hive ConstantPropagate optimizer when CBO has optimized the plan II
  • [HIVE-13129] - CliService leaks HMS connection
  • [HIVE-13130] - HS2 changes : API calls for retrieving primary keys and foreign keys information
  • [HIVE-13198] - Authorization issues with cascading views
  • [HIVE-13290] - Support primary keys/foreign keys constraint as part of create table command in Hive
  • [HIVE-13318] - Cache the result of getTable from metastore
  • [HIVE-13341] - Stats state is not captured correctly: differentiate load table and create table
  • [HIVE-13349] - Metastore Changes : API calls for retrieving primary keys and foreign keys information
  • [HIVE-13350] - Support Alter commands for Rely/NoRely novalidate for PK/FK constraints
  • [HIVE-13351] - Support drop Primary Key/Foreign Key constraints
  • [HIVE-13358] - Stats state is not captured correctly: turn off stats optimizer for sampled table
  • [HIVE-13360] - Refactoring Hive Authorization
  • [HIVE-13362] - Commit binary file required for HIVE-13361
  • [HIVE-13420] - Clarify HS2 WebUI Query 'Elapsed TIme'
  • [HIVE-13424] - Refactoring the code to pass a QueryState object rather than HiveConf object
  • [HIVE-13442] - LLAP: refactor submit API to be amenable to signing
  • [HIVE-13444] - LLAP: add HMAC signatures to LLAP; verify them on LLAP side
  • [HIVE-13477] - Set HivePrivilegeObjectType to TABLE_OR_VIEW
  • [HIVE-13486] - Cast the column type for column masking
  • [HIVE-13505] - Skip running TestDummy where possibe during precommit builds
  • [HIVE-13507] - Improved logging for ptest
  • [HIVE-13511] - Run clidriver tests from within the qtest dir for the precommit tests
  • [HIVE-13520] - Don't allow any test to run for longer than 60minutes in the ptest setup
  • [HIVE-13541] - Pass view's ColumnAccessInfo to HiveAuthorizer
  • [HIVE-13564] - Deprecate HIVE_STATS_COLLECT_RAWDATASIZE
  • [HIVE-13565] - thrift change
  • [HIVE-13566] - Auto-gather column stats - phase 1
  • [HIVE-13620] - Merge llap branch work to master
  • [HIVE-13637] - Fold CASE into NVL when CBO optimized the plan
  • [HIVE-13638] - CBO rule to pull up constants through Sort/Limit
  • [HIVE-13639] - CBO rule to pull up constants through Union
  • [HIVE-13654] - Add JAVA8_URL to jenkins-submit-build.sh
  • [HIVE-13722] - Add flag to detect constants to CBO pull up rules
  • [HIVE-13758] - "Create table like" command should initialize the basic stats for the table
  • [HIVE-13786] - Fix the unit test failure org.apache.hive.service.cli.session.TestHiveSessionImpl.testLeakOperationHandle
  • [HIVE-13794] - HIVE_RPC_QUERY_PLAN should always be set when generating LLAP splits
  • [HIVE-13806] - Extension to folding NOT expressions in CBO
  • [HIVE-13807] - Extend metadata provider to pull up predicates through Union
  • [HIVE-13808] - Use constant expressions to backtrack when we create ReduceSink
  • [HIVE-13838] - Set basic stats as inaccurate for all ACID tables
  • [HIVE-13852] - NPE in TaskLocationHints during LLAP GetSplits request
  • [HIVE-13905] - optimize ColumnStatsTask::constructColumnStatsFromPackedRows to have lesser number of getTable calls
  • [HIVE-13910] - [Ranger-Hive] select from a table is not working if used as
  • [HIVE-13922] - Optimize the code path that analyzes/updates col stats
  • [HIVE-13942] - Correctness of CASE folding in the presence of NULL values
  • [HIVE-13984] - Use multi-threaded approach to listing files for msck
  • Bug:
  • [HIVE-1608] - use sequencefile as the default for storing intermediate results
  • [HIVE-4662] - first_value can't have more than one order by column
  • [HIVE-8343] - Return value from BlockingQueue.offer() is not checked in DynamicPartitionPruner
  • [HIVE-9144] - Beeline + Kerberos shouldn't prompt for unused username + password
  • [HIVE-9457] - Fix obsolete parameter name in HiveConf description of hive.hashtable.initialCapacity
  • [HIVE-9499] - hive.limit.query.max.table.partition makes queries fail on non-partitioned tables
  • [HIVE-9534] - incorrect result set for query that projects a windowed aggregate
  • [HIVE-9862] - Vectorized execution corrupts timestamp values
  • [HIVE-10171] - Create a storage-api module
  • [HIVE-10187] - Avro backed tables don't handle cyclical or recursive records
  • [HIVE-10632] - Make sure TXN_COMPONENTS gets cleaned up if table is dropped before compaction.
  • [HIVE-10729] - Query failed when select complex columns from joinned table (tez map join only)
  • [HIVE-11097] - HiveInputFormat uses String.startsWith to compare splitPath and PathToAliases
  • [HIVE-11388] - Allow ACID Compactor components to run in multiple metastores
  • [HIVE-11427] - Location of temporary table for CREATE TABLE SELECT broken by HIVE-7079
  • [HIVE-11484] - Fix ObjectInspector for Char and VarChar
  • [HIVE-11550] - ACID queries pollute HiveConf
  • [HIVE-11675] - make use of file footer PPD API in ETL strategy or separate strategy
  • [HIVE-11716] - Reading ACID table from non-acid session should raise an error
  • [HIVE-11806] - Create test for HIVE-11174
  • [HIVE-11828] - beeline -f fails on scripts with tabs between column type and comment
  • [HIVE-11848] - tables in subqueries don't get locked
  • [HIVE-11866] - Add framework to enable testing using LDAPServer using LDAP protocol
  • [HIVE-11935] - Race condition in HiveMetaStoreClient: isCompatibleWith and close
  • [HIVE-11959] - add simple test case for TestTableIterable
  • [HIVE-12039] - Temporarily disable TestSSL#testSSLVersion
  • [HIVE-12045] - ClassNotFoundException for GenericUDF [Spark Branch]
  • [HIVE-12064] - prevent transactional=false
  • [HIVE-12075] - add analyze command to explictly cache file metadata in HBase metastore
  • [HIVE-12165] - wrong result when hive.optimize.sampling.orderby=true with some aggregate functions
  • [HIVE-12367] - Lock/unlock database should add current database to inputs and outputs of authz hook
  • [HIVE-12395] - Turn off CBO for hive.support.special.characters.tablename tests until feature is complete
  • [HIVE-12441] - Driver.acquireLocksAndOpenTxn() should only call recordValidTxns() when needed
  • [HIVE-12466] - SparkCounter not initialized error
  • [HIVE-12478] - Improve Hive/Calcite Transitive Predicate inference
  • [HIVE-12502] - to_date UDF cannot accept NULLs of VOID type
  • [HIVE-12528] - don't start HS2 Tez sessions in a single thread
  • [HIVE-12529] - HiveTxnManager.acquireLocks() should not block forever
  • [HIVE-12538] - After set spark related config, SparkSession never get reused
  • [HIVE-12552] - Wrong number of reducer estimation causing job to fail
  • [HIVE-12554] - Fix Spark branch build after merge [Spark Branch]
  • [HIVE-12558] - LLAP: output QueryFragmentCounters somewhere
  • [HIVE-12567] - Enhance TxnHandler retry logic to handle ORA-08176
  • [HIVE-12568] - Provide an option to specify network interface used by Spark remote client [Spark Branch]
  • [HIVE-12570] - Incorrect error message Expression not in GROUP BY key thrown instead of Invalid function
  • [HIVE-12608] - Parquet Schema Evolution doesn't work when a column is dropped from array
  • [HIVE-12612] - beeline always exits with 0 status when reading query from standard input
  • [HIVE-12616] - NullPointerException when spark session is reused to run a mapjoin
  • [HIVE-12619] - (Parquet) Switching the field order within an array of structs causes the query to fail
  • [HIVE-12620] - Misc improvement to Acid module
  • [HIVE-12635] - Hive should return the latest hbase cell timestamp as the row timestamp value
  • [HIVE-12643] - For self describing InputFormat don't replicate schema information in partitions
  • [HIVE-12650] - Improve error messages for Hive on Spark in case the cluster has no resources available
  • [HIVE-12673] - Orcfiledump throws NPE when no files are available
  • [HIVE-12708] - Hive on Spark doesn't work with Kerboresed HBase [Spark Branch]
  • [HIVE-12723] - stats_filemetadata test was added to the wrong driver
  • [HIVE-12725] - CompactionTxnHandler.findNextToCompact() may produce "Operation not allowed after ResultSet closed"
  • [HIVE-12749] - Constant propagate returns string values in incorrect format
  • [HIVE-12752] - Change the schema version to 2.1.0
  • [HIVE-12757] - Fix TestCodahaleMetrics#testFileReporting
  • [HIVE-12780] - Fix the output of the history command in Beeline
  • [HIVE-12784] - Group by SemanticException: Invalid column reference
  • [HIVE-12789] - Fix output twice in the history command of Beeline
  • [HIVE-12792] - HIVE-12075 didn't update operation type for plugins
  • [HIVE-12795] - Vectorized execution causes ClassCastException
  • [HIVE-12799] - Always use Schema Evolution for ACID
  • [HIVE-12808] - Logical PPD: Push filter clauses through PTF(Windowing) into TS
  • [HIVE-12834] - Fix to accept the arrow keys in BeeLine CLI
  • [HIVE-12837] - Better memory estimation/allocation for hybrid grace hash join during hash table loading
  • [HIVE-12848] - Change derby scripts, for HMS upgrade tests, to accomodate 32-bit VM.
  • [HIVE-12862] - Fix pom.xml to package hiveserver2.jsp
  • [HIVE-12865] - Exchange partition does not show inputs field for post/pre execute hooks
  • [HIVE-12867] - Semantic Exception Error Msg should be with in the range of "10000 to 19999"
  • [HIVE-12880] - spark-assembly causes Hive class version problems
  • [HIVE-12885] - LDAP Authenticator improvements
  • [HIVE-12886] - invalid column reference error on grouping by constant
  • [HIVE-12887] - Handle ORC schema on read with fewer columns than file schema (after Schema Evolution changes)
  • [HIVE-12888] - TestSparkNegativeCliDriver does not run in Spark mode[Spark Branch]
  • [HIVE-12894] - Detect whether ORC is reading from ACID table correctly for Schema Evolution
  • [HIVE-12909] - Some encryption q-tests fail because trash is disabled in encryption_with_trash.q
  • [HIVE-12927] - HBase metastore: sequences should be one per row, not all in one row
  • [HIVE-12933] - Beeline will hang when authenticating with PAM when libjpam.so is missing
  • [HIVE-12937] - DbNotificationListener unable to clean up old notification events
  • [HIVE-12941] - Unexpected result when using MIN() on struct with NULL in first field
  • [HIVE-12951] - Reduce Spark executor prewarm timeout to 5s
  • [HIVE-12963] - LIMIT statement with SORT BY creates additional MR job with hardcoded only one reducer
  • [HIVE-12965] - Insert overwrite local directory should perserve the overwritten directory permission
  • [HIVE-12966] - Change some ZooKeeperHiveLockManager logs to debug
  • [HIVE-12969] - Fix Javadoc for PredicatePushDown class
  • [HIVE-12976] - MetaStoreDirectSql doesn't batch IN lists in all cases
  • [HIVE-12981] - ThriftCLIService uses incompatible getShortName() implementation
  • [HIVE-12990] - LLAP: ORC cache NPE without FileID support
  • [HIVE-12992] - Hive on tez: Bucket map join plan is incorrect
  • [HIVE-12993] - user and password supplied from URL is overwritten by the empty user and password of the JDBC connection string when it's calling from beeline
  • [HIVE-12995] - LLAP: Synthetic file ids need collision checks
  • [HIVE-12996] - Temp tables shouldn't be locked
  • [HIVE-12998] - ORC FileDump.printJsonData() does not close RecordReader
  • [HIVE-12999] - Tez: Vertex creation reduce NN IPCs
  • [HIVE-13002] - Hive object is not thread safe, is shared via a threadlocal and thus should not be passed around too much - part 1
  • [HIVE-13008] - WebHcat DDL commands in secure mode NPE when default FileSystem doesn't support delegation tokens
  • [HIVE-13009] - Fix add_jar_file.q on Windows
  • [HIVE-13013] - Further Improve concurrency in TxnHandler
  • [HIVE-13015] - Bundle Log4j2 jars with hive-exec
  • [HIVE-13016] - ORC FileDump recovery utility fails in Windows
  • [HIVE-13017] - Child process of HiveServer2 fails to get delegation token from non default FileSystem
  • [HIVE-13020] - Hive Metastore and HiveServer2 to Zookeeper fails with IBM JDK
  • [HIVE-13021] - GenericUDAFEvaluator.isEstimable(agg) always returns false
  • [HIVE-13036] - Split hive.root.logger separately to make it compatible with log4j1.x (for remaining services)
  • [HIVE-13038] - LLAP needs service class registration for token identifier
  • [HIVE-13039] - BETWEEN predicate is not functioning correctly with predicate pushdown on Parquet table
  • [HIVE-13042] - OrcFiledump runs into an ArrayIndexOutOfBoundsException when running against old versions of ORC files
  • [HIVE-13043] - Reload function has no impact to function registry
  • [HIVE-13045] - move guava dependency back to 14 after HIVE-12952
  • [HIVE-13047] - Disabling Web UI leads to NullPointerException
  • [HIVE-13048] - Rogue SQL statement in an upgrade SQL file for oracle.
  • [HIVE-13051] - Deadline class has numerous issues
  • [HIVE-13052] - Allow tests to start MiniHS2 for manual testing
  • [HIVE-13056] - delegation tokens do not work with HS2 when used with http transport and kerberos
  • [HIVE-13057] - Remove duplicate copies of TableDesc property values in PartitionDesc
  • [HIVE-13062] - Hive metastore test failing
  • [HIVE-13064] - Serde properties are not working while expecting output in a directory
  • [HIVE-13065] - Hive throws NPE when writing map type data to a HBase backed table
  • [HIVE-13070] - Precommit HMS tests should run in addition to precommit normal tests, not instead of
  • [HIVE-13077] - LLAP: Scrub daemon-site.xml from client configs
  • [HIVE-13079] - LLAP: Allow reading log4j properties from default JAR resources
  • [HIVE-13082] - Enable constant propagation optimization in query with left semi join
  • [HIVE-13083] - Writing HiveDecimal to ORC can wrongly suppress present stream
  • [HIVE-13084] - Vectorization add support for PROJECTION Multi-AND/OR
  • [HIVE-13086] - LLAP: Programmatically initialize log4j2 to print out the properties location
  • [HIVE-13087] - LLAP: Print STW pause time and useful application time
  • [HIVE-13089] - Rounding in Stats for equality expressions
  • [HIVE-13090] - Hive metastore crashes on NPE with ZooKeeperTokenStore
  • [HIVE-13093] - hive metastore does not exit on start failure
  • [HIVE-13094] - CBO: Assertion error in Case expression
  • [HIVE-13096] - Cost to choose side table in MapJoin conversion based on cumulative cardinality
  • [HIVE-13099] - Non-SQLOperations lead to Web UI NPE
  • [HIVE-13100] - Revert HIVE-13015 that bundles log4j2 jars in hive-exec.jar
  • [HIVE-13101] - NullPointerException in HiveLexer.g
  • [HIVE-13105] - LLAP token hashCode and equals methods are incorrect
  • [HIVE-13108] - Operators: SORT BY randomness is not safe with network partitions
  • [HIVE-13110] - LLAP: Package log4j2 jars into Slider pkg
  • [HIVE-13111] - Fix timestamp / interval_day_time wrong results with HIVE-9862
  • [HIVE-13112] - Expose Lineage information in case of CTAS
  • [HIVE-13115] - MetaStore Direct SQL getPartitions call fail when the columns schemas for a partition are null
  • [HIVE-13126] - Clean up MapJoinOperator properly to avoid object cache reuse with unintentional states
  • [HIVE-13128] - NullScan fails on a secure setup
  • [HIVE-13131] - TezWork queryName can be null after HIVE-12523
  • [HIVE-13134] - JDBC: JDBC Standalone should not be in the lib dir by default
  • [HIVE-13135] - LLAP: HTTPS Webservices needs trusted keystore configs
  • [HIVE-13141] - Hive on Spark over HBase should accept parameters starting with "zookeeper.znode"
  • [HIVE-13144] - HS2 can leak ZK ACL objects when curator retries to create the persistent ephemeral node
  • [HIVE-13146] - OrcFile table property values are case sensitive
  • [HIVE-13151] - Clean up UGI objects in FileSystem cache for transactions
  • [HIVE-13153] - SessionID is appended to thread name twice
  • [HIVE-13160] - HS2 unable to load UDFs on startup when HMS is not ready
  • [HIVE-13163] - ORC MemoryManager thread checks are fatal, should WARN
  • [HIVE-13169] - HiveServer2: Support delegation token based connection when using http transport
  • [HIVE-13174] - Remove Vectorizer noise in logs
  • [HIVE-13175] - Disallow making external tables transactional
  • [HIVE-13178] - Enhance ORC Schema Evolution to handle more standard data type conversions
  • [HIVE-13184] - LLAP: DAG credentials (e.g. HBase tokens) are not passed to the tasks in Tez plugin
  • [HIVE-13185] - orc.ReaderImp.ensureOrcFooter() method fails on small text files with IndexOutOfBoundsException
  • [HIVE-13186] - ALTER TABLE RENAME should lowercase table name and hdfs location
  • [HIVE-13197] - Add adapted constprog2.q and constprog_partitioner.q tests back
  • [HIVE-13199] - NDC stopped working in LLAP logging
  • [HIVE-13200] - Aggregation functions returning empty rows on partitioned columns
  • [HIVE-13201] - Compaction shouldn't be allowed on non-ACID table
  • [HIVE-13209] - metastore get_delegation_token fails with null ip address
  • [HIVE-13210] - Revert changes in HIVE-12994 related to metastore
  • [HIVE-13211] - normalize Hive.get overloads to go thru one path
  • [HIVE-13213] - make DbLockManger work for non-acid resources
  • [HIVE-13216] - ORC Reader will leave file open until GC when opening a malformed ORC file
  • [HIVE-13217] - Replication for HoS mapjoin small file needs to respect dfs.replication.max
  • [HIVE-13218] - LLAP: better configs part 1
  • [HIVE-13223] - HoS may hang for queries that run on 0 splits
  • [HIVE-13227] - LLAP: Change daemon initialization logs from INFO to WARN
  • [HIVE-13232] - Aggressively drop compression buffers in ORC OutStreams
  • [HIVE-13233] - Use min and max values to estimate better stats for comparison operators
  • [HIVE-13236] - LLAP: token renewal interval needs to be set
  • [HIVE-13237] - Select parquet struct field with upper case throws NPE
  • [HIVE-13240] - GroupByOperator: Drop the hash aggregates when closing operator
  • [HIVE-13241] - LLAP: Incremental Caching marks some small chunks as "incomplete CB"
  • [HIVE-13242] - DISTINCT keyword is dropped by the parser for windowing
  • [HIVE-13243] - Hive drop table on encyption zone fails for external tables
  • [HIVE-13246] - Add log line to ORC writer to print out the file path
  • [HIVE-13251] - hive can't read the decimal in AVRO file generated from previous version
  • [HIVE-13255] - FloatTreeReader.nextVector is expensive
  • [HIVE-13260] - ReduceSinkDeDuplication throws exception when pRS key is empty
  • [HIVE-13261] - Can not compute column stats for partition when schema evolves
  • [HIVE-13262] - LLAP: Remove log levels from DebugUtils
  • [HIVE-13263] - Vectorization: Unable to vectorize regexp_extract/regexp_replace " Udf: GenericUDFBridge, is not supported"
  • [HIVE-13267] - Vectorization: Add SelectLikeStringColScalar for non-filter operations
  • [HIVE-13269] - Simplify comparison expressions using column stats
  • [HIVE-13283] - LLAP: make sure IO elevator is enabled by default in the daemons
  • [HIVE-13285] - Orc concatenation may drop old files from moving to final path
  • [HIVE-13286] - Query ID is being reused across queries
  • [HIVE-13287] - Add logic to estimate stats for IN operator
  • [HIVE-13291] - ORC BI Split strategy should consider block size instead of file size
  • [HIVE-13293] - Query occurs performance degradation after enabling parallel order by for Hive on Spark
  • [HIVE-13294] - AvroSerde leaks the connection in a case when reading schema from a url
  • [HIVE-13296] - Add vectorized Q test with complex types showing count(*) etc work correctly
  • [HIVE-13298] - nested join support causes undecipherable errors in SemanticAnalyzer
  • [HIVE-13299] - Column Names trimmed of leading and trailing spaces
  • [HIVE-13300] - Hive on spark throws exception for multi-insert with join
  • [HIVE-13302] - direct SQL: cast to date doesn't work on Oracle
  • [HIVE-13303] - spill to YARN directories, not tmp, when available
  • [HIVE-13310] - Vectorized Projection Comparison Number Column to Scalar broken for !noNulls and selectedInUse
  • [HIVE-13311] - MetaDataFormatUtils throws NPE when HiveDecimal.create is null
  • [HIVE-13313] - TABLESAMPLE ROWS feature broken for Vectorization
  • [HIVE-13320] - Apply HIVE-11544 to explicit conversions as well as implicit ones
  • [HIVE-13322] - LLAP: ZK registry throws at shutdown due to slf4j trying to initialize a log4j logger
  • [HIVE-13324] - LLAP: history log for FRAGMENT_START doesn't log DagId correctly
  • [HIVE-13325] - Excessive logging when ORC PPD fails type conversions
  • [HIVE-13326] - HiveServer2: Make ZK config publishing configurable
  • [HIVE-13327] - SessionID added to HS2 threadname does not trim spaces
  • [HIVE-13330] - ORC vectorized string dictionary reader does not differentiate null vs empty string dictionary
  • [HIVE-13332] - support dumping all row indexes in ORC FileDump
  • [HIVE-13333] - StatsOptimizer throws ClassCastException
  • [HIVE-13338] - Differences in vectorized_casts.q output for vectorized and non-vectorized runs
  • [HIVE-13339] - Vectorization: GenericUDFBetween in Projection mode
  • [HIVE-13340] - Vectorization: from_unixtime UDF shim
  • [HIVE-13342] - Improve logging in llap decider and throw exception in case llap mode is all but we cannot run in llap.
  • [HIVE-13343] - Need to disable hybrid grace hash join in llap mode except for dynamically partitioned hash join
  • [HIVE-13346] - LLAP doesn't update metadata priority when reusing from cache; some tweaks in LRFU policy
  • [HIVE-13361] - Orc concatenation should enforce the compression buffer size
  • [HIVE-13372] - Hive Macro overwritten when multiple macros are used in one column
  • [HIVE-13373] - Use most specific type for numerical constants
  • [HIVE-13378] - LLAP help formatter is too narrow
  • [HIVE-13379] - HIVE-12851 args do not work (slider-keytab-dir, etc.)
  • [HIVE-13381] - Timestamp & date should have precedence in type hierarchy than string group
  • [HIVE-13388] - Fix inconsistent content due to Thrift changes
  • [HIVE-13390] - HiveServer2: Add more test to ZK service discovery using MiniHS2
  • [HIVE-13394] - Analyze table fails in tez on empty partitions/files/tables
  • [HIVE-13395] - Lost Update problem in ACID
  • [HIVE-13396] - LLAP: Include hadoop-metrics2.properties file LlapServiceDriver
  • [HIVE-13401] - Kerberized HS2 with LDAP auth enabled fails kerberos/delegation token authentication
  • [HIVE-13402] - Temporarily disable failing spark tests
  • [HIVE-13405] - Fix Connection Leak in OrcRawRecordMerger
  • [HIVE-13407] - Add more subtlety to TezCompiler Perf Logging
  • [HIVE-13410] - PerfLog metrics scopes not closed if there are exceptions on HS2
  • [HIVE-13415] - Decouple Sessions from thrift binary transport
  • [HIVE-13417] - Some vector operators return "OP" as name
  • [HIVE-13428] - ZK SM in LLAP should have unique paths per cluster
  • [HIVE-13434] - BaseSemanticAnalyzer.unescapeSQLString doesn't unescape u0000 style character literals.
  • [HIVE-13437] - httpserver getPort does not return the actual port when attempting to use a dynamic port
  • [HIVE-13438] - Add a service check script for llap
  • [HIVE-13439] - JDBC: provide a way to retrieve GUID to query Yarn ATS
  • [HIVE-13440] - remove hiveserver1 scripts and thrift generated files
  • [HIVE-13445] - LLAP: token should encode application and cluster ids
  • [HIVE-13446] - LLAP: set default management protocol acls to deny all
  • [HIVE-13447] - LLAP: check ZK acls for registry and fail if they are too permissive
  • [HIVE-13448] - LLAP: check ZK acls for ZKSM and fail if they are too permissive
  • [HIVE-13449] - LLAP: HS2 should get the token directly, rather than from LLAP
  • [HIVE-13458] - Heartbeater doesn't fail query when heartbeat fails
  • [HIVE-13462] - HiveResultSetMetaData.getPrecision() fails for NULL columns
  • [HIVE-13463] - Fix ImportSemanticAnalyzer to allow for different src/dst filesystems
  • [HIVE-13465] - Add ZK settings to MiniLlapCluster clusterSpecificConfiguration
  • [HIVE-13467] - Show llap info on hs2 ui when available
  • [HIVE-13476] - HS2 ShutdownHookManager holds extra of Driver instance in nested compile
  • [HIVE-13480] - Add hadoop2 metrics reporter for Codahale metrics
  • [HIVE-13485] - Session id appended to thread name multiple times.
  • [HIVE-13487] - Finish time is wrong when perflog is missing SUBMIT_TO_RUNNING
  • [HIVE-13488] - Restore dag summary when tez exec print summary enabled and in-place updates disabled
  • [HIVE-13491] - Testing : log thread stacks when metastore fails to start
  • [HIVE-13492] - TestMiniSparkOnYarnCliDriver.testCliDriver_index_bitmap3 is failing on master
  • [HIVE-13493] - Fix TransactionBatchImpl.getCurrentTxnId() and mis logging fixes
  • [HIVE-13494] - LLAP: Some metrics from daemon are not exposed to hadoop-metrics2
  • [HIVE-13498] - cleardanglingscratchdir does not work if scratchdir is not on defaultFs
  • [HIVE-13500] - Launching big queries fails with Out of Memory Exception
  • [HIVE-13502] - Beeline doesnt support session parameters in JDBC URL as documentation states.
  • [HIVE-13510] - Dynamic partitioning doesn’t work when remote metastore is used
  • [HIVE-13512] - Make initializing dag ids in TezWork thread safe for parallel compilation
  • [HIVE-13513] - cleardanglingscratchdir does not work in some version of HDFS
  • [HIVE-13514] - TestClearDanglingScratchDir fail on branch-1
  • [HIVE-13518] - Hive on Tez: Shuffle joins do not choose the right 'big' table.
  • [HIVE-13522] - regexp_extract.q hangs on master
  • [HIVE-13523] - Fix connection leak in ORC RecordReader and refactor for unit testing
  • [HIVE-13525] - HoS hangs when job is empty
  • [HIVE-13527] - Using deprecated APIs in HBase client causes zookeeper connection leaks.
  • [HIVE-13530] - Hive on Spark throws Kryo exception in some cases
  • [HIVE-13533] - Remove AST dump
  • [HIVE-13542] - Missing stats for tables in TPCDS performance regression suite
  • [HIVE-13551] - Make cleardanglingscratchdir work on Windows
  • [HIVE-13552] - Templeton job does not write out log files on InterruptedException
  • [HIVE-13553] - CTE with upperCase alias throws exception
  • [HIVE-13561] - HiveServer2 is leaking ClassLoaders when add jar / temporary functions are used
  • [HIVE-13563] - Hive Streaming does not honor orc.compress.size and orc.stripe.size table properties
  • [HIVE-13568] - Add UDFs to support column-masking
  • [HIVE-13570] - Some queries with Union all fail when CBO is off
  • [HIVE-13572] - Redundant setting full file status in Hive::copyFiles
  • [HIVE-13585] - Add counter metric for direct sql failures
  • [HIVE-13588] - NPE is thrown from MapredLocalTask.executeInChildVM
  • [HIVE-13592] - metastore calls map is not thread safe
  • [HIVE-13596] - HS2 should be able to get UDFs on demand from metastore
  • [HIVE-13597] - revert HIVE-12892
  • [HIVE-13598] - Describe extended table should show the primary keys/foreign keys associated with the table
  • [HIVE-13599] - LLAP: Incorrect handling of the preemption queue on finishable state updates
  • [HIVE-13602] - TPCH q16 return wrong result when CBO is on
  • [HIVE-13608] - We should provide better error message while constraints with duplicate names are created
  • [HIVE-13609] - Fix UDTFs to allow local fetch task to fetch rows forwarded by GenericUDTF.close()
  • [HIVE-13618] - Trailing spaces in partition column will be treated differently
  • [HIVE-13619] - Bucket map join plan is incorrect
  • [HIVE-13621] - compute stats in certain cases fails with NPE
  • [HIVE-13622] - WriteSet tracking optimizations
  • [HIVE-13628] - Support for permanent functions - error handling if no restart
  • [HIVE-13632] - Hive failing on insert empty array into parquet table
  • [HIVE-13642] - Update GUESS_FIELDS option in .reviewboardrc to support current version of RBTools.
  • [HIVE-13645] - Beeline needs null-guard around hiveVars and hiveConfVars read
  • [HIVE-13646] - make hive.optimize.sort.dynamic.partition compatible with ACID tables
  • [HIVE-13653] - improve config error messages for LLAP cache size/etc
  • [HIVE-13656] - need to set direct memory limit higher in LlapServiceDriver for certain edge case configurations
  • [HIVE-13657] - Spark driver stderr logs should appear in hive client logs
  • [HIVE-13659] - An empty where condition leads to vectorization exceptions instead of throwing a compile time error
  • [HIVE-13660] - Vectorizing IN expression with list of columns throws java.lang.ClassCastException ExprNodeColumnDesc cannot be cast to ExprNodeConstantDesc
  • [HIVE-13669] - LLAP: io.enabled config is ignored on the server side
  • [HIVE-13671] - Add PerfLogger to log4j2.properties logger
  • [HIVE-13676] - Tests failing because metastore doesn't come up
  • [HIVE-13682] - EOFException with fast hashtable
  • [HIVE-13683] - Remove erroneously included patch file
  • [HIVE-13686] - TestRecordReaderImpl is deleting target/tmp causing all the tests after it to fail
  • [HIVE-13691] - No record with CQ_ID=0 found in COMPACTION_QUEUE
  • [HIVE-13693] - Multi-insert query drops Filter before file output when there is a.val b.val
  • [HIVE-13699] - Make JavaDataModel#get thread safe for parallel compilation
  • [HIVE-13700] - TestHiveOperationType is failing on master
  • [HIVE-13701] - LLAP: Use different prefix for llap task scheduler metrics
  • [HIVE-13705] - Insert into table removes existing data
  • [HIVE-13710] - LLAP registry ACL check causes error due to namespacing
  • [HIVE-13712] - LLAP: LlapServiceDriver should package hadoop-metrics2-llapdaemon.properties when available
  • [HIVE-13719] - TestConverters fails on master
  • [HIVE-13720] - TestLlapTaskCommunicator fails on master
  • [HIVE-13728] - TestHBaseSchemaTool fails on master
  • [HIVE-13729] - FileSystem$Cache leaks in FileUtils.checkFileAccessWithImpersonation
  • [HIVE-13730] - Avoid double spilling the same partition when memory threshold is set very low
  • [HIVE-13743] - Data move codepath is broken with hive (2.1.0-SNAPSHOT)
  • [HIVE-13751] - LlapOutputFormatService should have a configurable send buffer size
  • [HIVE-13753] - Make metastore client thread safe in DbTxnManager
  • [HIVE-13767] - Wrong type inferred in Semijoin condition leads to AssertionError
  • [HIVE-13784] - Hive Metastore start failed on Oracle DB
  • [HIVE-13787] - LLAP: bug in recent security patches (wrong argument order; using full user name in id)
  • [HIVE-13809] - Hybrid Grace Hash Join memory usage estimation didn't take into account the bloom filter size
  • [HIVE-13810] - insert overwrite select from some table fails throwing org.apache.hadoop.security.AccessControlException
  • [HIVE-13818] - Fast Vector MapJoin Long hashtable has to handle all integral types
  • [HIVE-13821] - OrcSplit groups all delta files together into a single split
  • [HIVE-13823] - Remove unnecessary log line in common join operator
  • [HIVE-13826] - Make VectorUDFAdaptor work for GenericUDFBetween when used as FILTER
  • [HIVE-13831] - Error pushing predicates to HBase storage handler
  • [HIVE-13832] - Add missing license header to files
  • [HIVE-13833] - Add an initial delay when starting the heartbeat
  • [HIVE-13837] - current_timestamp() output format is different in some cases
  • [HIVE-13840] - Orc split generation is reading file footers twice
  • [HIVE-13841] - Orc split generation returns different strategies with cache enabled vs disabled
  • [HIVE-13844] - Invalid index handler in org.apache.hadoop.hive.ql.index.HiveIndex class
  • [HIVE-13845] - Delete beeline/pom.xml.orig
  • [HIVE-13849] - Wrong plan for hive.optimize.sort.dynamic.partition=true
  • [HIVE-13853] - Add X-XSRF-Header filter to HS2 HTTP mode and WebHCat
  • [HIVE-13856] - Fetching transaction batches during ACID streaming against Hive Metastore using Oracle DB fails
  • [HIVE-13857] - insert overwrite select from some table fails throwing org.apache.hadoop.security.AccessControlException - II
  • [HIVE-13858] - LLAP: A preempted task can end up waiting on completeInitialization if some part of the executing code suppressed the interrupt
  • [HIVE-13859] - mask() UDF not retaining day and month field values
  • [HIVE-13861] - Fix up nullability issue that might be created by pull up constants rules
  • [HIVE-13862] - org.apache.hadoop.hive.metastore.MetaStoreDirectSql.getNumPartitionsViaSqlFilter falls back to ORM
  • [HIVE-13863] - Improve AnnotateWithStatistics with support for cartesian product
  • [HIVE-13867] - restore HiveAuthorizer interface changes
  • [HIVE-13870] - Decimal vector is not resized correctly
  • [HIVE-13876] - Vectorization: Port HIVE-11544 to LazySimpleDeserializeRead
  • [HIVE-13885] - Hive session close is not resetting thread name
  • [HIVE-13903] - getFunctionInfo is downloading jar on every call
  • [HIVE-13904] - Ignore case when retrieving ColumnInfo from RowResolver
  • [HIVE-13909] - upgrade ACLs in LLAP registry when the cluster is upgraded to secure
  • [HIVE-13911] - load inpath fails throwing org.apache.hadoop.security.AccessControlException
  • [HIVE-13912] - DbTxnManager.commitTxn(): ORA-00918: column ambiguously defined
  • [HIVE-13924] - (Vectorization) Error evaluating ((bool0 and (not bool1)) or (bool1 and (not bool0)))
  • [HIVE-13927] - Adding missing header to Java files
  • [HIVE-13929] - org.apache.hadoop.hive.metastore.api.DataOperationType class not found error when a job is submitted by hive
  • [HIVE-13941] - Improve errors returned from SchemaTool
  • [HIVE-13948] - Incorrect timezone handling in Writable results in wrong dates in queries
  • [HIVE-13953] - Issues in HiveLockObject equals method
  • [HIVE-13954] - Parquet logs should go to STDERR
  • [HIVE-13955] - Include service-rpc and llap-ext-client in packaging files
  • [HIVE-13957] - vectorized IN is inconsistent with non-vectorized (at least for decimal in (string))
  • [HIVE-13959] - MoveTask should only release its query associated locks
  • [HIVE-13961] - ACID: Major compaction fails to include the original bucket files if there's no delta directory
  • [HIVE-13972] - Resolve class dependency issue introduced by HIVE-13354
  • [HIVE-13973] - Extend support for other primitive types in windowing expressions
  • [HIVE-14006] - Hive query with UNION ALL fails with ArrayIndexOutOfBoundsException
  • [HIVE-14008] - Duplicate line in LLAP SecretManager
  • [HIVE-14010] - parquet-logging.properties from HIVE_CONF_DIR should be used when available
  • [HIVE-14015] - SMB MapJoin failed for Hive on Spark when kerberized
  • [HIVE-14020] - Hive MS restart failed during EU with ORA-00922 error as part of DB schema upgrade
  • Improvement:
  • [HIVE-4570] - More information to user on GetOperationStatus in Hive Server2 when query is still executing
  • [HIVE-4924] - JDBC: Support query timeout for jdbc
  • [HIVE-5370] - format_number udf should take user specifed format as argument
  • [HIVE-6535] - JDBC: provide an async API to execute query and fetch results
  • [HIVE-10115] - HS2 running on a Kerberized cluster should offer Kerberos(GSSAPI) and Delegation token(DIGEST) when alternate authentication is enabled
  • [HIVE-10249] - ACID: show locks should show who the lock is waiting for
  • [HIVE-10468] - Create scripts to do metastore upgrade tests on jenkins for Oracle DB.
  • [HIVE-10982] - Customizable the value of java.sql.statement.setFetchSize in Hive JDBC Driver
  • [HIVE-11424] - Rule to transform OR clauses into IN clauses in CBO
  • [HIVE-11483] - Add encoding and decoding for query string config
  • [HIVE-11487] - Add getNumPartitionsByFilter api in metastore api
  • [HIVE-11752] - Pre-materializing complex CTE queries
  • [HIVE-11793] - SHOW LOCKS with DbTxnManager ignores filter options
  • [HIVE-11956] - SHOW LOCKS should indicate what acquired the lock
  • [HIVE-12431] - Support timeout for compile lock
  • [HIVE-12439] - CompactionTxnHandler.markCleaned() and TxnHandler.openTxns() misc improvements
  • [HIVE-12467] - Add number of dynamic partitions to error message
  • [HIVE-12481] - Occasionally "Request is a replay" will be thrown from HS2
  • [HIVE-12515] - Clean the SparkCounters related code after remove counter based stats collection[Spark Branch]
  • [HIVE-12541] - SymbolicTextInputFormat should supports the path with regex
  • [HIVE-12545] - Add sessionId and queryId logging support for methods like getCatalogs in HiveSessionImpl class
  • [HIVE-12595] - [REFACTOR] Make physical compiler more type safe
  • [HIVE-12611] - Make sure spark.yarn.queue is effective and takes the value from mapreduce.job.queuename if given [Spark Branch]
  • [HIVE-12637] - make retryable SQLExceptions in TxnHandler configurable
  • [HIVE-12653] - The property "serialization.encoding" in the class "org.apache.hadoop.hive.contrib.serde2.MultiDelimitSerDe" does not work
  • [HIVE-12763] - Use bit vector to track NDV
  • [HIVE-12776] - Add parse utility method for parsing any stand-alone HQL expression
  • [HIVE-12777] - Add capability to restore session in CLIService and SessionManager
  • [HIVE-12787] - Trace improvement - Inconsistent logging upon shutdown-start of the Hive metastore process
  • [HIVE-12811] - Name yarn application name more meaning than just "Hive on Spark"
  • [HIVE-12839] - Upgrade Hive to Calcite 1.6
  • [HIVE-12897] - Improve dynamic partition loading
  • [HIVE-12902] - Refactor TxnHandler to be an interface
  • [HIVE-12907] - Improve dynamic partition loading - II
  • [HIVE-12908] - Improve dynamic partition loading III
  • [HIVE-12935] - LLAP: Replace Yarn registry with Zookeeper registry
  • [HIVE-12942] - Remove Yarn WebApps from LLAP daemon instance
  • [HIVE-12946] - alter table should also add default scheme and authority for the location similar to create table
  • [HIVE-12950] - get rid of the NullScan emptyFile madness
  • [HIVE-12953] - Update description of hive.ppd.remove.duplicatefilters in HiveConf.java
  • [HIVE-12958] - Make embedded Jetty server more configurable
  • [HIVE-12959] - LLAP: Add task scheduler timeout when no nodes are alive
  • [HIVE-12967] - Change LlapServiceDriver to read a properties file instead of llap-daemon-site
  • [HIVE-12968] - genNotNullFilterForJoinSourcePlan: needs to merge predicates into the multi-AND
  • [HIVE-12970] - Add total open connections in HiveServer2
  • [HIVE-12983] - Provide a builtin function to get Hive version
  • [HIVE-12988] - Improve dynamic partition loading IV
  • [HIVE-13027] - Configuration changes to improve logging performance
  • [HIVE-13033] - SPDO unnecessarily duplicates columns in key & value of mapper output
  • [HIVE-13034] - Add jdeb plugin to build debian
  • [HIVE-13040] - Handle empty bucket creations more efficiently
  • [HIVE-13044] - Enable TLS encryption to HMS backend database
  • [HIVE-13054] - LLAP: disable permanent fns by default (for now)
  • [HIVE-13058] - Add session and operation_log directory deletion messages
  • [HIVE-13063] - Create UDFs for CHR and REPLACE
  • [HIVE-13069] - Enable cartesian product merging
  • [HIVE-13102] - CBO: Reduce operations in Calcite do not fold as tight as rule-based folding
  • [HIVE-13106] - STARTUP_MSG and SHUTDOWN_MSG are added to HiveMetaStore
  • [HIVE-13107] - LLAP: Rotate GC logs periodically to prevent full disks
  • [HIVE-13116] - LLAP: allow ignoring the UDF check during compile time
  • [HIVE-13118] - add some logging to LLAP token related paths
  • [HIVE-13120] - propagate doAs when generating ORC splits
  • [HIVE-13122] - LLAP: simple Model/View separation for UI
  • [HIVE-13156] - Allow specifying the name of the queue in which llap will run
  • [HIVE-13179] - Allow custom HiveConf to be passed to Authentication Providers
  • [HIVE-13183] - More logs in operation logs
  • [HIVE-13196] - UDFLike: reduce Regex NFA sizes
  • [HIVE-13204] - Vectorization: Add ChainedCheckerFactory for LIKE
  • [HIVE-13206] - Create a test-sources.jar when -Psources profile is invoked
  • [HIVE-13222] - Move rc-file-v0.rc used on TestRCFile.java to src/test/resources
  • [HIVE-13226] - Improve tez print summary to print query execution breakdown
  • [HIVE-13248] - Change date_add/date_sub/to_date functions to return Date type rather than String
  • [HIVE-13249] - Hard upper bound on number of open transactions
  • [HIVE-13295] - Improvement to LDAP search queries in HS2 LDAP Authenticator
  • [HIVE-13319] - Propagate external handles in task display
  • [HIVE-13352] - Seems unnecessary for HBase tests to call QTestUtil.tearDown to close zookeeper and others.
  • [HIVE-13354] - Add ability to specify Compaction options per table and per request
  • [HIVE-13363] - Add hive.metastore.token.signature property to HiveConf
  • [HIVE-13364] - Allow llap to work with dynamic ports for rpc, shuffle, ui
  • [HIVE-13365] - Change the MiniLLAPCluster to work with a MiniZKCluster
  • [HIVE-13367] - Extending HPLSQL parser
  • [HIVE-13376] - HoS emits too many logs with application state
  • [HIVE-13398] - LLAP: Simple /status and /peers web services
  • [HIVE-13400] - Following up HIVE-12481, add retry for Zookeeper service discovery
  • [HIVE-13413] - add a llapstatus command line tool
  • [HIVE-13421] - Propagate job progress in operation status
  • [HIVE-13429] - Tool to remove dangling scratch dir
  • [HIVE-13430] - Pass error message to failure hook
  • [HIVE-13436] - Allow the package directory to be specified for the llap setup script
  • [HIVE-13469] - LLAP: Support delayed scheduling for locality
  • [HIVE-13472] - Replace primitive wrapper's valueOf method with parse* method to avoid unnecessary boxing/unboxing
  • [HIVE-13501] - Invoke failure hooks if query fails on exception
  • [HIVE-13509] - HCatalog getSplits should ignore the partition with invalid path
  • [HIVE-13516] - Adding BTEQ .IF, .QUIT, ERRORCODE to HPL/SQL
  • [HIVE-13536] - LLAP: Add metrics for task scheduler
  • [HIVE-13559] - Pass exception to failure hooks
  • [HIVE-13562] - Enable vector bridge for all non-vectorized udfs
  • [HIVE-13616] - Investigate renaming a table without invalidating the column stats
  • [HIVE-13629] - Expose Merge-File task and Column-Truncate task from DDLTask
  • [HIVE-13643] - Various enhancements / fixes to llap cli tools
  • [HIVE-13661] - [Refactor] Move common FS operations out of shim layer
  • [HIVE-13666] - LLAP Provide the log url for a task attempt to display on the UI
  • [HIVE-13670] - Improve Beeline connect/reconnect semantics
  • [HIVE-13679] - Pass diagnostic message to failure hooks
  • [HIVE-13681] - Update README with latest Hive functionality
  • [HIVE-13716] - Improve dynamic partition loading V
  • [HIVE-13726] - Improve dynamic partition loading VI
  • [HIVE-13750] - Avoid additional shuffle stage created by Sorted Dynamic Partition Optimizer when possible
  • [HIVE-13783] - Display a secondary prompt on beeline for multi-line statements
  • [HIVE-13789] - Repeatedly checking configuration in TextRecordWriter/Reader hurts performance
  • [HIVE-13799] - Optimize TableScanRule::checkBucketedTable
  • [HIVE-13902] - [Refactor] Minimize metastore jar dependencies on task nodes
  • [HIVE-13933] - Add an option to turn off parallel file moves
  • New Feature:
  • [HIVE-12270] - Add DBTokenStore support to HS2 delegation token
  • [HIVE-12634] - Add command to kill an ACID transaction
  • [HIVE-12730] - MetadataUpdater: provide a mechanism to edit the basic statistics of a table (or a partition)
  • [HIVE-12878] - Support Vectorization for TEXTFILE and other formats
  • [HIVE-12994] - Implement support for NULLS FIRST/NULLS LAST
  • [HIVE-13029] - NVDIMM support for LLAP Cache
  • [HIVE-13095] - Support view column authorization
  • [HIVE-13125] - Support masking and filtering of rows/columns
  • [HIVE-13307] - LLAP: Slider package should contain permanent functions
  • [HIVE-13418] - HiveServer2 HTTP mode should support X-Forwarded-Host header for authorization/audits
  • [HIVE-13475] - Allow aggregate functions in over clause
  • [HIVE-13736] - View's input/output formats are TEXT by default
  • Task:
  • [HIVE-12205] - Spark: unify spark statististics aggregation between local and remote spark client
  • [HIVE-12796] - Switch to 32-bits containers for HMS upgrade tests
  • [HIVE-12828] - Update Spark version to 1.6
  • [HIVE-12836] - Install wget & curl packages on LXC containers for HMS upgrade tests
  • [HIVE-12940] - Cherry pick spark branch to master
  • [HIVE-12987] - Add metrics for HS2 active users and SQL operations
  • [HIVE-13097] - [Umbrella] Changes dependent on Tez 0.8.3
  • [HIVE-13188] - Allow users of RetryingThriftClient to close transport
  • [HIVE-13234] - Remove dead ODBC driver from Hive
  • [HIVE-13281] - Update some default configs for LLAP - disable default uber enabled
  • [HIVE-13385] - [Cleanup] Streamline Beeline instantiation
  • [HIVE-13393] - Beeline: Print help message for the --incremental option
  • [HIVE-13431] - Improvements to LLAPTaskReporter
  • [HIVE-13433] - Fixes for additional incompatible changes in tez-0.8.3
  • [HIVE-13537] - Update slf4j version to 1.7.10
  • [HIVE-13603] - Fix ptest unit tests broken by HIVE13505
  • [HIVE-13800] - Disable auth enabled by default on LLAP UI for secure clusters
  • [HIVE-13835] - TestMiniTezCliDriver.vector_complex_all.q needs golden file update
  • Test:
  • [HIVE-9147] - Add unit test for HIVE-7323
  • [HIVE-11615] - Create test for max thrift message setting
  • [HIVE-11887] - some tests break the build on a shared machine, can break HiveQA
  • [HIVE-12079] - Add units tests for HiveServer2 LDAP filters added in HIVE-7193
  • [HIVE-12279] - Testcase to verify session temporary files are removed after HIVE-11768
  • [HIVE-12600] - Make index tests more robust
  • [HIVE-12621] - PTest Backup additional Tez/Spark logs
  • [HIVE-12628] - Eliminate flakiness in TestMetrics
  • [HIVE-12715] - Unit test for HIVE-10685 fix
  • [HIVE-12956] - run CBO in tests with mapred.mode=strict
  • [HIVE-13055] - Add unit tests for HIVE-11512
  • [HIVE-13268] - Add a HA mini cluster type in MiniHS2
  • [HIVE-13371] - Fix test failure of testHasNull in TestColumnStatistics running on Windows
  • [HIVE-13591] - TestSchemaTool is failing on master
  • [HIVE-13615] - nomore_ambiguous_table_col.q is failing on master

New in Apache Hive 1.2.1 (Aug 18, 2015)

  • Sub-task:
  • [HIVE-10629] - Dropping table in an encrypted zone does not drop warehouse directory
  • [HIVE-10630] - Renaming tables across encryption zones renames table even though the operation throws error
  • [HIVE-10658] - Insert with values clause may expose data that should be encrypted
  • [HIVE-10747] - Enable the cleanup of side effect for the Encryption related qfile test
  • [HIVE-10910] - Alter table drop partition queries in encrypted zone failing to remove data from HDFS
  • [HIVE-11016] - MiniTez mergejoin test fails with Tez input error (issue in merge join under certain conditions)
  • Bug:
  • [HIVE-8931] - Test TestAccumuloCliDriver is not completing
  • [HIVE-9069] - Simplify filter predicates for CBO
  • [HIVE-9828] - Semantic analyzer does not capture view parent entity for tables referred in view with union all
  • [HIVE-9842] - Enable session/operation timeout by default in HiveServer2
  • [HIVE-10107] - Union All : Vertex missing stats resulting in OOM and in-efficient plans
  • [HIVE-10244] - Vectorization : TPC-DS Q80 fails with java.lang.ClassCastException when hive.vectorized.execution.reduce.enabled is enabled
  • [HIVE-10453] - HS2 leaking open file descriptors when using UDFs
  • [HIVE-10528] - Hiveserver2 in HTTP mode is not applying auth_to_local rules
  • [HIVE-10559] - IndexOutOfBoundsException with RemoveDynamicPruningBySize
  • [HIVE-10563] - MiniTezCliDriver tests ordering issues
  • [HIVE-10605] - Make hive version number update automatically in webhcat-default.xml during hive tar generation
  • [HIVE-10606] - Divide by zero error in HybridHashTableContainer
  • [HIVE-10627] - Queries fail with Failed to breakup Windowing invocations into Groups
  • [HIVE-10628] - Incorrect result when vectorized native mapjoin is enabled using null safe operators
  • [HIVE-10659] - Beeline command which contains semi-colon as a non-command terminator will fail
  • [HIVE-10664] - Unit tests run fail in windows because of illegal escape character in file path
  • [HIVE-10672] - Analyze command on a table using row format serde JsonSerDe fails with NoClassDefFoundError
  • [HIVE-10674] - jars should not be checked in to the source control repo
  • [HIVE-10675] - Provide option to skip Accumulo related Hive tests in itests directory
  • [HIVE-10677] - hive.exec.parallel=true has problem when it is used for analyze table column stats
  • [HIVE-10678] - update sql standard authorization configuration whitelist - more optimization flags
  • [HIVE-10679] - JsonSerde ignores varchar and char size limit specified during table creation
  • [HIVE-10684] - Fix the unit test failures for HIVE-7553 after HIVE-10674 removed the binary jar files
  • [HIVE-10685] - Alter table concatenate oparetor will cause duplicate data
  • [HIVE-10686] - java.lang.IndexOutOfBoundsException for query with rank() over(partition ...)
  • [HIVE-10688] - constant folding is broken for case-when udf
  • [HIVE-10689] - HS2 metadata api calls should use HiveAuthorizer interface for authorization
  • [HIVE-10690] - ArrayIndexOutOfBounds exception in MetaStoreDirectSql.aggrColStatsForPartitions()
  • [HIVE-10696] - TestAddResource tests are non-portable
  • [HIVE-10704] - Errors in Tez HashTableLoader when estimated table size is 0
  • [HIVE-10711] - Tez HashTableLoader attempts to allocate more memory than available when HIVECONVERTJOINNOCONDITIONALTASKTHRESHOLD exceeds process max mem
  • [HIVE-10719] - Hive metastore failure when alter table rename is attempted.
  • [HIVE-10724] - WebHCat e2e test TestStreaming_5 fails on Windows
  • [HIVE-10727] - Import throws error message "org.apache.thrift.protocol.TProtocolException: Required field 'filesAdded' is unset!"
  • [HIVE-10735] - Cached plan race condition - VectorMapJoinCommonOperator has no closeOp()
  • [HIVE-10736] - HiveServer2 shutdown of cached tez app-masters is not clean
  • [HIVE-10741] - count distinct rewrite is not firing
  • [HIVE-10745] - Better null handling by Vectorizer
  • [HIVE-10746] - Hive 1.2.0+Tez produces 1-byte FileSplits from mapred.TextInputFormat
  • [HIVE-10753] - hs2 jdbc url - wrong connection string cause error on beeline/jdbc/odbc client, misleading message
  • [HIVE-10760] - Templeton: HCatalog Get Column for Non-existent column returns Server Error (500) rather than Not Found(404)
  • [HIVE-10768] - In QTestGenTask.execute() we should not throw an exception right away if we are unable to clean any old files
  • [HIVE-10776] - Schema on insert for bucketed tables throwing NullPointerException
  • [HIVE-10789] - union distinct query with NULL constant on both the sides throws "Unsuported vector output type: void" error
  • [HIVE-10801] - 'drop view' fails throwing java.lang.NullPointerException
  • [HIVE-10805] - OOM in vectorized reduce
  • [HIVE-10811] - RelFieldTrimmer throws NoSuchElementException in some cases
  • [HIVE-10813] - Fix current test failures after HIVE-8769
  • [HIVE-10819] - SearchArgumentImpl for Timestamp is broken by HIVE-10286
  • [HIVE-10828] - Insert with schema and dynamic partitions NullPointerException
  • [HIVE-10829] - ATS hook fails for explainTask
  • [HIVE-10839] - TestHCatLoaderEncryption.* tests fail in windows because of path related issues
  • [HIVE-10840] - NumberFormatException while running analyze table partition compute statics query
  • [HIVE-10841] - [WHERE col is not null] does not work sometimes for queries with many JOIN statements
  • [HIVE-10843] - desc database and show tables commands don't pass db to HiveAuthorizer check
  • [HIVE-10845] - TezJobMonitor uses killedTaskCount instead of killedTaskAttemptCount
  • [HIVE-10857] - Accumulo storage handler fail throwing java.lang.IllegalArgumentException: Cannot determine SASL mechanism for token class: class org.apache.accumulo.core.client.security.tokens.PasswordToken
  • [HIVE-10858] - WebHCat specific resources should be added to HADOOP_CLASSPATH first
  • [HIVE-10862] - TestHiveAuthorizerShowFilters tests fail when run in sequence
  • [HIVE-10874] - Fail in TestMinimrCliDriver.testCliDriver_ql_rewrite_gbtoidx_cbo_2.q due to duplicate column name
  • [HIVE-10875] - Select query with view in subquery adds underlying table as direct input
  • [HIVE-10877] - TestUtil class name confuses ptest2
  • [HIVE-10885] - with vectorization enabled join operation involving interval_day_time fails
  • [HIVE-10887] - TestCliDriver tests ordering issues with Mac and CentOS
  • [HIVE-10892] - TestHCatClient should not accept external metastore param from -Dhive.metastore.uris
  • [HIVE-10907] - Hive on Tez: Classcast exception in some cases with SMB joins
  • [HIVE-10919] - Windows: create table with JsonSerDe failed via beeline unless you add hcatalog core jar to classpath
  • [HIVE-10922] - In HS2 doAs=false mode, file system related errors in one query causes other failures
  • [HIVE-10925] - Non-static threadlocals in metastore code can potentially cause memory leak
  • [HIVE-10929] - In Tez mode,dynamic partitioning query with union all fails at moveTask,Invalid partition key & values
  • [HIVE-10931] - Wrong columns selected on multiple joins
  • [HIVE-10934] - Restore support for DROP PARTITION PURGE
  • [HIVE-10941] - Provide option to disable spark tests outside itests
  • [HIVE-10949] - Disable hive-minikdc tests in Windows
  • [HIVE-10957] - QueryPlan's start time is incorrect in certain cases
  • [HIVE-10958] - Centos: TestMiniTezCliDriver.testCliDriver_mergejoin fails
  • [HIVE-10959] - webhcat launcher job should reconnect to the running child job on task retry
  • [HIVE-10965] - direct SQL for stats fails in 0-column case
  • [HIVE-10966] - direct SQL for stats has a cast exception on some databases
  • [HIVE-10967] - add mapreduce.job.tags to sql std authorization config whitelist
  • [HIVE-10968] - Windows: analyze json table via beeline failed throwing Class org.apache.hive.hcatalog.data.JsonSerDe not found
  • [HIVE-10971] - count(*) with count(distinct) gives wrong results when hive.groupby.skewindata=true
  • [HIVE-10992] - WebHCat should not create delegation tokens when Kerberos is not enabled
  • [HIVE-10994] - Hive.moveFile should not fail on a no-op move
  • [HIVE-11001] - HS2 http cookie mode does not honor doAs url parameter
  • [HIVE-11006] - improve logging wrt ACID module
  • [HIVE-11023] - Disable directSQL if datanucleus.identifierFactory = datanucleus2
  • [HIVE-11027] - Hive on tez: Bucket map joins fail when hashcode goes negative
  • [HIVE-11031] - ORC concatenation of old files can fail while merging column statistics
  • [HIVE-11033] - BloomFilter index is not honored by ORC reader
  • [HIVE-11035] - PPD: Orc Split elimination fails because filterColumns=[-1]
  • [HIVE-11040] - Change Derby dependency version to 10.10.2.0
  • [HIVE-11041] - Update tests for HIVE-9302 after removing binaries
  • [HIVE-11047] - Update versions of branch-1.2 to 1.2.1
  • [HIVE-11102] - ReaderImpl: getColumnIndicesFromNames does not work for some cases
  • [HIVE-11313] - dynamic partition with null key from union select will fail
  • [HIVE-11456] - HCatStorer should honor mapreduce.output.basename
  • [HIVE-11498] - HIVE Authorization v2 should not check permission for dummy entity
  • Improvement
  • [HIVE-8769] - Physical optimizer : Incorrect CE results in a shuffle join instead of a Map join (PK/FK pattern not detected)
  • [HIVE-10812] - Scaling PK/FK's selectivity for stats annotation
  • [HIVE-10900] - Fix the indeterministic stats for some hive queries
  • [HIVE-11179] - HIVE should allow custom converting from HivePrivilegeObjectDesc to privilegeObject for different authorizers
  • New Feature
  • [HIVE-10636] - CASE comparison operator rotation optimization
  • [HIVE-10716] - Fold case/when udf for expression involving nulls in filter operator.
  • Task
  • [HIVE-10327] - Remove ExprNodeNullDesc
  • [HIVE-11018] - Turn on cbo in more q files
  • Test
  • [HIVE-10869] - fold_case.q failing on trunk
  • [HIVE-10909] - Make TestFilterHooks robust
  • [HIVE-10939] - Make TestFileDump robust
  • [HIVE-10955] - CliDriver leaves tables behind at end of test run
  • [HIVE-11026] - Make vector_outer_join* test more robust

New in Apache Hive 1.2.0 (May 19, 2015)

  • Sub-task:
  • [HIVE-8119] - Implement Date in ParquetSerde
  • [HIVE-8164] - Adding in a ReplicationTask that converts a Notification Event to actionable tasks
  • [HIVE-8165] - Annotation changes for replication
  • [HIVE-8379] - NanoTimeUtils performs some work needlessly
  • [HIVE-8696] - HCatClientHMSImpl doesn't use a Retrying-HiveMetastoreClient.
  • [HIVE-8817] - Create unit test where we insert into an encrypted table and then read from it with pig
  • [HIVE-8818] - Create unit test where we insert into an encrypted table and then read from it with hcatalog mapreduce
  • [HIVE-9009] - order by (limit) meaning for the last subquery of union in Hive is different from other main stream RDBMS
  • [HIVE-9253] - MetaStore server should support timeout for long running requests
  • [HIVE-9271] - Add ability for client to request metastore to fire an event
  • [HIVE-9273] - Add option to fire metastore event on insert
  • [HIVE-9327] - CBO (Calcite Return Path): Removing Row Resolvers from ParseContext
  • [HIVE-9333] - Move parquet serialize implementation to DataWritableWriter to improve write speeds
  • [HIVE-9432] - CBO (Calcite Return Path): Removing QB from ParseContext
  • [HIVE-9501] - DbNotificationListener doesn't include dbname in create database notification and does not include tablename in create table notification
  • [HIVE-9508] - MetaStore client socket connection should have a lifetime
  • [HIVE-9550] - ObjectStore.getNextNotification() can return events inside NotificationEventResponse as null which conflicts with its thrift "required" tag
  • [HIVE-9558] - [Parquet] support HiveDecimalWritable, HiveCharWritable, HiveVarcharWritable in vectorized mode
  • [HIVE-9563] - CBO(Calcite Return Path): Translate GB to Hive OP [CBO branch]
  • [HIVE-9571] - CBO (Calcite Return Path): Generate FileSink Op [CBO branch]
  • [HIVE-9582] - HCatalog should use IMetaStoreClient interface
  • [HIVE-9585] - AlterPartitionMessage should return getKeyValues instead of getValues
  • [HIVE-9657] - Use new parquet Types API builder to construct data types
  • [HIVE-9666] - Improve some qtests
  • [HIVE-9690] - Refactoring for non-numeric arithmetic operations
  • [HIVE-9750] - avoid log locks in operators
  • [HIVE-9792] - Support interval type in expressions/predicates
  • [HIVE-9810] - prep object registry for multi threading
  • [HIVE-9819] - Add timeout check inside the HMS server
  • [HIVE-9824] - LLAP: Native Vectorization of Map Join
  • [HIVE-9894] - Use new parquet Types API builder to construct DATE data type
  • [HIVE-9906] - Add timeout mechanism in RawStoreProxy
  • [HIVE-9937] - LLAP: Vectorized Field-By-Field Serialize / Deserialize to support new Vectorized Map Join
  • [HIVE-9982] - CBO (Calcite Return Path): Prune TS Relnode schema
  • [HIVE-9998] - Vectorization support for interval types
  • [HIVE-10037] - JDBC support for interval expressions
  • [HIVE-10044] - Allow interval params for year/month/day/hour/minute/second functions
  • [HIVE-10053] - Override new init API fom ReadSupport instead of the deprecated one
  • [HIVE-10071] - CBO (Calcite Return Path): Join to MultiJoin rule
  • [HIVE-10076] - Bump up parquet-hadoop-bundle and parquet-column to the version of 1.6.0rc6
  • [HIVE-10131] - LLAP: BytesBytesMultiHashMap and mapjoin container should reuse refs
  • [HIVE-10227] - Concrete implementation of Export/Import based ReplicationTaskFactory
  • [HIVE-10228] - Changes to Hive Export/Import/DropTable/DropPartition to support replication semantics
  • [HIVE-10243] - CBO (Calcite Return Path): Introduce JoinAlgorithm Interface
  • [HIVE-10252] - Make PPD work for Parquet in row group level
  • [HIVE-10262] - CBO (Calcite Return Path): Temporarily disable Aggregate check input for bucketing
  • [HIVE-10263] - CBO (Calcite Return Path): Aggregate checking input for bucketing should be conditional
  • [HIVE-10326] - CBO (Calcite Return Path): Invoke Hive's Cumulative Cost
  • [HIVE-10329] - Hadoop reflectionutils has issues
  • [HIVE-10343] - CBO (Calcite Return Path): Parameterize algorithm cost model
  • [HIVE-10347] - Merge spark to trunk 4/15/2015
  • [HIVE-10350] - CBO: Use total size instead of bucket count to determine number of splits & parallelism
  • [HIVE-10369] - CBO: Don't use HiveDefaultCostModel when With Tez and hive.cbo.costmodel.extended enabled
  • [HIVE-10375] - CBO (Calcite Return Path): disable the identity project remover for some union operators
  • [HIVE-10386] - CBO (Calcite Return Path): Disable Trivial Project Removal on ret path
  • [HIVE-10391] - CBO (Calcite Return Path): HiveOpConverter always assumes that HiveFilter does not include a partition column
  • [HIVE-10400] - CBO (Calcite Return Path): Exception when column name contains dot or colon characters
  • [HIVE-10413] - [CBO] Return path assumes distinct column cant be same as grouping column
  • [HIVE-10416] - CBO (Calcite Return Path): Fix return columns if Sort operator is on top of plan returned by Calcite
  • [HIVE-10426] - Rework/simplify ReplicationTaskFactory instantiation
  • [HIVE-10455] - CBO (Calcite Return Path): Different data types at Reducer before JoinOp
  • [HIVE-10462] - CBO (Calcite Return Path): MapJoin and SMBJoin conversion not triggered
  • [HIVE-10493] - Merge multiple joins when join keys are the same
  • [HIVE-10506] - CBO (Calcite Return Path): Disallow return path to be enable if CBO is off
  • [HIVE-10512] - CBO (Calcite Return Path): SMBJoin conversion throws ClassCastException
  • [HIVE-10520] - LLAP: Must reset small table result columns for Native Vectorization of Map Join
  • [HIVE-10522] - CBO (Calcite Return Path): fix the wrong needed column names when TS is created
  • [HIVE-10526] - CBO (Calcite Return Path): HiveCost epsilon comparison should take row count in to account
  • [HIVE-10547] - CBO (Calcite Return Path) : genFileSinkPlan uses wrong partition col to create FS
  • [HIVE-10549] - CBO (Calcite Return Path): Enable NonBlockingOpDeDupProc
  • Bug:
  • [HIVE-3454] - Problem with CAST(BIGINT as TIMESTAMP)
  • [HIVE-4625] - HS2 should not attempt to get delegation token from metastore if using embedded metastore
  • [HIVE-5545] - HCatRecord getInteger method returns String when used on Partition columns of type INT
  • [HIVE-5672] - Insert with custom separator not supported for non-local directory
  • [HIVE-6069] - Improve error message in GenericUDFRound
  • [HIVE-6099] - Multi insert does not work properly with distinct count
  • [HIVE-6950] - Parsing Error in GROUPING SETS
  • [HIVE-7351] - ANALYZE TABLE statement fails on postgres metastore
  • [HIVE-7641] - INSERT ... SELECT with no source table leads to NPE
  • [HIVE-8524] - When table is renamed stats are lost as changes are not propagated to metastore tables TAB_COL_STATS and PART_COL_STATS
  • [HIVE-8626] - Extend HDFS super-user checks to dropPartitions
  • [HIVE-8746] - ORC timestamp columns are sensitive to daylight savings time
  • [HIVE-8890] - HiveServer2 dynamic service discovery: use persistent ephemeral nodes curator recipe
  • [HIVE-8915] - Log file explosion due to non-existence of COMPACTION_QUEUE table
  • [HIVE-9002] - union all does not generate correct result for order by and limit
  • [HIVE-9023] - HiveHistoryImpl relies on removed counters to print num rows
  • [HIVE-9073] - NPE when using custom windowing UDAFs
  • [HIVE-9083] - New metastore API to support to purge partition-data directly in dropPartitions().
  • [HIVE-9086] - Add language support to PURGE data while dropping partitions.
  • [HIVE-9115] - Hive build failure on hadoop-2.7 due to HADOOP-11356
  • [HIVE-9118] - Support auto-purge for tables, when dropping tables/partitions.
  • [HIVE-9151] - Checking s against null in TezJobMonitor#getNameWithProgress() should be done earlier
  • [HIVE-9228] - Problem with subquery using windowing functions
  • [HIVE-9303] - Parquet files are written with incorrect definition levels
  • [HIVE-9322] - Make null-checks consistent for MapObjectInspector subclasses.
  • [HIVE-9350] - Add ability for HiveAuthorizer implementations to filter out results of 'show tables', 'show databases'
  • [HIVE-9397] - SELECT max(bar) FROM foo is broken after ANALYZE ... FOR COLUMNS
  • [HIVE-9430] - NullPointerException on ALTER TABLE ADD PARTITION if no value given
  • [HIVE-9438] - The standalone-jdbc jar missing some jars
  • [HIVE-9456] - Make Hive support unicode with MSSQL as Metastore backend
  • [HIVE-9468] - Test groupby3_map_skew.q fails due to decimal precision difference
  • [HIVE-9471] - Bad seek in uncompressed ORC, at row-group boundary.
  • [HIVE-9472] - Implement 7 simple UDFs added to Hive
  • [HIVE-9474] - truncate table changes permissions on the target
  • [HIVE-9481] - allow column list specification in INSERT statement
  • [HIVE-9482] - Hive parquet timestamp compatibility
  • [HIVE-9484] - ThriftCLIService#getDelegationToken does case sensitive comparison
  • [HIVE-9486] - Use session classloader instead of application loader
  • [HIVE-9489] - add javadoc for UDFType annotation
  • [HIVE-9496] - Slf4j warning in hive command
  • [HIVE-9507] - Make "LATERAL VIEW inline(expression) mytable" tolerant to nulls
  • [HIVE-9509] - Restore partition spec validation removed by HIVE-9445
  • [HIVE-9512] - HIVE-9327 causing regression in stats annotation
  • [HIVE-9513] - NULL POINTER EXCEPTION
  • [HIVE-9526] - ClassCastException thrown by HiveStatement
  • [HIVE-9529] - "alter table .. concatenate" under Tez mode should create TezTask
  • [HIVE-9539] - Wrong check of version format in TestWebHCatE2e.getHiveVersion()
  • [HIVE-9553] - Fix log-line in Partition Pruner
  • [HIVE-9555] - assorted ORC refactorings for LLAP on trunk
  • [HIVE-9560] - When hive.stats.collect.rawdatasize=true, 'rawDataSize' for an ORC table will result in value '0' after running 'analyze table TABLE_NAME compute statistics;'
  • [HIVE-9565] - Minor cleanup in TestMetastoreExpr.
  • [HIVE-9567] - JSON SerDe not escaping special chars when writing char/varchar data
  • [HIVE-9580] - Server returns incorrect result from JOIN ON VARCHAR columns
  • [HIVE-9587] - UDF decode should accept STRING_GROUP types for the second parameter
  • [HIVE-9588] - Reimplement HCatClientHMSImpl.dropPartitions() with HMSC.dropPartitions()
  • [HIVE-9592] - fix ArrayIndexOutOfBoundsException in date_add and date_sub initialize
  • [HIVE-9609] - AddPartitionMessage.getPartitions() can return null
  • [HIVE-9612] - Turn off DEBUG logging for Lazy Objects for tests
  • [HIVE-9613] - Left join query plan outputs wrong column when using subquery
  • [HIVE-9617] - UDF from_utc_timestamp throws NPE if the second argument is null
  • [HIVE-9619] - Uninitialized read of numBitVectors in NumDistinctValueEstimator
  • [HIVE-9620] - Cannot retrieve column statistics using HMS API if column name contains uppercase characters
  • [HIVE-9622] - Getting NPE when trying to restart HS2 when metastore is configured to use org.apache.hadoop.hive.thrift.DBTokenStore
  • [HIVE-9623] - NullPointerException in MapJoinOperator.processOp(MapJoinOperator.java:253) for TPC-DS Q75 against un-partitioned schema
  • [HIVE-9624] - NullPointerException in MapJoinOperator.processOp(MapJoinOperator.java:253) for TPC-DS Q75 against un-partitioned schema
  • [HIVE-9628] - HiveMetaStoreClient.dropPartitions(...List...) doesn't take (boolean needResult)
  • [HIVE-9633] - Add HCatClient.dropPartitions() overload to skip deletion of partition-directories.
  • [HIVE-9644] - Fold case & when udfs
  • [HIVE-9645] - Constant folding case NULL equality
  • [HIVE-9647] - Discrepancy in cardinality estimates between partitioned and un-partitioned tables
  • [HIVE-9648] - Null check key provider before doing set
  • [HIVE-9652] - Tez in place updates should detect redirection of STDERR
  • [HIVE-9655] - Dynamic partition table insertion error
  • [HIVE-9665] - Parallel move task optimization causes race condition
  • [HIVE-9667] - Disable ORC bloom filters for ORC v11 output-format
  • [HIVE-9674] - *DropPartitionEvent should handle partition-sets.
  • [HIVE-9679] - Remove redundant null-checks from DbNotificationListener.
  • [HIVE-9680] - GlobalLimitOptimizer is not checking filters correctly
  • [HIVE-9681] - Extend HiveAuthorizationProvider to support partition-sets.
  • [HIVE-9706] - HBase handler support for snapshots should confirm properties before use
  • [HIVE-9711] - ORC Vectorization DoubleColumnVector.isRepeating=false if all entries are NaN
  • [HIVE-9716] - Map job fails when table's LOCATION does not have scheme
  • [HIVE-9717] - The max/min function used by AggrStats for decimal type is not what we expected
  • [HIVE-9720] - Metastore does not properly migrate column stats when renaming a table across databases.
  • [HIVE-9721] - Hadoop23Shims.setFullFileStatus should check for null
  • [HIVE-9727] - GroupingID translation from Calcite
  • [HIVE-9731] - WebHCat MapReduce Streaming Job does not allow StreamXmlRecordReader to be specified
  • [HIVE-9734] - Correlating expression cannot contain unqualified column references
  • [HIVE-9735] - aggregate ( smalllint ) fails when ORC file used ava.lang.ClassCastException: java.lang.Long cannot be cast to java.lang.Short
  • [HIVE-9743] - Incorrect result set for vectorized left outer join
  • [HIVE-9749] - ObjectStore schema verification logic is incorrect
  • [HIVE-9754] - rename GenericUDFLevenstein to GenericUDFLevenshtein
  • [HIVE-9755] - Hive built-in "ngram" UDAF fails when a mapper has no matches.
  • [HIVE-9767] - Fixes in Hive UDF to be usable in Pig
  • [HIVE-9770] - Beeline ignores --showHeader for non-tablular output formats i.e csv,tsv,dsv
  • [HIVE-9772] - Hive parquet timestamp conversion doesn't work with new Parquet
  • [HIVE-9779] - ATSHook does not log the end user if doAs=false (it logs the hs2 server user)
  • [HIVE-9791] - insert into table throws NPE
  • [HIVE-9797] - Need update some spark tests for java 8
  • [HIVE-9813] - Hive JDBC - DatabaseMetaData.getColumns method cannot find classes added with "add jar" command
  • [HIVE-9817] - fix DateFormat pattern in hive-exec
  • [HIVE-9826] - Firing insert event fails on temporary table
  • [HIVE-9831] - HiveServer2 should use ConcurrentHashMap in ThreadFactory
  • [HIVE-9832] - Merge join followed by union and a map join in hive on tez fails.
  • [HIVE-9834] - VectorGroupByOperator logs too much
  • [HIVE-9836] - Hive on tez: fails when virtual columns are present in the join conditions (for e.g. partition columns)
  • [HIVE-9839] - HiveServer2 leaks OperationHandle on async queries which fail at compile phase
  • [HIVE-9841] - IOException thrown by ORC should include the path of processing file
  • [HIVE-9845] - HCatSplit repeats information making input split data size huge
  • [HIVE-9848] - readlink -f is GNU coreutils only (used in bin/hive)
  • [HIVE-9851] - org.apache.hadoop.hive.serde2.avro.AvroSerializer should use org.apache.avro.generic.GenericData.Array when serializing a list
  • [HIVE-9855] - Runtime skew join doesn't work when skewed data only exists in big table
  • [HIVE-9860] - MapredLocalTask/SecureCmdDoAs leaks local files
  • [HIVE-9866] - Changing a column's type doesn't change column stats type in metastore
  • [HIVE-9869] - Trunk doesn't build with hadoop-1
  • [HIVE-9873] - Hive on MR throws DeprecatedParquetHiveInput exception
  • [HIVE-9877] - Beeline cannot run multiple statements in the same row
  • [HIVE-9886] - Hive on tez: NPE when converting join to SMB in sub-query
  • [HIVE-9892] - various MSSQL upgrade scripts don't work
  • [HIVE-9908] - vectorization error binary type not supported, group by with binary columns
  • [HIVE-9915] - Allow specifying file format for managed tables
  • [HIVE-9919] - upgrade scripts don't work on some auto-created DBs due to absence of tables
  • [HIVE-9920] - DROP DATABASE IF EXISTS throws exception if database does not exist
  • [HIVE-9923] - No clear message when "from" is missing
  • [HIVE-9929] - StatsUtil#getAvailableMemory could return negative value
  • [HIVE-9930] - fix QueryPlan.makeQueryId time format
  • [HIVE-9932] - DDLTask.conf hides base class Task.conf
  • [HIVE-9934] - Vulnerability in LdapAuthenticationProviderImpl enables HiveServer2 client to degrade the authentication mechanism to "none", allowing authentication without password
  • [HIVE-9936] - fix potential NPE in DefaultUDAFEvaluatorResolver
  • [HIVE-9944] - Convert array[] to string properly in log messages
  • [HIVE-9945] - FunctionTask.conf hides Task.conf field
  • [HIVE-9947] - ScriptOperator replaceAll uses unescaped dot and result is not assigned
  • [HIVE-9948] - SparkUtilities.getFileName passes File.separator to String.split() method
  • [HIVE-9950] - fix rehash in CuckooSetBytes and CuckooSetLong
  • [HIVE-9951] - VectorizedRCFileRecordReader creates Exception but does not throw it
  • [HIVE-9952] - fix NPE in CorrelationUtilities
  • [HIVE-9953] - fix NPE in WindowingTableFunction
  • [HIVE-9954] - UDFJson uses the == operator to compare Strings
  • [HIVE-9955] - TestVectorizedRowBatchCtx compares byte[] using equals() method
  • [HIVE-9956] - use BigDecimal.valueOf instead of new in TestFileDump
  • [HIVE-9957] - Hive 1.1.0 not compatible with Hadoop 2.4.0
  • [HIVE-9961] - HookContext for view should return a table type of VIRTUAL_VIEW
  • [HIVE-9971] - Clean up operator class
  • [HIVE-9975] - Renaming a nonexisting partition should not throw out NullPointerException
  • [HIVE-9976] - Possible race condition in DynamicPartitionPruner for

New in Apache Hive 1.1.0 (Mar 16, 2015)

  • 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-9174] - Enable queuing of HCatalog notification events in metastore DB
  • [HIVE-9175] - Add alters to list of events handled by NotificationListener
  • [HIVE-9181] - Fix SkewJoinOptimizer related Java 8 ordering differences
  • [HIVE-9184] - Modify HCatClient to support new notification methods in HiveMetaStoreClient
  • [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-9211] - Research on build mini HoS cluster on YARN for unit test[Spark Branch]
  • [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-9321] - Notification message size can be arbitrarily long, DbNotificationListener limits to 1024
  • [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-9425] - Add jar/file doesn't work with yarn-cluster mode [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-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-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-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-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-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-8182] - beeline fails when executing multiple-line queries with trailing spaces
  • [HIVE-8257] - Accumulo introduces old hadoop-client dependency
  • [HIVE-8266] - create function using statement compilation should include resource URI entity
  • [HIVE-8284] - Equality comparison is done between two floating point variables in HiveRelMdUniqueKeys#getUniqueKeys()
  • [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-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-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-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-8708] - Add query id to explain log option
  • [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-8757] - YARN dep in scheduler shim should be optional
  • [HIVE-8762] - HiveMetaStore.BooleanPointer should be replaced with an AtomicBoolean
  • [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 is not working
  • [HIVE-8808] - HiveInputFormat caching cannot work with all input formats
  • [HIVE-8812] - TestMinimrCliDriver failure if run in the same command as TestHBaseNegativeCliDriver
  • [HIVE-8825] - SQLCompletor catches Throwable and ignores it
  • [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-8869] - RowSchema not updated for some ops when columns are pruned
  • [HIVE-8872] - Hive view of HBase range scan intermittently returns incorrect data.
  • [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-8877] - improve context logging during job submission via WebHCat
  • [HIVE-8879] - Upgrade derby version to address race candition
  • [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-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-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-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-9032] - Help for orcfiledump script does not reflect new options
  • [HIVE-9048] - Hive build failed on hadoop-1 after HIVE-8828.
  • [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-9077] - Set completer in CliDriver is not working
  • [HIVE-9096] - GenericUDF may be left unclosed in PartitionPrune#visitCall()
  • [HIVE-9113] - Explain on query failed with NPE
  • [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-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-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-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-9215] - Some mapjoin queries broken with IdentityProjectRemover with PPD
  • [HIVE-9221] - Remove deprecation warning for hive.metastore.local
  • [HIVE-9242] - Many places in CBO code eat exceptions
  • [HIVE-9243] - Static Map in IOContext is not thread safe
  • [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-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-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-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-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-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

New in Apache Hive 1.0.0 (Feb 5, 2015)

  • 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

New in Apache Hive 0.14.0 (Dec 27, 2014)

  • 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-5338] - TestJdbcDriver2 is failing on trunk.
  • [HIVE-5760] - Add vectorized support for CHAR/VARCHAR data types
  • [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-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-8003] - CBO: Handle Literal casting, Restrict CBO to select queries, Translate Strings, Optiq Log
  • [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-8076] - CBO Trunk Merge: Test Failure input23
  • [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-1879] - Remove hive.metastore.metadb.dir property from hive-default.xml and HiveConf
  • [HIVE-2390] - Add UNIONTYPE serialization support to LazyBinarySerDe
  • [HIVE-2597] - Repeated key in GROUP BY is erroneously displayed when using DISTINCT
  • [HIVE-2638] - Tests fail when Hive is run against Hadoop 0.23
  • [HIVE-3392] - Hive unnecessarily validates table SerDes when dropping a table
  • [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-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-5336] - HCatSchema.remove(HCatFieldSchema hcatFieldSchema) should renumber the fieldPositionMap and the fieldPositionMap should not be cached by the end user
  • [HIVE-5339] - TestJdbcDriver2 is failing on trunk.
  • [HIVE-5376] - Hive does not honor type for partition columns when altering column type
  • [HIVE-5456] - Queries fail on avro backed table with empty partition
  • [HIVE-5607] - Hive fails to parse the "%" (mod) sign after brackets.
  • [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-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-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-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-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-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-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-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-7403] - stats are not updated correctly after doing insert into table
  • [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-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-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-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-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-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-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-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-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-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 message for non-existent table in update and delete
  • [HIVE-8112] - Change reporting string to reflect update in Tez
  • [HIVE-8114] - Type resolution for udf arguments of Decimal Type results in error
  • [HIVE-8115] - Hive select query hang when fields contain map
  • [HIVE-8126] - Standalone hive-jdbc jar is not packaged in the Hive distribution
  • [HIVE-8138] - Global Init file should allow specifying file name not only directory
  • [HIVE-8139] - Upgrade commons-lang from 2.4 to 2.6
  • [HIVE-8142] - Add merge operators to queryplan.thrift instead of generated source file
  • [HIVE-8143] - Create root scratch dir with 733 instead of 777 perms
  • [HIVE-8146] - Test TestTempletonUtils.testFindContainingJar failing
  • [HIVE-8148] - HDFS Path named with file:// instead of file:/// results in Unit test failures in Windows
  • [HIVE-8149] - hive.optimize.reducededuplication should be set to false for IUD ops
  • [HIVE-8151] - Dynamic partition sort optimization inserts record wrongly to partition when used with GroupBy
  • [HIVE-8152] - Update with expression in set fails
  • [HIVE-8153] - Reduce the verbosity of debug logs in ORC record reader
  • [HIVE-8154] - HadoopThriftAuthBridge20S.getHadoopSaslProperties is incompatible with Hadoop 2.4.1 and later
  • [HIVE-8156] - Vectorized reducers need to avoid memory build-up during a single key
  • [HIVE-8158] - Optimize writeValue/setValue in VectorExpressionWriterFactory (in VectorReduceSinkOperator codepath)
  • [HIVE-8162] - Dynamic sort optimization propagates additional columns even in the absence of order by
  • [HIVE-8167] - mvn install command broken by HIVE-8126 commit
  • [HIVE-8169] - Windows: alter table ..set location from hcatalog failed with NullPointerException
  • [HIVE-8170] - Hive Metastore schema script missing for mssql for v0.14.0
  • [HIVE-8171] - Tez and Vectorized Reduce doesn't create scratch columns
  • [HIVE-8175] - Hive metastore upgrade from v0.13.0 to v0.14.0 script for Oracle is missing an upgrade step
  • [HIVE-8178] - OrcNewInputFormat::getSplits() calls OrcInputFormat.generateSplitsInfo twice
  • [HIVE-8179] - Fetch task conversion: Remove some dependencies on AST
  • [HIVE-8184] - inconsistence between colList and columnExprMap when ConstantPropagate is applied to subquery
  • [HIVE-8185] - hive-jdbc-0.14.0-SNAPSHOT-standalone.jar fails verification for signatures in build
  • [HIVE-8188] - ExprNodeGenericFuncEvaluator::_evaluate() loads class annotations in a tight loop
  • [HIVE-8189] - A select statement with a subquery is failing with HBaseSerde
  • [HIVE-8191] - Update and delete on tables with non Acid output formats gives runtime error
  • [HIVE-8196] - Joining on partition columns with fetch column stats enabled results it very small CE which negatively affects query performance
  • [HIVE-8200] - Make beeline use the hive-jdbc standalone jar
  • [HIVE-8201] - Remove hardwiring to HiveInputFormat in acid qfile tests
  • [HIVE-8203] - ACID operations result in NPE when run through HS2
  • [HIVE-8205] - Using strings in group type fails in ParquetSerDe
  • [HIVE-8210] - TezJobMonitor should print time spent in Application (RUNNING)
  • [HIVE-8212] - Regression for hcat commandline alter view set tblproperties
  • [HIVE-8217] - WebHCat 'jobs' endpoint fails if it runs into issues with any of the jobs
  • [HIVE-8221] - authorize additional metadata read operations in metastore storage based authorization
  • [HIVE-8225] - CBO trunk merge: union11 test fails due to incorrect plan
  • [HIVE-8226] - Vectorize dynamic partitioning in VectorFileSinkOperator
  • [HIVE-8227] - NPE w/ hive on tez when doing unions on empty tables
  • [HIVE-8229] - Add multithreaded tests for the Hive Writable data types
  • [HIVE-8231] - Error when insert into empty table with ACID
  • [HIVE-8235] - Insert into partitioned bucketed sorted tables fails with "this file is already being created by"
  • [HIVE-8236] - VectorHashKeyWrapper allocates too many zero sized arrays
  • [HIVE-8239] - MSSQL upgrade schema scripts does not map Java long datatype columns correctly for transaction related tables
  • [HIVE-8240] - VectorColumnAssignFactory throws "Incompatible Bytes vector column and primitive category VARCHAR"
  • [HIVE-8246] - HiveServer2 in http-kerberos mode is restrictive on client usernames
  • [HIVE-8248] - TestHCatLoader.testReadDataPrimitiveTypes() occasionally fails
  • [HIVE-8250] - Truncating table doesnt invalidate stats
  • [HIVE-8257] - Accumulo introduces old hadoop-client dependency
  • [HIVE-8258] - Compactor cleaners can be starved on a busy table or partition.
  • [HIVE-8260] - CBO : Query query has date_dim d1,date_dim d2 and date_dim d3 but the explain has d1, d1 and d1
  • [HIVE-8261] - CBO : Predicate pushdown is removed by Optiq
  • [HIVE-8263] - CBO : TPC-DS Q64 is item is joined last with store_sales while it should be first as it is the most selective
  • [HIVE-8269] - Revert HIVE-8200 (Make beeline use the hive-jdbc standalone jar)
  • [HIVE-8270] - JDBC uber jar is missing some classes required in secure setup.
  • [HIVE-8271] - Jackson incompatibility between hadoop-2.4 and hive-14
  • [HIVE-8272] - Query with particular decimal expression causes NPE during execution initialization
  • [HIVE-8273] - Beeline doesn't print applicationID for submitted DAG
  • [HIVE-8277] - IP address string in HS2, metastore have a "/" prefix
  • [HIVE-8279] - sql std auth - additional test cases
  • [HIVE-8280] - CBO : When filter is applied on dimension table PK/FK code path is not in effect.
  • [HIVE-8281] - NPE with dynamic partition pruning on Tez
  • [HIVE-8283] - Missing break in FilterSelectivityEstimator#visitCall()
  • [HIVE-8287] - Metadata action errors don't have information about cause
  • [HIVE-8290] - With DbTxnManager configured, all ORC tables forced to be transactional
  • [HIVE-8292] - Reading from partitioned bucketed tables has high overhead in MapOperator.cleanUpInputFileChangedOp
  • [HIVE-8296] - Tez ReduceShuffle Vectorization needs 2 data buffers (key and value) for adding rows
  • [HIVE-8298] - Incorrect results for n-way join when join expressions are not in same order across joins
  • [HIVE-8299] - HiveServer2 in http-kerberos & doAs=true is failing with org.apache.hadoop.security.AccessControlException
  • [HIVE-8304] - Tez Reduce-Side GROUP BY Vectorization doesn't copy NULL keys correctly
  • [HIVE-8310] - RetryingHMSHandler is not used when kerberos auth enabled
  • [HIVE-8311] - Driver is encoding transaction information too late
  • [HIVE-8313] - Optimize evaluation for ExprNodeConstantEvaluator and ExprNodeNullEvaluator
  • [HIVE-8314] - Restore thrift string interning of HIVE-7975
  • [HIVE-8315] - CBO : Negate condition underestimates selectivity which results in an in-efficient plan
  • [HIVE-8316] - CBO : cardinality estimation for filters is much lower than actual row count
  • [HIVE-8318] - Null Scan optimizer throws exception when no partitions are selected
  • [HIVE-8321] - Fix serialization of TypeInfo for qualified types
  • [HIVE-8322] - VectorReduceSinkOperator: ClassCastException: ~StandardUnionObjectInspector$StandardUnion cannot be cast to ~IntWritable
  • [HIVE-8324] - Shim KerberosName (causes build failure on hadoop-1)
  • [HIVE-8328] - MapJoin implementation in Tez should not reload hashtables
  • [HIVE-8332] - Reading an ACID table with vectorization on results in NPE
  • [HIVE-8335] - TestHCatLoader/TestHCatStorer failures on pre-commit tests
  • [HIVE-8336] - Update pom, now that Optiq is renamed to Calcite
  • [HIVE-8340] - Windows: HiveServer2 service doesn't stop backend jvm process, which prevents follow-up service start.
  • [HIVE-8341] - Transaction information in config file can grow excessively large
  • [HIVE-8344] - Hive on Tez sets mapreduce.framework.name to yarn-tez
  • [HIVE-8348] - Fix Hive to match changes introduced by TEZ-1510
  • [HIVE-8349] - DISTRIBUTE BY should work with tez auto-parallelism enabled
  • [HIVE-8354] - HIVE-7156 introduced required dependency on tez
  • [HIVE-8361] - NPE in PTFOperator when there are empty partitions
  • [HIVE-8363] - AccumuloStorageHandler compile failure hadoop-1
  • [HIVE-8364] - We're not waiting for all inputs in MapRecordProcessor on Tez
  • [HIVE-8366] - CBO fails if there is a table sample in subquery
  • [HIVE-8367] - delete writes records in wrong order in some cases
  • [HIVE-8368] - compactor is improperly writing delete records in base file
  • [HIVE-8372] - Potential NPE in Tez MergeFileRecordProcessor
  • [HIVE-8378] - NPE in TezTask due to null counters
  • [HIVE-8380] - NanoTime class serializes and deserializes Timestamp incorrectly
  • [HIVE-8382] - ConstantPropagateProcFactory#isDeterministicUdf adds a lot of ERROR level logs
  • [HIVE-8386] - HCAT api call is case sensitive on fields in struct column
  • [HIVE-8387] - add retry logic to ZooKeeperStorage in WebHCat
  • [HIVE-8389] - Fix CBO when indexes are used
  • [HIVE-8390] - CBO produces annoying exception message and wraps exceptions too much
  • [HIVE-8391] - Comparion between TIMESTAMP and Integer types goes to STRING as "common comparison denominator" instead of a numeric type
  • [HIVE-8392] - HiveServer2 Operation.close fails on windows
  • [HIVE-8393] - Handle SIGINT on Tez
  • [HIVE-8394] - HIVE-7803 doesn't handle Pig MultiQuery, can cause data-loss.
  • [HIVE-8399] - Build failure on trunk & 14 branch
  • [HIVE-8401] - OrcFileMergeOperator only close last orc file it opened, which resulted in stale data in table directory
  • [HIVE-8402] - Orc pushing SARGs into delta files causing ArrayOutOfBoundsExceptions
  • [HIVE-8403] - Build broken by datanucleus.org being offline
  • [HIVE-8404] - ColumnPruner doesnt prune columns from limit operator
  • [HIVE-8407] - [CBO] Handle filters with non-boolean return type
  • [HIVE-8408] - hcat cli throws NPE when authorizer using new api is enabled
  • [HIVE-8409] - SMB joins fail intermittently on tez
  • [HIVE-8411] - Support partial partition spec for certain ALTER PARTITION statements
  • [HIVE-8413] - [CBO] Handle ill-formed queries which have distinct, having in incorrect context
  • [HIVE-8415] - Vectorized comparison of timestamp and integer needs to treat integer as seconds since epoch
  • [HIVE-8417] - round(decimal, negative) errors out/wrong results with reduce side vectorization
  • [HIVE-8421] - [CBO] Use OptiqSemanticException in error conditions
  • [HIVE-8427] - Hive Streaming : secure streaming hangs leading to time outs.
  • [HIVE-8429] - Add records in/out counters
  • [HIVE-8433] - CBO loses a column during AST conversion
  • [HIVE-8434] - Vectorization logic using wrong values for DATE and TIMESTAMP partitioning columns in vectorized row batches...
  • [HIVE-8442] - Revert HIVE-8403
  • [HIVE-8443] - Disable tez_smb_1 for mapreduce and prevent from test hang
  • [HIVE-8444] - update pom to junit 4.11
  • [HIVE-8445] - TestColumnAccess, TestReadEntityDirect use same table names
  • [HIVE-8452] - Cleanup handling of resource configuration for tez
  • [HIVE-8460] - ORC SARG literal creation for double from float may lead to wrong evaluation of SARG
  • [HIVE-8461] - Make Vectorized Decimal query results match Non-Vectorized query results with respect to trailing zeroes... .0000
  • [HIVE-8462] - CBO duplicates columns
  • [HIVE-8464] - Vectorized reducer nested group by query returns wrong results
  • [HIVE-8474] - Vectorized reads of transactional tables fail when not all columns are selected
  • [HIVE-8475] - add test case for use of index from not-current database
  • [HIVE-8476] - JavaDoc updates to HiveEndPoint.newConnection() for secure streaming with Kerberos
  • [HIVE-8478] - Vectorized Reduce-Side Group By doesn't handle Decimal type correctly
  • [HIVE-8479] - Tez sessions cannot change queues once assigned to one within a CLI session
  • [HIVE-8484] - HCatalog throws an exception if Pig job is of type 'fetch'
  • [HIVE-8489] - Add sanity check to dynamic partition pruning
  • [HIVE-8495] - Add progress bar for Hive on Tez queries
  • [HIVE-8497] - StatsNoJobTask doesn't close RecordReader, FSDataInputStream of which keeps open to prevent stale data clean
  • [HIVE-8498] - Insert into table misses some rows when vectorization is enabled
  • [HIVE-8510] - HIVE-8462 didn't update tez test output
  • [HIVE-8511] - fix build failure: cbo_correctness on tez
  • [HIVE-8514] - TestCliDriver.testCliDriver_index_in_db fails in trunk
  • [HIVE-8517] - When joining on partition column NDV gets overridden by StatsUtils.getColStatisticsFromExpression
  • [HIVE-8526] - Hive : CBO incorrect join order in TPC-DS Q45 as self join selectivity has incorrect CE
  • [HIVE-8534] - sql std auth : update configuration whitelist for 0.14
  • [HIVE-8543] - Compactions fail on metastore using postgres
  • [HIVE-8546] - Handle "add archive scripts.tar.gz" in Tez
  • [HIVE-8547] - CBO and/or constant propagation breaks partition_varchar2 test
  • [HIVE-8550] - Hive cannot load data into partitioned table with Unicode key
  • [HIVE-8551] - NPE in FunctionRegistry (affects CBO in negative tests)
  • [HIVE-8555] - Too many casts results in loss of original string representation for constant
  • [HIVE-8557] - automatically setup ZooKeeperTokenStore to use kerberos authentication when kerberos is enabled
  • [HIVE-8558] - CBO: enable n-way joins after CBO join reordering
  • [HIVE-8560] - SerDes that do not inherit AbstractSerDe do not get table properties during initialize()
  • [HIVE-8562] - ResultSet.isClosed sometimes doesn't work with mysql
  • [HIVE-8563] - Running annotate_stats_join_pkfk.q in TestMiniTezCliDriver is causing NPE
  • [HIVE-8566] - Vectorized queries output wrong timestamps
  • [HIVE-8567] - Vectorized queries output extra stuff for Binary columns
  • [HIVE-8575] - CBO: decimal_udf is broken by recent changes (and other tests have type changes)
  • [HIVE-8576] - Guaranteed NPE in StatsRulesProcFactory
  • [HIVE-8577] - Cannot deserialize Avro schema with a map with null values
  • [HIVE-8579] - Guaranteed NPE in DDLSemanticAnalyzer
  • [HIVE-8586] - Record counters aren't updated correctly for vectorized queries
  • [HIVE-8587] - Vectorized Extract operator needs to update the Vectorization Context column map
  • [HIVE-8588] - sqoop REST endpoint fails to send appropriate JDBC driver to the cluster
  • [HIVE-8596] - HiveServer2 dynamic service discovery: ZK throws too many connections error
  • [HIVE-8603] - auto_sortmerge_join_5 is getting stuck on tez
  • [HIVE-8604] - Re-enable auto_sortmerge_join_5 on tez
  • [HIVE-8605] - HIVE-5799 breaks backward compatibility for time values in config
  • [HIVE-8614] - Upgrade hive to use tez version 0.5.2-SNAPSHOT
  • [HIVE-8615] - beeline csv,tsv outputformat needs backward compatibility mode
  • [HIVE-8619] - CBO causes some more type problems
  • [HIVE-8620] - CBO: HIVE-8433 RowResolver check is too stringent
  • [HIVE-8624] - Record counters don't work with Tez container reuse
  • [HIVE-8625] - Some union queries result in plans with many unions with CBO on
  • [HIVE-8628] - NPE in case of shuffle join in tez
  • [HIVE-8629] - Streaming / ACID : hive cli session creation takes too long and times out if execution engine is tez
  • [HIVE-8631] - Compressed transaction list cannot be parsed in job.xml
  • [HIVE-8632] - VectorKeyHashWrapper::duplicateTo allocates too many zero sized arrays
  • [HIVE-8634] - HiveServer2 fair scheduler queue mapping doesn't handle the secondary groups rules correctly
  • [HIVE-8635] - CBO: ambiguous_col negative test no longer fails
  • [HIVE-8641] - Disable skew joins in tez.
  • [HIVE-8643] - DDL operations via WebHCat with doAs parameter in secure cluster fail
  • [HIVE-8646] - Hive class loading failure when executing Hive action via oozie workflows
  • [HIVE-8647] - HIVE-8186 causes addition of same child operator multiple times
  • [HIVE-8660] - sql std auth: property missing from whitelist - hive.exec.dynamic.partition.mode
  • [HIVE-8663] - Fetching Vectorization scratch column map in Reduce-Side stop working
  • [HIVE-8664] - Use Apache Curator in JDBC Driver and HiveServer2 for better reliability
  • [HIVE-8665] - Fix misc unit tests on Windows
  • [HIVE-8668] - mssql sql script has carriage returns
  • [HIVE-8671] - Overflow in estimate row count and data size with fetch column stats
  • [HIVE-8675] - Increase thrift server protocol test coverage
  • [HIVE-8677] - TPC-DS Q51 : fails with "init not supported" exception in GenericUDAFStreamingEvaluator.init
  • [HIVE-8685] - DDL operations in WebHCat set proxy user to "null" in unsecure mode
  • [HIVE-8687] - Support Avro through HCatalog

New in Apache Hive 0.12.0 (Dec 6, 2013)

  • Sub-task:
  • [HIVE-2304] - Support PreparedStatement.setObject
  • [HIVE-4055] - add Date data type
  • [HIVE-4266] - Refactor HCatalog code to org.apache.hive.hcatalog
  • [HIVE-4324] - ORC Turn off dictionary encoding when number of distinct keys is greater than threshold
  • [HIVE-4355] - HCatalog test TestPigHCatUtil might fail on JDK7
  • [HIVE-4460] - Publish HCatalog artifacts for Hadoop 2.x
  • [HIVE-4478] - In ORC, add boolean noNulls flag to column stripe metadata
  • [HIVE-4626] - join_vc.q is not deterministic
  • [HIVE-4646] - skewjoin.q is failing in hadoop2
  • [HIVE-4690] - stats_partscan_1.q makes different result with different hadhoop.mr.rev
  • [HIVE-4708] - Fix TestCliDriver.combine2.q on 0.23
  • [HIVE-4711] - Fix TestCliDriver.list_bucket_query_oneskew_{1,2,3}.q on 0.23
  • [HIVE-4712] - Fix TestCliDriver.truncate_* on 0.23
  • [HIVE-4713] - Fix TestCliDriver.skewjoin_union_remove_{1,2}.q on 0.23
  • [HIVE-4715] - Fix TestCliDriver.{recursive_dir.q,sample_islocalmode_hook.q,input12.q,input39.q,auto_join14.q} on 0.23
  • [HIVE-4717] - Fix non-deterministic TestCliDriver on 0.23
  • [HIVE-4721] - Fix TestCliDriver.ptf_npath.q on 0.23
  • [HIVE-4746] - Fix TestCliDriver.list_bucket_dml_{2,4,5,9,12,13}.q on 0.23
  • [HIVE-4750] - Fix TestCliDriver.list_bucket_dml_{6,7,8}.q on 0.23
  • [HIVE-4756] - Upgrade Hadoop 0.23 profile to 2.0.5-alpha
  • [HIVE-4761] - ZooKeeperHiveLockManage.unlockPrimitive has race condition with threads
  • [HIVE-4762] - HMS cannot handle concurrent requests
  • [HIVE-4763] - add support for thrift over http transport in HS2
  • [HIVE-4767] - ObjectStore.getPMF has concurrency problems
  • [HIVE-4871] - Apache builds fail with Target "make-pom" does not exist in the project "hcatalog".
  • [HIVE-4894] - Update maven coordinates of HCatalog artifacts
  • [HIVE-4895] - Move all HCatalog classes to org.apache.hive.hcatalog
  • [HIVE-4896] - create binary backwards compatibility layer hcatalog 0.12 and 0.11
  • [HIVE-4908] - rename templeton to webhcat?
  • [HIVE-4940] - udaf_percentile_approx.q is not deterministic
  • [HIVE-4980] - Fix the compiling error in TestHadoop20SAuthBridge
  • [HIVE-5013] - [HCatalog] Create hcat.py, hcat_server.py to make HCatalog work on Windows
  • [HIVE-5014] - [HCatalog] Fix HCatalog build issue on Windows
  • [HIVE-5015] - [HCatalog] Fix HCatalog unit tests on Windows
  • [HIVE-5028] - Some tests with fail OutOfMemoryError PermGen Space on Hadoop2
  • [HIVE-5035] - [WebHCat] Hardening parameters for Windows
  • [HIVE-5036] - [WebHCat] Add cmd script for WebHCat
  • [HIVE-5063] - Fix some non-deterministic or not-updated tests
  • [HIVE-5066] - [WebHCat] Other code fixes for Windows
  • [HIVE-5069] - Tests on list bucketing are failing again in hadoop2
  • [HIVE-5078] - [WebHCat] Fix e2e tests on Windows plus test cases for new features
  • [HIVE-5163] - refactor org.apache.hadoop.mapred.HCatMapRedUtil
  • [HIVE-5213] - remove hcatalog/shims directory
  • [HIVE-5233] - move hbase storage handler to org.apache.hcatalog package
  • [HIVE-5236] - Change HCatalog spacing from 4 spaces to 2
  • [HIVE-5260] - Introduce HivePassThroughOutputFormat that allows Hive to use general purpose OutputFormats instead of HiveOutputFormats in StorageHandlers
  • [HIVE-5261] - Make the Hive HBase storage handler work from HCatalog, and use HiveStorageHandlers instead of HCatStorageHandlers
  • Bug:
  • [HIVE-2015] - Eliminate bogus Datanucleus.Plugin Bundle ERROR log messages
  • [HIVE-2379] - Hive/HBase integration could be improved
  • [HIVE-2473] - Hive throws an NPE when $HADOOP_HOME points to a tarball install directory that contains a build/ subdirectory.
  • [HIVE-2702] - Enhance listPartitionsByFilter to add support for integral types both for equality and non-equality
  • [HIVE-2905] - Desc table can't show non-ascii comments
  • [HIVE-3189] - cast ( as bigint) returning null values
  • [HIVE-3191] - timestamp - timestamp causes null pointer exception
  • [HIVE-3253] - ArrayIndexOutOfBounds exception for deeply nested structs
  • [HIVE-3256] - Update asm version in Hive
  • [HIVE-3264] - Add support for binary dataype to AvroSerde
  • [HIVE-3475] - INLINE UDTF doesn't convert types properly
  • [HIVE-3562] - Some limit can be pushed down to map stage
  • [HIVE-3588] - Get Hive to work with hbase 94
  • [HIVE-3632] - Upgrade datanucleus to support JDK7
  • [HIVE-3691] - TestDynamicSerDe failed with IBM JDK
  • [HIVE-3756] - "LOAD DATA" does not honor permission inheritence
  • [HIVE-3772] - Fix a concurrency bug in LazyBinaryUtils due to a static field
  • [HIVE-3810] - HiveHistory.log need to replace '\r' with space before writing Entry.value to historyfile
  • [HIVE-3846] - alter view rename NPEs with authorization on.
  • [HIVE-3891] - physical optimizer changes for auto sort-merge join
  • [HIVE-3926] - PPD on virtual column of partitioned table is not working
  • [HIVE-3953] - Reading of partitioned Avro data fails because of missing properties
  • [HIVE-3957] - Add pseudo-BNF grammar for RCFile to Javadoc
  • [HIVE-3978] - HIVE_AUX_JARS_PATH should have : instead of , as separator since it gets appended to HADOOP_CLASSPATH
  • [HIVE-4003] - NullPointerException in exec.Utilities
  • [HIVE-4051] - Hive's metastore suffers from 1+N queries when querying partitions & is slow
  • [HIVE-4057] - LazyHBaseRow may return cache data if the field is null and make the result wrong
  • [HIVE-4089] - javax.jdo : jdo2-api dependency not in Maven Central
  • [HIVE-4106] - SMB joins fail in multi-way joins
  • [HIVE-4171] - Current database in metastore.Hive is not consistent with SessionState
  • [HIVE-4181] - Star argument without table alias for UDTF is not working
  • [HIVE-4194] - JDBC2: HiveDriver should not throw RuntimeException when passed an invalid URL
  • [HIVE-4214] - OVER accepts general expression instead of just function
  • [HIVE-4222] - Timestamp type constants cannot be deserialized in JDK 1.6 or less
  • [HIVE-4233] - The TGT gotten from class 'CLIService' should be renewed on time
  • [HIVE-4251] - Indices can't be built on tables whose schema info comes from SerDe
  • [HIVE-4290] - Build profiles: Partial builds for quicker dev
  • [HIVE-4295] - Lateral view makes invalid result if CP is disabled
  • [HIVE-4299] - exported metadata by HIVE-3068 cannot be imported because of wrong file name
  • [HIVE-4300] - ant thriftif generated code that is checkedin is not up-to-date
  • [HIVE-4322] - SkewedInfo in Metastore Thrift API cannot be deserialized in Python
  • [HIVE-4339] - build fails after branch (hcatalog version not updated)
  • [HIVE-4343] - HS2 with kerberos- local task for map join fails
  • [HIVE-4344] - CREATE VIEW fails when redundant casts are rewritten
  • [HIVE-4347] - Hcatalog build fail on Windows because javadoc command exceed length limit
  • [HIVE-4348] - Unit test compile fail at hbase-handler project on Windows becuase of illegal escape character
  • [HIVE-4350] - support AS keyword for table alias
  • [HIVE-4351] - Thrift code generation fails due to hcatalog
  • [HIVE-4364] - beeline always exits with 0 status, should exit with non-zero status on error
  • [HIVE-4369] - Many new failures on hadoop 2
  • [HIVE-4375] - Single sourced multi insert consists of native and non-native table mixed throws NPE
  • [HIVE-4377] - Add more comment to https://reviews.facebook.net/D1209 (HIVE-2340)
  • [HIVE-4392] - Illogical InvalidObjectException throwed when use mulit aggregate functions with star columns
  • [HIVE-4403] - Running Hive queries on Yarn (MR2) gives warnings related to overriding final parameters
  • [HIVE-4406] - Missing "/" or "/" in hs2 jdbc uri switches mode to embedded mode
  • [HIVE-4407] - TestHCatStorer.testStoreFuncAllSimpleTypes fails because of null case difference
  • [HIVE-4418] - TestNegativeCliDriver failure message if cmd succeeds is misleading
  • [HIVE-4421] - Improve memory usage by ORC dictionaries
  • [HIVE-4422] - Test output need to be updated for Windows only unit test in TestCliDriver
  • [HIVE-4424] - MetaStoreUtils.java.orig checked in mistakenly by HIVE-4409
  • [HIVE-4428] - Misspelling in describe extended output
  • [HIVE-4430] - Semantic analysis fails in presence of certain literals in on clause
  • [HIVE-4433] - Fix C++ Thrift bindings broken in HIVE-4322
  • [HIVE-4435] - Column stats: Distinct value estimator should use hash functions that are pairwise independent
  • [HIVE-4436] - hive.exec.parallel=true doesn't work on hadoop-2
  • [HIVE-4438] - Remove unused join configuration parameter: hive.mapjoin.size.key
  • [HIVE-4439] - Remove unused join configuration parameter: hive.mapjoin.cache.numrows
  • [HIVE-4440] - SMB Operator spills to disk like it's 1999
  • [HIVE-4441] - [HCatalog] WebHCat does not honor user home directory
  • [HIVE-4442] - [HCatalog] WebHCat should not override user.name parameter for Queue call
  • [HIVE-4465] - webhcat e2e tests succeed regardless of exitvalue
  • [HIVE-4466] - Fix continue.on.failure in unit tests to -well- continue on failure in unit tests
  • [HIVE-4471] - Build fails with hcatalog checkstyle error
  • [HIVE-4474] - Column access not tracked properly for partitioned tables
  • [HIVE-4475] - Switch RCFile default to LazyBinaryColumnarSerDe
  • [HIVE-4486] - FetchOperator slows down SMB map joins by 50% when there are many partitions
  • [HIVE-4487] - Hive does not set explicit permissions on hive.exec.scratchdir
  • [HIVE-4489] - beeline always return the same error message twice
  • [HIVE-4492] - Revert HIVE-4322
  • [HIVE-4496] - JDBC2 won't compile with JDK7
  • [HIVE-4497] - beeline module tests don't get run by default
  • [HIVE-4502] - NPE - subquery smb joins fails
  • [HIVE-4510] - HS2 doesn't nest exceptions properly (fun debug times)
  • [HIVE-4513] - disable hivehistory logs by default
  • [HIVE-4516] - Fix concurrency bug in serde/src/java/org/apache/hadoop/hive/serde2/io/TimestampWritable.java
  • [HIVE-4521] - Auto join conversion fails in certain cases (empty tables, empty partitions, no partitions)
  • [HIVE-4525] - Support timestamps earlier than 1970 and later than 2038
  • [HIVE-4535] - hive build fails with hadoop 0.20
  • [HIVE-4540] - JOIN-GRP BY-DISTINCT fails with NPE when mapjoin.mapreduce=true
  • [HIVE-4542] - TestJdbcDriver2.testMetaDataGetSchemas fails because of unexpected database
  • [HIVE-4543] - Broken link in HCat 0.5 doc (Reader and Writer Interfaces)
  • [HIVE-4546] - Hive CLI leaves behind the per session resource directory on non-interactive invocation
  • [HIVE-4547] - A complex create view statement fails with new Antlr 3.4
  • [HIVE-4550] - local_mapred_error_cache fails on some hadoop versions
  • [HIVE-4554] - Failed to create a table from existing file if file path has spaces
  • [HIVE-4559] - hcatalog/webhcat scripts in tar.gz don't have execute permissions set
  • [HIVE-4562] - HIVE-3393 brought in Jackson library,and these four jars should be packed into hive-exec.jar
  • [HIVE-4566] - NullPointerException if typeinfo and nativesql commands are executed at beeline before a DB connection is established
  • [HIVE-4572] - ColumnPruner cannot preserve RS key columns corresponding to un-selected join keys in columnExprMap
  • [HIVE-4573] - Support alternate table types for HiveServer2
  • [HIVE-4578] - Changes to Pig's test harness broke HCat e2e tests
  • [HIVE-4580] - Change DDLTask to report errors using canonical error messages rather than http status codes
  • [HIVE-4581] - HCat e2e tests broken by changes to Hive's describe table formatting
  • [HIVE-4585] - Remove unused MR Temp file localization from Tasks
  • [HIVE-4586] - [HCatalog] WebHCat should return 404 error for undefined resource
  • [HIVE-4589] - Hive Load command failed when inpath contains space or any restricted characters
  • [HIVE-4591] - Making changes to webhcat-site.xml have no effect
  • [HIVE-4593] - ErrorMsg has several messages that reuse the same error code
  • [HIVE-4611] - SMB joins fail based on bigtable selection policy.
  • [HIVE-4615] - Invalid column names allowed when created dynamically by a SerDe
  • [HIVE-4618] - show create table creating unusable DDL when field delimiter is \001
  • [HIVE-4619] - Hive 0.11.0 is not working with pre-cdh3u6 and hadoop-0.23
  • [HIVE-4638] - Thread local PerfLog can get shared by multiple hiveserver2 sessions
  • [HIVE-4650] - Getting Execution Error, return code 2 from org.apache.hadoop.hive.ql.exec.MapRedTask on auto convert to MapJoin after upgrade to Hive-0.11.0.x from hive-0.10.0.x
  • [HIVE-4657] - HCatalog checkstyle violation after HIVE-2670
  • [HIVE-4677] - [HCatalog] WebHCat e2e tests fail on Hadoop 2
  • [HIVE-4679] - WebHCat can deadlock Hadoop if the number of concurrently running tasks if higher or equal than the number of mappers
  • [HIVE-4683] - fix coverage org.apache.hadoop.hive.cli
  • [HIVE-4689] - For outerjoins, joinEmitInterval might make wrong result
  • [HIVE-4691] - orc_createas1.q has minor inconsistency
  • [HIVE-4692] - Constant agg parameters will be replaced by ExprNodeColumnDesc with single-sourced multi-gby cases
  • [HIVE-4696] - WebHCat e2e test framework is missing files and instructions
  • [HIVE-4707] - Support configurable domain name for HiveServer2 LDAP authentication using Active Directory
  • [HIVE-4710] - ant maven-build -Dmvn.publish.repo=local fails
  • [HIVE-4724] - ORC readers should have a better error detection for non-ORC files
  • [HIVE-4730] - Join on more than 2^31 records on single reducer failed (wrong results)
  • [HIVE-4733] - HiveLockObjectData is not compared properly
  • [HIVE-4740] - HIVE-2379 is missing hbase.jar itself
  • [HIVE-4742] - A useless CAST makes Hive fail to create a VIEW based on an UNION
  • [HIVE-4748] - Fix TempletonUtilsTest failure on Windows
  • [HIVE-4757] - LazyTimestamp goes into irretrievable NULL mode once inited with NULL once
  • [HIVE-4781] - LEFT SEMI JOIN generates wrong results when the number of rows belonging to a single key of the right table exceed hive.join.emit.interval
  • [HIVE-4784] - ant testreport doesn't include any HCatalog tests
  • [HIVE-4785] - Implement isCaseSensitive for Hive JDBC driver
  • [HIVE-4789] - FetchOperator fails on partitioned Avro data
  • [HIVE-4798] - NPE when we call isSame from an instance of ExprNodeConstantDesc with null value
  • [HIVE-4802] - Fix url check for missing "/" or "/ after hostname in jdb uri
  • [HIVE-4804] - parallel order by fails for small datasets
  • [HIVE-4807] - Hive metastore hangs
  • [HIVE-4808] - WebHCat job submission is killed by TaskTracker since it's not sending a heartbeat properly
  • [HIVE-4810] - Refactor exec package
  • [HIVE-4811] - (Slightly) break up the SemanticAnalyzer monstrosity
  • [HIVE-4812] - Logical explain plan
  • [HIVE-4814] - Adjust WebHCat e2e tests until HIVE-4703 is addressed
  • [HIVE-4818] - SequenceId in operator is not thread safe
  • [HIVE-4820] - webhcat_config.sh should set default values for HIVE_HOME and HCAT_PREFIX that work with default build tree structure
  • [HIVE-4829] - TestWebHCatE2e checkstyle violation causes all tests to fail
  • [HIVE-4830] - Test clientnegative/nested_complex_neg.q got broken due to 4580
  • [HIVE-4833] - Fix eclipse template classpath to include the correct jdo lib
  • [HIVE-4836] - make checkstyle ignore IntelliJ files and templeton e2e files
  • [HIVE-4838] - Refactor MapJoin HashMap code to improve testability and readability
  • [HIVE-4839] - build-common.xml has
  • [HIVE-4840] - Fix eclipse template classpath to include the BoneCP lib
  • [HIVE-4843] - Refactoring MapRedTask and ExecDriver for better re-usability (for tez) and readability
  • [HIVE-4845] - Correctness issue with MapJoins using the null safe operator
  • [HIVE-4852] - -Dbuild.profile=core fails
  • [HIVE-4853] - junit timeout needs to be updated
  • [HIVE-4854] - testCliDriver_load_hdfs_file_with_space_in_the_name fails on hadoop 2
  • [HIVE-4863] - Fix parallel order by on hadoop2
  • [HIVE-4865] - HiveLockObjects: Unlocking retries/times out when query contains ":"
  • [HIVE-4869] - Clean up HCatalog build post Hive integration
  • [HIVE-4870] - Explain Extended to show partition info for Fetch Task
  • [HIVE-4875] - hive config template is not parse-able due to angle brackets in description
  • [HIVE-4876] - Beeling help text do not contain -f and -e parameters
  • [HIVE-4878] - With Dynamic partitioning, some queries would scan default partition even if query is not using it.
  • [HIVE-4883] - TestHadoop20SAuthBridge tests fail sometimes because of race condition
  • [HIVE-4891] - Distinct includes duplicate records
  • [HIVE-4892] - PTest2 cleanup after merge
  • [HIVE-4893] - [WebHCat] HTTP 500 errors should be mapped to 400 for bad request
  • [HIVE-4899] - Hive returns non-meanful error message for ill-formed fs.default.name
  • [HIVE-4900] - Fix the mismatched column names in package.jdo
  • [HIVE-4915] - unit tests fail on windows because of difference in input file size
  • [HIVE-4927] - When we merge two MapJoin MapRedTasks, the TableScanOperator of the second one should be removed
  • [HIVE-4928] - Date literals do not work properly in partition spec clause
  • [HIVE-4929] - the type of all numeric constants is changed to double in the plan
  • [HIVE-4930] - Classes of metastore should not be included MR-task
  • [HIVE-4932] - PTFOperator fails resetting PTFPersistence
  • [HIVE-4935] - Potential NPE in MetadataOnlyOptimizer
  • [HIVE-4942] - Fix eclipse template files to use correct datanucleus libs
  • [HIVE-4951] - combine2_win.q.out needs update for HIVE-3253 (increasing nesting levels)
  • [HIVE-4952] - When hive.join.emit.interval is small, queries optimized by Correlation Optimizer may generate wrong results
  • [HIVE-4955] - serde_user_properties.q.out needs to be updated
  • [HIVE-4962] - fix eclipse template broken by HIVE-3256
  • [HIVE-4964] - Cleanup PTF code: remove code dealing with non standard sql behavior we had original introduced
  • [HIVE-4968] - When deduplicating multiple SelectOperators, we should update RowResolver accordinly
  • [HIVE-4970] - BinaryConverter does not respect nulls
  • [HIVE-4972] - update code generated by thrift for DemuxOperator and MuxOperator
  • [HIVE-4987] - Javadoc can generate argument list too long error
  • [HIVE-4990] - ORC seeks fails with non-zero offset or column projection
  • [HIVE-4991] - hive build with 0.20 is broken
  • [HIVE-4995] - select * may incorrectly return empty fields with hbase-handler
  • [HIVE-4998] - support jdbc documented table types in default configuration
  • [HIVE-5010] - HCatalog maven integration doesn't override mvn.local.repo in two locations
  • [HIVE-5011] - Dynamic partitioning in HCatalog broken on external tables
  • [HIVE-5012] - [HCatalog] Make HCatalog work on Windows
  • [HIVE-5017] - DBTokenStore gives compiler warnings
  • [HIVE-5023] - Hive get wrong result when partition has the same path but different schema or authority
  • [HIVE-5026] - HIVE-3926 is committed in the state of not rebased to trunk
  • [HIVE-5034] - [WebHCat] Make WebHCat work for Windows
  • [HIVE-5046] - Hcatalog's bin/hcat script doesn't respect HIVE_HOME
  • [HIVE-5047] - Hive client filters partitions incorrectly via pushdown in certain cases involving "or"
  • [HIVE-5048] - StorageBasedAuthorization provider causes an NPE when asked to authorize from client side.
  • [HIVE-5049] - Create an ORC test case that has a 0.11 ORC file
  • [HIVE-5051] - StorageBasedAuthorizationProvider masks lower level exception with IllegalStateException
  • [HIVE-5055] - SessionState temp file gets created in history file directory
  • [HIVE-5056] - MapJoinProcessor ignores order of values in removing RS
  • [HIVE-5060] - JDBC driver assumes executeStatement is synchronous
  • [HIVE-5061] - Row sampling throws NPE when used in sub-query
  • [HIVE-5075] - bug in ExprProcFactory.genPruner
  • [HIVE-5079] - Make Hive compile under Windows
  • [HIVE-5084] - Fix newline.q on Windows
  • [HIVE-5085] - Hive Metatool errors out if HIVE_OPTS is set
  • [HIVE-5087] - Rename npath UDF to matchpath
  • [HIVE-5089] - Non query PreparedStatements are always failing on remote HiveServer2
  • [HIVE-5091] - ORC files should have an option to pad stripes to the HDFS block boundaries
  • [HIVE-5100] - RCFile::sync(long) missing 1 byte in System.arraycopy()
  • [HIVE-5104] - HCatStorer fails to store boolean type
  • [HIVE-5105] - HCatSchema.remove(HCatFieldSchema hcatFieldSchema) does not clean up fieldPositionMap
  • [HIVE-5106] - HCatFieldSchema overrides equals() but not hashCode()
  • [HIVE-5120] - document what hive.server2.thrift.sasl.qop values mean in hive-default.xml.template
  • [HIVE-5122] - Add partition for multiple partition ignores locations for non-first partitions
  • [HIVE-5123] - group by on a same key producing wrong result
  • [HIVE-5127] - Upgrade xerces and xalan for WebHCat
  • [HIVE-5128] - Direct SQL for view is failing
  • [HIVE-5129] - Multiple table insert fails on count(distinct)
  • [HIVE-5131] - JDBC client's hive variables are not passed to HS2
  • [HIVE-5137] - A Hive SQL query should not return a ResultSet when the underlying plan does not include a FetchTask
  • [HIVE-5144] - HashTableSink allocates empty new Object[] arrays & OOMs - use a static emptyRow instead
  • [HIVE-5145] - Fix TestCliDriver.list_bucket_query_multiskew_2.q on hadoop 0.23
  • [HIVE-5149] - ReduceSinkDeDuplication can pick the wrong partitioning columns
  • [HIVE-5156] - HiveServer2 jdbc ResultSet.close should free up resources on server side
  • [HIVE-5161] - Additional SerDe support for varchar type
  • [HIVE-5167] - webhcat_config.sh checks for env variables being set before sourcing webhcat-env.sh
  • [HIVE-5196] - ThriftCLIService.java uses stderr to print the stack trace, it should use the logger instead.
  • [HIVE-5198] - WebHCat returns exitcode 143 (w/o an explanation)
  • [HIVE-5199] - Custom SerDe containing a nonSettable complex data type row object inspector throws cast exception with HIVE 0.11
  • [HIVE-5203] - FunctionRegistry.getMethodInternal() should prefer method arguments with closer affinity to the original argument types
  • [HIVE-5210] - WebHCatJTShim implementations are missing Apache license headers
  • [HIVE-5239] - LazyDate goes into irretrievable NULL mode once inited with NULL once
  • [HIVE-5241] - Default log4j log level for WebHCat should be INFO not DEBUG
  • [HIVE-5246] - Local task for map join submitted via oozie job fails on a secure HDFS
  • [HIVE-5255] - Missing metastore schema files for version 0.11
  • [HIVE-5265] - Direct SQL fallback broken on Postgres
  • [HIVE-5274] - HCatalog package renaming backward compatibility follow-up
  • [HIVE-5285] - Custom SerDes throw cast exception when there are complex nested structures containing NonSettableObjectInspectors.
  • [HIVE-5292] - Join on decimal columns fails to return rows
  • [HIVE-5296] - Memory leak: OOM Error after multiple open/closed JDBC connections.
  • [HIVE-5297] - Hive does not honor type for partition columns
  • [HIVE-5301] - Add a schema tool for offline metastore schema upgrade
  • [HIVE-5322] - FsPermission is initialized incorrectly in HIVE 5513
  • [HIVE-5329] - Date and timestamp type converts invalid strings to '1970-01-01'
  • [HIVE-5337] - org.apache.hcatalog.common.HCatUtil is used by org.apache.hive.hcatalog.templeton.tool
  • [HIVE-5352] - cast('1.0' as int) returns null
  • [HIVE-5357] - ReduceSinkDeDuplication optimizer pick the wrong keys in pRS-cGBYm-cRS-cGBYr scenario when there are distinct keys in child GBY
  • [HIVE-5362] - TestHCatHBaseInputFormat has a bug which will not allow it to run on JDK7 and RHEL 6
  • [HIVE-5364] - NPE on some queries from partitioned orc table
  • [HIVE-5374] - hive-schema-0.13.0.postgres.sql doesn't work
  • [HIVE-5375] - Bug in Hive-0.12 branch with parameterized types due to merge conflict with HIVE-5199
  • [HIVE-5394] - ObjectInspectorConverters.getConvertedOI() does not return the correct object inspector for primitive type.
  • [HIVE-5401] - Array Out Of Bounds in OrcRecordReader
  • [HIVE-5402] - StorageBasedAuthorizationProvider is not correctly able to determine that it is running from client-side
  • [HIVE-5405] - Need to implement PersistenceDelegate for org.antlr.runtime.CommonToken
  • [HIVE-5410] - Hive command line option --auxpath still does not work post HIVE-5363
  • [HIVE-5413] - StorageDelegationAuthorizationProvider uses non-existent org.apache.hive.hcatalog.hbase.HBaseHCatStorageHandler
  • [HIVE-5416] - templeton/tests/jobsubmission2.conf erroneously removed
  • [HIVE-5419] - Fix schema tool issues with Oracle metastore
  • [HIVE-5426] - TestThriftBinaryCLIService tests fail on branch 0.12
  • [HIVE-5429] - HiveVarcharWritable length not reset when value is changed
  • [HIVE-5431] - PassthroughOutputFormat SH changes causes IllegalArgumentException
  • [HIVE-5433] - Fix varchar unit tests to work with hadoop-2.1.1
  • [HIVE-5476] - Authorization-provider tests fail in sequential run
  • [HIVE-5477] - maven-publish fails because it can't find hive-metastore-0.12.0.pom
  • [HIVE-5488] - some files are missing apache license headers
  • [HIVE-5489] - NOTICE copyright dates are out of date, README needs update
  • [HIVE-5493] - duplicate jars with different versions for guava, commons-logging
  • [HIVE-5497] - Hive trunk broken against hadoop 0.20.2
  • [HIVE-5769] - when "hive.server2.authentication" set "NONE", is "hive.server2.enable.doAs" always work?
  • [HIVE-5864] - Hive Table filter Not working (ERROR:SemanticException MetaException)
  • Improvement:
  • [HIVE-2084] - Upgrade datanucleus from 2.0.3 to a more recent version (3.?)
  • [HIVE-2608] - Do not require AS a,b,c part in LATERAL VIEW
  • [HIVE-2906] - Support providing some table properties by user via SQL
  • [HIVE-3603] - Enable client-side caching for scans on HBase
  • [HIVE-3725] - Add support for pulling HBase columns with prefixes
  • [HIVE-3764] - Support metastore version consistency check
  • [HIVE-3807] - Hive authorization should use short username when Kerberos authentication
  • [HIVE-4002] - Fetch task aggregation for simple group by query
  • [HIVE-4068] - Size of aggregation buffer which uses non-primitive type is not estimated correctly
  • [HIVE-4172] - JDBC2 does not support VOID type
  • [HIVE-4209] - Cache evaluation result of deterministic expression and reuse it
  • [HIVE-4228] - Bump up hadoop2 version in trunk
  • [HIVE-4241] - optimize hive.enforce.sorting and hive.enforce bucketing join
  • [HIVE-4268] - Beeline should support the -f option
  • [HIVE-4294] - Single sourced multi query cannot handle lateral view
  • [HIVE-4310] - optimize count(distinct) with hive.map.groupby.sorted
  • [HIVE-4393] - Make the deleteData flag accessable from DropTable/Partition events
  • [HIVE-4409] - Prevent incompatible column type changes
  • [HIVE-4423] - Improve RCFile::sync(long) 10x
  • [HIVE-4443] - [HCatalog] Have an option for GET queue to return all job information in single call
  • [HIVE-4444] - [HCatalog] WebHCat Hive should support equivalent parameters as Pig
  • [HIVE-4459] - Script hcat is overriding HIVE_CONF_DIR variable
  • [HIVE-4530] - Enforce minmum ant version required in build script
  • [HIVE-4549] - JDBC compliance change TABLE_SCHEMA to TABLE_SCHEM
  • [HIVE-4579] - Create a SARG interface for RecordReaders
  • [HIVE-4588] - Support session level hooks for HiveServer2
  • [HIVE-4601] - WebHCat needs to support proxy users
  • [HIVE-4609] - Allow hive tests to specify an alternative to /tmp
  • [HIVE-4610] - HCatalog checkstyle violation after HIVE-4578
  • [HIVE-4617] - Asynchronous execution in HiveServer2 to run a query in non-blocking mode
  • [HIVE-4620] - MR temp directory conflicts in case of parallel execution mode
  • [HIVE-4647] - RetryingHMSHandler logs too many error messages
  • [HIVE-4658] - Make KW_OUTER optional in outer joins
  • [HIVE-4675] - Create new parallel unit test environment
  • [HIVE-4682] - Temporary files are not closed in PTFPersistence on jvm reuse.
  • [HIVE-4737] - Allow access to MapredContext
  • [HIVE-4772] - Enable parallel execution of various E2E tests
  • [HIVE-4825] - Separate MapredWork into MapWork and ReduceWork
  • [HIVE-4827] - Merge a Map-only task to its child task
  • [HIVE-4858] - Sort "show grant" result to improve usability and testability
  • [HIVE-4873] - Sort candidate functions in case of UDFArgumentException
  • [HIVE-4874] - Identical methods PTFDeserializer.addOIPropertiestoSerDePropsMap(), PTFTranslator.addOIPropertiestoSerDePropsMap()
  • [HIVE-4877] - In ExecReducer, remove tag from the row which will be passed to the first Operator at the Reduce-side
  • [HIVE-4879] - Window functions that imply order can only be registered at compile time
  • [HIVE-4885] - Alternative object serialization for execution plan in hive testing
  • [HIVE-4913] - Put deterministic ordering in the top-K ngrams output of UDF context_ngrams()
  • [HIVE-4920] - PTest2 handle Spot Price increases gracefully and improve rsync paralllelsim
  • [HIVE-4948] - WriteLockTest and ZNodeNameTest do not follow test naming pattern
  • [HIVE-4954] - PTFTranslator hardcodes ranking functions
  • [HIVE-4960] - lastAlias in CommonJoinOperator is not used
  • [HIVE-4967] - Don't serialize unnecessary fields in query plan
  • [HIVE-4985] - refactor/clean up partition name pruning to be usable inside metastore server
  • [HIVE-4992] - add ability to skip javadoc during build
  • [HIVE-5006] - Re-factor HiveServer2 JDBC PreparedStatement to avoid duplicate code
  • [HIVE-5027] - Upgrade Ivy to 2.3
  • [HIVE-5031] - [WebHCat] GET job/:jobid to return userargs for a job in addtion to status information
  • [HIVE-5062] - Insert + orderby + limit does not need additional RS for limiting rows
  • [HIVE-5111] - ExprNodeColumnDesc doesn't distinguish partition and virtual columns, causing partition pruner to receive the latter
  • [HIVE-5121] - Remove obsolete code on SemanticAnalyzer#genJoinTree
  • [HIVE-5158] - allow getting all partitions for table to also use direct SQL path
  • [HIVE-5182] - log more stuff via PerfLogger
  • [HIVE-5206] - Support parameterized primitive types
  • [HIVE-5209] - JDBC support for varchar
  • [HIVE-5267] - Use array instead of Collections if possible in DemuxOperator
  • [HIVE-5278] - Move some string UDFs to GenericUDFs, for better varchar support
  • [HIVE-5363] - HIVE-3978 broke the command line option --auxpath
  • New Feature:
  • [HIVE-305] - Port Hadoop streaming's counters/status reporters to Hive Transforms
  • [HIVE-1402] - Add parallel ORDER BY to Hive
  • [HIVE-2206] - add a new optimizer for query correlation discovery and optimization
  • [HIVE-2482] - Convenience UDFs for binary data type
  • [HIVE-2517] - Support group by on struct type
  • [HIVE-2655] - Ability to define functions in HQL
  • [HIVE-2670] - A cluster test utility for Hive
  • [HIVE-3255] - Add DBTokenStore to store Delegation Tokens in DB
  • [HIVE-4005] - Column truncation
  • [HIVE-4095] - Add exchange partition in Hive
  • [HIVE-4123] - The RLE encoding for ORC can be improved
  • [HIVE-4246] - Implement predicate pushdown for ORC
  • [HIVE-4531] - [WebHCat] Collecting task logs to hdfs
  • [HIVE-4614] - Support outer lateral view
  • [HIVE-4844] - Add varchar data type
  • [HIVE-4911] - Enable QOP configuration for Hive Server 2 thrift transport
  • [HIVE-4963] - Support in memory PTF partitions
  • Task:
  • [HIVE-4331] - Integrated StorageHandler for Hive and HCat using the HiveStorageHandler
  • [HIVE-4819] - Comments in CommonJoinOperator for aliasTag is not valid
  • [HIVE-4886] - beeline code should have apache license headers
  • [HIVE-4999] - Shim class HiveHarFileSystem does not have a hadoop2 counterpart
  • [HIVE-5059] - Meaningless warning message from TypeCheckProcFactory
  • [HIVE-5116] - HIVE-2608 didn't removed udtf_not_supported2.q test
  • [HIVE-5219] - Move VerifyingObjectStore into ql package
  • [HIVE-5313] - HIVE-4487 breaks build because 0.20.2 is missing FSPermission(string)
  • Test:
  • [HIVE-4526] - auto_sortmerge_join_9.q throws NPE but test is succeeded
  • [HIVE-4636] - Failing on TestSemanticAnalysis.testAddReplaceCols in trunk
  • [HIVE-4645] - Stat information like numFiles and totalSize is not correct when sub-directory is exists
  • [HIVE-4743] - Improve test coverage of package org.apache.hadoop.hive.ql.io
  • [HIVE-4779] - Enhance coverage of package org.apache.hadoop.hive.ql.udf
  • [HIVE-4791] - improve test coverage of package org.apache.hadoop.hive.ql.udf.xml
  • [HIVE-4796] - Increase coverage of package org.apache.hadoop.hive.common.metrics
  • [HIVE-4805] - Enhance coverage of package org.apache.hadoop.hive.ql.exec.errors
  • [HIVE-4813] - Improve test coverage of package org.apache.hadoop.hive.ql.optimizer.pcr
  • [HIVE-5029] - direct SQL perf optimization cannot be tested well
  • [HIVE-5033] - Test result of ppd_vc.q is not udpated
  • [HIVE-5096] - Add q file tests for ORC predicate pushdown
  • [HIVE-5117] - orc_dictionary_threshold is not deterministic
  • [HIVE-5147] - Newly added test TestSessionHooks is failing on trunk
  • [HIVE-5197] - TestE2EScenerios.createTaskAttempt should use MapRedUtil