Re: [PR] MINOR: Fix the flaky TBRLMM `testInternalTopicExists` test [kafka]

2023-11-27 Thread via GitHub
showuon commented on code in PR #14840: URL: https://github.com/apache/kafka/pull/14840#discussion_r1407350742 ## storage/src/test/java/org/apache/kafka/server/log/remote/metadata/storage/TopicBasedRemoteLogMetadataManagerTest.java: ## @@ -70,18 +70,20 @@ public TopicBasedRemote

Re: [PR] KAFKA-15695: Update the local log start offset of a log after rebuilding the auxiliary state [kafka]

2023-11-27 Thread via GitHub
nikramakrishnan commented on code in PR #14649: URL: https://github.com/apache/kafka/pull/14649#discussion_r1407348678 ## core/src/main/scala/kafka/log/UnifiedLog.scala: ## @@ -1754,6 +1754,7 @@ class UnifiedLog(@volatile var logStartOffset: Long, leaderEpochCache.forea

[PR] MINOR: Ensure that DisplayName is set in all parameterized tests [kafka]

2023-11-27 Thread via GitHub
dajac opened a new pull request, #14850: URL: https://github.com/apache/kafka/pull/14850 This is a follow-up to https://github.com/apache/kafka/pull/14687 as we found out that some parameterized tests do not include the test method name in their name. For the context, the JUnit XML report d

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
showuon commented on PR #14428: URL: https://github.com/apache/kafka/pull/14428#issuecomment-1829267766 > Hi @showuon , > > Thanks for the changes. They look good to me in general. One potential issue with this implementation is that the leader doesn't check that the fetching voters

[jira] [Created] (KAFKA-15911) KRaft quorum leader should make sure the follower fetch is making progress

2023-11-27 Thread Luke Chen (Jira)
Luke Chen created KAFKA-15911: - Summary: KRaft quorum leader should make sure the follower fetch is making progress Key: KAFKA-15911 URL: https://issues.apache.org/jira/browse/KAFKA-15911 Project: Kafka

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
showuon commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1407337495 ## raft/src/main/java/org/apache/kafka/raft/KafkaRaftClient.java: ## @@ -1990,7 +1995,7 @@ private long pollLeader(long currentTimeMs) { LeaderState state = qu

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
showuon commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1407336829 ## raft/src/test/java/org/apache/kafka/raft/LeaderStateTest.java: ## @@ -447,6 +452,38 @@ public void testDescribeQuorumWithObservers() { observerState);

Re: [PR] KAFKA-15901: Client changes for registering telemetry and API calls (KIP-714) [kafka]

2023-11-27 Thread via GitHub
apoorvmittal10 commented on code in PR #14843: URL: https://github.com/apache/kafka/pull/14843#discussion_r1407336676 ## clients/src/main/java/org/apache/kafka/clients/admin/KafkaAdminClient.java: ## @@ -4387,7 +4398,52 @@ public FenceProducersResult fenceProducers(Collection t

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
showuon commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1407334210 ## raft/src/main/java/org/apache/kafka/raft/KafkaRaftClient.java: ## @@ -1340,6 +1341,9 @@ private FetchSnapshotResponseData handleFetchSnapshotRequest( Una

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
showuon commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1407333526 ## raft/src/main/java/org/apache/kafka/raft/LeaderState.java: ## @@ -79,6 +86,39 @@ protected LeaderState( this.grantingVoters = Collections.unmodifiableSet(ne

Re: [PR] KAFKA-15618: Kafka metrics collector and supporting classes (KIP-714) [kafka]

2023-11-27 Thread via GitHub
apoorvmittal10 commented on PR #14620: URL: https://github.com/apache/kafka/pull/14620#issuecomment-1829257829 @xvrl @mjsax Please help closing the PR, do we need to address any concern in the PR or we can merge. If required we can have a follow up PR as well. -- This is an automated mess

Re: [PR] KAFKA-15143: Adding in MockFixedKeyProcessorContext and Test [kafka]

2023-11-27 Thread via GitHub
lihaosky commented on code in PR #14605: URL: https://github.com/apache/kafka/pull/14605#discussion_r1407319712 ## streams/test-utils/src/test/java/org/apache/kafka/streams/test/MockFixedKeyProcessorContextTest.java: ## @@ -0,0 +1,315 @@ +/* + * Licensed to the Apache Software F

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1407198957 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/ConsumerNetworkThread.java: ## @@ -269,60 +275,56 @@ void cleanup() { * completed in time.

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1407198120 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -210,17 +210,19 @@ public CompletableFuture maybeAutoCommitAllC

Re: [PR] MINOR: Fix the flaky TBRLMM `testInternalTopicExists` test [kafka]

2023-11-27 Thread via GitHub
kamalcph commented on code in PR #14840: URL: https://github.com/apache/kafka/pull/14840#discussion_r1407187421 ## storage/src/test/java/org/apache/kafka/server/log/remote/metadata/storage/TopicBasedRemoteLogMetadataManagerTest.java: ## @@ -70,18 +70,20 @@ public TopicBasedRemot

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406787063 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -154,7 +154,7 @@ public NetworkClientDelegate.PollResult poll(fi

[PR] KAFKA-15910: New group coordinator needs to generate snapshots while loading [kafka]

2023-11-27 Thread via GitHub
jeffkbkim opened a new pull request, #14849: URL: https://github.com/apache/kafka/pull/14849 After the new coordinator loads a __consumer_offsets partition, it logs the following exception when making a read operation (fetch/list groups, etc): ``` java.lang.RuntimeException: No in

Re: [PR] KAFKA-15047: Roll active segment when it breaches the retention policy [kafka]

2023-11-27 Thread via GitHub
satishd merged PR #14766: URL: https://github.com/apache/kafka/pull/14766 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. To unsubscribe, e-mail: jira-unsubscr...@kafka.apache.

Re: [PR] KAFKA-15047: Roll active segment when it breaches the retention policy [kafka]

2023-11-27 Thread via GitHub
satishd commented on PR #14766: URL: https://github.com/apache/kafka/pull/14766#issuecomment-1829038408 Thanks @kamalcph for pointing out the JIRA to track the existing intermittent tiered storage related test failure. -- This is an automated message from the Apache Git Service. To respo

Re: [PR] KAFKA-15224: automating version change [kafka]

2023-11-27 Thread via GitHub
github-actions[bot] commented on PR #14229: URL: https://github.com/apache/kafka/pull/14229#issuecomment-1829016302 This PR is being marked as stale since it has not had any activity in 90 days. If you would like to keep this PR alive, please ask a committer for review. If the PR has merge

[jira] [Created] (KAFKA-15910) New group coordinator needs to generate snapshots while loading

2023-11-27 Thread Jeff Kim (Jira)
Jeff Kim created KAFKA-15910: Summary: New group coordinator needs to generate snapshots while loading Key: KAFKA-15910 URL: https://issues.apache.org/jira/browse/KAFKA-15910 Project: Kafka Issu

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406995366 ## raft/src/main/java/org/apache/kafka/raft/KafkaRaftClient.java: ## @@ -1990,7 +1995,7 @@ private long pollLeader(long currentTimeMs) { LeaderState state = qu

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406995366 ## raft/src/main/java/org/apache/kafka/raft/KafkaRaftClient.java: ## @@ -1990,7 +1995,7 @@ private long pollLeader(long currentTimeMs) { LeaderState state = qu

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406995366 ## raft/src/main/java/org/apache/kafka/raft/KafkaRaftClient.java: ## @@ -1990,7 +1995,7 @@ private long pollLeader(long currentTimeMs) { LeaderState state = qu

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406806920 ## raft/src/main/java/org/apache/kafka/raft/LeaderState.java: ## @@ -79,6 +86,39 @@ protected LeaderState( this.grantingVoters = Collections.unmodifiableSet(ne

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406803592 ## raft/src/main/java/org/apache/kafka/raft/LeaderState.java: ## @@ -79,6 +86,39 @@ protected LeaderState( this.grantingVoters = Collections.unmodifiableSet(ne

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406771117 ## raft/src/main/java/org/apache/kafka/raft/LeaderState.java: ## @@ -79,6 +86,39 @@ protected LeaderState( this.grantingVoters = Collections.unmodifiableSet(ne

Re: [PR] KAFKA-15670: add "inter.broker.listener.name" config in KRaft controller config [kafka]

2023-11-27 Thread via GitHub
showuon commented on PR #14631: URL: https://github.com/apache/kafka/pull/14631#issuecomment-1828916867 @mumrah , call for review. Thanks. -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the spec

[PR] KAFKA-15870: Move new group coordinator metrics from Yammer to Metrics [kafka]

2023-11-27 Thread via GitHub
jeffkbkim opened a new pull request, #14848: URL: https://github.com/apache/kafka/pull/14848 Move the following metrics from Yammer to Kafka metrics to continue with the migration from yammer to kafka metrics. These are not exposed and newly created metrics so there are no compatibility iss

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
soarez commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406925061 ## metadata/src/test/java/org/apache/kafka/metadata/util/MetadataFeatureUtil.java: ## @@ -0,0 +1,32 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
soarez commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406924620 ## metadata/src/main/java/org/apache/kafka/metadata/PartitionRegistration.java: ## @@ -377,7 +386,7 @@ public ApiMessageAndVersion toRecord(Uuid topicId, int partitionI

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
soarez commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406913694 ## metadata/src/main/java/org/apache/kafka/metadata/placement/DefaultDirProvider.java: ## @@ -0,0 +1,28 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under

Re: [PR] MINOR: Fix flaky BrokerLifecycleManagerTest [kafka]

2023-11-27 Thread via GitHub
soarez commented on code in PR #14836: URL: https://github.com/apache/kafka/pull/14836#discussion_r1406906907 ## core/src/test/scala/unit/kafka/server/BrokerLifecycleManagerTest.scala: ## @@ -201,7 +201,7 @@ class BrokerLifecycleManagerTest { while (!future.isDone || contex

Re: [PR] KAFKA-14438: Throw error when consumer configured with empty/whitespace-only group.id for AsyncKafkaConsumer [kafka]

2023-11-27 Thread via GitHub
kirktrue commented on PR #14768: URL: https://github.com/apache/kafka/pull/14768#issuecomment-1828804792 @mjsax would you be willing to review this PR? It's small and (hopefully!) straightforward. Thanks! -- This is an automated message from the Apache Git Service. To respond to the messa

Re: [PR] KAFKA-15046: Get rid of unnecessary fsyncs inside UnifiedLog.lock to stabilize performance [kafka]

2023-11-27 Thread via GitHub
ocadaruma commented on PR #14242: URL: https://github.com/apache/kafka/pull/14242#issuecomment-1828798534 @junrao Oh I misinterpreted as all green with only checking pipeline-view but I had to check tests view. I checked. Seems none of them are related to this change, and failures are

Re: [PR] MINOR: Fix flaky BrokerLifecycleManagerTest [kafka]

2023-11-27 Thread via GitHub
junrao commented on code in PR #14836: URL: https://github.com/apache/kafka/pull/14836#discussion_r1406880863 ## core/src/test/scala/unit/kafka/server/BrokerLifecycleManagerTest.scala: ## @@ -201,7 +201,7 @@ class BrokerLifecycleManagerTest { while (!future.isDone || contex

[jira] [Updated] (KAFKA-15908) Remove deprecated Consumer API poll(long timeout)

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15908?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15908: -- Fix Version/s: 4.0.0 > Remove deprecated Consumer API poll(long timeout) > ---

[jira] [Updated] (KAFKA-14438) Throw error when consumer configured with empty/whitespace-only group.id for AsyncKafkaConsumer

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-14438?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-14438: -- Fix Version/s: 3.7.0 (was: 4.0.0) > Throw error when consumer configured with e

[jira] [Updated] (KAFKA-15907) Remove previously deprecated Consumer features from 4.0

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15907?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15907: -- Fix Version/s: 4.0.0 > Remove previously deprecated Consumer features from 4.0 > -

[jira] [Updated] (KAFKA-15909) Throw error when consumer configured with empty/whitespace-only group.id for LegacyKafkaConsumer

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15909?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15909: -- Summary: Throw error when consumer configured with empty/whitespace-only group.id for LegacyKafkaConsu

[jira] [Updated] (KAFKA-14438) Throw error when consumer configured with empty/whitespace-only group.id for AsyncKafkaConsumer

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-14438?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-14438: -- Summary: Throw error when consumer configured with empty/whitespace-only group.id for AsyncKafkaConsum

[jira] [Updated] (KAFKA-15909) Remove support for empty "group.id" for "generic" group protocol

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15909?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15909: -- Description: Per [KIP-289|https://cwiki.apache.org/confluence/display/KAFKA/KIP-289%3A+Improve+the+de

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406862990 ## metadata/src/test/java/org/apache/kafka/metadata/util/MetadataFeatureUtil.java: ## @@ -0,0 +1,32 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under on

[jira] [Updated] (KAFKA-15909) Remove support for empty "group.id" for "generic" group protocol

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15909?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15909: -- Description: Per KIP-289, the use of an empty value for {{group.id}} configuration was deprecated bac

Re: [PR] MINOR: Fix flaky BrokerLifecycleManagerTest [kafka]

2023-11-27 Thread via GitHub
soarez commented on code in PR #14836: URL: https://github.com/apache/kafka/pull/14836#discussion_r1406861254 ## core/src/test/scala/unit/kafka/server/BrokerLifecycleManagerTest.scala: ## @@ -214,28 +214,20 @@ class BrokerLifecycleManagerTest { ctx.controllerNodeProvider.no

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406861113 ## metadata/src/main/java/org/apache/kafka/metadata/PartitionRegistration.java: ## @@ -377,7 +386,7 @@ public ApiMessageAndVersion toRecord(Uuid topicId, int partition

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406859690 ## metadata/src/main/java/org/apache/kafka/metadata/placement/DefaultDirProvider.java: ## @@ -0,0 +1,28 @@ +/* + * Licensed to the Apache Software Foundation (ASF) unde

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406858333 ## metadata/src/main/java/org/apache/kafka/controller/PartitionChangeBuilder.java: ## @@ -405,7 +415,7 @@ private void completeReassignmentIfNeeded() { targetA

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406858333 ## metadata/src/main/java/org/apache/kafka/controller/PartitionChangeBuilder.java: ## @@ -405,7 +415,7 @@ private void completeReassignmentIfNeeded() { targetA

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14820: URL: https://github.com/apache/kafka/pull/14820#discussion_r1406856346 ## metadata/src/main/java/org/apache/kafka/controller/PartitionChangeBuilder.java: ## @@ -123,6 +127,7 @@ public PartitionChangeBuilder( this.targetElr = Repli

Re: [PR] MINOR: Fix flaky BrokerLifecycleManagerTest [kafka]

2023-11-27 Thread via GitHub
soarez commented on code in PR #14836: URL: https://github.com/apache/kafka/pull/14836#discussion_r1406855449 ## core/src/test/scala/unit/kafka/server/BrokerLifecycleManagerTest.scala: ## @@ -201,7 +201,7 @@ class BrokerLifecycleManagerTest { while (!future.isDone || contex

Re: [PR] KAFKA-15890: Consumer.poll with long timeout unaware of assigned partitions [kafka]

2023-11-27 Thread via GitHub
AndrewJSchofield commented on code in PR #14835: URL: https://github.com/apache/kafka/pull/14835#discussion_r1406853731 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/HeartbeatRequestManager.java: ## @@ -417,4 +394,127 @@ private void updateHeartbeatInterva

[jira] [Updated] (KAFKA-15909) Remove support for empty "group.id" for "generic" group protocol

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15909?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15909: -- Summary: Remove support for empty "group.id" for "generic" group protocol (was: Remove support for em

[jira] [Updated] (KAFKA-15909) Remove support for empty "group.id"

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15909?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15909: -- Fix Version/s: 4.0.0 > Remove support for empty "group.id" > --- > >

[jira] [Updated] (KAFKA-15908) Remove deprecated Consumer API poll(long timeout)

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15908?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15908: -- Description: Per [KIP-266|https://cwiki.apache.org/confluence/display/KAFKA/KIP-266%3A+Fix+consumer+i

[jira] [Created] (KAFKA-15909) Remove support for empty "group.id"

2023-11-27 Thread Kirk True (Jira)
Kirk True created KAFKA-15909: - Summary: Remove support for empty "group.id" Key: KAFKA-15909 URL: https://issues.apache.org/jira/browse/KAFKA-15909 Project: Kafka Issue Type: Sub-task

[jira] [Updated] (KAFKA-15908) Remove deprecated Consumer API poll(long timeout)

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15908?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15908: -- Component/s: clients consumer > Remove deprecated Consumer API poll(long timeout) > -

[jira] [Created] (KAFKA-15908) Remove deprecated Consumer API poll(long timeout)

2023-11-27 Thread Kirk True (Jira)
Kirk True created KAFKA-15908: - Summary: Remove deprecated Consumer API poll(long timeout) Key: KAFKA-15908 URL: https://issues.apache.org/jira/browse/KAFKA-15908 Project: Kafka Issue Type: Sub-t

Re: [PR] KAFKA-15886: Always specify directories for new partition registrations [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on PR #14820: URL: https://github.com/apache/kafka/pull/14820#issuecomment-1828735267 @soarez : `BrokerLifecycleManagerTest.testAlwaysSendsAccumulatedOfflineDirs` seems to be failing -- can you update this with the latest from trunk? -- This is an automated message from

[jira] [Updated] (KAFKA-15896) Flaky test: shouldQuerySpecificStalePartitionStores() – org.apache.kafka.streams.integration.StoreQueryIntegrationTest

2023-11-27 Thread Matthias J. Sax (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15896?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Matthias J. Sax updated KAFKA-15896: Labels: flaky-test (was: ) > Flaky test: shouldQuerySpecificStalePartitionStores() – > o

[jira] [Updated] (KAFKA-15896) Flaky test: shouldQuerySpecificStalePartitionStores() – org.apache.kafka.streams.integration.StoreQueryIntegrationTest

2023-11-27 Thread Matthias J. Sax (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15896?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Matthias J. Sax updated KAFKA-15896: Component/s: streams unit tests > Flaky test: shouldQuerySpecificStalePar

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on code in PR #14428: URL: https://github.com/apache/kafka/pull/14428#discussion_r1406768273 ## raft/src/main/java/org/apache/kafka/raft/LeaderState.java: ## @@ -79,6 +86,39 @@ protected LeaderState( this.grantingVoters = Collections.unmodifiableSet(ne

[jira] [Updated] (KAFKA-15907) Remove previously deprecated Consumer features from 4.0

2023-11-27 Thread Kirk True (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15907?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Kirk True updated KAFKA-15907: -- Component/s: clients consumer > Remove previously deprecated Consumer features from 4

[jira] [Created] (KAFKA-15907) Remove previously deprecated Consumer features from 4.0

2023-11-27 Thread Kirk True (Jira)
Kirk True created KAFKA-15907: - Summary: Remove previously deprecated Consumer features from 4.0 Key: KAFKA-15907 URL: https://issues.apache.org/jira/browse/KAFKA-15907 Project: Kafka Issue Type:

Re: [PR] KAFKA-15831: KIP-1000 protocol and admin client [kafka]

2023-11-27 Thread via GitHub
AndrewJSchofield commented on PR #14811: URL: https://github.com/apache/kafka/pull/14811#issuecomment-1828718746 Build is almost green. A small number of test failures unrelated to this PR. -- This is an automated message from the Apache Git Service. To respond to the message, please log o

Re: [PR] MINOR: Fix flaky BrokerLifecycleManagerTest [kafka]

2023-11-27 Thread via GitHub
junrao commented on code in PR #14836: URL: https://github.com/apache/kafka/pull/14836#discussion_r1406820475 ## core/src/test/scala/unit/kafka/server/BrokerLifecycleManagerTest.scala: ## @@ -201,7 +201,7 @@ class BrokerLifecycleManagerTest { while (!future.isDone || contex

Re: [PR] MINOR: Fix flaky BrokerLifecycleManagerTest [kafka]

2023-11-27 Thread via GitHub
cmccabe merged PR #14836: URL: https://github.com/apache/kafka/pull/14836 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. To unsubscribe, e-mail: jira-unsubscr...@kafka.apache.

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on PR #14842: URL: https://github.com/apache/kafka/pull/14842#issuecomment-1828686697 Hi @lucasbru - I just opened the PR for you to review. I'm not 100% happy with the way tests are setup therefore I made some changes around optionally disabling autocommit in the netwo

Re: [PR] MINOR: Zk to KRaft migration is now production ready [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on PR #14546: URL: https://github.com/apache/kafka/pull/14546#issuecomment-1828684914 Thanks for the PR, @ocadaruma . There is a PR we've been working on for a while, https://github.com/apache/kafka/pull/14160/files , which I think includes your fix and much more. I

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406792003 ## clients/src/test/java/org/apache/kafka/clients/consumer/internals/ConsumerTestBuilder.java: ## @@ -279,7 +287,7 @@ public ConsumerNetworkThreadTestBuilder(Optiona

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406789593 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -206,21 +206,21 @@ public CompletableFuture maybeAutoCommit(fina

Re: [PR] KAFKA-15468: Prevent transaction coordinator reloads on already loaded leaders [kafka]

2023-11-27 Thread via GitHub
hachikuji commented on code in PR #14489: URL: https://github.com/apache/kafka/pull/14489#discussion_r1406789222 ## core/src/main/scala/kafka/coordinator/transaction/TransactionStateManager.scala: ## @@ -514,8 +520,14 @@ class TransactionStateManager(brokerId: Int, * When th

[jira] [Resolved] (KAFKA-15860) ControllerRegistration must be written out to the metadata image

2023-11-27 Thread Colin McCabe (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15860?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Colin McCabe resolved KAFKA-15860. -- Fix Version/s: 3.7.0 Resolution: Fixed > ControllerRegistration must be written out to

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406788484 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -184,7 +184,7 @@ private static long findMinTime(final Collectio

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406787063 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -154,7 +154,7 @@ public NetworkClientDelegate.PollResult poll(fi

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406788484 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -184,7 +184,7 @@ private static long findMinTime(final Collectio

Re: [PR] KAFKA-15311: Fix docs about reverting to ZooKeeper mode during KRaft migration [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14160: URL: https://github.com/apache/kafka/pull/14160#discussion_r1406786870 ## docs/ops.html: ## @@ -3778,6 +3784,14 @@ Migrating brokers to KRaft Each broker is restarted with a KRaft configuration until the entire cluster is running in

Re: [PR] KAFKA-15311: Fix docs about reverting to ZooKeeper mode during KRaft migration [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14160: URL: https://github.com/apache/kafka/pull/14160#discussion_r1406786425 ## docs/ops.html: ## @@ -3603,39 +3603,45 @@ Supporting JBOD configurations with multiple storage directories Modifying certain dynamic configurations on the

Re: [PR] KAFKA-15311: Fix docs about reverting to ZooKeeper mode during KRaft migration [kafka]

2023-11-27 Thread via GitHub
cmccabe commented on code in PR #14160: URL: https://github.com/apache/kafka/pull/14160#discussion_r1406786099 ## docs/ops.html: ## @@ -3603,39 +3603,45 @@ Supporting JBOD configurations with multiple storage directories Modifying certain dynamic configurations on the

Re: [PR] KAFKA-15819: Fix leaked KafkaRaftManager in ZK mode during migration [kafka]

2023-11-27 Thread via GitHub
cmccabe merged PR #14751: URL: https://github.com/apache/kafka/pull/14751 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. To unsubscribe, e-mail: jira-unsubscr...@kafka.apache.

Re: [PR] MINOR: Rename method sendBrokerHeartbeat [kafka]

2023-11-27 Thread via GitHub
cmccabe merged PR #14658: URL: https://github.com/apache/kafka/pull/14658 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. To unsubscribe, e-mail: jira-unsubscr...@kafka.apache.

Re: [PR] KAFKA-15768: StateQueryResult#getOnlyPartitionResult should not throw for FailedQueryResult [kafka]

2023-11-27 Thread via GitHub
hanyuzheng7 closed pull request #14821: KAFKA-15768: StateQueryResult#getOnlyPartitionResult should not throw for FailedQueryResult URL: https://github.com/apache/kafka/pull/14821 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub a

Re: [PR] KAFKA-15629: Proposal to introduce IQv2 Query Types: TimestampedKeyQuery and TimestampedRangeQuery [kafka]

2023-11-27 Thread via GitHub
hanyuzheng7 commented on PR #14570: URL: https://github.com/apache/kafka/pull/14570#issuecomment-1828621306 @mjsax ready for final code review. -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the

Re: [PR] KAFKA-15629: Proposal to introduce IQv2 Query Types: TimestampedKeyQuery and TimestampedRangeQuery [kafka]

2023-11-27 Thread via GitHub
hanyuzheng7 commented on code in PR #14570: URL: https://github.com/apache/kafka/pull/14570#discussion_r1406752014 ## streams/src/test/java/org/apache/kafka/streams/integration/IQv2StoreIntegrationTest.java: ## @@ -1584,7 +1646,43 @@ public void shouldHandleKeyQuery( )

Re: [PR] KAFKA-15629: Proposal to introduce IQv2 Query Types: TimestampedKeyQuery and TimestampedRangeQuery [kafka]

2023-11-27 Thread via GitHub
hanyuzheng7 commented on code in PR #14570: URL: https://github.com/apache/kafka/pull/14570#discussion_r1406751704 ## streams/src/test/java/org/apache/kafka/streams/integration/IQv2StoreIntegrationTest.java: ## @@ -1632,10 +1729,65 @@ public void shouldHandleRangeQuery(

Re: [PR] KAFKA-15456: Client support for OffsetFetch/OffsetCommit v9 [kafka]

2023-11-27 Thread via GitHub
kirktrue commented on PR #14557: URL: https://github.com/apache/kafka/pull/14557#issuecomment-1828563894 Thanks for the PR, @lianetm. This is tricky stuff, to be sure! My feedback is mostly minor. Hopefully I can do another pass in a day or so with more time. -- This is an automated messa

Re: [PR] KAFKA-15456: Client support for OffsetFetch/OffsetCommit v9 [kafka]

2023-11-27 Thread via GitHub
kirktrue commented on code in PR #14557: URL: https://github.com/apache/kafka/pull/14557#discussion_r1406678397 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -161,16 +172,16 @@ public NetworkClientDelegate.PollResult poll(f

Re: [PR] KAFKA-15887: Ensure FindCoordinatorRequest is sent before closing [kafka]

2023-11-27 Thread via GitHub
philipnee commented on code in PR #14842: URL: https://github.com/apache/kafka/pull/14842#discussion_r1406699542 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/ConsumerNetworkThread.java: ## @@ -269,22 +270,40 @@ void cleanup() { * completed in time.

Re: [PR] KAFKA-15890: Consumer.poll with long timeout unaware of assigned partitions [kafka]

2023-11-27 Thread via GitHub
AndrewJSchofield commented on code in PR #14835: URL: https://github.com/apache/kafka/pull/14835#discussion_r1406699697 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/HeartbeatRequestManager.java: ## @@ -417,4 +394,127 @@ private void updateHeartbeatInterva

Re: [PR] KAFKA-15489: resign leadership when no fetch from majority voters [kafka]

2023-11-27 Thread via GitHub
jsancio commented on PR #14428: URL: https://github.com/apache/kafka/pull/14428#issuecomment-1828499581 Excuse the delays @showuon . I'll review this today and this week! -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use

Re: [PR] KAFKA-15373: fix exception thrown in Admin#describeTopics for unknown ID [kafka]

2023-11-27 Thread via GitHub
MikeEdgar commented on PR #14599: URL: https://github.com/apache/kafka/pull/14599#issuecomment-1828509146 Hi @jolshan , please take a look at this PR to modify the exception thrown when describing a topic by an unknown topic ID. The CI failures don't appear related to the change. -- This

Re: [PR] KAFKA-15372: Reconfigure dedicated MM2 connectors after leadership change [kafka]

2023-11-27 Thread via GitHub
gharris1727 commented on PR #14293: URL: https://github.com/apache/kafka/pull/14293#issuecomment-1828464698 Hi @C0urante @yashmayya I'd like to get this into the 3.7.0 release, and code freeze is currently planned for Dec 20th. PTAL, thanks! -- This is an automated message from the Apache

Re: [PR] KAFKA-15890: Consumer.poll with long timeout unaware of assigned partitions [kafka]

2023-11-27 Thread via GitHub
AndrewJSchofield commented on code in PR #14835: URL: https://github.com/apache/kafka/pull/14835#discussion_r1406686948 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/HeartbeatRequestManager.java: ## @@ -181,36 +191,19 @@ public NetworkClientDelegate.PollRe

Re: [PR] KAFKA-15468: Prevent transaction coordinator reloads on already loaded leaders [kafka]

2023-11-27 Thread via GitHub
jolshan commented on code in PR #14489: URL: https://github.com/apache/kafka/pull/14489#discussion_r1406686608 ## core/src/main/scala/kafka/coordinator/transaction/TransactionStateManager.scala: ## @@ -514,8 +520,14 @@ class TransactionStateManager(brokerId: Int, * When this

Re: [PR] KAFKA-15890: Consumer.poll with long timeout unaware of assigned partitions [kafka]

2023-11-27 Thread via GitHub
AndrewJSchofield commented on code in PR #14835: URL: https://github.com/apache/kafka/pull/14835#discussion_r1406683119 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/HeartbeatRequestManager.java: ## @@ -417,4 +394,127 @@ private void updateHeartbeatInterva

Re: [PR] KAFKA-15890: Consumer.poll with long timeout unaware of assigned partitions [kafka]

2023-11-27 Thread via GitHub
kirktrue commented on code in PR #14835: URL: https://github.com/apache/kafka/pull/14835#discussion_r1406656043 ## clients/src/main/java/org/apache/kafka/clients/consumer/internals/CommitRequestManager.java: ## @@ -159,11 +159,19 @@ public NetworkClientDelegate.PollResult poll(f

Re: [PR] KAFKA-15468: Prevent transaction coordinator reloads on already loaded leaders [kafka]

2023-11-27 Thread via GitHub
hachikuji commented on code in PR #14489: URL: https://github.com/apache/kafka/pull/14489#discussion_r1406616682 ## core/src/main/scala/kafka/coordinator/transaction/TransactionStateManager.scala: ## @@ -514,8 +520,14 @@ class TransactionStateManager(brokerId: Int, * When th

[jira] [Updated] (KAFKA-15372) MM2 rolling restart can drop configuration changes silently

2023-11-27 Thread Greg Harris (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15372?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Greg Harris updated KAFKA-15372: Fix Version/s: 3.7.0 > MM2 rolling restart can drop configuration changes silently > -

[jira] [Updated] (KAFKA-15906) Emit offset syncs more often than offset.lag.max for low-throughput/finite partitions

2023-11-27 Thread Greg Harris (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-15906?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Greg Harris updated KAFKA-15906: Description: Right now, the offset.lag.max configuration limits the number of offset syncs are em

Re: [PR] MINOR: Fix the flaky TBRLMM `testInternalTopicExists` test [kafka]

2023-11-27 Thread via GitHub
junrao commented on code in PR #14840: URL: https://github.com/apache/kafka/pull/14840#discussion_r1406631952 ## storage/src/test/java/org/apache/kafka/server/log/remote/metadata/storage/TopicBasedRemoteLogMetadataManagerTest.java: ## @@ -70,18 +70,20 @@ public TopicBasedRemoteL

  1   2   >