Skip to content

Releases: StarRocks/starrocks

4.0.2

06 Dec 06:31
1f1aa9c

Choose a tag to compare

4.0.2

Release Date: December 4, 2025

New Features

  • Introduced a new resource group attribute, mem_pool, allowing multiple resource groups to share the same memory pool and enforce a joint memory limit for the pool. This feature is backward compatible. default_mem_pool is used if mem_pool is not specified. #64112

Improvements

  • Reduced remote storage access during Vacuum after File Bundling is enabled. #65793
  • The File Bundling feature caches the latest tablet metadata. #65640
  • Improved safety and stability for long-string scenarios. #65433 #65148
  • Optimized the SplitTopNAggregateRule logic to avoid performance regression. #65478
  • Applied the Iceberg/DeltaLake table statistics collection strategy to other external data sources to avoid collecting statistics when the table is a single table. #65430
  • Added Page Cache metrics to the Data Cache HTTP API api/datacache/app_stat. #65341
  • Supports ORC file splitting to enable parallel scanning of a single large ORC file. #65188
  • Added selectivity estimation for IF predicates in the optimizer. #64962
  • Supports constant evaluation of hour, minute, and second for DATE and DATETIME types in the FE. #64953
  • Enabled rewrite of simple aggregation to MetaScan by default. #64698
  • Improved multiple-replica assignment handling in shared-data clusters for enhanced reliability. #64245
  • Exposes cache hit ratio in audit logs and metrics. #63964
  • Estimates per-bucket distinct counts for histograms using HyperLogLog or sampling to provide more accurate NDV for predicates and joins. #58516
  • Supports FULL OUTER JOIN USING with SQL-standard semantics. #65122
  • Prints memory information when Optimizer times out for diagnostics. #65206

Bug Fixes

The following issues have been fixed:

  • DECIMAL56 mod-related issue. #65795
  • Issue related to Iceberg scan range handling. #65658
  • MetaScan rewrite issues on temporary partitions and random buckets. #65617
  • JsonPathRewriteRule uses the wrong table after transparent materialized view rewrite. #65597
  • Materialized view refresh failures when partition_retention_condition referenced generated columns. #65575
  • Iceberg min/max value typing issue. #65551
  • Issue with queries against information_schema.tables and views across different databases when enable_evaluate_schema_scan_rule is set to true. #65533
  • Integer overflow in JSON array comparison. #64981
  • MySQL Reader does not support SSL. #65291
  • ARM build issue caused by SVE build incompatibility. #65268
  • Queries based on bucket-aware execution may get stuck for bucketed Iceberg tables. #65261
  • Robust error propagation and memory safety issues for the lack of memory limit checks in OLAP table scan. #65131

Behavior Changes

  • When a materialized view is inactivated, the system recursively inactivates its dependent materialized views. #65317
  • Uses the original materialized view query SQL (including comments/formatting) when generating SHOW CREATE output. #64318

3.5.9

27 Nov 02:24
49d8fe2

Choose a tag to compare

Improvements

  • Added transaction latency metrics to FE for observing timing across transaction stages. #64948
  • Supports overwriting S3 unpartitioned Hive tables to simplify full-table rewrites in data lake scenarios. #65340
  • Introduced CacheOptions to provide finer-grained control over tablet metadata caching. #65222
  • Supports sample statistics collection for INSERT OVERWRITE to ensure statistics stay consistent with the latest data. #65363
  • Optimized the statistics collection strategy after INSERT OVERWRITE to avoid missing or incorrect statistics due to asynchronous tablet reports. #65327
  • Introduced a retention period for partitions dropped or replaced by INSERT OVERWRITE or materialized view refresh operations, keeping them in the recycle bin for a while to improve recoverability. #64779

Bug Fixes

The following issues have been fixed:

  • Lock contention and concurrency issues related to LocalMetastore.truncateTable(). #65191
  • Lock contention and replica check performance issues related to TabletChecker. #65312
  • Incorrect error logging when changing user via HTTP SQL. #65371
  • Checksum failures caused by DelVec CRC32 upgrade compatibility issues. #65442
  • Tablet metadata load failures caused by RocksDB iteration timeout. #65146
  • When the internal flat_path string is empty because the JSON hyper extraction path is $ or all paths are skipped, calling substr will throw an exception and cause BE crash. #65260
  • The PREPARED flag in fragment execution is not correctly set. #65423
  • Inaccurate write and flush metrics caused by duplicated load profile counters. #65252
  • When multiple HTTP requests reuse the same TCP connection, if a non‑ExecuteSQL request arrives after an ExecuteSQL request, the HttpConnectContext cannot be unregistered at channel close, causing HTTP context leaks. #65203
  • MySQL 8.0 schema introspection errors (Fixed by adding session variables default_authentication_plugin and authentication_policy). #65330
  • SHOW ANALYZE STATUS errors caused by unnecessary statistics collection for temporary partitions created after partition overwrite operations. #65298
  • Global Runtime Filter race in the Event Scheduler. #65200
  • Data Cache is aggressively disabled because the minimum Data Cache disk size constraint is too large. #64909
  • An aarch64 build issue related to the gold linker automatic fallback. #65156

3.4.9

24 Nov 10:27
fafa0ce

Choose a tag to compare

Release Date: November 24, 2025

Behavior Changes

  • Changed the return type of json_extract in the Trino dialect from STRING to JSON. This may cause incompatibility in CAST, UNNEST, and type check logic. #59718
  • The metric that reports “connections per user” under /metrics now requires admin authentication. Without authentication, only total connection counts are exposed, preventing information leakage of all usernames via metrics. #64635
  • Removed the deprecated system variable analyze_mv. Materialized view refresh no longer automatically triggers ANALYZE jobs, avoiding large numbers of background statistics tasks. This changes expectations for users relying on legacy behavior. #64863
  • Changed the overflow detection logic of casting from LARGEINT to DECIMAL128 on x86. INT128_MIN * 1 is no longer considered an overflow to ensure consistent casting semantics for extreme values. #63559
  • Added a configurable table-level lock timeout to finishTransaction. If a table lock cannot be acquired within the timeout, finishing the transaction will fail for this round and be retried later, rather than blocking indefinitely. The final result is unchanged, but the lock behavior is more explicit. #63981

Bug Fixes

The following issues have been fixed:

  • During BE start, if loading tablet metadata from RocksDB times out, RocksDB may restart loading from the beginning and accidentally pick up stale tablet entries, risking data version loss. #65146
  • Data corruption issues related to CRC32C checksum for delete-vectors of Lake Primary Key tables. #65006 #65354 #65442 #65354
  • When the internal flat_path string is empty because the JSON hyper extraction path is $ or all paths are skipped, calling substr will throw an exception and cause BE crash. #65260
  • When spilling large strings to disk, insufficient length checks, using 32‑bit attachment sizes, and issues in the BlockReader could cause crashes. #65373
  • When multiple HTTP requests reuse the same TCP connection, if a non‑ExecuteSQL request arrives after an ExecuteSQL request, the HttpConnectContext cannot be unregistered at channel close, causing HTTP context leaks. #65203
  • Primitive value loss issue under certain circumstances when JSON data is being flattened. #64939 #64703
  • Crash in ChunkAccumulator when chunks are appended with incompatible JSON schemas. #64894
  • In AsyncFlushOutputStream, asynchronous I/O tasks may attempt to access a destroyed MemTracker, resulting in use‑after‑free crashes. #64735
  • Concurrent Compaction tasks against the same Lake Primary Key table lack integrity checks, which could leave metadata in an inconsistent state after a failed publish. #65005
  • When spilling Hash Joins, if the build side’s set_finishing task failed, it only recorded the status in the spiller, allowing the Probe side to continue, and eventually causing a crash or an indefinite loop. #65027
  • During tablet migration, if the only newest replica is marked as DECOMMISSION, the version of the target replica is outdated and stuck at VERSION_INCOMPLETE. #62942
  • Use-after-free issue because the relevant Block Group is not released when PartitionedSpillerWriter is removing partitions. #63903 #63825
  • BE crash caused by MorselQueue's failure to get splits. #62753
  • In shared-data clusters, Sorted-by-key Scans with multiple I/O tasks could produce wrong results in sort-based aggregations. #63849
  • On ARM, reading Parquet columns for certain Hive external tables could crash in LZ4 conversion when copying NULL bitmaps because the destination null buffer pointer was stale due to out-of-order execution. #63294

3.3.20

18 Nov 03:51
bc0523a

Choose a tag to compare

3.3.20

Release Date: November 18, 2025

Bug Fixes

The following issues have been fixed:

  • CVE-2024-47561. #64193
  • CVE-2025-59419. #64142
  • Incorrect row count for lake Primary Key tables. #64007
  • Window function with IGNORE NULLS flags can not be consolidated with its counterpart without IGNORE NULLS flag. #63958
  • ASAN error in PartitionedSpillerWriter::_remove_partition. #63903
  • Wrong results for sorted aggregation in shared-data clusters. #63849
  • NPE when creating a partitioned materialized view. #63830
  • Partitioned Spill crash when removing partitions. #63825
  • NPE when removing expired load jobs in FE. #63820
  • A potential deadlock during initialization of ExceptionStackContext. #63776
  • Degraded scan performance caused by the profitless simplification of CASE WHEN with complex functions. #63732
  • Materialized view rewrite failures caused by type mismatch. #63659
  • Materialized view rewrite throws IllegalStateException under certain plans. #63655
  • LZ4 compression and decompression errors cannot be perceived. #63629
  • Stability issue caused by incorrect overflow detection when casting LARGEINT to DECIMAL128 at sign-edge cases (for example, INT128_MIN) #63559
  • date_trunc partition pruning with combined predicates that mistakenly produced EMPTYSET. #63464
  • Incomplete Left Join results caused by ARRAY low-cardinality optimization. #63419
  • An issue caused by the aggregate intermediate type uses ARRAY<NULL_TYPE>. #63371
  • Metadata inconsistency in partial updates based on auto-increment columns. #63370
  • Incompatible Bitmap index reuse for Fast Schema Evolution in shared-data clusters. #63315
  • Unnecessary CN deregistration during pod restart/upgrade. #63085
  • Profiles showing SQL as omit for returns of the PREPARE/EXECUTE statements. #62988

4.0.1

17 Nov 03:37
cd9df36

Choose a tag to compare

4.0.1

Release Date: November 17, 2025

Improvements

  • Optimized TaskRun session variable handling to process known variables only. #64150
  • Supports collecting statistics of Iceberg and Delta Lake tables from metadata by default. #64140
  • Supports collecting statistics of Iceberg tables with bucket and truncate partition transform. #64122
  • Supports inspecting FE /proc profile for debugging. #63954
  • Enhanced OAuth2 and JWT authentication support for Iceberg REST catalogs. #63882
  • Improved bundle tablet metadata validation and recovery handling. #63949
  • Improved scan-range memory estimation logic. #64158

Bug Fixes

The following issues have been fixed:

  • Transaction logs were deleted when publishing bundle tablets. #64030
  • The join algorithm cannot guarantee the sort property because, after joining, the sort property is not reset. #64086
  • Issues related to transparent materialized view rewrite. #63962

Behavior Changes

  • Added the property enable_iceberg_table_cache to Iceberg Catalogs to optionally disable Iceberg table cache and allow it always to read the latest data. #64082
  • Ensured INSERT ... SELECT reads the freshest metadata by refreshing external tables before planning. #64026
  • Increased lock table slots to 256 and added rid to slow-lock logs. #63945
  • Temporarily disabled shared_scan due to incompatibility with event-based scheduling. #63543
  • Changed the default Hive Catalog cache TTL to 24 hours and removed unused parameters. #63459
  • Automatically determine the Partial Update mode based on the session variable and the number of inserted columns. #62091

3.5.8

10 Nov 03:28
88ffb18

Choose a tag to compare

Release date: November 10, 2025

Improvements

  • Upgraded Arrow to 19.0.1 to support the Parquet legacy list to include nested, complex files. #64238
  • FILES() supports legacy Parquet LIST encodings. #64160
  • Automatically determine the Partial Update mode based on the session variable and the number of inserted columns. #62091
  • Applied low-cardinality optimization on analytic operators above table functions. #63378
  • Added configurable table lock timeout to finishTransaction to avoid blocking. #63981
  • Shared-data clusters support table-level scan metrics attribution. #62832
  • Window functions LEAD/LAG/FIRST_VALUE/LAST_VALUE now accept ARRAY type arguments. #63547
  • Supports constant folding for several array functions to improve predicate pushdown and join simplification. #63692
  • Supports batched API to optimize tabletNum retrieval for a given node via SHOW PROC /backends/{id}. Added an FE configuration item enable_collect_tablet_num_in_show_proc_backend_disk_path (Default: true). #64013
  • Ensured INSERT ... SELECT reads the freshest metadata by refreshing external tables before planning. #64026
  • Added capacity_limit_reached checks to table functions, NL-join probe, and hash-join probe to avoid constructing overflowing columns. #64009
  • Added FE configuration item collect_stats_io_tasks_per_connector_operator (Default: 4) for setting the maximum number of tasks to collect statistics for external tables. #64016
  • Updated the default partition size for sample collection from 1000 to 300. #64022
  • Increased lock table slots to 256 and added rid to slow-lock logs. #63945
  • Improved robustness of Gson deserialization in the presence of legacy data. #63555
  • Reduced metadata lock scope for FILES() schema pushdown to cut lock contention and planning latency. #63796
  • Added Task Run execute timeout checker by introducing an FE configuration item task_runs_timeout_second, and refined cancellation logics for overdue runs. #63842
  • Ensured REFRESH MATERIALIZED VIEW ... FORCE always refreshes target partitions (even in inconsistent or corrupted cases). #63844

Bug Fixes

The following issues have been fixed:

  • An exception when parsing the Nullable (Decimal) type of ClickHouse. #64195
  • An issue with tablet migration and Primary Key index lookup concurrency. #64164
  • Lack of FINISHED status in materialized view refresh. #64191
  • Schema Change Publish does not retry in shared-data clusters. #64093
  • Wrong row count statistics on Primary Key tables in Data Lake. #64007
  • When tablet creation times out in shared-data clusters, node information cannot be returned. #63963
  • Corrupted Lake DataCache cannot be cleared. #63182
  • Window function with IGNORE NULLS flags can not be consolidated with its counterpart without iIGNORE NULLS flag. #63958
  • Table compaction cannot be scheduled again after FE restart if the compaction was previously aborted. #63881
  • Tasks fail to be scheduled if FE restarts frequently. #63966
  • An issue with GCS error codes. #64066
  • Instability issue with StarMgr gRPC executor. #63828
  • Deadlock when creating an exclusive work group. #63893
  • Cache for Iceberg tables is not properly invalidated. #63971
  • Wrong results for sorted aggregation in shared-data clusters. #63849
  • ASAN error in PartitionedSpillerWriter::_remove_partition. #63903
  • BE crash when failing to get splits from morsel queue. #62753
  • A bug with aggregate push-down type cast in materialized view rewrite. #63875
  • NPE when removing expired load jobs in FE. #63820
  • Partitioned Spill crash when removing partitions. #63825
  • Materialized view rewrite throws IllegalStateException under certain plans. #63655
  • NPE when creating a partitioned materialized view. #63830

3.5.7

21 Oct 08:27
d2da301

Choose a tag to compare

Improvements

  • Improved memory statistics accuracy for Scan operators by introducing retry backoff under heavy memory contention scenarios. #63788
  • Optimized materialized view bucketing inference by leveraging existing tablet distribution to prevent excessive bucket creation. #63367
  • Revised the Iceberg table caching mechanism to enhance consistency and reduce cache invalidation risks during frequent metadata updates. #63388
  • Added the querySource field to QueryDetail and AuditEvent for better traceability of query origins across APIs and schedulers. #63480
  • Enhanced Persistent Index diagnostics by printing detailed context when duplicate keys are detected in MemTable writes. #63560
  • Reduced lock contention in materialized view operations by refining lock granularity and sequencing in concurrent scenarios. #63481

Bug Fixes

The following issues have been fixed:

  • Materialized view rewrite failures caused by type mismatch. #63659
  • regexp_extract_all has wrong behavior and lacks support for pos=0. #63626
  • Degraded scan performance caused by the profitless simplification of CASE WHEN with complex functions. #63732
  • Incorrect DCG data reading when partial updates switch from column mode to row mode. #61529
  • A potential deadlock during initialization of ExceptionStackContext. #63776
  • Crashes in Parquet numeric conversion for ARM architecture machines. #63294
  • An issue caused by the aggregate intermediate type uses ARRAY<NULL_TYPE>. #63371
  • Stability issue caused by incorrect overflow detection when casting LARGEINT to DECIMAL128 at sign-edge cases (for example, INT128_MIN) #63559
  • LZ4 compression and decompression errors cannot be perceived. #63629
  • ClassCastException when querying tables partitioned by FROM_UNIXTIME on INT-type columns. #63684
  • Tablets cannot be repaired after a balance-triggered migration when the only valid source replica is marked DECOMMISSION. #62942
  • Profiles lost SQL statements and Planner Trace when the PREPARE statement is used. #63519
  • The extract_number, extract_bool, and extract_string functions are not exception-safe. #63575
  • Shutdown tablets cannot be garbage-collected properly. #63595
  • Profiles showing SQL as omit for returns of the PREPARE/EXECUTE statements. #62988
  • date_trunc partition pruning with combined predicates that mistakenly produced EMPTYSET. #63464
  • Crashes in release builds due to the CHECK in NullableColumn. #63553

4.0.0

17 Oct 08:53
dccb665

Choose a tag to compare

StarRocks version 4.0

4.0.0

Release date: October 17, 2025

Data Lake Analytics

  • Unified Page Cache and Data Cache for BE metadata, and adopted an adaptive strategy for scaling. #61640
  • Optimized metadata file parsing for Iceberg statistics to avoid repetitive parsing. #59955
  • Optimized COUNT/MIN/MAX queries against Iceberg metadata by efficiently skipping over data file scans, significantly improving aggregation query performance on large partitioned tables and reducing resource consumption. #60385
  • Supports compaction for Iceberg tables via procedure rewrite_data_files.
  • Supports Iceberg tables with hidden partitions, including creating, writing, and reading the tables. #58914
  • Supports setting sort keys when creating Iceberg tables.
  • Optimizes sink performance for Iceberg tables.
    • Iceberg Sink supports spilling large operators, global shuffle, and local sorting to optimize memory usage and address small file issues. #61963
    • Iceberg Sink optimizes local sorting based on Spill Partition Writer to improve write efficiency. #62096
    • Iceberg Sink supports global shuffle for partitions to further reduce small files. #62123
  • Enhanced bucket-aware execution for Iceberg tables to improve concurrency and distribution capabilities of bucketed tables. #61756
  • Supports the TIME data type in the Paimon catalog. #58292
  • Upgraded Iceberg version to 1.10.0. #63667

Security and Authentication

  • In scenarios where JWT authentication and the Iceberg REST Catalog are used, StarRocks supports the passthrough of user login information to Iceberg via the REST Session Catalog for subsequent data access authentication. #59611 #58850
  • Supports vended credentials for the Iceberg catalog.
  • Supports granting StarRocks internal roles to external groups obtained via Group Provider. #63385 #63258
  • Added REFRESH privilege to external tables to control the permission to refresh them. #63385

Storage Optimization and Cluster Management

  • Introduced  the File Bundling optimization for the cloud-native table in shared-data clusters to automatically bundle the data files generated by loading, Compaction, or Publish operations, thereby reducing the API cost caused by high-frequency access to the external storage system. #58316
  • Supports Multi-Table Write-Write Transaction to allow users to control the atomic submission of INSERT, UPDATE, and DELETE operations. The transaction supports Stream Load and INSERT INTO interfaces, effectively guaranteeing cross-table consistency in ETL and real-time write scenarios. #61362
  • Supports Kafka 4.0 for Routine Load.
  • Supports full-text inverted indexes on Primary Key tables in shared-nothing clusters.
  • Supports modifying aggregate keys of Aggregate tables. #62253
  • Supports enabling case-insensitive processing on names of catalogs, databases, tables, views, and materialized views. #61136
  • Supports blacklisting Compute Nodes in shared-data clusters. #60830
  • Supports global connection ID. #57256
  • Added the recyclebin_catalogs metadata view to Information Schema to display recoverable deleted metadata. #51007

Query and Performance Improvement

  • Supports DECIMAL256 data type, expanding the upper limit of precision from 38 to 76 bits. Its 256-bit storage provides better adaptability to high-precision financial and scientific computing scenarios, effectively mitigating DECIMAL128's precision overflow problem in very large aggregations and high-order operations. #59645
  • Improved the performance for basic operators.#61691 #61632 #62585 #61405 #61429
  • Optimized the performance of the JOIN and AGG operators. #61691
  • [Preview] Introduced SQL Plan Manager to allow users to bind a query plan to a query, thereby preventing the query plan from changing due to system state changes (mainly data updates and statistics updates), thus stabilizing query performance. #56310
  • Introduced Partition-wise Spillable Aggregate/Distinct operators to replace the original Spill implementation based on sorted aggregation, significantly improving aggregation performance and reducing read/write overhead in complex and high-cardinality GROUP BY scenarios. #60216
  • Flat JSON V2:
    • Supports configuring Flat JSON on the table level. #57379
    • Enhance JSON columnar storage by retaining the V1 mechanism while adding page- and segment-level indexes (ZoneMaps, Bloom filters), predicate pushdown with late materialization, dictionary encoding, and integration of a low-cardinality global dictionary to significantly boost execution efficiency. #60953
  • Supports an adaptive ZoneMap index creation strategy for the STRING data type. #61960
  • Enhanced query observability:
    • Optimized EXPLAIN ANALYZE output to display the execution metrics by group and by operator for better readability. #63326
    • QueryDetailActionV2 and QueryProfileActionV2 now support JSON format, enhancing cross-FE query capabilities. #63235
    • Supports retrieving Query Profile information across all FEs. #61345
    • SHOW PROCESSLIST statements display Catalog, Query ID, and other information. #62552
    • Enhanced query queue and process monitoring, supporting display of Running/Pending statuses.#62261
  • Materialized view rewrites consider the distribution and sort keys of the original table, improving the selection of optimal materialized views. #62830

Functions and SQL Syntax

  • Added the following functions:
  • Provides the following syntactic extensions:
    • Supports IF NOT EXISTS keywords in CREATE ANALYZE FULL TABLE. #59789
    • Supports EXCLUDE clauses in SELECT. #57411
    • Supports FILTER clauses in aggregate functions, improving readability and execution efficiency of conditional aggregations. #58937

Behavior Changes

  • Adjust the logic of the materialized view parameter auto_partition_refresh_number to limit the number of partitions to refresh regardless of auto refresh or manual refresh. #62301
  • Flat JSON is enabled by default. #62097
  • The default value of the system variable enable_materialized_view_agg_pushdown_rewrite is set to true, indicating that aggregation pushdown for materialized view query rewrite is enabled by default. #60976
  • Changed the type of some columns in `i...
Read more

3.3.19

14 Oct 07:13
d4ed3d0

Choose a tag to compare

3.3.19

Release Date: October 14, 2025

Bug Fixes

The following issues have been fixed:

  • UserProperty had lower priority than Session Variables. #63173
  • Materialized view refresh failures that could occur when the Hive base table was dropped and recreated. #63072
  • Issues with the aggregation pushdown rewrite rule. #63060
  • Inconsistencies between null columns and data columns in Boolean extraction functions for JSON. #63054
  • Issues when getting partition columns in Delta Lake format tables. #62953
  • Lack of colocation support for materialized views in shared-data clusters. #62941
  • Projection mapping errors in view-based materialized view rewrite. #62918
  • SQL syntax errors in histogram statistics when Most Common Values (MCV) contained single quotes. #62853
  • KILL ANALYZE did not work. #62842
  • CVE-2025-58056 vulnerability. #62801
  • Executing SHOW CREATE ROUTINE LOAD without specifying a database causes wrong results. #62745
  • Data loss caused by incorrectly skipping CSV headers in files(). #62719
  • Version check failures when Replication and Compaction transactions were committed together. #62663
  • Materialized view refresh is skipped because the materialized view version map is not cleared after a failed restore job. #62634
  • Issues caused by case-sensitive partition column validation in the materialized view analyzer. #62598

4.0.0-RC02

29 Sep 07:32
b95e90b

Choose a tag to compare

4.0.0-RC02 Pre-release
Pre-release

4.0.0-RC02

Release Date: September 29, 2025

New Features

  • Supports setting sort keys when creating Iceberg tables.
  • Supports Multi-Table Write-Write Transactions, allowing users to atomically commit INSERT, UPDATE, and DELETE operations. These transactions are compatible with both Stream Load and INSERT INTO interfaces, ensuring cross-table consistency in ETL and real-time ingestion scenarios.
  • Supports modifying aggregation keys of aggregate tables.

Improvements

  • Optimized Delta Lake Catalog cache configuration: adjusted default values of DELTA_LAKE_JSON_META_CACHE_TTL and DELTA_LAKE_CHECKPOINT_META_CACHE_TTL to 24 hours, and simplified Parquet handler logic. #63441
  • Improved Delta Lake Catalog error log format and content for better debugging. #63389
  • External groups (e.g., LDAP Group) now support role grant/revoke and display, improving SQL syntax and test coverage for stronger access control. #63385
  • Strengthened Stream Load parameter consistency checks to reduce risks caused by parameter drift. #63347
  • Optimized Stream Load label passing mechanism to reduce dependencies. #63334
  • Improved ANALYZE PROFILE format: ExplainAnalyzer now supports grouping metrics by operator. #63326
  • Enhanced QueryDetailActionV2 and QueryProfileActionV2 APIs to return results in JSON format. #63235
  • Improved predicate parsing in scenarios with large numbers of CompoundPredicates. #63139
  • Adjusted certain FE metrics to be leader-aware. #63004
  • Enhanced SHOW PROCESS LIST with Catalog and Query ID information. #62552
  • Improved BE JVM memory monitoring metrics. #62210
  • Optimized materialized view rewrite logic and log outputs. #62985
  • Optimized random bucketing strategy. #63168
  • Supports resetting AUTO_INCREMENT start value with ALTER TABLE <table_name> AUTO_INCREMENT = 10000;. #62767
  • Group Provider now supports matching groups by DN. #62711

Bug Fixes

The following issues have been fixed:

  • Incomplete Left Join results caused by ARRAY low-cardinality optimization. #63419
  • Incorrect execution plan generated after materialized view aggregate pushdown rewrite. #63060
  • Redundant warning logs printed in JSON field pruning scenarios when schema fields were not found. #63414
  • Infinite loop caused by SIMD Batch parameter errors when inserting DECIMAL256 data in ARM environments. #63406
  • Three storage-related issues: #63398
    • Cache exception when disk path is empty.
    • Incorrect Azure cache key prefix.
    • S3 multipart upload failure.
  • ZoneMap filter invalidation after CHAR-to-VARCHAR schema change with Fast Schema Evolution. #63377
  • ARRAY aggregation type analysis error caused by intermediate type ARRAY<NULL_TYPE>. #63371
  • Metadata inconsistency in partial updates based on auto-increment columns. #63370
  • Metadata inconsistency when deleting tablets or querying concurrently. #63291
  • Failure to create spill directory during Iceberg table writes. #63278
  • Ranger Hive Service permission changes not taking effect. #63251
  • Group Provider did not support IF NOT EXISTS and IF EXISTS clauses. #63248
  • Errors caused by using reserved keywords in Iceberg partitions. #63243
  • Prometheus metric format issue. #62742
  • Version check failure when starting replication transactions with Compaction enabled. #62663
  • Missing Compaction Profile when File Bunding was enabled. #62638
  • Issues handling redundant replicas after Clone. #62542
  • Delta Lake tables failed to find partition columns. #62953
  • Materialized views did not support Colocation in shared-data clusters. #62941
  • Issues reading NULL partitions in Iceberg tables. #62934
  • SQL syntax error caused by single quotes in Histogram statistics MCV (Most Common Values). #62853
  • KILL ANALYZE command not working. #62842
  • Failure collecting Stream Load profiles. #62802
  • Incorrect CTE reuse plan extraction. #62784
  • Rebalance failure due to incorrect BE selection. #62776
  • User Property priority is lower than Session Variable. #63173