kafka icon indicating copy to clipboard operation
kafka copied to clipboard

Mirror of Apache Kafka

Results 736 kafka issues
Sort by recently updated
recently updated
newest added

Replace `singleton` with `Set.of` in the SubscriptionStateTest.

consumer
tests
clients
ci-approved
triage

Finalise the share group SimpleAssignor for homogeneous subscriptions. The assignor code is much more accurate about the number of partitions assigned to each member, and the number of members assigned...

performance
KIP-932
ci-approved

Description * Replace `org.apache.kafka.common.test.TestUtils` with `org.apache.kafka.test.TestUtils` in outer package modules to standardize test utility usage * Move `waitUntilLeaderIsElectedOrChangedWithAdmin` method from `org.apache.kafka.test.TestUtils` to `ClusterInstance` and refactor for better code organization *...

core
storage
transactions
clients
ci-approved

- Metadata doesn't have the full view of topicNames to ids during rebootstrap of client or when topic has been deleted/recreated. The solution is to pass down topic id and...

core
producer
clients
ci-approved

**What** This PR updates the behavior of client.id assignment when a user provides a custom value via override configs in Kafka Connect. **Why** Currently, if a user overrides the client.id,...

connect
stale
ci-approved
small

- Rename `KafkaMetadataLog` to `KafkaRaftLog` - Make `raft` depend on `storage` - Remove `storage` dependency on `metadata` as this otherwise create a cyclic dependency

core
tools
connect
performance
kraft
mirror-maker-2
storage
build
clients

Pull request to implement KIP-1138, which aims to address several issues related to the configuration application process in Kafka Streams. This PR has multiple goals: - Deprecate `TopologyConfig` in favor...

streams
kip
stale

In KRaft, custom KafkaPrincipalBuilder instances must implement KafkaPrincipalSerde to support the forward mechanism. Currently, this requirement is not enforced and relies on the developer's attention. With this patch, we can...

core
clients
ci-approved
small
triage

[https://github.com/apache/kafka/commit/ba7b5c9b327558ee0b0169cd6a22216eae7ee6cd](url)

ci-approved

Current Behavior: - When a batch fails with a fatal error (e.g., ProducerFencedException), the TM transitions to FATAL state - However, subsequent batches that fail can still trigger state transitions...

producer
stale
clients
ci-approved
small
triage
needs-attention