Features
- Add custom partitioning of Iceberg tables: partition spec of a newly created Iceberg table is now determined by the
redpanda.iceberg.partition.spectopic property. by @ztlpn in #24952 - During Iceberg translation if a record fails to be translated to Iceberg schema (missing schema, unsupported schema, corrupted data) they will be written to a table with
~dlqsuffix. A cluster config which acts as a default and per-topic property is introduced to control this behavior. Available options are: "drop" and "dlq_table" (default). by @nvartolomei in #24980 - When translating kafka records to Iceberg/Parquet in case translation fails these will be written in the key_value mode to a
redpanda.<topic>~dlqtable. by @nvartolomei in #24893 - Redpanda now supports the SASL/PLAIN authentication mechanism. To enable it add
"PLAIN"to thesasl_mechanismscluster configuration list by @michael-redpanda in #24525 - Schema Registry: Support
?normalize=truefor protobuf by @BenPope in #24719 - metrics: Consumer Group Lag can now be enabled by @BenPope in #25216
- pre-restart check API endpoint by @bashtanov in #24928
- rpk: add support for
--formatinrpk cluster infoby @r-vasquez in #25223 - Improved partition density - This release increased the amount of partitions Redpanda can handle. At the same time we also change the behaviour and defaults of the related topic properties
topic_memory_per_partition(new default 200KiB) andtopic_partitions_per_shard(new default 5000). To calculate the total allowable amount of partition replicas we no longer divide the total memory space bytopic_memory_per_partitionbut rather an explicit amount that is reserved for partitions via a new propertytopic_partitions_memory_allocation_percent(default 10%). This effectively results in allowing double the amount of partitions as previously by default. We heuristically try to detect if these settings were previously overriden and apply the previous logic if so. by @StephanDollberg in #24472 - rpk debug bundle will now collect the
startup_logfile andcrash_reportsdirectory if they are present in the data directory. by @r-vasquez in #24778 - rpk: Introduce
rpk debug remote-bundleto gather a debug bundle from a remote cluster. by @r-vasquez in #23986 - rpk:
rpk group describenow supports printing instance IDs by @daisukebe in #24881 - Redpanda now includes information about previous crashes in the telemetry data. by @pgellert in #25173
- Redpanda now supports selecting which format the client certificate's subject DN will be parsed in. The new cluster config
tls_certificate_name_formatcan take two options:legacyorrfc2253. See documentation of the cluster config to understand the difference in how the an X.509 certificate's subject DN will be formatted. by @michael-redpanda in #25312 - Add cluster config
cloud_storage_enable_segment_uploadsthat can be used to pause the Tiered Storage safely. by @Lazin in * Adds a newrpk topic analyzecommand that determines information like batch rate and size for a given set of topics. by @ballard26 in #25164 - New cluster config
cloud_storage_enable_remote_allow_gapsis added. If it's set toTrueRedpanda is allowed to create gaps in the offset range when TS is paused. by @Lazin in #24871 - New metric
redpanda_cloud_storage_paused_archiverswhich tracks number of partitions with paused segment uploads is added. by @Lazin in #24871 - New topic property
redpanda.remote.allow_gapsis added. If it's set toTrueRedpanda is allowed to create gaps in the offset range when TS is paused. by @Lazin in #24871
Bug Fixes
- Addresses startup behavior in SR that may result in inconsistent SR state between nodes by @michael-redpanda in #25403
- Avoid large allocations for the kafka response sequencing map. by @pgellert in #24725
- Ensure
redpanda_cloud_storage_cloud_log_sizemetric consistent across all replicas. We used to update it seldomly from the leader replica only which lead to inconsistent/stale values. by @nvartolomei in #24342 - FIxed an issue that, when Redpanda was under extremely heavy load, the incorrect certificate was used for mTLS authorization result in authorization errors to the client by @michael-redpanda in #25149
- Fix a bug in group management behaviour when the last member of a group expires while there are pending
members in the group. by @pgellert in #25270 - Fix the endianness of
snappy_java_compressorheaders to match that ofsnappy-javaby @WillemKauf in #25092 - Fixed a bug in which sliding window compaction may become stuck on failing to build an index map for a single segment. by @WillemKauf in #24323
- Fixed a bug over-restricting bundled json schemas to treat both "id" and "$id" as restricted keywords, regardless of the active draft. by @IoannisRP in #25020
- Fixed an issue where creating a topic with a huge number of partitions could lead to a crash. by @IoannisRP in #24135
- Fixes Iceberg metadata serialization to avoid writing an extraneous empty Avro block. This would previously prevent some query engines (e.g. BigQuery) from reading tables created by Iceberg Topics. by @andrwng in #24913
- Fixes a bug in Redpanda's Iceberg manifest list Avro definition that previously resulted in an end-of-file (EOF) error when reading manifest list Avro files written by other engines. This could previously crash Redpanda or block Redpanda from appending Iceberg data, and could also prevent certain query engines from successfully reading Iceberg data written by Redpanda. by @andrwng in #24602
- Fixes a bug in which a segment being rolled and closed could race, leading to a triggered
vassert. by @WillemKauf in #24483 - Fixes a bug in which a segment being added to a log while the log was being closed could race, leading to a triggered
vassert(). by @WillemKauf in #24635 - Fixes a bug in which segments which may have tombstones in them were not considered eligible for self-compaction by @WillemKauf in #24187
- Fixes a bug in which urgent garbage collection of multiple partitions may only consider one partition in the set. by @WillemKauf in #25257
- Fixes a bug that could prevent topic recovery on ABS object storage when there are objects in a bucket from multiple clusters (e.g. following a whole cluster restore). by @andrwng in #24439
- Fixes a bug where
rpkwasn't parsing--helpwhen used alongside--redpanda-idinrpk cloud <provider> byoc applyby @r-vasquez in #24369 - Fixes a bug where failing to audit an authentication event could lead to a broker crash. by @pgellert in #24727
- Fixes a bug where serializing manifests for Iceberg topics with decimal fields could cause Redpanda to crash or upload invalid manifests by @oleiman in #24463
- Fixes a bug which may lead to
archival_metadata_stminconsistencies when reconfiguring clusters with recovered compacted topics. by @mmaslankaprv in #24664 - Fixes a crash during partition shutdown. This can happen during partition moves (cross core/broker) or at broker shutdown. by @bharathv in #24936
- Fixes a crash resulting from incorrect cleanup of log readers used for iceberg translation. by @bharathv in #24572
- Fixes a crash that could happen when an error occurred during translation in an Iceberg Topic. by @andrwng in #25215
- Fixes a race that could prevent Iceberg translation from happening following a leadership change. by @andrwng in #24556
- Fixes accounting of iceberg commit lag metric that can remain erroneously high in some cases even though the translation if fully caught up. Additionally the change ensures that only partition leaders emit lag metrics while followers emit 0 lag. by @bharathv in #24568
- Fixes an issue that blocked the compaction of consumer offsets with group transactions. by @bharathv in #24637
- Fixes an issue where transactions incorrectly timeout due incorrect cleanup of evicted producers. by @bharathv in #24852
- If a discrete disk is used for cloud storage cache Redpanda previously rejected writes if that disk (cache disk) was full (in degraded state). This is incorrect since the cache disk isn't in the way of writes. From now on, reject writes only if the data disk is full (in degraded state). by @nvartolomei in #24436
- Previously if redpanda was configured with different mountpoints for data and cache directory we would report metrics only for the cache directory. Now, the original
storage_disk_{total,free}_bytesmetric will report metrics for the data directory mountpoint and a newstorage_cache_disk_{total,free}_bytesmetric will report metrics for the cache directory mountpoint. Metrics will be equivalent if both are on the same mountpoint. by @nvartolomei in #24138 - Remove partial kvstore snapshots at startup. by @ztlpn in #24815
- Schema Registry/Protobuf: Fix a regression with maps. by @BenPope in #25001
- The
vectorized_internal_rpc_produce_bad_create_timemetric has been removed. This metric was introduced in error and never had a value other than zero. by @travisdowns in #25341 - #16649 Schema Registry: fixes a bug in the Avro compatibility check reader_field_missing_default_value where it was too lenient for missing default values of null-able types. by @pgellert in #24032
- #23363 rpk: fixes a bug where rpk incorrectly handles IPv6 by adding extra brackets. by @r-vasquez in #24982
- #23661 Redpanda neglected to include ECDSA based ciphers in the cipher strings used for TLSv1.2 and below. This caused TLS connections that used ECDSA based certificates to fail cipher negotiation when using TLSv1.2 and below. ECDSA ciphers are now in the list of supported ciphers. by @michael-redpanda in #24191
- #24543 Redpanda will now permit topics to be created with
redpanda.remote.[read|write]set totruewhen a license is expired or missing provided that the cluster configcloud_storage_enabledis set tofalse. by @michael-redpanda in #24570 - #24782 Fixes integer overflow issues when given a schema via the
POST /subject/{subject}/versionwhere version was > INT_MAX or a negative value was provided. by @michael-redpanda in #24860 - fixes a very rare situation in which Raft leader can enter into infinite loop trying to recover follower. by @mmaslankaprv in #25018
- fixes rare bug leading to offset translation inconsistency in recovered topics by @mmaslankaprv in #24618
- rpk: fixes a bug that prevented serverless cloud profiles from using
rpk security usercommands. by @r-vasquez in #25371
Improvements
- The client quota cluster configs are removed (kafka_client_group_byte_rate_quota, kafka_client_group_fetch_byte_rate_quota, target_quota_byte_rate, target_fetch_quota_byte_rate, kafka_admin_topic_api_rate). Please follow the migration docs to migrate from cluster configuration quotas to Kafka API-based quotas. by @pgellert in #24697
- Introduces the node config
crash_loop_sleep_sec, which sets the time the broker sleeps before terminating the process when the limit on the number of consecutive times a broker can crash has been reached. This is most useful in Kubernetes environments where setting this value allows customers to have ssh access into a crash looping pod for a short window of time. by @pgellert in #24787 - Make Iceberg and topic mount/unmount work well together by @bashtanov in #24780
- A new metric, vectorized_kafka_produced_bytes, is added to the /metrics endpoint which breaks down bytes produced to Redpanda at the Kafka API by batch compression type. by @travisdowns in #25340
- Improve the user messages when the
topic_partitions_reserve_shard0cluster config is used and a user tries to create a topic with more partitions than the core-based partition limit. by @pgellert in #24378 - Added metrics for pandaproxy resource usage. by @IoannisRP in #24537
- Adds a chunked compaction routine to local storage, which is used as a fallback in the case that we fail to index a single segment during sliding window compaction. by @WillemKauf in #24423
- Adds a number of new metrics to improve observability of the compaction subsystem: by @WillemKauf in #24187
- Added the
_segment_cleanly_compactedmetric tosegment::probe. - Added the
_segments_marked_tombstone_freemetric tosegment::probe. - Added the
_num_rounds_window_compactionmetric tosegment::probe.
- Added the
- Adds additional debug log messages in the datalake coordinator regarding files to be committed to Iceberg. by @andrwng in #24555
- Adds logging to mention data removed by compaction. by @andrwng in #24659
- Adds the observable metrics
dirty_segment_bytesandclosed_segment_bytesto the storage layer. by @WillemKauf in #24649 - Adds the tunable
log_compaction_adjacent_merge_self_compaction_count, which allows for adjacent merge compaction to make more forward progress in all situations whenlog_compaction_use_sliding_windowis disabled. by @WillemKauf in #25119 - Allow for optional scheduling of compaction via
min_cleanable_dirty_ratioby @WillemKauf in #24991 - Beta version of Iceberg support was incorrectly classified as "enterprise only". by @oleiman in #24421
- Disable datalake services in recovery mode by @ztlpn in #24446
- Enables full struct schema evolution for Iceberg topics by @oleiman in #24862
- Fixes an overly restrictive condition for retention in Iceberg-enabled topics. by @WillemKauf in #24610
- Generated parquet files for Iceberg Topics are now compressed with zstd compression. by @rockwotj in #24933
- Iceberg data files are now uploaded to the table location prefix instead of
/datalake-iceberg/prefix. by @nvartolomei in #24960 - Iceberg/Datalake: Adds support for schema evolution by primitive type promotion by @oleiman in #24561
- Implement deleting iceberg tables on topic deletion. by @ztlpn in #24119
- Improved TLS connection related error messages by @michael-redpanda in #24749
- Introduce
iceberg_target_lag_mstopic property by @oleiman in #25056 - Leader balancer: don't treat each core as independent and balance total number of leaders on each node as well. by @ztlpn in #24403
- Makes urgent garbage collection and compaction of logs separate, concurrent processes. by @WillemKauf in #25134
- Move failed authorization log statements from the
kafkalogger to a newkafka/authzlogger, allowing for fine grained control over log statements for failed authorization. by @rockwotj in #24712 - Redpanda will now periodically remove expired snapshots from Iceberg Topic tables. by @andrwng in #24813
- Redpanda will now schedule local segment merges of compacted topics, even when windowed compaction has occurred in a given housekeeping round. This ensures progress in reducing segment count in compacted topics with high produce traffic. by @andrwng in #24874
- Schema Registry: Add Some metrics for resource usage taken by in-memory schemas by @BenPope in #23794
- Show leader id in
/v1/cluster/partitionsresponse. by @ztlpn in #24565 - Use streaming parsing of transaction range manifests in tiered storage to avoid large allocations which lead to OOMs with heavy use of transactions. by @nvartolomei in #24728
rpk security useris now available for users with Cloud profiles. by @r-vasquez in #24671rpk topic describenow supports the--formatflag to display the output in either JSON or YAML. by @r-vasquez in #24387- controlling Iceberg translation backlog by @mmaslankaprv in #24990
- kafka/server: Remove throughput throttling v1 by @BenPope in #16823
- rpk improvements in
rpk cluster health: rpk now exits with code 10 if the cluster is unhealthy; added support of--formatto the command and added the cluster UUID to the commands' output. by @r-vasquez in #25213 - rpk now supports well-known protobuf types when encoding/decoding records using Schema Registry. by @r-vasquez in #24480
- rpk: save the output of
uptimeto bare-metal debug bundles created through rpk. by @r-vasquez in #24686 - schema_registry/protobuf: Rewrite protobuf normalization to improve compatibility with Java client by @BenPope in #25094
- stable leadership under load by @mmaslankaprv in #24590
None
No release notes explicitly specified.
-
PR #10256 tests/many_clients: run many clients test with idempotent producers by @mmaslankaprv
-
PR #13409 Update config doc for partition limits by @travisdowns
-
PR #17631 Add write caching to OMB validation tests by @ballard26
-
PR #21324 Fixed race condition in
disk_log_impl::truncate_prefixby @mmaslankaprv -
PR #22632 Improved Raft replicate backpressure handling by @mmaslankaprv
-
PR #23105 Completely retire creating raft configurations with
model::brokerby @mmaslankaprv -
PR #23284 [rptest] clean up ConfigProfileVerifyTest by @clee
-
PR #23398 tests/gtest_raft_rpunit: monitor_test_fixture to honour leadership changes by @bashtanov
-
PR #23878 Add storage_e2e_single_threaded test in bazel by @travisdowns
-
PR #23919 ct: Add
write_pipelineandthrottlercomponents by @Lazin -
PR #23960 ct: dl_stm mvcc snapshot by @nvartolomei
-
PR #24055 Feature cleanup by @bashtanov
-
PR #24109 kafka: backfill kafka client fixture tests by @dotnwat
-
PR #24112 Fix race between bootstrap and shutdown by @bashtanov
-
PR #24116 [rptest] Auto-retry in RedpandaInstaller._avail_for_download by @clee
-
PR #24129 Datalake
data_writerinterface refactoring by @mmaslankaprv -
PR #24134 rpk: add Redpanda Cloud support to
rpk cluster storagemount/unmount commands by @r-vasquez -
PR #24136 Added ability to use datalake with
serde::parquetby @mmaslankaprv -
PR #24139 rptest: validate the shape of node_config_overrides by @nvartolomei
-
PR #24142 Save and show creation and completion time in migrations by @bashtanov
-
PR #24145
storage: addtombstones_removedmetric toprobeby @WillemKauf -
PR #24154 datalake: manage protobuf descriptor lifetimes correctly by @ballard26
-
PR #24155 Add
record_multiplexermicrobenchmarks by @ballard26 -
PR #24156 license: Reduced evaluation period to 30 days by @michael-redpanda
-
PR #24157 gh: Updated PR template for v24.3.x backports by @michael-redpanda
-
PR #24158 [CORE-8245] dt/license: fix expected license response in fips by @pgellert
-
PR #24159 [CORE-7961] rptest: Add ducktape test for partition movement in RRR cluster by @Lazin
-
PR #24160 Iceberg:
drop_tableimplementation for REST catalog by @ztlpn -
PR #24163 bazel: add crypto unit test key_tests by @IoannisRP
-
PR #24165 [rptest] More verbose _async_download_on_node_unlocked by @clee
-
PR #24169 raft/tests: fix a race condition in raft_fixture by @bashtanov
-
PR #24175 datalake: cleanup schema registry error handling by @andrwng
-
PR #24177 Bazelize ssx tests by @IoannisRP
-
PR #24178 rptest: datalake azure support by @nvartolomei
-
PR #24179 Datalake in Random Node Operations test by @mmaslankaprv
-
PR #24180 tm_stm: fixed use after move in tm_stm by @mmaslankaprv
-
PR #24184 rpc: Change max internal rpc connection count limit by @StephanDollberg
-
PR #24188 rptest: tolerate redpanda not running during when using bg failure injector by @nvartolomei
-
PR #24189 cst/cache: fix use-after-move caused by calling get_exception twice by @nvartolomei
-
PR #24193 Avoid some oversized allocs at high partition density by @StephanDollberg
-
PR #24194 rptest: do not compare disk_free_bytes with cache_disk_free bytes by @nvartolomei
-
PR #24197 tests: removed not required node configuration override by @mmaslankaprv
-
PR #24210 [CORE-8010] cluster: Fix race condition in the
archival_metadata_stmby @Lazin -
PR #24212 Use Redpanda implementation of Parquet by default by @mmaslankaprv
-
PR #24213 rptest/s: use abfss (secure) scheme for iceberg catalog by @nvartolomei
-
PR #24220 datalake: split record translator into distinct modes by @andrwng
-
PR #24222 datalake/configs: rework iceberg enablement configs by @bharathv
-
PR #24225 iceberg: couple miscellaneous fixes found in prolonged testing by @andrwng
-
PR #24226 Support TLS in datalake rest catalog by @mmaslankaprv
-
PR #24228 serde/parquet: support creating multiple row groups by @rockwotj
-
PR #24231 bazel/version: remove version.cc as a runfile by @rockwotj
-
PR #24233 CONTRIBUTING.md: allow longer commit subject lines by @bashtanov
-
PR #24236 Ik bazel tests serde by @IoannisRP
-
PR #24240 iceberg: azure support by @nvartolomei
-
PR #24245 [CORE-8249] Allow more time for segment clean up by @dotnwat
-
PR #24249 k/test: Addition for dry create_topics dry run by @oleiman
-
PR #24253 reflection: bazelize tests by @IoannisRP
-
PR #24258 Redpanda Connect in ducktape by @mmaslankaprv
-
PR #24261 [CORE 8273] Adjust license warning text to include trial license links by @BenPope
-
PR #24263 bazel: Update hwloc to 2.11.2 by @StephanDollberg
-
PR #24264 rpk: license warning text changes. by @r-vasquez
-
PR #24265 [CORE-7257] cloud_storage: Remove assertion in
remote_segmentby @Lazin -
PR #24275 k/data: Add CMakeLists for record_batcher test by @oleiman
-
PR #24286 [CORE-8345] rptest: Disable fips in one of the upgrade tests by @Lazin
-
PR #24288 Misc fixes for Datalake data path by @mmaslankaprv
-
PR #24290 Iceberg Verifier by @mmaslankaprv
-
PR #24296 rpk: improve error messages in security/acl by @r-vasquez
-
PR #24297 ducktape: fix download of redpanda-data/ocsf-schema by @andrewhsu
-
PR #24298 datalake: gcs support by @nvartolomei
-
PR #24299 iceberg: add simple drop_table support for filesystem_catalog by @ztlpn
-
PR #24304 ducktape: follow-up fix download of redpanda-data/ocsf-schema by @andrewhsu
-
PR #24306 Fixed race condition between appends and prefix truncation by @mmaslankaprv
-
PR #24310 serde: bazelize serde/bench by @IoannisRP
-
PR #24311 raft/tests: adjust memory requirements for raft reconfiguration test by @mmaslankaprv
-
PR #24315 d/coordinator: fixed possible iterator generation mismatch by @mmaslankaprv
-
PR #24319 rptest/s: apache iceberg rest catalog with fs mode on gcp by @nvartolomei
-
PR #24320 bytes: bazelize iobuf_fuzz by @IoannisRP
-
PR #24326 config: remove the meta tag for iceberg_delete by @Deflaimun
-
PR #24334 tests/docker: increase cargo retry and verbosity by @andrewhsu
-
PR #24336 c/balancer_planner: check if topic exists in node count map by @mmaslankaprv
-
PR #24337 cmake: remove duplicate arguments as these are implict for bench by @nvartolomei
-
PR #24340 CORE-8290 dt/redpanda: increase expect_fail timeout to 40s by @pgellert
-
PR #24341 [CORE-6936] archival: Handle nested shutdown errors by @Lazin
-
PR #24343 bazel: Updated Seastar commit by @michael-redpanda
-
PR #24344 [CORE-8249] Shutdown http/client promptly on scrubber exit by @dotnwat
-
PR #24351 storage: bazelize some tests by @IoannisRP
-
PR #24354 bazel: add layering check in redpanda_test_cc_library by @IoannisRP
-
PR #24358 c/controller_backend: allow
shutdown_partitionto fail on app shutdown by @bashtanov -
PR #24362 dt/rbac_upgrade: pin upgraded version to 24.1 by @pgellert
-
PR #24366 model: bazelize some tests by @IoannisRP
-
PR #24368 config: Remove reference to
kafka_throughput_throttling_v2by @BenPope -
PR #24373 bazel: Enable LTO for redpanda by @StephanDollberg
-
PR #24375 tests: added missing timeout setting in partition reconfiguration test by @mmaslankaprv
-
PR #24376 feature_table: Add v25.1 version by @StephanDollberg
-
PR #24377 tests: wrapped querying high watermark with exception handler by @mmaslankaprv
-
PR #24379 tests: made fast partition movement test a bit more tolerant by @mmaslankaprv
-
PR #24384 rpc: bazelize some tests by @IoannisRP
-
PR #24386 [CORE-8338]
rptest: addtimeoutto_polaris_ready()check by @WillemKauf -
PR #24389 tests/connect: added timeout when checking if connect is started by @mmaslankaprv
-
PR #24393 rptest/s: continue waiting for manifest uploads after MaxRetryError by @nvartolomei
-
PR #24400 rpc: bazelize rpc_gen_cycling_test by @IoannisRP
-
PR #24401 rptest: await all replicas to recover before validation by @nvartolomei
-
PR #24402 datalake/tests: deflake max_translated_offset utility by @bharathv
-
PR #24404 raft/c: fix an indefinite hang in transfer leadership by @bharathv
-
PR #24406 datalake/tests: add a verifier test with cross core partition movements by @bharathv
-
PR #24409 cluster: exclude internal topics from check_cluster_limits by @pgellert
-
PR #24410 Made reconfiguration cancel in Raft symmetric by @mmaslankaprv
-
PR #24413 gha: use full major.minor.patch version ID by @ivotron
-
PR #24418 [CORE-8392] http: Shutdown connection if shutdown_now was called by @Lazin
-
PR #24419 Datalake OMB tests by @ballard26
-
PR #24420
rptest: deflakemax_translated_offset()by @WillemKauf -
PR #24422 Update OMB ducktape dep by @ballard26
-
PR #24426 dt/license_enforcement: delay disabling trial license by @pgellert
-
PR #24433 tests: add reasoning for skip fips mode by @dotnwat
-
PR #24434 archival: calculate time based retention from first addressable segment by @nvartolomei
-
PR #24435 [CORE-8081] rptest: fix config_profile_verify_test null handling by @andrwng
-
PR #24447 Migrations check license by @bashtanov
-
PR #24450 Handling missing features in snapshot by @bashtanov
-
PR #24460 [CORE-8278]
rptest: adjustnum_segments_deleted()condition by @WillemKauf -
PR #24464 [CORE-6933]
rptest: deflakesi_utilsassertion functions by @WillemKauf -
PR #24465 datalake/tests: test with transactions by @bharathv
-
PR #24470 Removed Arrow and Parquet libraries dependency by @mmaslankaprv
-
PR #24473 bazel: Updated seastar ref by @michael-redpanda
-
PR #24474 tests/setup: update ducktape to 0.12 by @gousteris
-
PR #24476 c/partition_recovery_manager: avoid oversized allocations when logging by @bashtanov
-
PR #24477 change the
consensus::replicatemethod to acceptchunked_vectorby @mmaslankaprv -
PR #24482 gha: use setup-python v5 by @andrewhsu
-
PR #24489 test: redirect boost test output under bazel by @travisdowns
-
PR #24490 rm_stm/tests: add a stress test for concurrent eviction / replication / snapshots by @bharathv
-
PR #24494 Half chunk cache memory reservations by @StephanDollberg
-
PR #24495 [rptest] Use "redpanda" namespace for KubeNodeShell by @clee
-
PR #24497 rpk: update help description to match docs by @Deflaimun
-
PR #24498 bazel: update target for openssl executable by @IoannisRP
-
PR #24501 [rptest] Fix "ContainerAlreadyExists" in test_recovery_mode by @clee
-
PR #24502
rptest: use properWriteCachingModestring for parameterization by @WillemKauf -
PR #24503 Cache parsed schemas in datalake by @ballard26
-
PR #24506 storage: Reduce default read-ahead count by @StephanDollberg
-
PR #24507 Re-add partition manifest logging by @bashtanov
-
PR #24508 Decommission status improvement by @mmaslankaprv
-
PR #24509 base: Rename assert-unreachable logger to assert by @Lazin
-
PR #24510 Updated minio by @mmaslankaprv
-
PR #24511
rptest: make check forNoneexplicit by @WillemKauf -
PR #24512
storage: log on clampedsegment.msvalue by @WillemKauf -
PR #24513 [rptest] RedpandaInstaller async download rework by @clee
-
PR #24514 Add a general key-value cache to utils by @ballard26
-
PR #24518 gha: add permissions for jira_issue_manage to write issue by @andrewhsu
-
PR #24521 raft/tests/reconfiguration: allow more memory by @bashtanov
-
PR #24522 [CORE-8485] Reset translation state on snapshot by @mmaslankaprv
-
PR #24523 Using newer client versions in Ducktape tests by @mmaslankaprv
-
PR #24529 tests: reduce logging in random_node_operations_test by @mmaslankaprv
-
PR #24534 cloud_io: Treat 'unknown' backend as a valid case by @Lazin
-
PR #24544
config: disable bounded property checks with environment variable by @WillemKauf -
PR #24550
rptest: fixcloud_storage_typeparameterization inrandom_node_operations_test.pyby @WillemKauf -
PR #24551 bazel: Enable SEASTAR_DEBUG_SHARED_PTR in debug by @StephanDollberg
-
PR #24553 r/buffered_protocol: added a missing call to setup metrics by @mmaslankaprv
-
PR #24558
rptest: bumpkgo-verifierversion by @WillemKauf -
PR #24564 pandaproxy: add missing internal metrics by @IoannisRP
-
PR #24569 rpk remote debug bundle: job-id help text change by @r-vasquez
-
PR #24571
rptest: fixrandom_node_operations_testparameterization by @WillemKauf -
PR #24574 [CORE-NNNN] archival: Use read-write fence in the ntp_archiver by @Lazin
-
PR #24578 Some oversized alloc high partition count improvements by @StephanDollberg
-
PR #24579 omb: Limit cloud read throughput in TS read test by @StephanDollberg
-
PR #24580 [CORE-627] archival: Convert assertion to exception by @Lazin
-
PR #24581 fmt: remove formatter workaround for old fmt by @travisdowns
-
PR #24582 kafka/client: replace std::vector with chunked vector by @IoannisRP
-
PR #24583 tests/polaris: use curl to query polaris catalog health check by @mmaslankaprv
-
PR #24586 config: bazelize unit tests by @IoannisRP
-
PR #24596 bazel: add compile commands generator by @rockwotj
-
PR #24597 pandaproxy: bazelize tests by @IoannisRP
-
PR #24601 c/leader_balancer: improve log message wording by @ztlpn
-
PR #24607 Offset translator consistency validation by @mmaslankaprv
-
PR #24613 rpk: update topic describe help text by @Deflaimun
-
PR #24614 rptest/s: always cleanup azurite containers to avoid slowdown by @nvartolomei
-
PR #24617 Validate offset delta in append entries handler by @mmaslankaprv
-
PR #24622 rptest: disable leader balancer in cache stress test by @nvartolomei
-
PR #24626 [CORE-8742] archival: Add replica validator by @Lazin
-
PR #24631 cst/cache: ubsan fix, fix highly unlikely full cache trim if free disk info is delayed, more tests by @nvartolomei
-
PR #24632 admin: document query params for /v1/cloud_storage/cache/trim by @nvartolomei
-
PR #24636
storage: compaction alignment test by @WillemKauf -
PR #24641 Abort translation using translation task abort source by @mmaslankaprv
-
PR #24642 ducktape: Respect rpk timeout in rpk by @StephanDollberg
-
PR #24643 rptest/datalake: test metadata interoperability with 3rd party system by @nvartolomei
-
PR #24653 bazel: Update seastar by @StephanDollberg
-
PR #24656 ducktape: Verify using consumer groups in the MPT by @StephanDollberg
-
PR #24657 pandaproxy/sr: bazelize compatibility_protobuf test by @IoannisRP
-
PR #24661 tests/datalake: deflake partition_movement_test by @bharathv
-
PR #24663 ducktape: Fix TS reader stress test by @StephanDollberg
-
PR #24670 tests/migrations: allow for node clock discrepancies by @bashtanov
-
PR #24675 rpk bundle: Fix race condition in SASL credential redaction by @r-vasquez
-
PR #24676 [CORE-8525] - Iceberg schema evolution by @oleiman
-
PR #24679 CORE-6963 wait for all the topics to be created by @mmaslankaprv
-
PR #24683 rptest/s: support logger level overrides when running mixed version by @nvartolomei
-
PR #24687 c/rm_stm: correct error codes by @bashtanov
-
PR #24696 CORE-2701 Quotas: use kafka quotas in tests by @pgellert
-
PR #24698 Iceberg custom partitioning: translation path by @ztlpn
-
PR #24709 c/migration/table: when applying a snapshot update completed timestamp by @bashtanov
-
PR #24710 ducktape: Increase partition density to 3k per shard in the MPT by @StephanDollberg
-
PR #24716 Replace
get0withgetby @ballard26 -
PR #24720 tools/dev_cluster: default data directory to repo root by @rockwotj
-
PR #24721 tests/setup: bump ducktape version to log node IPs by @bashtanov
-
PR #24723 Fix some oversized allocs during topic operations by @StephanDollberg
-
PR #24724 dt: Double consumer count in test_max_partition by @StephanDollberg
-
PR #24745 bazel: extend ca certificate duration by @IoannisRP
-
PR #24751 licenses: update go deps used in RPK by @r-vasquez
-
PR #24753 dt: Increase message size in MPT TS warmup by @StephanDollberg
-
PR #24755 bazel: bump buildifier by @andrewhsu
-
PR #24756 bazel: fix bazel lock update by @andrewhsu
-
PR #24760 rpk: add
rpk generate licenseby @r-vasquez -
PR #24761 c/topic_table: notify ntp delta waiters in batches by @ztlpn
-
PR #24767 iceberg: action for removing snapshots from table metadata by @andrwng
-
PR #24771 Partition
replicateAPI changes, follow up by @mmaslankaprv -
PR #24772 [CORE-8654] Add flag to re-enable TLS client renegotiation by @michael-redpanda
-
PR #24774 Use
chunked_vectorinappend_entries_requestby @mmaslankaprv -
PR #24775 protobuf: move proto files to schema/protobuf by @IoannisRP
-
PR #24776 [CORE-8450] schema_registry: Normalization improvements by @BenPope
-
PR #24777 Update seastar bazel repository to v25.1.x by @ballard26
-
PR #24779 Measure entire produce path in microbenchmark by @ballard26
-
PR #24781 kafka: return log offests for ooor error by @nvartolomei
-
PR #24788 rpk/connect: print download message to stderr by @rockwotj
-
PR #24792 bazel: simplify btest/gtest split targets by @IoannisRP
-
PR #24793 Datalake: introduce unresolved partition spec and set it from coordinator by @ztlpn
-
PR #24794 [CORE-8450] schema_registry/protobuf: Optimize construction of iobuf by @BenPope
-
PR #24795 Bumping replicas timeout for Operator v1 back as it was before by @rpdevmp
-
PR #24797 rpk: improve error message when mount/unmount ID is not found by @daisukebe
-
PR #24798 rm_stm: improved logging related to producer eviction by @bharathv
-
PR #24801 datalake: refactor schema manager to use table in public interface by @nvartolomei
-
PR #24802 kafka/server|hashing: bazelize benchmarks by @IoannisRP
-
PR #24804 bazel: rename benchmarks to match CMake by @rockwotj
-
PR #24807 rpk: modify CODEOWNER by @r-vasquez
-
PR #24811 Fix
finishmethod intest_serde_parquet_data_writerby @ballard26 -
PR #24814 datalake: extract table_id_provider as static method by @nvartolomei
-
PR #24816 bazel: updated module.lock file by @mmaslankaprv
-
PR #24818 iceberg: correctly set purge requested param by @nvartolomei
-
PR #24821 cloud_storage: Improve logging in the partition_manifest by @Lazin
-
PR #24822 gha/clang-format: don't update lockfile by @rockwotj
-
PR #24824 datalake: on demand dlq table creation by @nvartolomei
-
PR #24828 CORE-8617 crash_tracker: prepare a new module for development by @pgellert
-
PR #24830 licenses: update rpk third party code list by @rockwotj
-
PR #24831 rptests/datalake: update test to use logical types by @andrwng
-
PR #24833 r/stm_manager: stop state machines before waiting for gate by @mmaslankaprv
-
PR #24837 Fix partitions local summary by @bashtanov
-
PR #24839 Buffered protocol changes by @mmaslankaprv
-
PR #24848 tx/ducktape: breakup transactions_test.py monolith by @bharathv
-
PR #24854 CORE-8618 crash_tracker: record uncaught startup exceptions by @pgellert
-
PR #24855 datalake/coordinator: introduce table_commit_builder by @nvartolomei
-
PR #24856 pandaproxy/sr: Fix normalized rendering for custom options by @IoannisRP
-
PR #24857 tests/partition_reassignment: tmp disable test_reassignments_kafka_cli by @bashtanov
-
PR #24858 ducktape: rename basic_kafka_compat_tests.py by @bharathv
-
PR #24863 Adding error handling for get nodes or instances by @rpdevmp
-
PR #24864 Small improvements in Raft by @mmaslankaprv
-
PR #24865 kafka: Add batch size histogram by @StephanDollberg
-
PR #24877 [UX-33] rpk: migrate login + profile creation flow to the Public API. by @r-vasquez
-
PR #24880 storage: fix bounds check in offset range size method by @andrwng
-
PR #24882 tests: enable datalake trace logs in RandomNodeOperationsTest by @mmaslankaprv
-
PR #24883 CORE-8619 crash_tracker: print recorded crash reports by @pgellert
-
PR #24884 Introduced separate scheduling group for produce by @mmaslankaprv
-
PR #24886 dt: Actually set resource limits in OMB MPT by @StephanDollberg
-
PR #24888 r/apppend_entries_buf: run flush in raft scheduling group by @mmaslankaprv
-
PR #24889 pandaproxy/sr: Add rendering support for extension range options by @IoannisRP
-
PR #24890 cluster: Make partition creation refusal more clear by @StephanDollberg
-
PR #24891 CORE-8804 Make brokers field no longer required by @michael-redpanda
-
PR #24895 tests/partition_reassignments_test/verification: process 3.9.0 output by @bashtanov
-
PR #24896 config: Enabling SASL PLAIN requires SCRAM by @michael-redpanda
-
PR #24898 datalake: add redpanda.iceberg.invalid.record.action topic property by @nvartolomei
-
PR #24912 archival: Remove alternative upload code-path by @Lazin
-
PR #24921 dl/translation/scheduling: API for scheduling translations by @bharathv
-
PR #24922 bazel: extract test_utils:logs from test_utils by @nvartolomei
-
PR #24925 r/buffered_protocol: disable buffering in raft buffered protocol by @mmaslankaprv
-
PR #24926 r/tests: do not rely on timeouts in truncation detection test by @mmaslankaprv
-
PR #24929 [CORE-8870] Provide more UUID information by @michael-redpanda
-
PR #24930 pandaproxy/sr: Fix issues discovered in the protobuf renderer followup by @IoannisRP
-
PR #24934 Update CODEOWNERS by @Deflaimun
-
PR #24945 cloud_storage: Move s3_imposter to cloud_io by @Lazin
-
PR #24946 Update and enable large_messages_test (LMT) by @travisdowns
-
PR #24947
rptest: addnessiecatalog and smoke testing by @WillemKauf -
PR #24949 bump ducktape version to print exception stack trace on load error by @bashtanov
-
PR #24953 iceberg_topics: use Redpanda Community License by @andrwng
-
PR #24955 [CORE-8530] Handle out-of-sync producers by writing records to past-schema parquet by @oleiman
-
PR #24959 CORE-8685 crash_tracker: crash signal handlers for crash recording by @pgellert
-
PR #24961 CORE-8937 admin: swagger docs for patch cluster config body by @pgellert
-
PR #24966 datalake: assign field ids to dlq record type by @nvartolomei
-
PR #24970 bazel: Update krb5 by @StephanDollberg
-
PR #24971 cluster: Also track batches produced by @StephanDollberg
-
PR #24972 CORE-8686 crash_tracker: remove old crash files by @pgellert
-
PR #24973 Process kafka requests in a separate scheduling group by @mmaslankaprv
-
PR #24976 raft: dispatch heartbeats in dedicated scheduling group by @mmaslankaprv
-
PR #24977 kafka/server: add metrics and config for consumer lag reporting by @IoannisRP
-
PR #24978 [CORE-8690]: Update offline log viewer to be able to parse crash reports by @michael-redpanda
-
PR #24979 tests/node_operations: enable cloud_storage debug logs by @mmaslankaprv
-
PR #24981 Updating search filter based on new naming conventions by @rpdevmp
-
PR #24983 ducktape: handle SIGABORT in Redpanda by @travisdowns
-
PR #24986
config: addiceberg_rest_catalog_authentication_modeby @WillemKauf -
PR #24987
config: removeshard_local_cfgchecks fortombstone_retention_msvalidator by @WillemKauf -
PR #24989 bazel/test: use RP_FIXTURE_ENV=1 for all unit tests by @bashtanov
-
PR #24992 pandaproxy/sr: protobuf rendering: refactor string rendering by @IoannisRP
-
PR #24997 parquet: support multiple pages in a column per row group by @rockwotj
-
PR #24998 CORE-8964 Add protobuf support to existing ducktape suite for schema evolution. by @oleiman
-
PR #25004 bazel: build seastar in debug mode by default by @nvartolomei
-
PR #25005 k/fetch: fix selecting replica with highest high watermark by @mmaslankaprv
-
PR #25006 Produce request cleanup by @mmaslankaprv
-
PR #25016 dl/translation: scheduling policy for translation lag by @bharathv
-
PR #25017 ci: add redpanda version in promote trigger by @gousteris
-
PR #25021 crash_tracker: reduce size of crash_description by @pgellert
-
PR #25023 k/server/test: reduce quota manager bench reqs by @pgellert
-
PR #25031 io: update interval tests and add bazel coverage helper by @dotnwat
-
PR #25035 raft/tests: deflake truncation_detection_test by @bharathv
-
PR #25036 rptest/simple_connect_test: refactor out mount/unmount tests by @andrwng
-
PR #25038 dl/coordinator: add tag to redpanda commits by @andrwng
-
PR #25039 Throttle requests if the translation backlog hits the limit by @mmaslankaprv
-
PR #25040 CORE-9028 crash_tracker: test no allocs in
record_crash_sighandlerby @pgellert -
PR #25047 rptest/datalake_dlq_test: fix unintentional filesystem catalog by @andrwng
-
PR #25051 CORE-8687 Track vassert messages for crash log by @michael-redpanda
-
PR #25052 [CORE-8949] Incorporate datalake into space management accounting by @dotnwat
-
PR #25053 iobuf: replace boost::intrusive_list with hand rolled implementation by @rockwotj
-
PR #25054 crash_tracker: add shared object name to stacktrace by @pgellert
-
PR #25058 [CORE-9064]
rptest: add credentials type check inNessieServiceby @WillemKauf -
PR #25059 Overriding executable
rpathwith patchelf by @mmaslankaprv -
PR #25062 datalake: metric for invalid records by @nvartolomei
-
PR #25063 bazel: use relative paths for debug symbols by @rockwotj
-
PR #25064 cloud_storage_clients: skip lexical_cast on empty strings by @nvartolomei
-
PR #25065 bazel: bump remote_partition_fuzz_test timeout by @nvartolomei
-
PR #25066 rpk/chore: Bump Go dependencies. by @r-vasquez
-
PR #25069 Fix iceberg data migration test timeout by @bashtanov
-
PR #25071 iceberg: serialize snapshot removals individually by @andrwng
-
PR #25072 kafka-probe: remove latency label on batch_size by @travisdowns
-
PR #25073 Fixing check azure instances output parsing by @rpdevmp
-
PR #25075 [CORE-8848]
rptest: adjust compaction settings indatalake/compaction_testby @WillemKauf -
PR #25076
storage: fixes for book keeping ofdirtyandclosedbytes by @WillemKauf -
PR #25080 pandaproxy/sr: Improve schema lookup by @IoannisRP
-
PR #25090 [CORE-8990]
storage: usesegment_closed_exceptionin compaction utils by @WillemKauf -
PR #25093 Added directory mode package for ducktape by @mmaslankaprv
-
PR #25095 Iceberg: adapt
merge_append_actionto schema evolution and multiple partition specs by @ztlpn -
PR #25105 config: add gets_restored tag to properties by @andrwng
-
PR #25109 tests: prettier ducktape reports by @nvartolomei
-
PR #25111
rptest: useRedpandaVersionTripleinjava_compression_test.pyby @WillemKauf -
PR #25114 [CORE-8532] Disallow certain schema evolution actions if a field appears in the partition spec by @oleiman
-
PR #25116 datalake: invalid record action metrics followup by @nvartolomei
-
PR #25117 dt: disable core dumps in crash tracker tests by @pgellert
-
PR #25118 iceberg: make snapshot expiration an explicit 64-bit by @andrwng
-
PR #25120 bazel: rebuild clang and fix sanitizers by @rockwotj
-
PR #25121 debug bundle: use common file io utility by @dotnwat
-
PR #25122 storage: use inheritence for compacted index writer by @dotnwat
-
PR #25126 [CORE-8933] Setup for translation scheduling port by @oleiman
-
PR #25127
rptest: fix race incompaction_recovery_test.pyby @WillemKauf -
PR #25130 CORE-8695 crash_tracker: implement crash report upload markers by @pgellert
-
PR #25132 bazel: Update zstd to 1.5.7 by @StephanDollberg
-
PR #25133
ssx: movewatchdogintossxnamespace by @WillemKauf -
PR #25139 datalake/coordinator: consider cluster UUID to deduplicate files by @andrwng
-
PR #25143
rptest: setAPPLICATION_GLOBALprovider forAWSinnessie_catalogby @WillemKauf -
PR #25144 Partition field source columns should be primitive typed by @oleiman
-
PR #25145 datalake: introduced function converting partition key to path by @mmaslankaprv
-
PR #25148 kafka/server: fix case of use after move by @IoannisRP
-
PR #25150 Raft tests cleanup by @mmaslankaprv
-
PR #25151 rpk: use
runtime.GO*information instead of injecting it by @rockwotj -
PR #25152 [CORE-8933] - Port partition_translator into scheduler interface by @oleiman
-
PR #25153
storage: adddisk_log_impl::reset_dirty_and_closed_bytes()by @WillemKauf -
PR #25157 [CORE-9154]
rptest: adjust timeouts injava_compression_test.pyby @WillemKauf -
PR #25158 rpk: only include tuner package files in linux builds by @r-vasquez
-
PR #25165
rptest: correct authentication property name innessieby @WillemKauf -
PR #25166 [CORE-9167] Refactored Raft protocol scheduling groups by @mmaslankaprv
-
PR #25167 gha/rpk-build: test and build multi os and arch by @andrewhsu
-
PR #25168 http/utils: changed url encoding to use upper case hex representation by @mmaslankaprv
-
PR #25169 Include partition key in the Iceberg data file location by @mmaslankaprv
-
PR #25170 [rptest] Add rpk_cloud_logout to CloudClusterUtils by @clee
-
PR #25177 rptest: datalake catalogs spring cleanup by @nvartolomei
-
PR #25181 Adding try and log message with pod details to better handle missing nodeName in the spec by @rpdevmp
-
PR #25186 rptest: unique cloud diagnostics archive per run with deflake by @nvartolomei
-
PR #25187 bazel: update markupsafe to 2.1.5 by @travisdowns
-
PR #25189 bazel: add utility binaries to packaging by @rockwotj
-
PR #25195
rptest: setAPPLICATION_DEFAULTprovider forGCPinnessie_catalogby @WillemKauf -
PR #25199 dl/coordinator: implement service method for creating DLQ table by @andrwng
-
PR #25201 rpc: abstract service base by @nvartolomei
-
PR #25202 CORE-8694 Implement rate limiting crash report telemetry by @pgellert
-
PR #25203 CORE-9231 Add
redpanda_version()into crash reports and telemetry by @pgellert -
PR #25204 bazel: remove seastar fortify patch by @travisdowns
-
PR #25205
storage: addLogCompactionSchedulingTest::dirty_ratio_scheduling_testducktape test by @WillemKauf -
PR #25207 gha/promote: fix trigger promote action by @andrewhsu
-
PR #25218 CORE-7595 security/tests: bazel build for ocsf_schemas_test.cc by @pgellert
-
PR #25221 CORE-8688: Tracking OOM's in crash tracker by @michael-redpanda
-
PR #25222 iceberg/rest_client: don't throw shutdown exceptions by @andrwng
-
PR #25224 [CORE-9204] admin: Make v1/features/license public by @oleiman
-
PR #25225 [DEVPROD-1912]
rptest: add retry inget_high_watermarks()by @WillemKauf -
PR #25226 Partition spec parser improvements by @bashtanov
-
PR #25227 [CORE-9153] [CORE-9154] [CORE-9155]
rptest: deflakejava_compression_test.pyby @WillemKauf -
PR #25228 kafka: validator for Iceberg topics and read replicas by @andrwng
-
PR #25229 dl/coordinator: property to disable snapshot expiry by @andrwng
-
PR #25230 dl/coordinator: property to disable snapshot tags by @andrwng
-
PR #25231 [CORE-9218]
storage: reducedirty_and_closed_bytes_bookkeeping::num_operationsby @WillemKauf -
PR #25232 [CORE-9244]
rptest: deflakedatalake/compaction_test.pyby @WillemKauf -
PR #25233 dl/dt: Add rest catalo to schema_evolution_test.py by @oleiman
-
PR #25234 tests/java/iceberg-rest-catalog: add .gradle to .gitignore by @bashtanov
-
PR #25237 bazel: add consumer_groups_test, segment_meta_cstore_fuzz_rpfixture, security_test by @pgellert
-
PR #25238 [CORE-9072] [CORE-9137]
rptest: deflakelog_compaction_testby @WillemKauf -
PR #25239
rptest: addnessieend to enddatalaketesting by @WillemKauf -
PR #25240 CORE-7598 serde/test: bazel for serde_fuzz_test by @pgellert
-
PR #25241
storage: check ifseg->is_closed()in self compaction locations before removing bytes by @WillemKauf -
PR #25243 Pre restart probe fixup by @bashtanov
-
PR #25245 base/vassert: type-erase assert handling by @travisdowns
-
PR #25246 bazel/toolchain: fix llvm 18 toolcahin by @rockwotj
-
PR #25247 rptest: fix rpk error Bearer token is invalid by @andrewhsu
-
PR #25248 dl/coordinator: only load tables with pending state by @andrwng
-
PR #25249 dl/coordinator: remove expired snapshots from DLQ table by @andrwng
-
PR #25253 dl/translation: add jitter to partition_translator by @andrwng
-
PR #25255 datalake/translator: followups to #5152 by @bharathv
-
PR #25256 rpk: set User Agent in public API requests. by @r-vasquez
-
PR #25258 schema: make get API used by Iceberg more robust by @andrwng
-
PR #25259
rptest: add ABS endpoint tonessiecredentials by @WillemKauf -
PR #25260 pandaproxy/sr: Fix normalization not being applied on stored schemas by @IoannisRP
-
PR #25261 ssx/async_algorithm: trust caller to keep the container alive themselves by @bashtanov
-
PR #25262 bazel: support microsoft fips compiler by @rockwotj
-
PR #25264 ice/compat: Remove support for date -> timestamp promotion by @oleiman
-
PR #25265 crash_tracker: fix helper for clang-20 by @pgellert
-
PR #25271
storage: performgc()everylog_compaction_interval_msby @WillemKauf -
PR #25272 bazel/packaging: rename binaries by @andrewhsu
-
PR #25273 iceberg/rest_client: catch exception in retry() attempt by @andrwng
-
PR #25277 [bazel] use bazelisk-linux-$TARGETARCH in dockerfile by @clee
-
PR #25278 k/topic_utils: do not iterate over the assignments set by @mmaslankaprv
-
PR #25281 Added Iceberg time transforms by @mmaslankaprv
-
PR #25282 bazel/sesatar: remove the libnuma patch by @travisdowns
-
PR #25285 rptest: rework redpanda installer concurrency and logging by @nvartolomei
-
PR #25288 iceberg/filesystem_catalog: create table with initialized snapshots by @andrwng
-
PR #25289 rptest: update test parametrization to have stable test ids by @nvartolomei
-
PR #25290 rpk: add cloud_environment to profile by @r-vasquez
-
PR #25297
storage: makedisk_log_impl::request_eviction_until_offset()synchronous by @WillemKauf -
PR #25304 CORE-9383 crash_tracker: minor improvements and cleanup by @pgellert
-
PR #25305 Exposing translation status from partition translator by @mmaslankaprv
-
PR #25306 tests/setup: update ducktape ref by @gousteris
-
PR #25307 datalake: shutdown datalake managers before stopping partitions by @mmaslankaprv
-
PR #25308 rptest: refresh gcp tokens when they expire by @nvartolomei
-
PR #25309 [CORE-9036]
archival: fix invalid iterator dereference inretention_calculatorby @WillemKauf -
PR #25310 dl/translator: add batching to translator by @bharathv
-
PR #25311 rpc_compiler slimming by @travisdowns
-
PR #25314 rpk: make CLI and cluster versions explicit by @daisukebe
-
PR #25315 Iceberg custom partitioning: spec evolution by @ztlpn
-
PR #25318 Pass in an abort source into replicate options by @mmaslankaprv
-
PR #25319
nessie: fixadlssettings by @WillemKauf -
PR #25320 cloud_storage: improve remote partition finalizer by @nvartolomei
-
PR #25321 rptest: do not warn on expected log lines by @nvartolomei
-
PR #25322 rptest: remove useless warning when running tests against abs by @nvartolomei
-
PR #25324 [CORE-9074]
cluster: removenode_health_reportlogging by @WillemKauf -
PR #25325 fair_scheduler: make shares maps a class member by @bharathv
-
PR #25327 rpk: bump dependencies to include security fixes by @r-vasquez
-
PR #25329 Follow up to recent raft changes allowing passing the abort source to replicate call by @mmaslankaprv
-
PR #25330 application: stop coordinator before translators by @andrwng
-
PR #25331 [CORE-8946] Improve logging in the retention_calc by @Lazin
-
PR #25332 pandaproxy/probe: Eliminate unnecessary members by @BenPope
-
PR #25335 rptest: fix flaky transaction test by @nvartolomei
-
PR #25342 Fixed URL encoding in Azure Blob Store client by @mmaslankaprv
-
PR #25343 dl/translation/tests: misc changes to tests by @bharathv
-
PR #25347 config: make minimum Iceberg commit interval 10s by @andrwng
-
PR #25348
datalake: callfinally()on reader in early return path by @WillemKauf -
PR #25349 rptest: kill redpanda if it fails to stop timely by @nvartolomei
-
PR #25350 rptest: memoize arch with a lock by @nvartolomei
-
PR #25353 Allow to get RPS/BPS per shard even with metric aggregation by @StephanDollberg
-
PR #25357 rptest: do not warn on expected log lines by @nvartolomei
-
PR #25358 rptest: correctly redirect boto logs by @nvartolomei
-
PR #25359 cpu_profiler test fixes by @travisdowns
-
PR #25361 Murmur3 iobuf by @bashtanov
-
PR #25363 dl/translation: simplify writer mem tracking by @bharathv
-
PR #25364 Bazilify resource_mgmt tests by @travisdowns
-
PR #25369 [CORE-9073]
rptest: deflakelog_compaction_testby @WillemKauf -
PR #25370 [CORE-9244]
rptest: deflakedatalake/compaction_test.pyby @WillemKauf -
PR #25372 datalake: benchmark zstd compressed batch translation by @ballard26
-
PR #25373 dl/parquet_writer: ensure stream closure in all cases by @bharathv
-
PR #25374 [CORE-9519] utils/arch: Fix compilation failure by @BenPope
-
PR #25376 [CORE-9520] schema_registry/protobuf: Add test for map field by @BenPope
-
PR #25382 [CORE-9524] Schema Registry/Protobuf: Remove protobuf_renderer config by @BenPope
-
PR #25387
rpk: adddatalakeandicebergloggers topossibleLoggersby @WillemKauf -
PR #25388 kafka/bench: make the fetch plan bench runnable in debug by @rockwotj
-
PR #25390 Use partition max collectible offset to gate FPM by @mmaslankaprv
-
PR #25392 [CORE-8946] cloud_storage: Update process_anomalies method by @Lazin
-
PR #25401 r/buffered_protocol: fixed potential uaf error in append_entries_queue by @mmaslankaprv
-
PR #25402 CORE-9546: disable libpci dep for hwloc by @travisdowns
-
PR #25404 Do not enable translation stm when datalake is disabled by @mmaslankaprv
-
PR #25405 r/stm_manager: do not populate batch cache when background apply happens by @mmaslankaprv
-
PR #25413
archival: uselog_level_for_error()infind_reupload_candidate()by @WillemKauf -
PR #25418 metrics: Export host metrics from Redpanda by @StephanDollberg
-
PR #25498 [v25.1.x] [backport] dl/translation: fixes for OOM handling #25423 by @bharathv
-
PR #25699 [v25.1.x] Manual backport of
rpk security secretsby @r-vasquez
Full Changelog: v24.3.1...v25.1.1