-
Notifications
You must be signed in to change notification settings - Fork 14.3k
Insights: apache/kafka
Overview
-
0 Active issues
-
- 48 Merged pull requests
- 29 Open pull requests
- 0 Closed issues
- 0 New issues
Could not load contribution data
Please try again later
48 Pull requests merged by 28 people
-
KAFKA-19026: add note in ZK to KRaft migration
#19563 merged
Apr 26, 2025 -
MINOR: update KafkaStreamsTelemetryIntegrationTest for Java17
#19567 merged
Apr 25, 2025 -
KAFKA-16718-3/n: Added the ShareGroupStatePartitionMetadata record during deletion of share group offsets
#19478 merged
Apr 25, 2025 -
MINOR: code cleanup GroupMetadataManagerTestContext
#19554 merged
Apr 25, 2025 -
KAFKA-19042: [6/N] Move PlaintextConsumerFetchTest to client-integration-tests module
#19520 merged
Apr 25, 2025 -
MINOR: Move request static validations to GroupCoordinatorService
#19556 merged
Apr 25, 2025 -
HOTFIX: Fix StreamThreadTest
#19562 merged
Apr 25, 2025 -
KAFKA-19131: Adjust remote storage reader thread maximum pool size to avoid illegal argument
#19532 merged
Apr 25, 2025 -
HOTFIX: GroupMetadataManagerTest fails to compile
#19558 merged
Apr 25, 2025 -
KAFKA-17747: [1/N] Add MetadataHash field to Consumer/Share/StreamGroupMetadataValue
#19504 merged
Apr 25, 2025 -
KAFKA-19190: Handle shutdown application correctly
#19544 merged
Apr 25, 2025 -
KAFKA-19198: Resolve NPE when topic assigned in share group is deleted
#19552 merged
Apr 25, 2025 -
KAFKA-19195: Only send the right group ID subset to each GC shard
#19548 merged
Apr 25, 2025 -
KAFKA-19128: Kafka Streams should not get offsets when close dirty
#19450 merged
Apr 25, 2025 -
MINOR: Use meaningful name in AsyncKafkaConsumerTest
#19550 merged
Apr 24, 2025 -
KAFKA-19192: Old bootstrap.metadata files cause problems with post-KAFKA-18601 servers
#19545 merged
Apr 24, 2025 -
MINOR: Small refactor in group coordinator
#19551 merged
Apr 24, 2025 -
KAFKA-18988: Connect Multiversion Support (Updates to status and metrics)
#17988 merged
Apr 24, 2025 -
KAFKA-19082: [1/4] Add client config for enable2PC and overloaded initProducerId (KIP-939)
#19429 merged
Apr 24, 2025 -
KAFKA-18889: Make records in ShareFetchResponse non-nullable
#19536 merged
Apr 24, 2025 -
MINOR: Improve member epoch mismatch logging for share groups
#19549 merged
Apr 24, 2025 -
MINOR: Use readable interface to parse response
#19353 merged
Apr 24, 2025 -
MINOR: Change KIP-932 log messages from early access to preview
#19547 merged
Apr 24, 2025 -
KAFKA-19110: Add missing unit test for Streams-consumer integration
#19457 merged
Apr 24, 2025 -
KAFKA-15767: Refactor TransactionManager to avoid use of ThreadLocal
#19440 merged
Apr 23, 2025 -
KAFKA-19124: Follow up on code improvements
#19453 merged
Apr 23, 2025 -
KAFKA-18170: Add scheduled job to snapshot cold share partitions.
#19443 merged
Apr 23, 2025 -
KAFKA-19156: Streamlined share group configs, with usage in ShareSessionCache
#19505 merged
Apr 23, 2025 -
KAFKA-14690; Add TopicId to OffsetCommit API
#19461 merged
Apr 23, 2025 -
KAFKA-16538; Upgrade kraft version
#19416 merged
Apr 22, 2025 -
KAFKA-18572: Update Kafka Streams metric documenation
#18673 merged
Apr 22, 2025 -
MINOR: Improve javadoc for share consumer
#19533 merged
Apr 22, 2025 -
KAFKA-19159: Removed time based evictions for share sessions
#19500 merged
Apr 22, 2025 -
MINOR: Update system test dev version to 3.9.1
#19534 merged
Apr 22, 2025 -
KAFKA-19057: Stabilize KIP-932 RPCs for AK 4.1
#19378 merged
Apr 22, 2025 -
KAFKA-19166 Fix RC tag in release script
#19518 merged
Apr 22, 2025 -
MINOR: redundant gradle expression is removed
#19200 merged
Apr 22, 2025 -
KAFKA-19179: remove the dot from thread_dump_url
#19525 merged
Apr 22, 2025 -
KAFKA-19019: Add support for remote storage fetch for share groups
#19437 merged
Apr 21, 2025 -
MINOR: ignore null judgement in LogCleaner
#19524 merged
Apr 21, 2025 -
[KAFKA-8830] KIP-512: make Record Headers available in onAcknowledgement
#17099 merged
Apr 21, 2025 -
KAFKA-19180: Fix the hanging testPendingTaskSize
#19526 merged
Apr 21, 2025 -
KAFKA-14487: Move LogManager static methods/fields to storage module
#19302 merged
Apr 21, 2025 -
MINOR: Fix typo in ApiKeyVersionsProvider exception message
#19521 merged
Apr 21, 2025 -
MINOR: bump zstd minor version to 1.5.6-10
#19512 merged
Apr 21, 2025 -
KAFKA-18854: remove
DynamicConfig
inner class#19487 merged
Apr 20, 2025 -
MINOR: Extend @ApiKeyVersionsSource annotation
#19516 merged
Apr 20, 2025
29 Pull requests opened by 19 people
-
KAFKA-14691; Add TopicId to OffsetFetch API
#19515 opened
Apr 19, 2025 -
KAFKA-18066: Fix mismatched StreamThread ID in log messages
#19517 opened
Apr 19, 2025 -
KAFKA-19139 Plugin#wrapInstance should use LinkedHashMap instead of Map
#19519 opened
Apr 20, 2025 -
KAFKA-19176: Update Transactional producer to translate retriable into abortable exceptions
#19522 opened
Apr 21, 2025 -
KAFKA-17747: [2/N] Add compute topic and group hash
#19523 opened
Apr 21, 2025 -
[WIP]KAFKA-18896 add KIP-877 support for Login
#19527 opened
Apr 21, 2025 -
[WIP] KAFKA-19170: Move MetricsDuringTopicCreationDeletionTest to client-integration-tests module
#19528 opened
Apr 21, 2025 -
KAFKA-19178: Replace Vector by ArrayList for PluginClassLoader#getResources
#19529 opened
Apr 21, 2025 -
KAFKA-19183: Remove kafka.utils.Pool and refactor usages
#19531 opened
Apr 22, 2025 -
KAFKA-19183: Replace Pool with ConcurrentHashMap
#19535 opened
Apr 22, 2025 -
MINOR: support ipv6 in ducker-ak
#19537 opened
Apr 22, 2025 -
KAFKA-19185: add logs
#19538 opened
Apr 22, 2025 -
KAFKA-19082:[3/4] Add prepare txn method (KIP-939)
#19539 opened
Apr 22, 2025 -
KAFKA-19169: Enhance AuthorizerIntegrationTest for share group APIs
#19540 opened
Apr 23, 2025 -
KAFKA-16894: Exploit share feature [3/N]
#19542 opened
Apr 23, 2025 -
KAFKA-19109: Don't print null in kafka-metadata-quorum describe status
#19543 opened
Apr 23, 2025 -
MINOR: improve JavaDocs for consumer CloseOptions
#19546 opened
Apr 24, 2025 -
KAFKA-19091: Fix race condition in DelayedFutureTest
#19553 opened
Apr 24, 2025 -
KAFKA-19195: Only send the right group ID subset to each GC shard
#19555 opened
Apr 25, 2025 -
Handle delete topics
#19559 opened
Apr 25, 2025 -
KAFKA-19202: Enable KIP-1071 in streams_smoke_test.py
#19560 opened
Apr 25, 2025 -
MINOR: add repartitionSourceTopics to Streams group description
#19561 opened
Apr 25, 2025 -
MINOR: Update jgit to the latest version
#19564 opened
Apr 25, 2025 -
MINOR: Update apacheds to 2.0.0.AM27
#19565 opened
Apr 25, 2025 -
KAFKA-19087: Move TransactionState to transaction-coordinator module (wip)
#19568 opened
Apr 26, 2025 -
MINOR: fix bug in TimeWindowedDeserializerTest
#19570 opened
Apr 26, 2025 -
MINOR: Clean up CloseOptions
#19571 opened
Apr 26, 2025
65 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-18185: remove internal.leave.group.on.close config
#19400 commented on
Apr 26, 2025 • 17 new comments -
KAFKA-10551: Add topic id support to produce request and response
#15968 commented on
Apr 24, 2025 • 16 new comments -
[WIP] KIP-891: Multiversioning in Kafka Connect - Plugin Loading Isolation Tests
#18325 commented on
Apr 25, 2025 • 16 new comments -
KAFKA-19082: [2/4] Add preparedTxnState class to Kafka Producer (KIP-939)
#19470 commented on
Apr 25, 2025 • 14 new comments -
KAFKA-17541:[1/2] Improve handling of delivery count
#19430 commented on
Apr 25, 2025 • 9 new comments -
KAFKA-19015: Remove share session from cache on share consumer connection drop
#19329 commented on
Apr 25, 2025 • 6 new comments -
KAFKA-19068: Eliminate the duplicate type check in creating ControlRecord
#19346 commented on
Apr 25, 2025 • 6 new comments -
KAFKA-19173: Add `Feature` for "streams" group
#19509 commented on
Apr 25, 2025 • 6 new comments -
KAFKA-19080 The constraint on segment.ms is not enforced at topic level
#19371 commented on
Apr 25, 2025 • 6 new comments -
KAFKA-19171: Kafka Streams crashes with UnsupportedOperationException
#19507 commented on
Apr 25, 2025 • 5 new comments -
KAFKA-19073: add transactional ID pattern filter to ListTransactions
#19355 commented on
Apr 24, 2025 • 3 new comments -
KAFKA-14830: Illegal state error in transactional producer
#17022 commented on
Apr 22, 2025 • 2 new comments -
KAFKA-17897: Deprecate Admin.listConsumerGroups [2/N]
#19508 commented on
Apr 25, 2025 • 2 new comments -
KAFKA-16580: Enable dynamic quorum reconfiguration for raft simulation tests
#18987 commented on
Apr 25, 2025 • 2 new comments -
KAFKA-19160: Improve performance of fetching stable offsets
#19497 commented on
Apr 21, 2025 • 1 new comment -
MINOR: Replaced internal KafkaConfig field in TransactionLogConfig
#19482 commented on
Apr 21, 2025 • 1 new comment -
KAFKA-18960: The default type of ssh key used by vagrant is disabled …
#19264 commented on
Apr 25, 2025 • 1 new comment -
KAFKA-18563: move RaftClientTestContext RpcVersion methods into RaftProtocol
#19349 commented on
Apr 23, 2025 • 0 new comments -
MINOR cleanup log related test
#19375 commented on
Apr 24, 2025 • 0 new comments -
KAFKA-19042: [5/N] Move PlaintextConsumerCommitTest to client-integration-tests module
#19389 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-19060 Documented null edge cases in the Clients API JavaDoc
#19393 commented on
Apr 24, 2025 • 0 new comments -
KAFKA-18870 Implement describeDelegationToken for controller
#19306 commented on
Apr 22, 2025 • 0 new comments -
MINOR: Small cleanups in streams tests
#19446 commented on
Apr 21, 2025 • 0 new comments -
KAFKA-16913 - Support external schemas in JSONConverter
#19449 commented on
Apr 24, 2025 • 0 new comments -
Kafka 16582
#19455 commented on
Apr 20, 2025 • 0 new comments -
KAFKA-19117: Client Throttling Log messages should be of log level - WARN (Java client)
#19456 commented on
Apr 21, 2025 • 0 new comments -
[KAFKA-15580] First attempt at UncleanRecoveryManager
#19468 commented on
Apr 22, 2025 • 0 new comments -
KAFKA-19140 ConnectAssignor#performAssignment parameter can be replace to ConnectProtocolCompatibility
#19476 commented on
Apr 26, 2025 • 0 new comments -
KAFKA-17862: [buffer pool] corruption during buffer reuse from the pool
#19489 commented on
Apr 24, 2025 • 0 new comments -
KAFKA-19163: Avoid deleting groups with pending transactional offsets
#19496 commented on
Apr 24, 2025 • 0 new comments -
KAFKA-18752: Fix the warning of no-operation caused by slf4j in building kafka
#19501 commented on
Apr 25, 2025 • 0 new comments -
MINOR: Cleanup Core Module- Scala Modules (2/n)
#19510 commented on
Apr 24, 2025 • 0 new comments -
MINOR: Move candidateClients set creation outside of task loop for StickyTaskAssignor
#19511 commented on
Apr 26, 2025 • 0 new comments -
[Work in progress] [KAFKA-19174] Gradle version upgrade 8 -->> 9
#19513 commented on
Apr 26, 2025 • 0 new comments -
WIP: Test against Java 24
#19514 commented on
Apr 26, 2025 • 0 new comments -
Use ByteBuffers for LZ4 OutputStream
#11052 commented on
Apr 24, 2025 • 0 new comments -
MINOR: Delete temporary directories after using them in RaftManagerTest
#11193 commented on
Apr 24, 2025 • 0 new comments -
KAFKA-13468: Consumers may hang because IOException in Log#<init> does not trigger KafkaStorageException
#11520 commented on
Apr 26, 2025 • 0 new comments -
MINOR: Add __cluster_metadata topic to list of internal topics
#12305 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-15845: Detect leaked Kafka clients and servers with LeakTestingExtension
#14783 commented on
Apr 25, 2025 • 0 new comments -
Add demo template for transactional client
#15913 commented on
Apr 22, 2025 • 0 new comments -
KAFKA-10840: Propagating Authentication errors when client setup fails with AuthenticationException
#16418 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-13154 : Changes for the OffsetSpec.latest() to correctly represent the latest offset per partition
#16729 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-16907: Fix RaftUtil's type complexity
#16831 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-17456: Make sure FindCoordinatorResponse get created before consumer
#17404 commented on
Apr 20, 2025 • 0 new comments -
KAFKA-17798 : Adding forbiddenApi check
#17565 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-17871: avoid blocking the herder thread when producer flushing hangs
#18142 commented on
Apr 25, 2025 • 0 new comments -
[WIP] KIP-891: Multiversioning in Kafka Connect - Config and Validation Tests
#18326 commented on
Apr 26, 2025 • 0 new comments -
KAFKA-18356 Explicitly setting up instrumentation for inline mocking (Java 21+)
#18339 commented on
Apr 21, 2025 • 0 new comments -
[WIP] KIP-891: Multiversioning in Kafka Connect - Connector Multiversion Integration Test
#18360 commented on
Apr 26, 2025 • 0 new comments -
KAFAK-14604: SASL session expiration time will be overflowed when calculation
#18526 commented on
Apr 21, 2025 • 0 new comments -
KAFKA-16368: Constraints update for segment.index.bytes
#18596 commented on
Apr 21, 2025 • 0 new comments -
KAFKA-18561: Remove withKip853Rpc and replace it with withRaftProtocol
#18600 commented on
Apr 21, 2025 • 0 new comments -
KAFKA-18754: Allow `PlainSaslServer` to pass client info through the negotiated properties.
#18828 commented on
Apr 26, 2025 • 0 new comments -
[WIP] JWT bearer grant type support
#18912 commented on
Apr 26, 2025 • 0 new comments -
[WIP] KAFKA-16717 [2/N]: Add AdminClient.alterShareGroupOffsets
#18929 commented on
Apr 20, 2025 • 0 new comments -
KAFKA-17651: Implement `describeUserScramCredentials`
#19066 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-18424: Consider splitting PlaintextAdminIntegrationTest#testConsumerGroups
#19093 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-18778 Fix the inconsistent lastest supported version in StorageTool.scala and FutureCommand
#19157 commented on
Apr 24, 2025 • 0 new comments -
KAFKA-18760: Deprecate Optional<String> and return String from public Endpoint#listener
#19191 commented on
Apr 25, 2025 • 0 new comments -
KAFKA-18877: Add an mechanism to find cases where we accessed variables from the wrong thread.
#19231 commented on
Apr 26, 2025 • 0 new comments -
KAFKA-17573: Move KRaftMetadataCache to metadata module
#19232 commented on
Apr 21, 2025 • 0 new comments -
KAFKA-18379: Enforce resigned cannot transition to any other state in same epoch
#19236 commented on
Apr 26, 2025 • 0 new comments -
KAFKA-19008 Remove scala version from artifacts
#19241 commented on
Apr 26, 2025 • 0 new comments -
KAFKA-19048: Minimal movement replica balancing algorithm for reassignment
#19297 commented on
Apr 22, 2025 • 0 new comments