Features
Remote Read Replicas
- cluster: add configs for read_replica to topic properties by @LenaAn #5082
- cluster: use remote revision id for read replicas by @LenaAn #5175
- kafka: merge remote.readreplica and bucket by @LenaAn #5455
- read replica: use remote partition count by @LenaAn #5228
- read_replica: Download manifest for read replica by @LenaAn #5048
- kafka: add read replica fields to create topic request by @LenaAn #5100
- read replica: always serve cloud data for read replicas by @LenaAn #5242
Continuous & Self-Healing Data Balancing
- Partition autobalancer planner by @ZeDRoman #5142
- Partition autobalancer planner cancel movement to unavailable nodes by @ZeDRoman #5365
- Partition balancer backend by @ztlpn #5371
- Partition movement interruption APIs by @mmaslankaprv #5334
- Support rack awareness on partition reallocation by @ZeDRoman #5614
Full Disk Handling & Alerting
- Reject writes as needed to avoid full disks (v1) by @ajfabbri #4803
- metrics: Move disk space metrics to /public_metrics by @BenPope #5547
mTLS Principal Mapping
Per-Listener Authentication Settings
Static Consumer Group Membership
- Added handling members with group.instance.id set i.e. static members by @mmaslankaprv #4684
Cloud Provider IAM Roles Support
- cloud_storage: support IAM roles in redpanda by @abhijat #5309
- cloud_roles: optionally enable tls in http client by @abhijat #5497
Streamlined Metrics Endpoint
- Minimal primary metrics endpoint by @VladLazar #5165
- Add namespace to labels for metrics on public endpoint by @VladLazar #5469
- kafka/probe: separate internal and public metrics by @NyaliaLui #5377
- Aggregate metrics to reduce cardinality by @VladLazar #5166
- pandaproxy: add metrics for error count to /public_metrics by @BenPope #5457
- kafka/group: add new consumer group metrics by @NyaliaLui #5349
Bug Fixes
- Fix for bug where some requests would not respect min/max version checks by @graphcareful #5308
- Fixed printing group instance id in rpk group describe by @mmaslankaprv #4644
- fix logging in group_metadata_migration by @VadimPlh #4902
- rpk: fix build for windows OS by @r-vasquez #5260
- rpk: fix data race in container purge and stop by @r-vasquez #4586
- Fixed: find tran coordinator was not ACL verified by @dlex #5370
- chore: fix warning backgrounding futures by @dotnwat #4858
- cluster: fix disabling leader balancer at runtime by @jcsp #4545
- cluster: fix reactor stalls during shutdown by @jcsp #5151
- config: fix name+handling of topic_partitions_reserve_shard0 by @jcsp #5335
- fix various typos by @andrwng #4916
- kafka/server: Fix operator<< for offset_metadata by @VadimPlh #4927
- rpc: fix assertion after parsing failure by @dotnwat #4355
- kafka: fix replication factor when creating __consumer_offsets by @jcsp #4454
- kafka: fix undefined behavior in consumer group topic migration by @dotnwat #4487
- rpk: fix panic on cluster config export by @ustadhm #5421
- storage: fix intermittent failure in disposing_in_use_reader by @jcsp #5144
- #4433 rpk bugfix: running rpk wasm generate path/to/dir on an existent directory made rpk falsely claim that main.js. main.test.js, package.json, and webpack.js existed. by @r-vasquez #4580
- #4911 rpk now redacts all unknown field values when using rpk debug bundle by @r-vasquez #4915
- #5186 rpk bugfix: Now rpk exits with code 1 when the rpk redpanda tune command either fails to run, or it has a tuner enabled but it's not supported by @r-vasquez #5295
- #5391 fix handling of shadow indexing flags by @Lazin #5392
- #5521. rpk: fix cluster health never showing leaderless partitions by @travisdowns #5523
- A new --version flag is added to the redpanda binary. When supplied, the program will print the version and exit immediately. by @andrwng #5123
- Enable idempotency by default. by @RafalKorepta #4627
- You can now manage your cluster licenses with rpk cluster license by @r-vasquez #5223
- fixes aborted reads violation by @rystsov #5025
- rpk: add rpk redpanda tune list command to check for available tuners. by @r-vasquez #5298
- Fixes: rpk: more descriptive logs for tuner checkers in rpk redpanda tune and rpk redpanda start commands. by @r-vasquez #5462
- ducky: use prealloc nodes test by @NyaliaLui #4491
- a rpk: Fix a bug that caused rpk topic add-partitions to panic when an unfeasible number of partitions were passed by @r-vasquez #5369
- a rpk: fixed bug in IPv6 parsing that previously caused IPv6 hosts to be doubly wrapped in brackets by @r-vasquez #4777
- Fix linearizable barrier by @mmaslankaprv #4555
- Fix lost update consistency error by @rystsov #5026
- Fix raft linearizable barrier by @mmaslankaprv #4507
- Fixed dispatching update finished command after partition reconfiguration by @mmaslankaprv #5357
- Fixed isolation availability issue by @mmaslankaprv #4368
- Fixed serialization of group tombstones by @mmaslankaprv #4901
- Fetch long poll fix by @mmaslankaprv #4506
- k8s: fix lint warnings and disabling gomnd by @r-vasquez #4396
- Fix for bug where some requests would not respect min/max version checks by @graphcareful #5308
- Fix for kafka/protocol unit tests not running by @graphcareful #4584
- Fixed printing group instance id in
rpk group describe
by @mmaslankaprv #4644 - KIP-525 - Return topic configs in create topics responses by @graphcareful #5133
- Nit fixes: unused imports, stale comments, py annotations, clang tidy polish. by @ajfabbri #4896
- storage: Fix dynamic reconfiguration of log segment size by @bharathv #5106
- cloud_storage: Fix race condition in topic recovery by @Lazin #5544
- cluster: Fix snapshot initialization for topic recovery by @Lazin #5819
- cluster: fix config status write pre-check by @jcsp #5680
- cluster: fix shutdown hang in health_monitor_backend by @jcsp #5756
- cluster: fix timeouts creating topics with many partitions by @jcsp #5376
- Partition_balancer: fix leader_id if leader not stable by @ZeDRoman #5521
- Fixed incorrect assumptions in
replace_whole_group
test by @mmaslankaprv #5696 - consensus: fix expected condition variable exception by @andrwng #5734
- kafka: fix assertion failure in join_empty_group_static_member by @dotnwat #5607
- gh: fix if conditional for rpk packaging by @r-vasquez #5592
- gha/rpk: fix upload of darwin binaries by @andrewhsu #5815
- fixed log entry when adding ntp to shard table by @mmaslankaprv #5864
- rpc: fix request/response codec mismatch by @dotnwat #5743
- rpk group: fix describe by @twmb #5872
- cloud_storage: cache minor fixes by @abhijat #5892
- fixes a bug where
rpk group seek
would seek to the start of all topics if seeking a non-existent group by @twmb #4594 - Fix readers cache truncation deadlock by @mmaslankaprv #5861
- Fix use-after-free during
consensus
shutdown by @mmaslankaprv #5759 - Fixed availability loss during reconfiguration. by @mmaslankaprv #5542
Improvements
- Add partition size to health monitor by @ZeDRoman #5010
- Additional detail in config error message by @travisdowns #5213
- Change alter-config help text to use --delete by @travisdowns #5042
- Cmake: bump seastar version by @ztlpn #4503
- Extend lifetime of group for background tasks by @travisdowns #5119
- KIP-525 - Return topic configs in create topics responses by @graphcareful #5133
- Operator: execute centralized configuration operations always on the same node by @nicolaferraro #5125
- Pass node report by reference by @travisdowns #5217
- Per-handler memory estimation, more accurate estimate for metadata handler by @travisdowns #5346
- Updated client swarm version by @mmaslankaprv #4940
- admin_server: redact configs in admin API by @andrwng #5024
- application: handle unwanted positional args by @abhijat #4941
- build(deps): bump async from 3.2.0 to 3.2.4 in /src/js by @dependabot #5271
- build(deps): bump jackson-databind from 2.13.1 to 2.13.2.1 in /tests/java/e2e-verifiers by @dependabot #5266
- build: install unzip and support manjaro by @balusch #4508
- build: simplify admin server json handling by @dotnwat #4400
- c/persisted_stm: suppress error when offset monitor wait was aborted by @mmaslankaprv #5342
- c/types: removed unused sort from get_metadata by @mmaslankaprv #4323
- chore: tools/ readability improvements by @ryanrussell #5235
- cloud_storage: handle fail to write cache item by @LenaAn #5364
- cloud_storage: redacts fields from header by @abhijat #4939
- cluster: recheck raft0 leader existence under semaphore by @travisdowns #4913
- cmake: adds option to enable distcc by @abhijat #5218
- cmake: bump seastar tag by @vbotbuildovich #5508
- cmake: fail when distcc is enabled but not found by @abhijat #5273
- cmake: update seastar tag for OSS build by @VladLazar #5436
- expiring_promise: fix loss of exception information by @dotnwat #4895
- http: tests and improvements for header logging by @abhijat #5454
- k/fetch: validate fetch offset against high watermark by @mmaslankaprv #4201
- k8s/configurator: remove unneeded log stmnt by @0x5d #4652
- k8s: Update by @RafalKorepta #5028
- kafka: no more special treatment for unknown_server_error code. by @balusch #5232
- md-viewer/controller: added support for centralized configuration by @mmaslankaprv #4922
- metrics: replicate selected seastar metrics by @VladLazar #5434
- operator: avoid logging unnecessary information in centralized config… by @nicolaferraro #4674
- r/consensus: try updating leader commit index after aborting config c… by @mmaslankaprv #5340
- r/recovery_stm: changed recovery stm append entries failure logging sev by @mmaslankaprv #4561
- r/vote_stm: do not step down when replicating configuration failed by @mmaslankaprv #4342
- rpk: add broker version info in 'redpanda admin broker ls' by @daisukebe #4333
- rpk: change default_topic_partitions to -1 by @daisukebe #5300
- serde serialization for topic_namespace by @felixguendling #4821
- serde: added bytes support by @mmaslankaprv #4841
- set default key rotation policy by @raresfirebolt #5307
- tools/metadata_viewer: Refactor metadata_viewer and add transaction metadata support by @bharathv #5294
- tools: added simple tool to map file path to the corresponding cloud storage path by @daisukebe #4776
- vassert: prevent assert condition from influencing formatting by @mmaslankaprv #5124
- Accumulated miscellaneous changes by @dotnwat #5505
- Add function to clear a container asynchronously by @ballard26 #4860
- Align feature manager's logical versions with v22.1.5 by @rystsov #5481
- Attempt to avoid repeated finds during housekeeping by @ballard26 #4891
- Autogen request_api stubs by @graphcareful #5037
- Bump seastar version for OSS builds by @VladLazar #5359
- Generate correct stubs for tags defined within kafka schemas by @graphcareful #5017
- Move feature_table outside from controller by @VadimPlh #5220
- Prepare for clang++-14 by @BenPope #4759
- Rate limit leadership transfers by @ballard26 #5159
- Speed up leader balancer by removing unneeded waits by @ballard26 #5135
- Update seastar part1 by @BenPope #5002
- Update seastar v22.2.x by @BenPope #5083
- Use explicit adl<> encoding for RPC types by @dotnwat #5029
- accept out_of_bounds exception for corrupt data by @felixguendling #5306
- admin/build: introduce cluster config schema util by @bharathv #5045
- admin: report maintenance mode status for brokers by @dotnwat #4319
- archival_metadata_stm: return error code instead of throwing by @ztlpn #4691
- build: Update seastar to avoid deprecated coroutine warning in clang-14 by @BenPope #4908
- chore: miscellaneous improvements and fixes by @dotnwat #4859
- cloud_storage: retry gracefully on EPIPE errors by @jcsp #4392
- cloud_storage: use SAX parsing for partition manifest by @LenaAn #4957
- cluster: add serde support for cluster::configuration_update_request by @dotnwat #5237
- cluster: add serde support for transaction gateway service rpc types by @dotnwat #5071
- cluster: add support for serde to metadata and id allocator service types by @dotnwat #5053
- cluster: clean up config error logging by @jcsp #4942
- cluster: swallog+log unexpected exceptions in report_metrics by @jcsp #4876
- cluster: use consistent chrono::duration type by @dotnwat #5094
- config: adjust visibility of enable_rack_awareness by @jcsp #4468
- config: redact secrets on bootstrap logging by @rystsov #4654
- config: reduce min allowed storage_min_free_bytes by @ajfabbri #5317
- controller/probe: Reduce lifecycle by @BenPope #5470
- controller: add serde support for controller rpc messages by @dotnwat #5281
- controller: add serde support for rpc messages by @dotnwat #5250
- controller: add serde support to controller rpc message types by @dotnwat #5301
- controller: add serde support to controller rpc types by @dotnwat #5336
- kafka/protocol: use default generated operator==() by @tchaikov #5138
- kafka/server: Prefer ss::bool to bool for is_flex by @graphcareful #5215
- kafka/server: run activate_feature in background by @VadimPlh #4474
- non-functional changes spotted in review post-merge by @andrwng #4938
- raft: add serde support for append entries and heartbeat messages by @dotnwat #5465
- readme: change domain name in docker pull URL by @ivotron #4668
- reflection/type_traits: use is_specialization_of<> template helper by @tchaikov #5511
- rm_stm: make recovery from memory reset faster by @rystsov #5027
- rpc: adaptive rpc message encoding by @dotnwat #4963
- rpc: graceful handling of unsupported methods and transport versions by @dotnwat #4853
- rpc: remove demos by @dotnwat #5352
- rpc: reset transport version via reconnect_transport by @dotnwat #5520
- rpk topic consume patch by @twmb #4583
- rpk-operator refactor: allow canceling admin API calls by propagating context by @nicolaferraro #5067
- rpk: add redpanda.aggregate_metrics to cfg struct by @r-vasquez #5513
- rpk: backward compatibility corrections by @r-vasquez #5449
- rpk: create params Write method. by @r-vasquez #4954
- rpk: improve configuration update message by @dotnwat #4512
- rpk: improve wording in topic create: replication factor must be odd by @r-vasquez #4786
- rpk: introduce basic weak types for custom unmarshaling by @r-vasquez #4894
- rpk: make redpanda_checkers run in order by @r-vasquez #5477
- rpk: remove manager.FindOrGenerate from commands by @r-vasquez #4832
- rpk: standardize command and flag output by @r-vasquez #5447
- security: don't log potentially sensitive messages by @andrwng #4955
- serde: Support absl::flat_hash_map and absl::btree_set by @bharathv #5431
- update more copyright headers to use Redpanda Data by @andrewhsu #4354
- v/rpc: use std::constructible_from when appropriate by @tchaikov #5145
- vim: add coc-settings.json to src/v by @andrwng #4808
- #3279 Implement KIP-447. In EOS transaction producer can work with consumer groups. by @VadimPlh #5162
- #4366 improve compatibility with franz-go by @rystsov #4669
- #5355 Add a workaround to bypass a java kafka client's consistency issue by @rystsov #5356
- #5494 The old default redpanda.yaml incorrectly specified the pandaproxy and schema_registry, and rpk had a bug that always added those sections by default. rpk will no longer add those sections no matter what, but the yaml file also now includes the sections properly by default. Using a new rpk on an old default yaml will no longer add the missing pandaproxy and schema_registry sections. by @r-vasquez #5503
- Add hooks for rolling restarts and upgrades by @nicolaferraro #4125
- Added rpk cluster health command by @mmaslankaprv #4295
- Added serde serialization support to cluster types by @mmaslankaprv #5033
- Added serde support for basic common types by @mmaslankaprv #5049
- Break ties randomly in partition allocator by @travisdowns #4974
- Catch unhandled exceptions within net::server by @graphcareful #5211
- Cleanups inspired by gcc by @tchaikov #5304
- Compaction keyspaces by @mmaslankaprv #5345
- Default partitions count for __consumer_offsets topic increased by @dlex #5412
- Drop the CONCEPT macro by @tchaikov #4919
- Handle aborted transactions in shadow indexing by @Lazin #5381
- Implemented node recommissioning by @mmaslankaprv #5323
- Implemented partition movement interruption by @mmaslankaprv #5158
- Improve idempotency latency by introducing rm_stm pipelining by @rystsov #5157
- Made recovery throttle runtime configurable by @mmaslankaprv #5108
- Minor improvement, switch to to_array by @theidexisted #4741
- Node operations fuzzy improvements by @mmaslankaprv #5360
- Operator: add support for downscaling by @nicolaferraro #5019
- Optimized partition metadata lookup by @mmaslankaprv #4443
- Partitions subcommand by @lacer-utkarsh #4425
- Refactor TLS certificates handling in k8s operator by @alenkacz #4540
- Release SMP service group before 2nd stage by @travisdowns #4980
- Remove viper and mapstructure from rpk by @r-vasquez #5061
- Support for flexible requests by @graphcareful #4513
- Two phase group processing follow up by @mmaslankaprv #4775
- Two stage processing in groups by @mmaslankaprv #4579
- Update external connectivity docs to get a valid VERSION environment variable by @vuldin #4988
- Use correct fn to move offset translator state by @ztlpn #4493
- Using serde in redpanda/controller/0 partition by @mmaslankaprv #4889
- admin: reject maintenance mode req on 1 node cluster by @jcsp #4921
- archival: Truncate archival metadata snapshot by @Lazin #5160
- build: drop unused set_option.cmake by @tchaikov #5236
- c/dissemination: do not query topic metadata for ntp by @mmaslankaprv #4389
- c/md_dissemination: do not capture unused variable by @tchaikov #4715
- cloud_storage: Improve SI cache by @Lazin #5044
- cloud_storage: add new error counting metrics by @NyaliaLui #5367
- cloud_storage: downgrade another log error to a warning by @jcsp #4408
- cloud_storage: treat S3 InternalError as a backoff by @jcsp #4706
- cluster, kafka, raft: Logging refinement by @jcsp #4977
- cluster,kafka: auto-populate cluster_id and prefix it with "redpanda." by @jcsp #4457
- cluster: bootstrap user creation during cluster creation by @jcsp #5231
- cluster: check abort source in reconcile_ntp loop by @jcsp #4720
- cluster: downgrade per-partition messages to DEBUG by @jcsp #4951
- cluster: drop redundant set_status config updates by @jcsp #4924
- cluster: make shards-per-core parameters configurable at runtime by @jcsp #5205
- dashboard: remove unused dashboard code by @jcsp #4542
- k/protocol: move kafka_request_schemata into v::kafka_protocol by @tchaikov #5139
- k/replicated_partition: do not validate fetch offset when stopping by @mmaslankaprv #5066
- k8s,docs: bump cert-manager to v1.4.4 by @sbocinec #5096
- kafka/server: add missing placeholder in format string. by @balusch #5320
- kafka: introduce separate TCP buffer sizes for kafka vs. internal RPC by @jcsp #5099
- kafka: validate user provided create_topic configuration literals by @VladLazar #4953
- net/kafka/rpc/cluster: Improved logging by @jcsp #5097
- net: add new rpc metrics by @NyaliaLui #5411
- raft: add serde support for raft message types by @dotnwat #5353
- redpanda: Sort config options before logging by @BenPope #4604
- rpc: add method_id accessors for generated code by @andrwng #4893
- rpc: enable setting a limit on the seastar/userspace receive buffer size by @jcsp #2275
- rpk redpanda admin command for MacOS by @lacer-utkarsh #4291
- rpk redpanda config set: improve setting arrays by @twmb #5522
- rpk/config: Add ServerTLS:Other by @BenPope #4603
- rpk/k8s: enable gofumpt as default go formatter by @r-vasquez #4653
- rpk: Add golangci-lint by @r-vasquez #4387
- rpk: Support listener authN by @BenPope #5482
- rpk: add debug logdirs describe by @twmb #4979
- rpk: add cluster maintenance status and enable barrier by @dotnwat #4390
- rpk: add metadata request in client creation to control sasl errors by @r-vasquez #4727
- rpk: add summary flag to group describe by @r-vasquez #4799
- rpk: allow write_disk_cache to fail in rpk tune by @r-vasquez #5348
- rpk: avoid duplicates in container port pool by @r-vasquez #4721
- rpk: avoid transmuting CLI args without equal sign by @r-vasquez #5397
- rpk: change Invalid Partitions err message in topic creation by @r-vasquez #4662
- rpk: change error in cluster health flag description by @r-vasquez #4703
- rpk: change exit status for topic command failures by @r-vasquez #4592
- rpk: change host flag help text for admin config print by @r-vasquez #4617
- rpk: changes in cluster config: by @r-vasquez #4636
- rpk: enable linters Part 2. by @r-vasquez #4412
- rpk: generate pool of available ports for container start command by @r-vasquez #4565
- rpk: include hint to set env variable when rpk container starts by @r-vasquez #4800
- rpk: remove base58 encoding to node.uuid to avoid confusion by @r-vasquez #4514
- rpk: remove readAsJson from config manager by @r-vasquez #4909
- rpk: rename httpError for httpResponseError by @r-vasquez #4912
- rpk: support hostnames in config bootstrapping by @r-vasquez #4770
- rpk: update feedback URL by @sbocinec #5080
- s3: Improve error handling by @Lazin #4749
- schema_registry: Support GET /mode by @BenPope #5098
- serde: use concepts instead of type traits implemented using SFINAE by @tchaikov #5288
- storage: do not hold open FDs for all segments+indices by @jcsp #4022
- storage: don't log errors during recovery by @jcsp #4969
- storage: explicitly mark clean segments in kvstore on clean shutdown by @jcsp #5127
- storage: introduce storage_resources for controlling resource use at scale by @jcsp #5150
- Handle upload failures overlapping with leadership transfer by @abhijat #4642
- Show the list of all nodes in rpk health by @travisdowns #5525
- Use named semaphores for better debuggability. by @ajfabbri #5490
- build(deps): bump pathval from 1.1.0 to 1.1.1 in /tools/ts-generator by @dependabot #5552
- cloud_storage: use is_elected_leader for leadership query by @abhijat #5769
- cmake: pin pex==2.1.100 by @andrewhsu #5660
- heartbeat_manager: reduce log severity when missing partition by @andrwng #5742
- r/heartbeat_manager: validate received heartbeat response group by @mmaslankaprv #5719
- security: Modify license timestamp to be unix epoch by @graphcareful #5849
- Add data serialization compatibility framework by @dotnwat #5692
- Bump macos version in rpk gha workflow by @ivotron #5689
- Change license nag message and other small license related changes by @graphcareful #5738
- Handle maintenance nodes in the leader balancer by @ballard26 #5426
- Make redpanda_kafka_replicas report configured replicas by @VladLazar #5770
- Raft rpc compat updates by @dotnwat #5796
- Report brokers without liveness by @VladLazar #5698
- archival: Always stop the ntp_archiver on shutdown by @BenPope #5700
- buildkite: add pre-exit script by @andrewhsu #5492
- cloud_storage: use stable iterator for absl::btree by @LenaAn #5704
- cluster: do not log errors on shutdown from persisted_stm by @jcsp #5765
- cluster: improved logging during shutdown by @jcsp #5672
- cluster: use serde auto fields by @dotnwat #5882
- config: Support optional arrays by @BenPope #5814
- config: increase storage min free bytes to 5 GiB by @ajfabbri #5861
- conn_quota: add leaving put trace message by @dotnwat #5714
- metrics: expose seastar runtime metric by @VladLazar #5845
- omb/perf: Bump client request timeouts to 5mins by @bharathv #5561
- redpanda_installer: don't initialize releases unless needed by @andrwng #5688
- rpc: add type info to error messages by @dotnwat #5624
- rpc: reset connections on protocol violations by @dotnwat #5879
- rpk: add a method to deprecate child commands by @r-vasquez #5841
- rpk: move logdirs command from debug to cluster by @r-vasquez #5823
- serde/type_str: drop MSVC bits by @tchaikov #5515
- serde: support std::chrono::duration by @bharathv #5432
- by @LenaAn #5344 - produce requests to read replica topics are rejected by @LenaAn #5484
- #5458 rpk: the redpanda.config_file field in redpanda.yaml is no longer written in new config files. #5709
- #5483 rpk no longer stores/adds empty/zero values in redpanda.yaml (except seed_servers and node_id) #5582
- #5501
rpk
now has an option to generatescrape_config
for both/metrics
and/public_metrics
endpoints using the--internal-metrics
flag #5526 - #5622 rpk: Now you can add
tls_config
to generated Prometheus scrape_config via--ca-file
,--cert-file
and--key-file
flags. #5820 - rpk: add
seastar_memory
andserde
to the list of loggers you can modify usingrpk redpanda admin config log-level all
by @r-vasquez #5557 - Log contents of node status cache update by @dlex #5804
- Log unsupported version with warn level by @mmaslankaprv #5869
- Return human readable error msg when stopping reconfigurations by @mmaslankaprv #5838
- archival: Handle archival metadata stm sync errors by @Lazin #5783
- c/controller_backend: do not require accessing topic metadata by @mmaslankaprv #5809
- *cmake: install pex==2.1.100 not pex=2.1.00 #5744
- k/group_router: pass func to sharded<>::invoke_on() directly by @tchaikov #5177
- kafka/client: improve list_offsets response error handling by @BenPope #5729
- raft: require full leadership before leadership transfer by @jcsp #5333
- rpk: remap group seek error on non-empty groups by @r-vasquez #5554
- rpk: replace ioutil with io and os by @estensen #5697
- schema_registry: Return schemaType for /schemas/ids/ by @BenPope #5568
- schema_registry: Support recursive protobuf structures by @BenPope #5573
- storage: per-shard limit on memory for spill_key_index by @jcsp #5722
- Read replica: validate no writes to s3 by @ajfabbri #5667
- Publish runtime metric in seconds by @vbotbuildovich #5976
- admin_server: added missing mapping from rpc errors to http status codes by @vbotbuildovich #5946
- archival: catch sem timeout in upload/sync loops by @vbotbuildovich #5978
- archival: tweak description of connection limit by @vbotbuildovich #5971
- cloud_storage: adjust condition to remove archiver by @vbotbuildovich #5942
- rpk: introduce
rpk redpanda start --mode -dev-container
#5997 - storage: add metrics clear to reader cache probe by @vbotbuildovich #5962
- compat: Last round of types for full compat support by @graphcareful #5919
- Partition balancer: interaction with maintenance mode and node decommission by @ztlpn #5894
- [transaction] Compare record from input and output by @VadimPlh #5907
- auth: Improvements for endpoint authentication by @BenPope #5906
- model: Refactor adl<timeout_clock> by @BenPope #5051
- #5780 * rpk: now you can query the partition auto balancer status via
rpk cluster partitions balancer-status
by @r-vasquez #5798 - #5781 * Now you can cancel ongoing partitions movement in a cluster running
rpk cluster partitions movement-cancel
by @r-vasquez #5925 - cluster: Lower log level for health stats collection by @BenPope #6000
- rpk: use redpanda.yaml instead of bootstrap file by @r-vasquez #6004
- More robust waiting for the quiescent state in partition balancer tests by @ztlpn in #6032
- cluster: Use bucket passed via
redpanda.remote.readreplica
in read-replica mode by @Lazin in #6040 - logging/observability: Additional log on shutdown. by @bharathv in #6045
- rpc: retain correlation idx across transport resets by @dotnwat in #6035
Full Changelog: v22.1.7...v22.2.1