v25.1.1 #25734
piyushredpanda
announced in
Releases
v25.1.1
#25734
Replies: 0 comments
Sign up for free
to join this conversation on GitHub.
Already have an account?
Sign in to comment
-
Features
redpanda.iceberg.partition.spec
topic property. by @ztlpn in #24952~dlq
suffix. 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 #24980redpanda.<topic>~dlq
table. by @nvartolomei in #24893"PLAIN"
to thesasl_mechanisms
cluster configuration list by @michael-redpanda in #24525?normalize=true
for protobuf by @BenPope in #24719--format
inrpk cluster info
by @r-vasquez in #25223topic_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_partition
but 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 #24472startup_log
file andcrash_reports
directory if they are present in the data directory. by @r-vasquez in #24778rpk debug remote-bundle
to gather a debug bundle from a remote cluster. by @r-vasquez in #23986rpk group describe
now supports printing instance IDs by @daisukebe in #24881tls_certificate_name_format
can take two options:legacy
orrfc2253
. 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 #25312cloud_storage_enable_segment_uploads
that can be used to pause the Tiered Storage safely. by @Lazin in * Adds a newrpk topic analyze
command that determines information like batch rate and size for a given set of topics. by @ballard26 in #25164cloud_storage_enable_remote_allow_gaps
is added. If it's set toTrue
Redpanda is allowed to create gaps in the offset range when TS is paused. by @Lazin in #24871redpanda_cloud_storage_paused_archivers
which tracks number of partitions with paused segment uploads is added. by @Lazin in #24871redpanda.remote.allow_gaps
is added. If it's set toTrue
Redpanda is allowed to create gaps in the offset range when TS is paused. by @Lazin in #24871Bug Fixes
redpanda_cloud_storage_cloud_log_size
metric consistent across all replicas. We used to update it seldomly from the leader replica only which lead to inconsistent/stale values. by @nvartolomei in #24342members in the group. by @pgellert in #25270
snappy_java_compressor
headers to match that ofsnappy-java
by @WillemKauf in #25092vassert
. by @WillemKauf in #24483vassert()
. by @WillemKauf in #24635rpk
wasn't parsing--help
when used alongside--redpanda-id
inrpk cloud <provider> byoc apply
by @r-vasquez in #24369archival_metadata_stm
inconsistencies when reconfiguring clusters with recovered compacted topics. by @mmaslankaprv in #24664storage_disk_{total,free}_bytes
metric will report metrics for the data directory mountpoint and a newstorage_cache_disk_{total,free}_bytes
metric will report metrics for the cache directory mountpoint. Metrics will be equivalent if both are on the same mountpoint. by @nvartolomei in #24138vectorized_internal_rpc_produce_bad_create_time
metric has been removed. This metric was introduced in error and never had a value other than zero. by @travisdowns in #25341redpanda.remote.[read|write]
set totrue
when a license is expired or missing provided that the cluster configcloud_storage_enabled
is set tofalse
. by @michael-redpanda in #24570POST /subject/{subject}/version
where version was > INT_MAX or a negative value was provided. by @michael-redpanda in #24860rpk security user
commands. by @r-vasquez in #25371Improvements
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 #24787topic_partitions_reserve_shard0
cluster config is used and a user tries to create a topic with more partitions than the core-based partition limit. by @pgellert in #24378_segment_cleanly_compacted
metric tosegment::probe
._segments_marked_tombstone_free
metric tosegment::probe
._num_rounds_window_compaction
metric tosegment::probe
.dirty_segment_bytes
andclosed_segment_bytes
to the storage layer. by @WillemKauf in #24649log_compaction_adjacent_merge_self_compaction_count
, which allows for adjacent merge compaction to make more forward progress in all situations whenlog_compaction_use_sliding_window
is disabled. by @WillemKauf in #25119min_cleanable_dirty_ratio
by @WillemKauf in #24991/datalake-iceberg/
prefix. by @nvartolomei in #24960iceberg_target_lag_ms
topic property by @oleiman in #25056kafka
logger to a newkafka/authz
logger, allowing for fine grained control over log statements for failed authorization. by @rockwotj in #24712/v1/cluster/partitions
response. by @ztlpn in #24565rpk security user
is now available for users with Cloud profiles. by @r-vasquez in #24671rpk topic describe
now supports the--format
flag to display the output in either JSON or YAML. by @r-vasquez in #24387rpk cluster health
: rpk now exits with code 10 if the cluster is unhealthy; added support of--format
to the command and added the cluster UUID to the commands' output. by @r-vasquez in #25213uptime
to bare-metal debug bundles created through rpk. by @r-vasquez in #24686None
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_prefix
by @mmaslankaprvPR #22632 Improved Raft replicate backpressure handling by @mmaslankaprv
PR #23105 Completely retire creating raft configurations with
model::broker
by @mmaslankaprvPR #23277 [rptest] unbreak Azure T4/T5 tests by @clee
PR #23284 [rptest] clean up ConfigProfileVerifyTest by @clee
PR #23398 tests/gtest_raft_rpunit: monitor_test_fixture to honour leadership changes by @bashtanov
PR #23405 archival: Update ntp_archiver (pt.4) by @Lazin
PR #23580 [rptest] support opV2 in HTT by @clee
PR #23878 Add storage_e2e_single_threaded test in bazel by @travisdowns
PR #23919 ct: Add
write_pipeline
andthrottler
components by @LazinPR #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 #24110 fix "Unexpected EOF" log errors by @oleiman
PR #24112 Fix race between bootstrap and shutdown by @bashtanov
PR #24115 datalake: update system fields by @andrwng
PR #24116 [rptest] Auto-retry in RedpandaInstaller._avail_for_download by @clee
PR #24124 tools/cmake_test: Fix _find_addr2line by @BenPope
PR #24129 Datalake
data_writer
interface refactoring by @mmaslankaprvPR #24134 rpk: add Redpanda Cloud support to
rpk cluster storage
mount/unmount commands by @r-vasquezPR #24136 Added ability to use datalake with
serde::parquet
by @mmaslankaprvPR #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_removed
metric toprobe
by @WillemKaufPR #24147 parquet: add zstd compression by @rockwotj
PR #24151 kafka: add server bazel tests by @dotnwat
PR #24153 Bazelize some enterprise tests by @oleiman
PR #24154 datalake: manage protobuf descriptor lifetimes correctly by @ballard26
PR #24155 Add
record_multiplexer
microbenchmarks by @ballard26PR #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_table
implementation for REST catalog by @ztlpnPR #24161 cloud_storage: add bazel tests by @dotnwat
PR #24163 bazel: add crypto unit test key_tests by @IoannisRP
PR #24165 [rptest] More verbose _async_download_on_node_unlocked by @clee
PR #24168 rptest: Start stress fiber in any test by @Lazin
PR #24169 raft/tests: fix a race condition in raft_fixture by @bashtanov
PR #24174 datalake/coordinator: snapshots by @bharathv
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 #24183 sec: bazelize role_store_bench by @oleiman
PR #24184 rpc: Change max internal rpc connection count limit by @StephanDollberg
PR #24186 dt/config_test: Add OIDC_ALLOW_LIST by @oleiman
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 #24190 iceberg: create namespace on demand by @andrwng
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_stm
by @LazinPR #24212 Use Redpanda implementation of Parquet by default by @mmaslankaprv
PR #24213 rptest/s: use abfss (secure) scheme for iceberg catalog by @nvartolomei
PR #24219 crypto: Bazelize some tests by @oleiman
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 #24244 thirdparty: upgrade core golang deps by @rockwotj
PR #24245 [CORE-8249] Allow more time for segment clean up by @dotnwat
PR #24248 raft: add bazel tests 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_segment
by @LazinPR #24273 datalake: add missing bazel dep by @dotnwat
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 #24305 datalake/metrics: lag metrics by @bharathv
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 #24339 datalake: make purging table idempotent by @ztlpn
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 #24355 parquet: introduce stats collection by @rockwotj
PR #24358 c/controller_backend: allow
shutdown_partition
to fail on app shutdown by @bashtanovPR #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_v2
by @BenPopePR #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
: addtimeout
to_polaris_ready()
check by @WillemKaufPR #24388 serde: remove serde.h by @dotnwat
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 @WillemKaufPR #24422 Update OMB ducktape dep by @ballard26
PR #24425 add coverage configuration by @dotnwat
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 #24441 High priority alerts detection by @rpdevmp
PR #24442 bazel: Update protobuf to v29.0 by @BenPope
PR #24444 bazel: upgrade to c++23 by @rockwotj
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 @WillemKaufPR #24464 [CORE-6933]
rptest
: deflakesi_utils
assertion functions by @WillemKaufPR #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::replicate
method to acceptchunked_vector
by @mmaslankaprvPR #24482 gha: use setup-python v5 by @andrewhsu
PR #24487 bazel: patch protobuf warning by @dotnwat
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 properWriteCachingMode
string for parameterization by @WillemKaufPR #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 forNone
explicit by @WillemKaufPR #24512
storage
: log on clampedsegment.ms
value by @WillemKaufPR #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 #24535 http: Handle nested exception correctly by @Lazin
PR #24536 [rptest] Add Azure V3 machinetypes by @clee
PR #24544
config
: disable bounded property checks with environment variable by @WillemKaufPR #24550
rptest
: fixcloud_storage_type
parameterization inrandom_node_operations_test.py
by @WillemKaufPR #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-verifier
version by @WillemKaufPR #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_test
parameterization by @WillemKaufPR #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 @WillemKaufPR #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 #24646 [rptest] Use HTTPS for metrics on opV2 by @clee
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 #24660 bazel: remove version warnings by @rockwotj
PR #24661 tests/datalake: deflake partition_movement_test by @bharathv
PR #24662 raft: Make load_snapshot exception safe by @Lazin
PR #24663 ducktape: Fix TS reader stress test by @StephanDollberg
PR #24669 bazel: use a sysroot for compilation by @rockwotj
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 #24715 storage: build tests with bazel by @dotnwat
PR #24716 Replace
get0
withget
by @ballard26PR #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 #24732 bazel: add rp_util and compat by @rockwotj
PR #24737 rm_stm_tests: fix broken test by @bharathv
PR #24745 bazel: extend ca certificate duration by @IoannisRP
PR #24748 licenses: add libxml2 by @rockwotj
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 license
by @r-vasquezPR #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
replicate
API changes, follow up by @mmaslankaprvPR #24772 [CORE-8654] Add flag to re-enable TLS client renegotiation by @michael-redpanda
PR #24774 Use
chunked_vector
inappend_entries_request
by @mmaslankaprvPR #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 #24796 bazel: change benchmarks to binaries by @rockwotj
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
finish
method intest_serde_parquet_data_writer
by @ballard26PR #24812 iceberg: Single-value JSON serde by @oleiman
PR #24814 datalake: extract table_id_provider as static method by @nvartolomei
PR #24816 bazel: updated module.lock file by @mmaslankaprv
PR #24817 bazel/bench: add tests to benchmarks by @rockwotj
PR #24818 iceberg: correctly set purge requested param by @nvartolomei
PR #24820 bazel: update module lock by @dotnwat
PR #24821 cloud_storage: Improve logging in the partition_manifest by @Lazin
PR #24822 gha/clang-format: don't update lockfile by @rockwotj
PR #24823 licenses: remove sasl2 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 #24829 [CORE-4268] Spill key optimizations by @dotnwat
PR #24830 licenses: update rpk third party code list by @rockwotj
PR #24831 rptests/datalake: update test to use logical types by @andrwng
PR #24832 bazel: remove unused configs by @rockwotj
PR #24833 r/stm_manager: stop state machines before waiting for gate by @mmaslankaprv
PR #24835 ducktape: bump spark version by @ztlpn
PR #24837 Fix partitions local summary by @bashtanov
PR #24839 Buffered protocol changes by @mmaslankaprv
PR #24842 iceberg: add dialhome metrics by @rockwotj
PR #24848 tx/ducktape: breakup transactions_test.py monolith by @bharathv
PR #24853 serde: fix c++23 enum handling by @dotnwat
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 #24867 bazel: add bench tag to benchmarks by @rockwotj
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 #24894 Iceberg custom partitioning: configs by @ztlpn
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 #24897 tools: fix deps by @dotnwat
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 #24927 archival: Handle nested shutdown errors by @Lazin
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 #24941 Add feature_spec for the RW-fence by @Lazin
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
: addnessie
catalog and smoke testing by @WillemKaufPR #24948 bazel: fix sanitizers by @rockwotj
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 #24984 bazel: fix sanitizers in debug mode by @rockwotj
PR #24986
config
: addiceberg_rest_catalog_authentication_mode
by @WillemKaufPR #24987
config
: removeshard_local_cfg
checks fortombstone_retention_ms
validator by @WillemKaufPR #24988 bazel: more sanitizer fixes by @rockwotj
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 #25022 bazel: build seastar iotune by @dotnwat
PR #25023 k/server/test: reduce quota manager bench reqs by @pgellert
PR #25030 ct: Fix unit-tests in cloud topics by @Lazin
PR #25031 io: update interval tests and add bazel coverage helper by @dotnwat
PR #25032 parquet: simplify stats tracking by @rockwotj
PR #25034 io: minor updates to io subsystem 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 #25037 io: remove scheduler by @dotnwat
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_sighandler
by @pgellertPR #25041 bazel: remove numactl by @rockwotj
PR #25042 bazel: specify -march compile flags by @rockwotj
PR #25047 rptest/datalake_dlq_test: fix unintentional filesystem catalog by @andrwng
PR #25049 parquet: improve performance by @rockwotj
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 inNessieService
by @WillemKaufPR #25059 Overriding executable
rpath
with patchelf by @mmaslankaprvPR #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_test
by @WillemKaufPR #25076
storage
: fixes for book keeping ofdirty
andclosed
bytes by @WillemKaufPR #25080 pandaproxy/sr: Improve schema lookup by @IoannisRP
PR #25090 [CORE-8990]
storage
: usesegment_closed_exception
in compaction utils by @WillemKaufPR #25093 Added directory mode package for ducktape by @mmaslankaprv
PR #25095 Iceberg: adapt
merge_append_action
to schema evolution and multiple partition specs by @ztlpnPR #25099 bazel: upgrade golang deps by @rockwotj
PR #25105 config: add gets_restored tag to properties by @andrwng
PR #25109 tests: prettier ducktape reports by @nvartolomei
PR #25111
rptest
: useRedpandaVersionTriple
injava_compression_test.py
by @WillemKaufPR #25113 bazel: upgrade openssl to 3.0.16 by @dotnwat
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.py
by @WillemKaufPR #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
: movewatchdog
intossx
namespace by @WillemKaufPR #25139 datalake/coordinator: consider cluster UUID to deduplicate files by @andrwng
PR #25143
rptest
: setAPPLICATION_GLOBAL
provider forAWS
innessie_catalog
by @WillemKaufPR #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 @rockwotjPR #25152 [CORE-8933] - Port partition_translator into scheduler interface by @oleiman
PR #25153
storage
: adddisk_log_impl::reset_dirty_and_closed_bytes()
by @WillemKaufPR #25157 [CORE-9154]
rptest
: adjust timeouts injava_compression_test.py
by @WillemKaufPR #25158 rpk: only include tuner package files in linux builds by @r-vasquez
PR #25165
rptest
: correct authentication property name innessie
by @WillemKaufPR #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_DEFAULT
provider forGCP
innessie_catalog
by @WillemKaufPR #25198 datalake: various tweaks to shutdown by @andrwng
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 @pgellertPR #25204 bazel: remove seastar fortify patch by @travisdowns
PR #25205
storage
: addLogCompactionSchedulingTest::dirty_ratio_scheduling_test
ducktape test by @WillemKaufPR #25206 [bazel] arm64 build fixes by @clee
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 @WillemKaufPR #25226 Partition spec parser improvements by @bashtanov
PR #25227 [CORE-9153] [CORE-9154] [CORE-9155]
rptest
: deflakejava_compression_test.py
by @WillemKaufPR #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_operations
by @WillemKaufPR #25232 [CORE-9244]
rptest
: deflakedatalake/compaction_test.py
by @WillemKaufPR #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_test
by @WillemKaufPR #25239
rptest
: addnessie
end to enddatalake
testing by @WillemKaufPR #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 @WillemKaufPR #25242 ct: Update write_pipeline and batcher by @Lazin
PR #25243 Pre restart probe fixup by @bashtanov
PR #25244 Minor translator cleanups by @oleiman
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 #25254 ct: Add read path by @Lazin
PR #25255 datalake/translator: followups to cannot kill Pod because of PID1 issue with container when redpanda exits unexpectedly #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 tonessie
credentials by @WillemKaufPR #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 #25268 ct: Improve data layout state machine by @Lazin
PR #25271
storage
: performgc()
everylog_compaction_interval_ms
by @WillemKaufPR #25272 bazel/packaging: rename binaries by @andrewhsu
PR #25273 iceberg/rest_client: catch exception in retry() attempt by @andrwng
PR #25276 iceberg: REST client metrics 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 @WillemKaufPR #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_calculator
by @WillemKaufPR #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
: fixadls
settings by @WillemKaufPR #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 #25323 rpk: disable fetch sessions by @twmb
PR #25324 [CORE-9074]
cluster
: removenode_health_report
logging by @WillemKaufPR #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 @WillemKaufPR #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_test
by @WillemKaufPR #25370 [CORE-9244]
rptest
: deflakedatalake/compaction_test.py
by @WillemKaufPR #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 #25375 [CORE-8917] Consumer Lag Improvements 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
: adddatalake
andiceberg
loggers topossibleLoggers
by @WillemKaufPR #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 #25398 dl/translation: some minor qol fixes by @bharathv
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 @WillemKaufPR #25418 metrics: Export host metrics from Redpanda by @StephanDollberg
PR #25498 [v25.1.x] [backport] dl/translation: fixes for OOM handling dl/translation: fixes for OOM handling #25423 by @bharathv
PR #25699 [v25.1.x] Manual backport of
rpk security secrets
by @r-vasquezFull Changelog: v24.3.1...v25.1.1
This discussion was created from the release v25.1.1.
Beta Was this translation helpful? Give feedback.
All reactions