-
Notifications
You must be signed in to change notification settings - Fork 14.5k
Insights: apache/kafka
Overview
-
0 Active issues
-
- 31 Merged pull requests
- 32 Open pull requests
- 0 Closed issues
- 0 New issues
Could not load contribution data
Please try again later
31 Pull requests merged by 23 people
-
MINOR: Moving the rollback out of lock in share partition
#20153 merged
Jul 11, 2025 -
KAFKA-19496: Deflake streams admin api describe test
#20154 merged
Jul 11, 2025 -
KAFKA-19495: update native image config for native images (v4.1.0)
#20151 merged
Jul 11, 2025 -
KAFKA-19495: update native image config for native images
#20150 merged
Jul 11, 2025 -
KAFKA-19494: Undeprecate JoinGroup V0 & V1
#20142 merged
Jul 11, 2025 -
MINOR: Cleanup Connect Module (1/n)
#19869 merged
Jul 10, 2025 -
KAFKA-19485: Added check before sending acknowledgements on initial epoch.
#20135 merged
Jul 10, 2025 -
MINOR: fix docker_release example
#19427 merged
Jul 10, 2025 -
KAFKA-19488: Update the docs of "if-not-exists"
#20133 merged
Jul 10, 2025 -
MINOR: Throw exceptions if source topic is missing
#20123 merged
Jul 9, 2025 -
MINOR: Tidy up in AlterShareGroupOffsetsHandler
#20130 merged
Jul 9, 2025 -
MINOR: Move partitions == 0 logic from waitForTopic to waitTopicDeletion
#20108 merged
Jul 9, 2025 -
KAFKA-19466: LogConcurrencyTest should close the log when the test completes; migrate LogConcurrencyTest
#20110 merged
Jul 9, 2025 -
KAFKA-19477: Sticky Assignor JMH Benchmark
#20118 merged
Jul 9, 2025 -
KAFKA-19184; Add documentation for upgrading the kraft version
#20071 merged
Jul 9, 2025 -
KAFKA-17715: Remove argument force_use_zk_connection from kafka_acls_cmd_with_optional_security_settings
#19209 merged
Jul 9, 2025 -
KAFKA-19457: Make share group init retry interval configurable.
#20104 merged
Jul 9, 2025 -
KAFKA-19474: Move WARN log on log truncation below HWM
#20106 merged
Jul 9, 2025 -
KAFKA-18681 Created GetReplicaLogInfo* RPCs
#19664 merged
Jul 8, 2025 -
KAFKA-18288: Fix Streams CLI describe
#20099 merged
Jul 8, 2025 -
KAFKA-19478 [1/N]: Precompute values in ProcessState
#20120 merged
Jul 8, 2025 -
MINOR: Prevent unnecessary test runs - KAFKA-19042 follow-up
#20122 merged
Jul 7, 2025 -
MINOR: Fix build warning in Streams
#20098 merged
Jul 7, 2025 -
KAFKA-19042 Move PlaintextConsumerTest to client-integration-tests module
#20081 merged
Jul 7, 2025 -
KAFKA-19444: Add back JoinGroup v0 & v1
#20116 merged
Jul 7, 2025 -
MINOR: Add 4.1 branch to CI
#20112 merged
Jul 7, 2025 -
KAFKA-19315: Move ControllerMutationQuotaManager to server module
#19807 merged
Jul 6, 2025 -
MINOR: Use <code> block instead of backtick
#20107 merged
Jul 6, 2025 -
KAFKA-19221: Backport to 4.0
#20072 merged
Jul 5, 2025
32 Pull requests opened by 28 people
-
KAFKA-19460 Improve documentation of fetch.min.bytes and replica.fetch.min.bytes
#20111 opened
Jul 6, 2025 -
MINOR: typo in javadoc
#20113 opened
Jul 6, 2025 -
(WIP)KAFKA-9965/KAFKA-13303: RoundRobinPartitioner broken by KIP-480
#20114 opened
Jul 6, 2025 -
MINOR: Cleanup metadata module
#20115 opened
Jul 6, 2025 -
KAFKA-19472 A BufferOverflowException is thrown by RemoteLogManager when FetchApiVersion <= 2
#20117 opened
Jul 7, 2025 -
WIP: Optimizing the sticky assingor
#20119 opened
Jul 7, 2025 -
KAFKA-19452: Fix flaky test LogRecoveryTest.testHWCheckpointWithFailuresMultipleLogSegments
#20121 opened
Jul 7, 2025 -
KAFKA-19476: Improve state transition handling in SharePartition
#20124 opened
Jul 8, 2025 -
KAFKA-19478 [2/N]: Remove task pairs
#20127 opened
Jul 8, 2025 -
KAFKA-19480: Recreate /migration when it has null value
#20128 opened
Jul 8, 2025 -
[KAFKA-19484] fix bug with tiered storage throttle metrics
#20129 opened
Jul 8, 2025 -
MINOR: Refactor LockUtils and improve comments (follow up to KAFKA-19390)
#20131 opened
Jul 9, 2025 -
MINOR: Upgrade log4j to version 2.25.0
#20132 opened
Jul 9, 2025 -
KAFKA-19213 Client ignores default properties
#20134 opened
Jul 9, 2025 -
Minor: Use MV to enable ELR
#20137 opened
Jul 9, 2025 -
Refactor code to avoid discovery conflicts for classes:{Supported|Finalized}VersionRange
#20139 opened
Jul 10, 2025 -
MINOR:Add a description document to batchlength
#20140 opened
Jul 10, 2025 -
KAFKA-19492: Add logging in deleteRecordsOnLocalLog for out of range …
#20141 opened
Jul 10, 2025 -
Minor : Use specific error in compression catch handle
#20144 opened
Jul 10, 2025 -
MINOR: fix e2e docs for test that cannot be run directly
#20145 opened
Jul 10, 2025 -
[WIP] KAFKA-19012: Messages ending up on the wrong topic
#20146 opened
Jul 10, 2025 -
KAFKA-19842: Fix flaky KafkaStreamsTelemetryIntegrationTest
#20147 opened
Jul 10, 2025 -
KAFKA-19471: Enable acknowledgement for a record which could not be deserialized
#20148 opened
Jul 11, 2025 -
KAFKA-14405: Log a warning when users attempt to set a config controlled by Streams
#20149 opened
Jul 11, 2025 -
KAFKA-19493: Incorrect rate metric with larger window size
#20152 opened
Jul 11, 2025 -
MINOR: Fix the handling source topic deletion integration test
#20155 opened
Jul 11, 2025 -
MINOR: Cleanup Connect Module (3/n)
#20156 opened
Jul 11, 2025 -
KAFKA-19459: List internal topics for the user
#20157 opened
Jul 11, 2025 -
KAFKA-19132 Move FetchSession and related classes to server module
#20158 opened
Jul 11, 2025 -
KAFKA-17019: Producer TimeoutException should include root cause
#20159 opened
Jul 12, 2025
70 Unresolved conversations
Sometimes conversations happen on old items that aren’t yet closed. Here is a list of all the Issues and Pull Requests with unresolved conversations.
-
KAFKA-18105 Fix flaky PlaintextAdminIntegrationTest#testElectPreferredLeaders
#20068 commented on
Jul 12, 2025 • 24 new comments -
KAFKA-19441: encapsulate MetadataImage in GroupCoordinator/ShareCoordinator
#20061 commented on
Jul 11, 2025 • 22 new comments -
KAFKA-19276: Trigger rebalance for streams config update [WIP]
#19967 commented on
Jul 9, 2025 • 18 new comments -
KAFKA-19400: Update AddRaftVoterRequest RPC to version 1
#19982 commented on
Jul 11, 2025 • 17 new comments -
Kafka-16505: Adding dead letter queue in Kafka Streams
#17942 commented on
Jul 11, 2025 • 17 new comments -
KAFKA-19306: Migrate LogCompactionTester to tools module
#19905 commented on
Jul 11, 2025 • 16 new comments -
KAFKA-18884: Move TransactionMetadata to transaction-coordinator module
#19699 commented on
Jul 8, 2025 • 13 new comments -
MINOR: Migrate CoordinatorLoaderImplTest from Scala to Java
#20089 commented on
Jul 9, 2025 • 12 new comments -
KAFKA-19431: Ensure consumer and share assignment consistency with subscriptions
#20055 commented on
Jul 11, 2025 • 10 new comments -
MINOR: Move ClientQuotasRequestTest to server module
#20053 commented on
Jul 8, 2025 • 9 new comments -
KAFKA-19377:Update /streams/developer-guide/security.html for KIP-1071
#20084 commented on
Jul 10, 2025 • 9 new comments -
MINOR: Cleanups in storage module
#20087 commented on
Jul 8, 2025 • 8 new comments -
KAFKA-15599: Move KafkaMetadataLog to the raft module
#19762 commented on
Jul 7, 2025 • 8 new comments -
KAFKA-19427: Allow the coordinator to grow its buffer dynamically
#20040 commented on
Jul 9, 2025 • 7 new comments -
KAFKA-18336: Improve jmh tests on ACL in AuthorizerBenchmark and StandardAuthorizerUpdateBenchmark
#18293 commented on
Jul 11, 2025 • 6 new comments -
KAFKA-19254: Add generic feature level metrics
#20021 commented on
Jul 11, 2025 • 5 new comments -
MINOR: Cleanups in coordinator-common/group-coordinator
#20097 commented on
Jul 9, 2025 • 5 new comments -
KAFKA-19301: Move and rewrite partition state classes to Java in org.apache.kafka.storage.internals.log
#20083 commented on
Jul 9, 2025 • 4 new comments -
KAFKA-10844: groupBy without shuffling
#18811 commented on
Jul 9, 2025 • 3 new comments -
KAFKA-19305 Ensure all image classes are immutable
#19847 commented on
Jul 11, 2025 • 3 new comments -
KAFKA-19354: KRaft observer should fetch from leader after rediscovery
#19854 commented on
Jul 9, 2025 • 2 new comments -
KAFKA-19435: Optimize `kafka-consumer-groups.sh` to return the offset info when some partitions without leaders
#20064 commented on
Jul 8, 2025 • 2 new comments -
KAFKA-19395 - Updated Junit and mockito version and license information in NOTICE-binary for Jakarta RESTful Web Services Project
#19943 commented on
Jul 11, 2025 • 2 new comments -
KAFKA-16717 [3/N]: Add AdminClient.alterShareGroupOffsets
#19820 commented on
Jul 11, 2025 • 2 new comments -
KAFKA-19122: updateClusterMetadata receives multiples PartitionInfo
#19803 commented on
Jul 7, 2025 • 1 new comment -
KAFKA-14915: allow read remote storage for multiple partitions in one fetchRequest
#20045 commented on
Jul 11, 2025 • 1 new comment -
MINOR: Add tests on TxnOffsetCommit and EndTxnMarker protection against invalid producer epoch when TV2 is used
#20024 commented on
Jul 10, 2025 • 1 new comment -
KAFKA-17601: Inter-broker connections do not expose their clientSoftwareName and clientSoftwareVersion tags
#17731 commented on
Jul 10, 2025 • 1 new comment -
KAFKA-19425: Stop the server when fail to initialize to avoid local segment never got deleted.
#20007 commented on
Jul 8, 2025 • 0 new comments -
KAFKA-1194: changes needed to run on Windows
#12331 commented on
Jul 8, 2025 • 0 new comments -
KAFKA-19272: Add initPid Response handling when keepPrepared is set to true (KIP-939)
#20039 commented on
Jul 10, 2025 • 0 new comments -
Bug fixes for delete and state epoch.
#20056 commented on
Jul 5, 2025 • 0 new comments -
KAFKA-19443: test-common ClusterInstance should make it easy to have more listeners
#20057 commented on
Jul 5, 2025 • 0 new comments -
MINOR Enable Gradle remote caching
#20073 commented on
Jul 8, 2025 • 0 new comments -
KAFKA-19458: resume cleaning on future replica dir change
#20082 commented on
Jul 9, 2025 • 0 new comments -
KAFKA-19451: fix flaky test RemoteIndexCacheTest.testCacheEntryIsDeletedOnRemoval()
#20085 commented on
Jul 10, 2025 • 0 new comments -
KAFKA-13965: Document broker-side socket-server-metrics
#20086 commented on
Jul 10, 2025 • 0 new comments -
MINOR: Cleanup Tools Module (1/n)
#20091 commented on
Jul 9, 2025 • 0 new comments -
KAFKA-15630 Improve documentation of offset.lag.max
#20095 commented on
Jul 8, 2025 • 0 new comments -
MINOR: Cleanup Tools Module (2/n)
#20096 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-19461: Add share group admin integration tests to PlaintextAdminIntegrationTest
#20103 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-19470 Avoid creating loggers repeatedly to affect the performance of request processing
#20105 commented on
Jul 8, 2025 • 0 new comments -
KAFKA-14768_KIP913: add new method to provide possibility for warming up first record's sending and reducing the max.block.ms safely.
#13320 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-18402: Optimise of comparison on org.apache.kafka.common.Uuid
#13627 commented on
Jul 7, 2025 • 0 new comments -
Minor : Increase Config change throwable log info to error
#14380 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-16394: Fix null propagation in foreign key join result
#15607 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-17259: Support to override serverProperties and restart cluster in ClusterTestExtensions
#16808 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-14830: Illegal state error in transactional producer
#17022 commented on
Jul 9, 2025 • 0 new comments -
KAFKA-10532: Handle state updater failed tasks
#17761 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-18166: Indefinite timeout when publishing events to RLMM (RemoteLogMetadataManager)
#18097 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-10730: KafkaApis#handleProduceRequest should use auto-generated protocol
#18216 commented on
Jul 7, 2025 • 0 new comments -
KAFKA 18238 - fIdentify the first commit where a test became flaky
#18334 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-18149: Docs improvement for dynamic kraft quorum
#18350 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-10409: Refactor Kakfa Streams RocksDB Iterators
#18610 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-17651: Implement `describeUserScramCredentials`
#19066 commented on
Jul 9, 2025 • 0 new comments -
KAFKA-13022: Optimize ClientQuotasImage#describe
#19079 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-16616: refactor mergeWith and updatePartitionLeadership
#19199 commented on
Jul 6, 2025 • 0 new comments -
KAFKA-17573: Move KRaftMetadataCache to metadata module
#19232 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-18379: Enforce resigned cannot transition to any other state in same epoch
#19236 commented on
Jul 10, 2025 • 0 new comments -
KAFKA-18981: Fix flaky QuorumControllerTest.testMinIsrUpdateWithElr
#19262 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-18913: Removing _state.updater.enabled_ flag through the Stream…
#19275 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-18563: move RaftClientTestContext RpcVersion methods into RaftProtocol
#19349 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-18185: remove internal.leave.group.on.close config
#19400 commented on
Jul 9, 2025 • 0 new comments -
KAFKA-18752: Fix the warning of no-operation caused by slf4j in building kafka
#19501 commented on
Jul 9, 2025 • 0 new comments -
[WIP]KAFKA-18896 add KIP-877 support for Login
#19527 commented on
Jul 6, 2025 • 0 new comments -
KAFKA-19048: Minimal movement replica balancing algorithm for reassignment
#19858 commented on
Jul 6, 2025 • 0 new comments -
MINOR: Cleanup Connect Module (2/n)
#19871 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-19357: AsyncConsumer#close hangs during closing because the commitAsync request never completes due to a missing coordinator
#19914 commented on
Jul 11, 2025 • 0 new comments -
KAFKA-19299: Fix race condition in RemoteIndexCacheTest
#19927 commented on
Jul 7, 2025 • 0 new comments -
KAFKA-19259: Async consumer fetch intermittent delays on console consumer
#19980 commented on
Jul 9, 2025 • 0 new comments