Releases: redpanda-data/redpanda
Releases · redpanda-data/redpanda
v21.1.4
release 21.1.4 Major release: This work includes 420 commits. Major features: * Initial feature of coprocessor with coproc wasm (WASM) feature exposed under `rpk wasm {deploy,remove}` commands. We note that this feature while in the tree is marked experimental. Documentation to follow. * Initial feature of archival (s3) backups. We landed the metadata description and s3 archival functions alongside all of the secure hashing schemes needed by s3. * Cross segmen compaction finally landed in tree which allows for compaction of adjacent segments. with an initially exposed max file handle size of 5G for adjacent segment compaction * RPK landed a huge number of bugfixes and simplifications, most notably namespacing the new namespacing is rpk {redpanda, debug, topic} - which should hopefully allow users to understand RPK better. * First patch of idempotent producer also landed with full compatibility targetted for the next release :) - We note that this is the first step in turn to support transactions. * A new `kafka::client` written in seastar was ported out of the http proxy into the top level kafka namespace * First pass for live partition migration landed, which included node id virtualization. Need to hook this up to the `controller backend` to expose it to users. * This build includes a HUGE amount of performance improvements where we can now gurantee hardware saturation in all modes of acknowledgement. * This change also comes with priority-based raft leader election, among RPC reordering optimization, amortized flushes by a 'look-ahead' flush on the followers. The TCP clients were increased to 8 from 3 to allow for saturation on large machines. * Added GCP specific tuner to `rpk tuner` to maximize throughput on GCP after chatting with the storage team at google Notable bug fixes: * rpk is effectively revamped and should be much less buggy from tuners to logging, to namespacing, to containers and configuration re-write * graceful recovery of an administration removing a directory manually on /var/lib/redpanda/data/*
v21.1.3
release 21.1.3 Added cold storage archival integration. Kafkak::client refactoring Systemd removal Minor bugfixes Expect major release notes on the next relese or so
v21.1.2
release 21.1.2 Includes packaging fixes in vtools+configuration updates from noah for multi NIC support
v21.1.1
Major release. Please stay tuned for news/updates on 21.1.2 or greater next week.
This release is safe to use in production.
This release is to exercise all the production channels, before major announcement.
v20.12.9
v20.12.7
Highlights
- basic SCRAM infrastructure landed
- throughput improvements by removing the timeout on
replicate batcher
from raft to match that of the network layer - supressed heartbeats while in replication (catch up) mode
- move api docs to /usr/share
- implemented priority based leader elections
- reduced the timeout on Kafka api fetch
- add basic incremental config parsing
List of Changes
v20.12.6
Highlights
- Add --kafka-addr, --rpc-addr, --advertise-kafka-addr, --advertise-rpc-addr & --node-id flags to
rpk start
. - Use the new flags in
rpk container start
, instead of relying on volumes.
List of changes
v20.12.5
Highlights
- Fix a bug in rpk start which caused any
existing seed nodes to be cleared. - Always use absolute paths for the config file.
List of changes
release-20.12.4
Highlights
- Fix the permissions for the config dir on both
rpm & debian-based distros.
List of changes
release-20.12.2
Highlights
- Fix the parsing of seed addrs in
rpk start