github apache/druid druid-31.0.0
Druid 31.0.0

9 hours ago

Apache Druid 31.0.0 contains over 589 new features, bug fixes, performance enhancements, documentation improvements, and additional test coverage from 64 contributors.

See the complete set of changes for additional details, including bug fixes.

Review the upgrade notes and incompatible changes before you upgrade to Druid 31.0.0.
If you are upgrading across multiple versions, see the Upgrade notes page, which lists upgrade notes for the most recent Druid versions.

# Important features, changes, and deprecations

This section contains important information about new and existing features.

# Compaction features

Druid now supports the following features:

  • Compaction scheduler with greater flexibility and control over when and what to compact.
  • MSQ task engine-based auto-compaction for more performant compaction jobs.

For more information, see Compaction supervisors.

#16291 #16768

Additionally, compaction tasks that take advantage of concurrent append and replace is now generally available as part of concurrent append and replace becoming GA.

# Window functions are GA

Window functions are now generally available in Druid's native engine and in the MSQ task engine.

  • You no longer need to use the query context enableWindowing to use window functions. #17087

# Concurrent append and replace GA

Concurrent append and replace is now GA. The feature safely replaces the existing data in an interval of a datasource while new data is being appended to that interval. One of the most common applications of this feature is appending new data (such as with streaming ingestion) to an interval while compaction of that interval is already in progress.

# Delta Lake improvements

The community extension for Delta Lake has been improved to support complex types and snapshot versions.

# Iceberg improvements

The community extension for Iceberg has been improved. For more information, see Iceberg improvements

# Projections (experimental)

Druid 31.0.0 includes experimental support for new feature called projections. Projections are grouped pre-aggregates of a segment that are automatically used at query time to optimize execution for any queries which 'fit' the shape of the projection by reducing both computation and i/o cost by reducing the number of rows which need to be processed. Projections are contained within segments of a datasource and do increase the segment size. But they can share data, such as value dictionaries of dictionary encoded columns, with the columns of the base segment.

Projections currently only support JSON-based ingestion, but they can be used by queries that use the MSQ task engine or the new Dart engine. Future development will allow projections to be created as part of SQL-based ingestion.

We have a lot of plans to continue to improve this feature in the coming releases, but are excited to get it out there so users can begin experimentation since projections can dramatically improve query performance.

For more information, see Projections.

# Low latency high complexity queries using Dart (experimental)

Distributed Asynchronous Runtime Topology (Dart) is designed to support high complexity queries, such as large joins, high cardinality group by, subqueries and common table expressions, commonly found in ad-hoc, data warehouse workloads. Instead of using data warehouse engines like Spark or Presto to execute high-complexity queries, you can use Dart, alleviating the need for additional infrastructure.

For more information, see Dart.

#17140

# Storage improvements

Druid 31.0.0 includes several improvements to how data is stored by Druid, including compressed columns and flexible segment sorting. For more information, see Storage improvements.

# Upgrade-related changes

See the Upgrade notes for more information about the following upgrade-related changes:

  • Array ingest mode now defaults to array
  • Disabled ZK-based segment loading
  • Removed task action audit logging
  • Removed Firehose and FirehoseFactory
  • Removed the scan query legacy mode

# Deprecations

# Java 8 support

Java 8 support is now deprecated and will be removed in 32.0.0.

# Other deprecations

  • Deprecated API /lockedIntervals is now removed #16799
  • Cluster-level compaction API deprecates task slots compaction API #16803
  • The arrayIngestMode context parameter is deprecated and will be removed. For more information, see Array ingest mode now defaults to array.

# Functional areas and related changes

This section contains detailed release notes separated by areas.

# Web console

# Improvements to the stages display

A number of improvements have been made to the query stages visualization
new_stages
These changes include:

  • Added a graph visualization to illustrate the flow of query stages #17135
  • Added a column for CPU counters in the query stages detail view when they are present. Also added tool tips to expose potentially hidden data like CPU time #17132

# Dart

Added the ability to detect the presence of the Dart engine and to run Dart queries from the console as well as to see currently running Dart queries.
dart.png

#17147

# Copy query results as SQL

You can now copy the results of a query as a Druid SQL statement:
copy-results-as-sql
When you copy the results of the pictured query, you get the following query:

SELECT
  CAST("c1" AS VARCHAR) AS "channel",
  CAST("c2" AS VARCHAR) AS "cityName",
  DECODE_BASE64_COMPLEX('thetaSketch', "c3") AS "user_theta"
FROM (
  VALUES
  ('ca', NULL, 'AQMDAAA6zJOcUskA1pEMGA=='),
  ('de', NULL, 'AQMDAAA6zJP43ITYexvoEw=='),
  ('de', NULL, 'AQMDAAA6zJNtue8WOvrJdA=='),
  ('en', NULL, 'AQMDAAA6zJMruSUUqmzufg=='),
  ('en', NULL, 'AQMDAAA6zJM6dC5sW2sTEg=='),
  ('en', NULL, 'AQMDAAA6zJM6dC5sW2sTEg=='),
  ('en', NULL, 'AQMDAAA6zJPqjEoIBIGtDw=='),
  ('en', 'Caulfield', 'AQMDAAA6zJOOtGipKE6KIA=='),
  ('fa', NULL, 'AQMDAAA6zJM8nxZkoGPlLw=='),
  ('vi', NULL, 'AQMDAAA6zJMk4ZadSFqHJw==')
) AS "t" ("c1", "c2", "c3")

#16458

# Explore view improvements

You can now configure the Explore view on top of a source query instead of only existing tables.
You can also point and click to edit the source query, store measures in the source query,
and return to the state of your view using stateful URLs.
#17180

Other changes to the Explore view include the following:

  • Added the ability to define expressions and measures on the fly
  • Added the ability to hide all null columns in the record table
  • Added the ability to expand a nested column into is constituent paths
    #17213 #17225 #17234 #17180

# Support Delta lake ingestion in the data loaders

  • Added the Delta tile to the data loader for SQL-based batch and classic batch ingestion methods
    #17160 #17023

# Support Kinesis input format

The web console now supports the Kinesis input format.
#16850

# Other web console improvements

  • You can now search for datasources in the segment timeline visualization - previously you had to find them manually #16371
  • Showing JSON values (in query results) now display both raw and formatted JSON, making the data easier to read and troubleshoot #16632
  • Added the ability to submit a suspended supervisor from the data loader #16696
  • Added column mapping information to the explain plan #16598
  • Updated the Web Console to use array mode by default for schema discovery #17133
  • Fixed NPE due to null values in numeric columns #16760

# Ingestion

# Optimized the loading of broadcast data sources

Previously all services and tasks downloaded all broadcast data sources.
To save task storage space and reduce task startup time, this modification prevents kill tasks and MSQ controller tasks from downloading unneeded broadcast data sources. All other tasks still load all broadcast data sources.

The CLIPeon command line option --loadBroadcastSegments is deprecated in favor of --loadBroadcastDatasourceMode.

#17027

# General ingestion improvements

  • The default value for druid.indexer.tasklock.batchAllocationWaitTime is now 0 #16578
  • Hadoop-based ingestion now works on Kubernetes deployments #16726
  • Hadoop-based ingestion now has a Boolean config useMaxMemoryEstimates parameter, which controls how memory footprint gets estimated. The default is false, so that the behavior matches native JSON-based batch ingestion #16280
  • Added druid-parquet-extensions to all example quickstart configurations #16664
  • Added support for ingesting CSV format data into Kafka records when Kafka ingestion is enabled with ioConfig.type = kafka #16630
  • Added logging for sketches on workers #16697
  • Removed obsolete tasks index_realtime and index_realtime_appenderator tasks—you can no longer use these tasks to ingest data #16602
  • Renamed TaskStorageQueryAdapter to TaskQueryTool and removed the isAudited method #16750
  • Improved Overlord performance by reducing redundant calls in SQL statements #16839
  • Improved CustomExceptionMapper so that it returns a correct failure message #17016
  • Improved time filtering in subqueries and non-table data sources #17173
  • Improved WindowOperatorQueryFrameProcessor to avoid unnecessary re-runs #17211
  • Improved memory management by dividing the amount of partitionStatsMemory by two to account for two simultaneous statistics collectors #17216
  • Fixed NPE in CompactSegments #16713
  • Fixed Parquet reader to ensure that Druid reads the required columns for a filter from the Parquet data files #16874
  • Fixed a distinct sketches issue where Druid called retainedKeys.firstKey() twice when adding another sketch #17184
  • Fixed a WindowOperatorQueryFrameProcessor issue where larger queries could reach the frame writer's capacity preventing it from outputting all of the result rows #17209
  • Fixed native ingestion task failures during rolling upgrades from a version before Druid 30 #17219

# SQL-based ingestion

# Optimized S3 storage writing for MSQ durable storage

For queries that use the MSQ task engine and write their output to S3 as durable storage, uploading chunks of data is now faster.

#16481

# Improved lookup performance

Improved lookup performance for queries that use the MSQ task engine by only loading required lookups. This applies to both ingestion and querying.

#16358

# Other SQL-based ingestion improvements

  • Added the ability to use useConcurrentLocks in task context to determine task lock type #17193
  • Improved error handling when retrieving Avro schemas from registry #16684
  • Fixed issues related to partitioning boundaries in the MSQ task engine's window functions #16729
  • Fixed a boost column issue causing quantile sketches to incorrectly estimate the number of output partitions to create #17141
  • Fixed an issue with ScanQueryFrameProcessor cursor build not adjusting intervals #17168
  • Improved worker cancellation for the MSQ task engine to prevent race conditions #17046
  • Improved memory management to better support multi-threaded workers #17057
  • Added new format for serialization of sketches between MSQ controller and worker to reduce memory usage #16269
  • Improved error handling when retrieving Avro schemas from registry #16684
  • Fixed issues related to partitioning boundaries in the MSQ task engine's window functions #16729
  • Fixed handling of null bytes that led to a runtime exception for "Invalid value start byte" #17232
  • Updated logic to fix incorrect query results for comparisons involving arrays #16780
  • You can now pass a custom DimensionSchema map to MSQ query destination of type DataSourceMSQDestination instead of using the default values #16864
  • Fixed the calculation of suggested memory in WorkerMemoryParameters to account for maxConcurrentStages which improves the accuracy of error messages #17108
  • Optimized the row-based frame writer to reduce failures when writing larger single rows to frames #17094

# Streaming ingestion

# New Kinesis input format

Added a Kinesis input format and reader for timestamp and payload parsing.
The reader relies on a ByteEntity type of KinesisRecordEntity which includes the underlying Kinesis record.

#16813

# Streaming ingestion improvements

  • Added a check for handing off upgraded real-time segments. This prevents data from being temporarily unavailable for queries during segment handoff #16162
  • Improved the user experience for autoscaling Kinesis. Switching to autoscaling based on max lag per shard from total lag for shard is now controlled by the lagAggregate config, defaulting to sum #16334
  • Improved the Supervisor so that it doesn't change to a running state from idle if the Overlord restarts #16844

# Querying

# Dart

Dart is a query engine with multi-threaded workers that conducts in-memory shuffles to provide tunable concurrency and infrastructure costs for low-latency high complexity queries.

To try out Dart, set druid.msq.dart.enabled to true in your common runtime properties. Then, you can select Dart as a query engine in the web console or through the API /druid/v2/sql/dart, which accepts the same JSON payload as /druid/v2/sql. Dart is fully compatible with current Druid query shapes and Druid's storage format. That means you can try Dart with your existing queries and datasources.

# Projections

As an experimental feature, projections are not well documented yet, but can be defined for streaming ingestion and 'classic' batch ingestion as part of the dataSchema. For an example ingestion spec, see the the pull request description for #17214.

The groupingColumns field in the spec defines the order which data is sorted in the projection. Instead of explicitly defining granularity like for the base table, you define it with a virtual column. During ingestion, the processing logic finds the ‘finest’ granularity virtual column that is a timestamp_floor expression and uses it as the __time column for the projection. Projections do not need to have a time column defined. In these cases, they can still match queries that are not grouping on time.

There are new query context flags that have been added to aid in experimentation with projections:

  • useProjection accepts a specific projection name and instructs the query engine that it must use that projection, and will fail the query if the projection does not match the query
  • forceProjections accepts true or false and instructs the query engine that it must use a projection, and will fail the query if it cannot find a matching projection
  • noProjections accpets true or false and instructs the query engines to not use any projections

#17214

# Enabled querying cold datasources

You can now query entirely cold datasources after you enable the CentralizedDatasourceSchema feature. For information about how to use a centralized datasource schema, see Centralized datasource schema.

#16676

# SQL DIV function

You can now use the SQL DIV function.

#16464

# Modified equality and typed in filter behavior

Modified the behavior of using EqualityFilter and TypedInFilter to match numeric values (particularly DOUBLE) against string columns by casting strings for numerical comparison. This ensures more consistent Druid behavior when the sqlUseBoundAndSelectors context flag is set.

#16593

# Window query guardrails

Druid blocks window queries that involve aggregation functions inside the window clause when the window is included in SELECT.
The error message provides details on updating your query syntax.

#16801

# Updated query from deep storage API response

Added the following fields from the query-based ingestion task report to the response for API request GET /v2/sql/statements/query-id?detail=true:

  • stages: Query stages
  • counters: Stage counters
  • warnings: Warning reports

#16808

# Other querying improvements

  • Improved window queries so that window queries without group by using the native engine don't return an empty response #16658
  • Window queries now support the guardrail maxSubqueryBytes #16800
  • Window functions that use the MSQ task engine now reject MVDs when they're used as the PARTITION BY column. Previously, an exception occurred #17036
  • A query that references aggregators called with unsupported distinct values now fails #16770
  • Druid now validates that a complex type aligns with the supported types when used with an aggregator #16682
  • Druid prevents you from using DISTINCT or unsupported aggregations with window functions #16738
  • Druid now deduces type from aggregators when materializing subquery results #16703
  • Added the ability to define the segment granularity of a table in the catalog #16680
  • Added a way for columns to provide GroupByVectorColumnSelectors, which controls how the groupBy engine operates on them #16338
  • Added sqlPlannerBloat query context parameter to control whether two project operators get merged when inlining expressions #16248
  • Improved window function offsets for ArrayListRowsAndColumns #16718
  • Improved the fallback strategy when the Broker is unable to materialize the subquery's results as frames for estimating the bytes #16679
  • Improved how Druid executes queries that contain a LIMIT clause #16643
  • Improved the code style of NestedDataOperatorConversions to be consistent for each SqlOperatorConversion #16695
  • Improved window functions so that they reject multi-value dimensions during processing instead of failing to process them #17002
  • Improved async query by increasing its timeout to 5 seconds #16656
  • Improved error message when the requested number of rows in a window exceeds the maximum #16906
  • Improved numeric aggregations so that Druid now coerces complex types to number when possible, such as for SpectatorHistogram #16564
  • Improved query filtering to correctly process cases where both an IN expression and an equality (=) filter are applied to the same string value #16597
  • Improved the speed of SQL IN queries that use the SCALAR_IN_ARRAY function #16388
  • Improved the ARRAY_TO_MV function to handle cases where an object selector encounters a multi-value string #17162
  • Improved query filtering so that Druid tries to arrange query filters based on the computational cost of bitmap indexes, prioritizing less expensive filters for computation first. Filters with high compute costs relative to the number of rows they can filter might be omitted. #17055 #17125
  • Updated the deserialization of dimensions in GROUP BY queries to operate on all dimensions at once rather than deserializing individual dimensions #16740
  • Fixed an issue that caused maxSubqueryBytes to fail when segments had missing columns #16619
  • Fixed an issue with the array type selector that caused the array aggregation over window frame to fail #16653
  • Fixed support for native window queries without a group by clause #16753
  • Window functions now support maxSubqueryBytes #16800
  • Fixed an issue with window functions and partitioning #17141
  • Updated window functions to disallow multi-value dimensions for partitioning #17036
  • Fixed an issue with casting objects to vector expressions #17148
  • Added several fixes and improvements to vectorization fallback #17098, #17162
  • You can now configure encoding method for sketches at query time #17086
  • Fixed an issue with joins failing to time out on Historicals #17099

# Cluster management

# Added cluster configuration for multivalue handling

Added an optional cluster configuration property druid.indexing.formats.stringMultiValueHandlingMode which overrides the default mode SORTED_SET used for string dimensions. Possible values are SORTED_SET (default), SORTED_ARRAY, ARRAY.

Note that we recommend you use array types instead of MVDs where possible. For more information, see Migration guide: MVD to arrays.

#16822

# API for cluster-level compaction configuration

Druid now offers an API to update the cluster-level compaction dynamic configuration:

POST /druid/coordinator/v1/config/compaction/cluster

Example payload:

{
     "compactionTaskSlotRatio": 0.5,
     "maxCompactionTaskSlots": 10,
     "engine": "msq"
}

This API deprecates the older API /druid/coordinator/v1/config/compaction/taskslots.

#16803

# Guardrail for task payload size

The druid.indexer.queue.maxTaskPayloadSize config defines the maximum size in bytes of a task payload accepted by the Overlord service. The default is 60 MB.

#16512

# Improved UX for Coordinator management

Improve the user experience around Coordinator management as follows:

  • Added an API GET /druid/coordinator/v1/duties that returns a status list of all duty groups currently running on the Coordinator
  • The Coordinator now emits the following metrics: segment/poll/time, segment/pollWithSchema/time, and segment/buildSnapshot/time
  • Remove redundant logs that indicate normal operation of well-tested aspects of the Coordinator

#16959

# Other cluster management improvements

  • The startup script for Docker-based deployments now specifies the node type #16282
  • The druid.sh script now uses the canonical hostname for druid.host by default. You can now set the following environment variable to use IP instead: DRUID_SET_HOST_IP=1 #16386
  • Fixed an issue with tombstone segments incorrectly appearing unavailable in the Web Console #17025

# Data management

# Compaction

# Compaction supervisors (experimental)

You can now configure automatic compaction to run as a supervisor rather than as a Coordinator duty. Compaction supervisors provide the following benefits over Coordinator duties:

  • Can use the supervisor framework to get information about the auto-compaction, such as status or state
  • More easily suspend or resume compaction for a datasource
  • Can use either the native compaction engine or the MSQ task engine
  • More reactive and submits tasks as soon as a compaction slot is available
  • Tracked compaction task status to avoid re-compacting an interval repeatedly

You can submit your existing auto-compaction configs as part of the supervisor spec; the two auto-compaction options share the same syntax.

For more information, see Automatic compaction.

#16291 #16768

# Kill tasks

  • The KillUnusedSegments coordinator duty now selects datasources in a round-robin manner during each run, ensuring varied selection instead of repeatedly choosing the same set of datasources #16719
  • Kill tasks can now use different types of locks, such as APPEND or REPLACE. This change is experimental and not recommended for production use #16362

# Other data management improvements

  • Improved the performance of the metadata query to fetch unused segments for a datasource returns results, which could cause issues with Overlord stability. Test queries that used to take over 30 seconds now complete in less than a second #16623
  • Fixed an issue in task bootstrapping that prevented tasks from accepting any segment assignments, including broadcast segments #16475
  • Improved the performance for writing segments #16698
  • Improved the logic so that unused segments and tombstones in the metadata cache don't get needlessly refreshed #16990 17025
  • Improved how segments are fetched so that they can be reused #17021

# Storage improvements

# Compression for complex columns

Compression is now available for all complex metric columns which don't have specialized implementations. You can configure the complexMetricCompression IndexSpec option to any compression strategy (lz4, zstd, etc). The default is uncompressed. This works for most complex columns except compressed-big-decimal and columns stored by first/last aggregators.

Note that enabling compression is not backwards compatible with Druid versions older than 31. Only enable it after comprehensive testing to ensure no need for rollback.

#16863

# Flexible segment sorting

Added the ability to sort segments by dimensions other than __time - this provides a significant storage benefit. Control the sorting method using the segmentSortOrder and forceSegmentSortByTime query context parameters.

This feature is not backwards compatible. Only enable it after comprehensive testing to ensure no need for rollback.

For more information, see Context parameters.

#16849
#16958

# APIs

# New API for exiting streaming task groups early

This new API does a best effort attempt to trigger the handoff for specified task groups of a supervisor early:

POST /druid/indexer/v1/supervisor/{supervisorId}/taskGroups/handoff

#16310

# API to fetch conflicting task locks

You can use the new /activeLocks API to view task locks for the following attributes:

  • Datasource
  • Priority
  • Interval list

Use this API for debugging, to view lock contention, and to observe any concurrent locks.

# Metrics and monitoring

# Cgroup usage

The following Cgroup metrics are now available:

Metric Description Dimensions Normal value
cgroup/cpu/usage/total/percentage Total cpu percentage used by cgroup of process that is running 0-100
cgroup/cpu/usage/user/percentage User cpu percentage used by cgroup of process that is running 0-100
cgroup/cpu/usage/sys/percentage Sys cpu percentage used by cgroup of process that is running 0-100
cgroup/disk/read/size Reports the number of bytes transferred to specific devices by a cgroup of process that is running. diskName Varies
cgroup/disk/write/size Reports the number of bytes transferred from specific devices by a cgroup of process that is running. diskName Varies
cgroup/disk/read/count Reports the number of read operations performed on specific devices by a cgroup of process that is running. diskName Varies
cgroup/disk/write/count Reports the number of write operations performed on specific devices by a cgroup of process that is running. diskName Varies

#16472

# Default Prometheus metrics

The default Prometheus metrics have been expanded to cover more of the available metrics for Druid.

#16340

# Configurable connection timeouts

Added HTTP client property clientConnectTimeout to enable configuration of connection timeouts for Druid HTTP client requests.

#16831

# Added indexer metrics

Added indexer/task/failed/count and indexer/task/failed/count metrics.

#16829

# Added subquery metrics

Added subquery/rows and subquery/bytes metrics, which indicate the size of the results materialized on the heap.

#16835

# Added segment loading rate metrics

Made the following changes to segment loading rate metrics:

  • Added LoadingRateTracker which computes a moving average load rate based on
    the last few GBs of successful segment loads.
  • Added expectedLoadTimeMillis to /druid/coordinator/v1/loadQueue?simple API response.
  • Updated the Coordinator to emit segment/loading/rateKbps.

#16691

# Extensions

# Kubernetes improvements

When the fabric client is unable to communicate with the Kubernetes server, the shutdown logic now proceeds without populating the task status location, ensuring all data structures are cleaned up.

#16711

# pac4j OIDC context

The pac4j extension now returns the OIDC context for AuthenticationResult.

#16109

# Middle Manager-less Druid improvements

The Dynamic Pod Template Selection feature enhances the K8s extension by enabling more flexible and dynamic selection of pod templates based on task properties, which can optimize resource utilization and task execution efficiency.

#16510

In MiddleManager-less ingestion, Druid adds the pod template name as an annotation to the created job or pod.

#16772

# Improved Iceberg input source support

  • You can now optionally use the caseSensitive Boolean config to configure how Druid reads column names from Iceberg. Iceberg table scans are case sensitive by default #16496
  • Added support to the iceberg input source to read from Iceberg REST catalogs #17124

# Delta Lake complex types

Added support for delta structs, arrays, and maps to the delta input source.

#16884

# Delta Lake snapshot versions

Added the ability to optionally specify a snapshotVersion in the delta input source payload to ingest versioned snapshots from a Delta Lake table. When not specified, Druid ingests the latest snapshot from the table.

#17004

# Other extensions improvements

  • Added an informational entry to the streaming supervisor log when task count is greater than the number of partitions #16948
  • Reduced logging in S3 output stream extension #16853
  • Reduced logging in basic security extension #16767

# Upgrade notes and incompatible changes

# Upgrade notes

# Array ingest mode now defaults to array

The SQL-based ingestion context flag arrayIngestMode now defaults to array instead of mvd. This means that SQL VARCHAR ARRAY types is no longer implicitly translated and stored in VARCHAR columns, but is instead stored as VARCHAR ARRAY. This change permits other array types such as BIGINT ARRAY and DOUBLE ARRAY to be inserted with MSQ into their respective array column types instead of failing as they do in mvd mode.

To continue to store multi-value strings, modify any insert/replace queries to wrap the array types with the ARRAY_TO_MV operator.

Validation is in place to prevent mixing VARCHAR and VARCHAR ARRAY columns in the same table, so any ingestions affected by this change will fail and provide a descriptive error message instead of exhibiting unexpected behavior.

The arrayIngestMode option of none has been removed. It was introduced prior to the table validation logic as a means for cluster operators to force query writers to explicitly set array or mvd on their query contexts but provides little utility in Druid 31.

See the following topics for more information:

#16789

# Removed task action audit logging

The deprecated task action audit logging has been removed. This change includes the following updates:

  • The endpoint /indexer/v1/task/{taskId}/segments is no longer supported.
  • Druid doesn't write to or read from the metadata table druid_taskLog.
  • Druid ignores the property druid.indexer.auditlog.enabled.
  • Druid doesn't emit the metric task/action/log/time.

These changes are backward compatible with all existing metadata storage extensions.

#16309

# Removed Firehose and FirehoseFactory

Removed Firehose and FirehoseFactory and remaining implementations.
Apache deprecated support for Druid firehoses in version 0.17. Support for firehose ingestion was removed in version 26.0.

#16758

# Front-coded dictionaries

In Druid 32.0.0, the front coded dictionaries feature will be turned on by default. Front-coded dictionaries reduce storage and improve performance by optimizing for strings where the front part looks similar.

Once this feature is on, you cannot easily downgrade to an earlier version that does not support the feature.

For more information, see Migration guide: front-coded dictionaries.

If you're already using this feature, you don't need to take any action.

# Storage improvement features

Druid 31.0.0 includes storage improvements that are not backwards compatible. Once you enable flexible segment sorting or compression for complex columns, you cannot downgrade to a release earlier than 31.0.0. Thoroughly test these features before rolling them out to your production cluster.

# Incompatible changes

# Removed the scan query legacy mode

The native scan query legacy mode has been removed. It was introduced in Druid 0.11 to maintain compatibility during an upgrade from older versions of Druid where the scan query was part of a contrib extension.

#16659

Hard-coded "legacy":false following removal of the legacy mode to prevent error during rolling upgrades or downgrades.

#16793

# ZK-based segment loading

ZK-based segment loading is now disabled. ZK servedSegmentsPath was deprecated in Druid 0.7.1. This legacy path has been replaced by liveSegmentsPath.

Segment-serving processes such as Peons, Historicals and Indexers no longer create ZK loadQueuePath entries. The druid.zk.paths.loadQueuePath and druid.zk.paths.servedSegmentsPath properties are no longer used.

Move to HTTP-based segment loading first and then perform the version upgrade.

# Developer notes

  • Fixed the hibernate-validator warning displayed during maven build #16746
  • Replaced the StorageAdapter interface with the CursorHolder interface #17024

# StorageAdapter changes

If you write custom extensions, specifically query engines or anything else involving the StorageAdapter interface, 31.0.0 includes changes to low-level APIs that may impact you. All methods on StorageAdapter now throw a Druid exception.

Prepare for these changes before upgrading to 31.0.0 or later. For more information, see the following pull requests:

# Dependency updates

Bumped the versions of the following dependencies:

  • Apache Avro to 1.11.4 #17230
  • Apache Calcite to 1.37.0 #16621
  • Delta Kernel from 3.1.0 to 3.2.1 #16513 #17179
  • MySQL Java connector to 8.2.0 #16024
  • OpenRewrite maven plugin from 5.27.0 to 5.31.0 #16477
  • Scala library from 2.13.11 to 2.13.14 #16364
  • Apache Curator reverted to 5.3.0 from 5.5.0 #16688
  • Updated Blueprint dependencies from v4 to v5 in web console #16756
  • io.grpc:grpc-netty-shaded from 1.57.2 to 1.65.1 #16731
  • jclouds.version from 2.5.0 to 2.6.0 #16796
  • Axios to 1.7.4 #16898

# Credits

@317brian
@a2l007
@aaronm-bi
@abhishekagarwal87
@abhishekrb19
@adarshsanjeev
@adithyachakilam
@aho135
@Akshat-Jain
@AlbericByte
@amaechler
@AmatyaAvadhanula
@amit-git-account
@arunramani
@asdf2014
@benkrug
@cecemei
@clintropolis
@Codegass
@cryptoe
@dave-mccowan
@dependabot[bot]
@edgar2020
@ektravel
@fectrain
@findingrish
@gargvishesh
@georgew5656
@gianm
@GWphua
@hardikbajaj
@hevansDev
@IgorBerman
@jakubmatyszewski
@jgoz
@jon-wei
@kaisun2000
@kfaraz
@kgyrtkirk
@LakshSingla
@lfrancke
@lorem--ipsum
@maytasm
@nozjkoitop
@pagrawal10
@pjain1
@pranavbhole
@rahulbansal3005
@rash67
@razinbouzar
@rbankar7
@rohangarg
@shigarg1
@sreemanamala
@suneet-s
@techdocsmith
@trompa
@TSFenwick
@vogievetsky
@vtlim
@writer-jill
@YongGang
@zachjsh
@ztzxt

Don't miss a new druid release

NewReleases is sending notifications on new releases.