Hive
This release provides Hive 3.1.0 and the listed Apache patches provided in the earlier versions of HDP 3.x.
HDP 3.1.0 provided Hive 3.1.0 and the following Apache patches:
-
HIVE-20827: Inconsistent results for empty arrays
-
HIVE-20998: HiveStrictManagedMigration utility should update DB/Table location as last migration steps
-
HIVE-20542: Incremental REPL DUMP progress information log message is incorrect
-
HIVE-20953: Remove a function from function registry when it can not be added to the metastore when creating it.
-
HIVE-20884: Support bootstrap of tables from HDP 2.6.5 to HDP 3.0. Added managed to external testcase.
-
HIVE-20926: Semi join reduction hint fails when bloom filter entries are high or when there are no stats
-
HIVE-20979: Fix memory leak in hive streaming
-
HIVE-20838: Timestamps with timezone are set to null when using the streaming API
-
HIVE-20988: Wrong results for group by queries with primary key on multiple columns
-
HIVE-20985: If select operator inputs are temporary columns vectorization may reuse some of them as output
-
HIVE-20842: Fix logic introduced in HIVE-20660 to estimate statistics for group by
-
HIVE-20951: LLAP: Set Xms to 50% always
-
HIVE-20822: Hive JDBC Storage Handler (Postgres): "java.lang.RuntimeException: While invoking method 'public org.apache.calcite.rel.rel2sql.SqlImplementor$Result" while executing TPCDS query GRP_2_85
-
HIVE-20884: Support bootstrap of tables from HDP 2.6.5 to HDP 3.0.
-
HIVE-20926: Semi join reduction hint fails when bloom filter entries are high or when there are no stats
-
HIVE-20976: Hive JDBC Storage Handler: TPCDS_GRP_3_88 doesn't output proper results
-
HIVE-20626: Backport Log more details when druid metastore transaction fails
-
HIVE-20954: Vector RS operator is not using uniform hash function for TPC-DS query 95
-
HIVE-20691: Fix org.apache.hadoop.hive.cli.TestMiniLlapCliDriver.testCliDriver[cttl]
-
HIVE-10296: Cast exception observed when hive runs a multi join query on metastore , since postgres pushes the filter into the join, and ignores the condition before applying cast
-
HIVE-20940: Bridge cases in which Calcite's type resolution is more stricter than Hive.
-
HIVE-20944: Not validate stats during query compilation
-
HIVE-20949: Improve PKFK cardinality estimation in physical planning
-
HIVE-20940: Bridge cases in which Calcite's type resolution is more stricter than Hive.
-
HIVE-20937: Postgres jdbc query fail with "LIMIT must not be negative"
-
HIVE-20775: Factor cost of each SJ reduction when costing a follow-up reduction
-
HIVE-19882: Fix QTestUtil session lifecycle addendum
-
HIVE-20920: Use SQL constraints to improve join reordering algorithm
-
HIVE-20918: Flag to enable/disable pushdown of computation from Calcite into JDBC connection
-
HIVE-20775: Factor cost of each SJ reduction when costing a follow-up reduction
-
HIVE-20910: Insert in bucketed table fails due to dynamic partition sort optimization
-
HIVE-20682: Async query execution can potentially fail if shared sessionHive is closed by master thread
-
HIVE-19552: Backport fix Druid kafka mini tests
-
HIVE-19882: Fix QTestUtil session lifecycle
-
HIVE-20822: Hive JDBC Storage Handler: TPCDS_GRP_3_88 doesn't output proper results
-
HIVE-20101: BloomKFilter: Avoid using the local byte[] arrays entirely
-
HIVE-20899: Keytab URI for LLAP YARN Service is restrictive to support HDFS only
-
HIVE-20744: Use SQL constraints to improve join reordering algorithm
-
HIVE-20898: For time related functions arguments may not be casted to a non nullable type
-
HIVE-20746: HiveProtoHookLogger does not close file at end of day.
-
HIVE-20873: Use Murmur hash for VectorHashKeyWrapperTwoLong to reduce hash collision
-
HIVE-20881: Constant propagation oversimplifies projections
-
HIVE-20853: Expose ShuffleHandler.registerDag in the llap daemon API
-
HIVE-20804: Further improvements to group by optimization with constraints
-
HIVE-20768: Adding Tumbling Window UDF
-
HIVE-20813: udf to_epoch_milli need to support timestamp without time zone as well.
-
HIVE-20868: SMB Join fails intermittently when TezDummyOperator has child op in getFinalOp in MapRecordProcessor
-
HIVE-20617: Fix type of constants in IN expressions to have correct type
-
HIVE-20486: Vectorization support for Kafka Storage Handler
-
HIVE-20767: Multiple project between join operators may affect join reordering using constraints
-
HIVE-20822: Improvements to push computation to JDBC from Calcite
-
HIVE-20835: Interaction between constraints and MV rewriting may create loop in Calcite planner
-
HIVE-20821: Rewrite SUM0 into SUM + COALESCE combination
-
HIVE-20820: MV partition on clause position
-
HIVE-20788: Extended SJ reduction may backtrack columns incorrectly when creating filters
-
HIVE-20477: OptimizedSql is not shown if the expression contains INs
-
HIVE-20834: Hive QueryResultCache entries keeping reference to SemanticAnalyzer from cached query
-
HIVE-20829: JdbcStorageHandler range split throws NPE
-
HIVE-20830: JdbcStorageHandler range query assertion failure in some cases
-
HIVE-20815: JdbcRecordReader.next shall not eat exception
-
HIVE-20792: Inserting timestamp with zones truncates the data
-
HIVE-20638: Upgrade version of Jetty to 9.3.25.v20180904
-
HIVE-20765:HIVE- : fetch partitions for txn stats validation in get_aggr_stats with one call
-
HIVE-20718: Add perf cli driver with constraints
-
HIVE-20763: Add google cloud storage to the exim uri schema whitelist
-
HIVE-20703: Put dynamic sort partition optimization under cost based decision
-
HIVE-20762: NOTIFICATION_LOG cleanup interval is hardcoded as 60s and is too small
-
HIVE-6980: Drop table by using direct sql
-
HIVE-20716: Set default value for hive.cbo.stats.correlated.multi.key.joins to true
-
HIVE-18986: Table rename will run java.lang.StackOverflowError in dataNucleus if the table contains large number of columns
-
HIVE-20720: Add partition column option to JDBC handler
-
HIVE-20735: Adding Support for Kerberos Auth, Removed start/end offset columns, remove the best effort mode and made 2pc default for EOS
-
HIVE-20754: Hive: java.lang.NoClassDefFoundError: org/apache/hadoop/security/SaslRpcServer exception occurs while using Hive JDBC standalone jar
-
HIVE-20761: [Intermittent]Hive DDL's failing with Error- Couldn't acquire the DB log notification lock because we reached the maximum # of retries: 5 retries.
-
HIVE-20644:HIVE- : Avoid exposing sensitive infomation through a Hive Runtime exception
-
HIVE-20731: keystore file in JdbcStorageHandler should be authorized
-
HIVE-20649: LLAP aware memory manager for Orc writers
-
HIVE-20648: LLAP: Vector group by operator should use memory per executor
-
HIVE-20696: msck_*.q tests are broken
-
HIVE-20537: Multi-column joins estimates with uncorrelated columns different in CBO and Hive
-
HIVE-20639: Add ability to Write Data from Hive Table/Query to Kafka Topic
-
HIVE-20561: Use the position of the Kafka Consumer to track progress instead of Consumer Records offsets
-
HIVE-20481: Add the Kafka Key record as part of the row
-
HIVE-20377: Hive Kafka Storage Handler
-
HIVE-20710: Constant folding may not create null constants without types
-
HIVE-20719: UPDATE with hive.optimize.sort.dynamic.partition corrupts table
-
HIVE-20660: Group by statistics estimation could be improved by bounding the total number of rows to source table
-
HIVE-17043: Remove non unique columns from group by keys if not referenced later
-
HIVE-20692: Enable folding of NOT x IS (NOT) [TRUE|FALSE] expressions
-
HIVE-14431: Recognize COALESCE as CASE
-
HIVE-20618: During join selection BucketMapJoin might be chosen for non bucketed tables
-
HIVE-20712: HivePointLookupOptimizer should extract deep cases
-
HIVE-20498:HIVE- Support date type for column stats autogather
-
HIVE-20657: pre-allocate LLAP cache at init time
-
HIVE-18871: hive on tez execution error due to set hive.aux.jars.path to hdfs://
-
HIVE-20583: Use canonical hostname only for kerberos auth in HiveConnection
-
HIVE-19993: Using a table alias which also appears as a column name is not possible
-
HIVE-20183: Inserting from bucketed table can cause data loss, if the source table contains empty bucket
-
HIVE-19850: Dynamic partition pruning in Tez is leading to 'No work found for tablescan' error
-
HIVE-20349: Implement Retry Logic in HiveDruidSplit for Scan Queries
-
HIVE-20700: Add config to diable rollup for druid tables
-
HIVE-20698: Add better message for NPE when inserting rows with null timestamp to druid
-
HIVE-20686: Sync query IDs between druid and Hive
-
HIVE-20684: Make compute stats work for Druid tables
-
HIVE-20582: Avoid hflush in hive proto logger
-
HIVE-20702: Account for overhead from datastructure aware estimations during mapjoin selection
-
HIVE-20704: Extend HivePreFilteringRule to support other functions
-
HIVE-20651: JdbcStorageHandler password should be encrypted
-
HIVE-20677: JDBC handler ordering problem - single split flag HIVE-20652: JdbcStorageHandler push join of two different datasource to jdbc driver HIVE-20669: JdbcStorageHandler push union of two different datasource to jdbc driver
-
HIVE-20455: Log spew from security.authorization.PrivilegeSynchonizer.run
-
HIVE-20676: HiveServer2: PrivilegeSynchronizer is not set to daemon status
-
HIVE-17040: Join elimination in the presence of FK relationship
-
HIVE-20636: Improve number of null values estimation after outer join
-
HIVE-20326: Create constraints with RELY as default instead of NO RELY
-
HIVE-20646: Partition condition not being pushed into metastore query if it has IS NOT NULL.
-
HIVE-18778: Needs to capture input/output entities in explain
-
HIVE-20623: Shared work: Extend sharing of map-join cache entries in LLAP
-
HIVE-20095: Fix feature to push computation to jdbc external tables
-
HIVE-20540:HIVE- : Vectorization : Support loading bucketed tables using sorted dynamic partition optimizer - II
-
HIVE-20603: "Wrong FS" error when inserting to partition after changing table location filesystem
-
HIVE-20620: manifest collisions when inserting into bucketed sorted MM tables with dynamic partitioning
-
HIVE-20612: Create new join multi-key correlation flag for CBO
-
HIVE-20625: Regex patterns not working in SHOW MATERIALIZED VIEWS '<pattern>'
-
HIVE-20593: Load Data for partitioned ACID tables fails with bucketId out of range: -1
-
HIVE-20522: HiveFilterSetOpTransposeRule may throw assertion error due to nullability of fields
-
HIVE-20517: Creation of staging directory and Move operation is taking time in S3
-
HIVE-20499: GetTablesOperation pull all the tables meta irrespective of auth.
-
HIVE-19432: GetTablesOperation is too slow if the hive has too many databases and tables
-
HIVE-18873: Skipping predicate pushdown for MR silently at HiveInputFormat can cause storage handlers to produce erroneous result
-
HIVE-20267: Concurrent async queries intermittently fails with LockException and cause memory leak.
-
HIVE-20632: Query with get_splits UDF fails if materialized view is created on queried table.
-
HIVE-20521: HS2 doAs=true has permission issue with hadoop.tmp.dir, with MR and S3A filesystem .
-
HIVE-1118: background updates fix
-
HIVE-20399: CTAS w/a custom table location that is not fully qualified fails for MM tables
-
HIVE-20311: add txn stats checks to some more paths
-
HIVE-20507: Beeline: Add a utility command to retrieve all uris from beeline-site.xml
-
HIVE-20503: Use datastructure aware estimations during mapjoin selection
-
HIVE-20513: Vectorization: Improve Fast Vector MapJoin Bytes Hash Tables
-
HIVE-20296: Improve HivePointLookupOptimizerRule to be able to extract from more sophisticated contexts
-
HIVE-20541: NoSuchElementException in REPL dump.
-
HIVE-19985: Benchmark - LLAP performance issue for fully compacted ACID tables
-
HIVE-20409: Hive ACID: Update/delete/merge leave behind the staging directory
-
HIVE-20491: Fix mapjoin size estimations for Fast implementation
-
HIVE-19097: related equals and in operators may cause inaccurate stats estimations
-
HIVE-20439: Use the inflated memory limit during join selection for llap
-
HIVE-20260: NDV of a column shouldn't be scaled when row count is changed by filter on another column
-
HIVE-20418: LLAP IO may not handle ORC files that have row index disabled correctly for queries with no columns selected
-
HIVE-20508:HIVE- : Hive does not support user names of type "user@realm"
-
HIVE-20193: cboInfo is not present in the explain plan json
-
HIVE-20510: Vectorization : Support loading bucketed tables using sorted dynamic partition optimizer
-
HIVE-20515: Empty query results when using results cache and query temp dir, results cache dir in different filesystems
-
HIVE-20476: CopyUtils used by REPL LOAD and EXPORT/IMPORT operations ignore distcp error
-
HIVE-20450: Add replication test for LOAD command on ACID table.
-
HIVE-20433: Implicit String to Timestamp conversion is slow
-
HIVE-20446: CachedStore: bug UT fixes when CachedStore is enabled
-
HIVE-19748: CREATE, INSERT commands fails with MetaException on HDI azure cluster due to NPE in MetaStoreUtils.decimalToDouble
-
HIVE-18624: Parsing time is extremely high (~10 min) for queries with complex select expressions
-
HIVE-20187: Incorrect query results in hive when hive.convert.join.bucket.mapjoin.tez is set to true
-
HIVE-20443: txn stats cleanup in compaction txn handler is unneeded
-
HIVE-20444: Parameter is not properly quoted in DbNotificationListener.addWriteNotificationLog
-
HIVE-20431: txn stats write ID check triggers on set location
-
HIVE-20329: Long running repl load (incr/bootstrap) causing OOM error
-
HIVE-19924: Tag distcp jobs run by Repl Load
-
HIVE-20411: Hive.loadPartition doesn't support catalogs
-
HIVE-20412: Hive upgrade: HBasestoragehandler tables fail to upgrade at HiveMetaStoreClient.alter_table with Null Pointer Exception - committing HIVE-20412.1.patch directly to HDP
-
HIVE-20410: aborted Insert Overwrite on transactional table causes "Not enough history available for..." error
-
HIVE-20407: Hive upgrade: Alter table(orc-bucket) owned by hive fails at seedWriteIdOnAcidConversion with Duplicate entry for key 'NEXT_WRITE_ID_IDX'
-
HIVE-20413: "cannot insert NULL" for TXN_WRITE_NOTIFICATION_LOG in Oracle
-
HIVE-20393: Semijoin Reduction : markSemiJoinForDPP behaves inconsistently
-
HIVE-20407: add txn stats support to upgrade tool
-
HIVE-14898: HS2 shouldn't log callstack for an empty auth header error
-
HIVE-20378: don't update stats during alter for txn table conversion
-
HIVE-20357: Introduce initOrUpgradeSchema option to schema tool
-
HIVE-19250: Schema column definitions inconsistencies in MySQL
-
HIVE-20391: HiveAggregateReduceFunctionsRule may infer wrong return type when decomposing aggregate function
-
HIVE-20383: Invalid queue name and synchronisation issues in hive proto events hook.
-
HIVE-20389: NPE in SessionStateUserAuthenticator when authenticator=SessionStateUserAuthenticator
-
HIVE-20345: Drop database may hang if the tables get deleted from a different call
-
HIVE-20033: PowerBI unable to connect to LLAP cluster with large Databases/Tables
-
HIVE-20098: Statistics: NPE when getting Date column partition statistics
-
HIVE-19860: HiveServer2 ObjectInspectorFactory memory leak with cachedUnionStructObjectInspector
-
HIVE-20382: Materialized views: Introduce heuristic to favour incremental rebuild
-
HIVE-20379: Rewriting with partitioned materialized views may reference wrong column
-
HIVE-18620: Improve error message while dropping a table that is part of a materialized view
-
HIVE-20067: mm_all test failing.
-
HIVE-19316: StatsTask fails due to ClassCastException
-
HIVE-20149: TestHiveCli failing/timing out
-
HIVE-20340: Druid Needs Explicit CASTs from Timestamp to STRING when the output of timestamp function is used as String
-
HIVE-20344: PrivilegeSynchronizer for SBA might hit AccessControlException
-
HIVE-20320: Turn on hive.optimize.remove.sq_count_check flag
-
HIVE-20354:HIVE- : Semijoin hints dont work with merge statements
-
HIVE-20264: Bootstrap repl dump with concurrent write and drop of ACID table makes target inconsistent
-
HIVE-20361: ReplDumpTaskTest is failing
-
HIVE-20316: Skip external table file listing for create table event
-
HIVE-19800: TestUpgradeTool.testPostUpgrade failing
-
HIVE-20337: Queries returning incorrect results using CachedStore. ObjectStore works fine
-
HIVE-20347: hive.optimize.sort.dynamic.partition should work with partitioned CTAS and MV
-
HIVE-20336: Masking and filtering policies for materialized views
-
HIVE-20301: Enable vectorization for materialized view rewriting tests
-
HIVE-20314: Include partition pruning in materialized view rewriting
-
HIVE-20302: LLAP: non-vectorized execution in IO ignores virtual columns, including ROW__ID
-
HIVE-19408: Improve show materialized views statement to show more information about invalidation
-
HIVE-20335: Add tests for materialized view rewriting with composite aggregation functions
-
HIVE-20165: Enable ZLIB for streaming ingest
-
HIVE-20147: Hive streaming ingest is contented on synchronized logging
-
HIVE-19800:HIVE- PreUpgrade Tool: Support upgrade from >= 2.6.0
-
HIVE-20315: Vectorization: Fix more NULL Wrong Results issues and avoid unnecessary casts/conversions : Vectorization: Backport HIVE-20315 to Atlantic-M05: Vectorization: Fix more NULL Wrong Results issues and avoid unnecessary casts/conversions
-
HIVE-19812: Disable external table replication by default via a coniguration property
-
HIVE-20277: Vectorization: Case expressions that return BOOLEAN are not supported for FILTER
-
HIVE-20130: Better logging for information schema synchronizer
-
HIVE-20118: SessionStateUserAuthenticator.getGroupNames is always empty
-
HIVE-20292: Adding contraints on TPCDS schema, changes query plan for query93 and degrades its perf by 4x times
-
HIVE-19970: Replication dump has a NPE when table is empty
-
HIVE-20120: Incremental repl load DAG generation is causing OOM error
-
HIVE-20322: FlakyTest: TestMiniDruidCliDriver
-
HIVE-19829: Incremental replication load should create tasks in execution phase rather than semantic phase
-
HIVE-20322: FlakyTest: TestMiniDruidCliDriver
-
HIVE-19927: Last Repl ID set by bootstrap dump is not proper and may cause loss of data if have ACID tables.
-
HIVE-17683: Add explain locks <sql> command
-
HIVE-20209: Metastore connection fails for first attempt in repl dump
-
HIVE-20294: Vectorization: Fix NULL Wrong Results issues in COALESCE ELT
-
HIVE-20245: Vectorization: Fix NULL Wrong Results issues in BETWEEN IN
-
HIVE-20207: Vectorization: Fix NULL Wrong Results issues in Filter Compare
-
HIVE-20281: SharedWorkOptimizer fails with 'operator cache contents and actual plan differ'
-
HIVE-20252: Semijoin Reduction : Cycles due to semi join branch may remain undetected if small table side has a map join upstream.
-
HIVE-14493: Partitioning support for materialized views
-
HIVE-20241: Support partitioning spec in CTAS statements
-
HIVE-20212: Hiveserver2 in http mode emitting metric default.General.open_connections incorrectly
-
HIVE-20105: Druid-Hive: tpcds query on timestamp throws java.lang.IllegalArgumentException: Cannot create timestamp, parsing error
-
HIVE-20263: Typo in HiveReduceExpressionsWithStatsRule variable
-
HIVE-20090: Extend creation of semijoin reduction filters to be able to discover new opportunities
-
HIVE-19568: Active/Passive HS2 HA: Disallow direct connection to passive HS2 instance
-
HIVE-20082: HiveDecimal to string conversion doesn't format the decimal correctly
-
HIVE-20204: Type conversion during IN () comparisons is using different rules from other comparison operations
-
HIVE-20240: Semijoin Reduction : Use local variable to check for external table condition
-
HIVE-19313: TestJdbcWithDBTokenStoreNoDoAs tests are failing
-
HIVE-20228: configure repl configuration directories based on user running hiveserver2
-
HIVE-19935: Hive WM session killed: Failed to update LLAP tasks count
-
HIVE-19800: TestUpgradeTool.testPostUpgrade failing
-
HIVE-19891: inserting into external tables with custom partition directories may cause data loss
-
HIVE-4367: enhance TRUNCATE syntax to drop data of external table
-
HIVE-19992: Vectorization: Follow-on to HIVE-19951 --> add call to SchemaEvolution.isOnlyImplicitConversion to disable encoded LLAP I/O for ORC only when data type conversion is not implicit : Vectorization: Backport HIVE-19992 to Atlantic-M05: Follow-on to HIVE-19951 --> add call to SchemaEvolution.isOnlyImplicitConversion to disable encoded LLAP I/O for ORC only when data type conversion is not implicit
-
HIVE-20069: Fix reoptimization in case of DPP and Semijoin optimization
-
HIVE-20152: reset db state, when repl dump fails, so rename table can be done
-
HIVE-20197: Vectorization: Add DECIMAL_64 testing, add Date/Interval/Timestamp arithmetic, and add more GROUP BY Aggregation tests : Vectorization: Backport HIVE-20197 to Atlantic-M05: Add DECIMAL_64 testing, add Date/Interval/Timestamp arithmetic, and add more GROUP BY Aggregation tests
-
HIVE-20174: Vectorization: Fix NULL Wrong Results issues in GROUP BY Aggregation Functions
-
HIVE-20192: HiveServer2 with embedded metastore is leaking JDOPersistenceManager objects
-
HIVE-19104: When test MetaStore is started with retry the instances should be independent
-
HIVE-20164: Murmur Hash : Make sure CTAS and IAS use correct bucketing version
-
HIVE-20116:HIVE- - TestOperationLoggingAPIWithTez failing
-
HIVE-20088: Beeline config location path is assembled incorrectly
-
HIVE-20011: Move away from append mode in proto logging hook
-
HIVE-19360: CBO: Add an "optimizedSQL" to QueryPlan object
-
HIVE-20127:HIVE- : fix some issues with LLAP Parquet cache
-
HIVE-19387:HIVE- Upgrade: Post the second truncate call, select query fails to fetch new results if query.results.cache is enabled
-
HIVE-20129: Revert to position based schema evolution for orc tables
-
HIVE-20126: OrcInputFormat does not pass conf to orc reader options
-
HIVE-20123: Fix masking tests after HIVE-19617
-
HIVE-19628:HIVE- : possible NPE in LLAP testSigning
-
HIVE-19759: Flaky test: TestRpc#testServerPort
-
HIVE-20111: Making storage handler tables external by default breaks HBase
-
HIVE-20112: Making storage handler tables external by default breaks Accumulo
-
HIVE-20102: Ranger row-level filter policies don't work with CTAS
-
HIVE-20001: With doas set to true, running select query as hrt_qa user on external table fails due to permission denied to read warehouse/tablespace/managed directory
-
HIVE-20100: OpTraits : Select Optraits should stop when a mismatch is detected
-
HIVE-20085: review comments and fix drop table to honour external table purge property, enable ctas by default on external tables
-
HIVE-20039: Bucket pruning: Left Outer Join on bucketed table gives wrong result
-
HIVE-20085: Make all Druid Tables as EXTERNAL tables
-
HIVE-20067: fix InsertEvent on mm tables to not cause failing capability checks
-
HIVE-20025: Clean-up of event files created by HiveProtoLoggingHook
-
HIVE-17840: HiveMetaStore eats exception if transactionalListeners.notifyEvent fail
-
HIVE-20051: Skip authorization for temp tables
-
HIVE-19938: Upgrade scripts for information schema
-
HIVE-19326: stats auto gather: incorrect aggregation during UNION queries
-
HIVE-20059: Hive streaming should try shade prefix unconditionally on exception
-
HIVE-20028: Metastore client cache config is used incorrectly
-
HIVE-20038: Updates/deletes on non-bucketed acid tables throw NPE
-
HIVE-20002: Shipping jdbd-storage-handler dependency jars in LLAP
-
HIVE-19967: SMB Join : Need Optraits for PTFOperator ala GBY Op
-
HIVE-20004:HIVE-" Wrong scale used by ConvertDecimal64ToDecimal results in incorrect results
-
HIVE-19995: Aggregate row traffic for acid tables
-
HIVE-20009: Fix runtime stats for merge statement
-
HIVE-19989: Metastore uses wrong application name for HADOOP2 metrics
-
HIVE-20035: Serialize boolean as long for druid
-
HIVE-20013: Add an Implicit cast to date type for to_date function
-
HIVE-18140: Partitioned tables statistics can go wrong in basic stats mixed case
-
HIVE-18729: Druid Time column type
-
HIVE-19938: Upgrade scripts for information schema
-
HIVE-20010: Fix create view over literals
-
HIVE-19753: Strict managed tables mode in Hive
-
HIVE-19972: Followup to HIVE-19928 : Fix the check for managed table
-
HIVE-19481: Tablesample uses incorrect logic to pick files corresponding to buckets.
-
HIVE-19981: Managed tables converted to external tables by the HiveStrictManagedMigration utility should be set to delete data when the table is dropped
-
HIVE-19898: Disable TransactionalValidationListener when the table is not in the Hive catalog
-
HIVE-19904: Load data rewrite into Tez job fails for ACID
-
HIVE-19775: Schematool should use HS2 embedded mode in privileged auth mode
-
HIVE-19800: HIVE-19598 + adjustments. needs HIVE-19750 for post upgrade file rename to work properly
-
HIVE-19440: fix merge conflicts that got dropped
-
HIVE-19258: add originals support to MM tables
-
HIVE-19476: Fix failures in TestReplicationScenariosAcidTables, TestReplicationOnHDFSEncryptedZones and TestCopyUtils
-
HIVE-17657: export/import for MM tables is broken
-
HIVE-19312: MM tables don't work with BucketizedHIF
-
HIVE-19825: HiveServer2 leader selection shall use different zookeeper znode
-
HIVE-19728: beeline with USE_BEELINE_FOR_HIVE_CLI fails when trying to set hive.aux.jars.path
-
HIVE-19485: dump directory for non native tables should not be created
-
HIVE-19440: Make StorageBasedAuthorizer work with information schema
-
HIVE-19465: Upgrade ORC to 1.5.0
-
HIVE-19631: reduce epic locking in AbstractService
-
HIVE-19258: add originals support to MM tables
-
HIVE-19660: update branch-3 to be version 3.1 and fix storage-api mismatch
-
HIVE-14247: Disable parallel query execution within a session
-
HIVE-18193: Migrate existing ACID tables to use table Write ID instead of global txn ID
-
HIVE-19476: Fix failures in TestReplicationScenariosAcidTables, TestReplicationOnHDFSEncryptedZones and TestCopyUtils
-
HIVE-19435: Incremental replication cause data loss if a table is dropped followed by create and insert-into with different partition type
-
HIVE-19322: Broken test: TestNegativeMinimrCliDriver#testCliDriver[minimr_broken_pipe]
-
HIVE-17657: Export/import for MM tables is broken
-
HIVE-19304: Update templates.py based on config changes in YARN-7142 and YARN-8122
-
HIVE-19194: addendum for branch-3: fix imports
-
HIVE-19193: TestActivePassiveHA fails
-
HIVE-19014: Utilize YARN-8028 (queue ACL check) in Hive Tez session pool
-
HIVE-19072: incorrect token handling for LLAP plugin endpoint
-
HIVE-18971: add HS2 WM metrics for use in Grafana and such
-
HIVE-18952: Tez session disconnect and reconnect on HS2 HA failover INTERNAL COMMIT
-
HIVE-18717: Avoid transitive dependency on jetty 6.x
-
HIVE-18414: upgrade to tez-0.9.1
-
HIVE-18037: align kerberos keytab and principal with YARN Service
-
HIVE-14498: Freshness period for query rewriting using materialized views
-
HIVE-18096: add a user-friendly show plan command
-
HIVE-18037: plug-in llapstatus with YARN Service
-
HIVE-18037: fix issue with replacement of % %(queue.string)s with correct queue value
-
HIVE-15393: Update Guava version
-
HIVE-18150: Upgrade Spark Version to 2.2.0
HDP 3.0.0 and HDP 3.0.1 provided Hive 3.1.0 and no additional Apache patches.