redpanda

Redpanda is a streaming data platform for developers. Kafka API compatible. 10x faster. No ZooKeeper. No JVM!

Downloads
16
Stars
8.7K
Committers
150

Bot releases are visible (Hide)

redpanda - v21.11.4

Published by github-actions[bot] over 2 years ago

Bug fixes

Features

Full Changelog: https://github.com/redpanda-data/redpanda/compare/v21.11.3...v21.11.4

redpanda - v21.11.3

Published by github-actions[bot] over 2 years ago

Bug fixes

Features

  • schema_registry: Support GET /subjects/{subject}/versions/{version}/referencedBy. by @BenPope in https://github.com/vectorizedio/redpanda/pull/3402
  • Cluster level configuration parameter cloud_storage_enable_remote_read can be used to enable shadow indexing fetch for all topics (disabled by default). Cluster level configuration parameter cloud_storage_enable_remote_write can be used to enable archival uploads for all topics (disabled by default). by @Lazin in https://github.com/vectorizedio/redpanda/pull/3248

Improvements

redpanda - v21.11.2

Published by github-actions[bot] almost 3 years ago

Bug fixes:

  • Shadow indexing: Add per-topic configurations into topic describe
  • Kafka API: Fix Sarama control record compatibility issue
redpanda - v21.10.3

Published by github-actions[bot] almost 3 years ago

Bug fixes:

  • Idempotent producers: Add deduplication window
  • Compatibility: Fix backward compatibility issues that may cause assertions
  • Kafka API: Fix timequery ListOffsets API from returning an error in some cases
redpanda - v21.11.1

Published by github-actions[bot] almost 3 years ago

Features

  • Shadow Indexing (Tech Preview): If cloud storage is enabled, start offset for the partition will take cloud data into account and fetches for data that was already deleted locally will go to cloud storage. A cluster with this feature enabled is not yet supported for usage.
  • Schema Registry: Support protobuf schema.
  • Cluster health monitor: Ability to query for cluster runtime parameters such as node versions, node availability, node resources and raft group status
  • API: The v1/cluster_config/schema admin API endpoint is added for discovering available cluster configuration properties.
  • API: Added support for manual partition assignment in CreateTopics API. Currently custom partition assignment is only used during initial partition allocation. Nodes decommissioning and automatic partition re-balancing may change the partition assignment
  • rpk: The new rpk group command can be used to list groups, delete groups, describe groups, and modify group offsets. rpk cluster offsets has been deprecated.
  • rpk: new topic add-partitions command to add partitions to existing topics

Improvements

  • Admin API: For requests that must be submitted to the controller leader node, or to the leader for a particular partition: other nodes will now respond with an HTTP 307 redirect to the leader rather than an HTTP 400 error.
  • configuration: describe_config now supports key specification in configuration_keys field.
  • install: Add Archlinux support for installDependencies.sh
  • k8s: External ports can now be specified in the Kafka API external listener configuration. When this port is specified, and if it's not available on all the nodes, redpanda will fail to schedule.
  • k8s: Operator now by default creates PodDisruptionBudget that defaults to MaxUnavailable=1 and can be configured via CRD
  • k8s: rpk-status sidecar is now disabled by default
  • k8s: rpk-status sidecar resource limits were increased from 10M to 30M
  • k8s: Operator depenencies bumped to 1.21.
  • k8s: Operator can now create ingresses for Kubernetes clusters by default.
  • raft: Initial leadership information for newly created topics is set more uniformly across the cluster, avoiding some client delays when accessing a newly created topic that has not gone through a leadership election yet.
  • rpk: The fstrim tuner, which enables or installs the fstrim.service and fstrim.timer, is no longer enabled by default when running rpk redpanda mode production

Bug fixes

  • ACL: Fix wrong ACL user create arguments
  • Idempotent producers: Fix bug affecting idempotent producers, reducing the rate of fatal errors
  • kafka/client: Fix retry handling for several operations
  • kafka/client: Fix concurrency bug with retry mitigation function
  • kafka/server: fix double counting bytes sent metric
  • schema_registry: Prevent deleting referenced schema
  • schema_registry/store: Use correct shard in get_subject_schema

Note that downgrades from 21.11.1 to earlier releases are not supported.

redpanda - v21.10.2

Published by github-actions[bot] almost 3 years ago

v21.10.2 contains fixes for the following issues and areas:

  • Reconfiguration availability
  • Violation of idempotent produces
  • Panda proxy client retires
  • Bug that prevented deleting ACLs by transactional ID
  • Bug that prevented rpk from creating deny ACLs
redpanda - v21.10.1

Published by github-actions[bot] almost 3 years ago

Release notes for 21.10.1

  • Upgrading franz-go in rpk for various bug fixes
  • Improvements to ACL handling in rpk
  • Fixes in schema registry for correct shard
  • Archival metadata STM
  • rpk now uses franz-go instead of sarama
  • General improvements to log messages
  • Community build now works
  • Normalised RPK commands descriptions, so all descriptions are consistent - starting with upper letter and ending with dot.
  • Lots of improvements to testing framework and tests
  • An issue is fixed where partition leadership transfers would sometimes fail to complete when the partition was under load.
  • Fixes for snappy producers that lead to OOM
  • General bug fixes in Raft
  • rpk topic delete now accepts the -r flag to delete any topics completely matching regular expressions
  • rpk topic list now accepts specific topics for listing, as well as the -r flag, so that the command can be used as a dry run for delete
  • rpk container: This change fixes a bug that fails to correctly set the schema registry port sPort when creating the port bindings.
  • raft: fix for one of the replicas not being created when moved cross cores #2642
  • coproc: support for most native topic operations on materialized topics
  • rpk: add the ability to print offsets for empty groups
  • Admin API now has more validation for inputs
  • rpk acl user create now accepts the user as an argument, and --new-password has been renamed to --password. These changes are backwards compatible; using the old format will continue to work for the time being.
  • rpk acl user delete now accepts the user to delete as an argument. Similar to the user create change, the --delete-username flag has been soft deprecated and will continue working for now.
  • rpk acl user create supports a new flag --mechanism which allows for using SCRAM-SHA-512.
  • Fix for a seg fault using transactions
  • k8s:fix values being parsed as scientific notation
  • Fixes for consumer group early startup race leading to serving request on old versions of group data
  • A bug is fixed where leadership transfers on partitions using acks=1 producers could lead to partitions becoming unwritable until the node restarts.
  • Plugins will now be named with a .rpk- prefix.
  • rpk topic produce and rpk topic consume now support expansive formatting options
  • rpk topic produce by default now requires a trailing newline, and strips that newline before producing
  • Feature: Topic recovery from archival storage
  • Fixes for partition movement
  • Consumer group state is now GCd from memory when possible
  • Fixes for return codes that result in better behaving clients while partitions are moved
  • schema registry: Release note: Avro name sanitization is now namespace aware.
  • New feature: Fully functional create partitions support.
  • cluster: A bug is fixed where redpanda could stop unexpectedly when topic properties were modified at the same time as a partition within the topic was being moved between nodes.
  • Fix for rare off-by-one kafka offset being exposed to client
  • Logging of IP connection information for client kafka connection errors (e.g. auth) to amke it easier to debug deployments that have lots of clients
  • Redpanda now logs the system file handle limit on startup, to help diagnose issues on systems where the limit may be too small for the number of log segments.
  • raft: In some situations, leadership of a topic's raft group could change unexpectedly when a non-leader node restarts. After this change, leadership should remain stable through follower node restarts, notwithstanding any intentional leadership changes orchestrated by the new leadership balancing feature.
  • Improvement deriving core counts when using dockerized redpanda
  • raft: fixed critical bug related to log truncation and join consensus
  • archival: ability to limit upload idle time
  • Provide user reliable way for querying partition movement status.
  • storage: A new configuration setting append_chunk_size enables tuning the disk write size (default is 16kB, same as what was previously hardcoded). No change to behavior unless the setting is actively changed by the operator.
redpanda - v21.9.6

Published by github-actions[bot] almost 3 years ago

Bug fixes

  • Ensure that the last applied offset is persisted only when it is flushed, fixing a potential stall that might happen during Redpanda startup after a crash
  • Fix segmentation fault when consumer was active while Redpanda was shutting down
  • Fix allocating to a large contiguous buffer when decompressing Snappy-compressed batches
redpanda - v21.9.5

Published by github-actions[bot] about 3 years ago

Bugfix release:

  • fixed problem leading to unrecoverable state of consumer groups coordinator, after group deletion
  • fixed issue leading to crash after disabling transactions
  • fixed rendering numeric properties in K8S operator
redpanda - v21.9.4

Published by github-actions[bot] about 3 years ago

Bug fixes:

  • Partition movement fixes (#2454)
  • Added group state cleanup when leadership is lost (#2529)
  • Fixed shutting down log (#2473)
  • ParamsFromConfig: return early on FlagConfig (#2536)
redpanda - v21.9.3

Published by github-actions[bot] about 3 years ago

Bug fixes

  • Schema registry: Avro name sanitization is now namespace aware #2480
  • Idempotency: Make id_allocator_stm support handle_eviction #2481
  • Fully functional create partitions support #2486
redpanda - v21.9.2

Published by github-actions[bot] about 3 years ago

redpanda - v21.9.1

Published by github-actions[bot] about 3 years ago

redpanda - v21.8.2

Published by github-actions[bot] about 3 years ago

Improvements

  • Networking: add TCP send/recv buffer size settings
  • Raft: introduced a couple of properties to control concurrency

Bug fixes

  • Partition allocation: ensure constaints are applied to all partitions that are allocated
  • Operator: multiple bug fixes to improve certificate handling
redpanda - v21.8.1

Published by github-actions[bot] about 3 years ago

Features

  • Automatic leadership rebalancing: Automatically rebalance Raft leadership of partitions across nodes in the cluster when a node becomes unavailable or available again.
  • Schema registry: Support a schema registry, with support for the Avro format.
  • Transactions (Tech Preview): Support the Kafka Transactions API

Improvements

  • Operator: On k8s, by default we set transaction_coordinator_replication and id_allocator_replication to 3 when having at least 3 replicas.
  • Operator: The Kubernetes operator now runs only one process in the main redpanda container which should prevent OOMs
  • Raft: A new configuration option raft_heartbeat_disconnect_failures is added, defaulting to three missed heartbeats before connections are closed (i.e. reconnected). This should not need manual adjustment unless running on extremely overloaded systems which are emitting many Closed unresponsive connection log messages.

Bug fixes

  • Automatic partition rebalancing: Bug fixes for corner cases
  • Node decommissioning: Bug fixes for corner cases
  • Seastar: Bug fix for hanging I/Os under heavy load
  • Schema Registry:
    • Support enum defaults for avro compatibility checks
    • Allow deserializing 3rdparty record format
    • Introduce POST /subjects/{subject}
    • Introduce GET /schemas/ids/{id}/versions
    • Soft-deleting a subject no longer returns soft-deleted versions
    • Set the default compatibility to BACKWARDS
    • Allow set_compatibility on non-existent subject
    • Add tests for union
    • Weaken AVRO resolve check to support integer promotion on e.g., arrays
    • Fix error_code and message for subject_version_not_found
    • Fix error_code for schema_id_not_found
    • Remove delete_subject_value::version - this is a breaking change, but it hasn't been released yet
    • Permanently deleting a subject_version twice should return subject_version_not_found, instead of subject_not_found
    • Validate schema on insert to prevent invalid schemas reaching the topic
redpanda - v21.7.6

Published by github-actions[bot] about 3 years ago

Releasing v21.7.6:

  • Added configuration option for controlling if auto partition rebalance
    occurs when nodes are added. This option is defaulted to off after
    observing some poor performance after upgrading.

  • Fixes for rpk's support of ipv6

redpanda - v21.7.2

Published by github-actions[bot] over 3 years ago

redpanda - v21.7.1

Published by github-actions[bot] over 3 years ago

redpanda - v21.6.6

Published by github-actions[bot] over 3 years ago

redpanda - v21.6.5

Published by github-actions[bot] over 3 years ago

Package Rankings
Top 1.35% on Proxy.golang.org
Top 33.63% on Crates.io
Top 36.49% on Npmjs.org
Badges
Extracted from project README
Documentation Slack Twitter Redpanda University