You are viewing a plain text version of this content. The canonical link for it is here.
Posted to jira@kafka.apache.org by "jeffkbkim (via GitHub)" <gi...@apache.org> on 2023/04/18 14:34:19 UTC

[GitHub] [kafka] jeffkbkim opened a new pull request, #13603: KAFKA-14869: Bump coordinator value records to flexible versions (KIP…

jeffkbkim opened a new pull request, #13603:
URL: https://github.com/apache/kafka/pull/13603

   …-915, Part-2) (#13526)
   
   This patch implemented the second part of KIP-915. It bumps the versions of the value records used by the group coordinator and the transaction coordinator to make them flexible versions. The new versions are not used when writing to the partitions but only when reading from the partitions. This allows downgrades from future versions that will include tagged fields.
   
   Reviewers: David Jacot <dj...@confluent.io>
   
   *More detailed description of your change,
   if necessary. The PR title and PR message become
   the squashed commit message, so use a separate
   comment to ping reviewers.*
   
   *Summary of testing strategy (including rationale)
   for the feature or bug fix. Unit and/or integration
   tests are expected for any behaviour change and
   system tests should be considered for larger changes.*
   
   ### Committer Checklist (excluded from commit message)
   - [ ] Verify design and implementation 
   - [ ] Verify test coverage and CI build status
   - [ ] Verify documentation (including upgrade notes)
   


-- 
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-unsubscribe@kafka.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [kafka] jeffkbkim commented on pull request #13603: KAFKA-14869: Bump coordinator value records to flexible versions (KIP…

Posted by "jeffkbkim (via GitHub)" <gi...@apache.org>.
jeffkbkim commented on PR #13603:
URL: https://github.com/apache/kafka/pull/13603#issuecomment-1520578217

   test are unrelated
   ```
   Build / JDK 8 and Scala 2.12 / testDescribeQuorumRequestToBrokers() – kafka.server.KRaftClusterTest
   31s
   Build / JDK 8 and Scala 2.12 / testUpdateMetadataVersion() – kafka.server.KRaftClusterTest
   19s
   Build / JDK 17 and Scala 2.13 / testDescribeAtMinIsrPartitions(String).quorum=kraft – kafka.admin.TopicCommandIntegrationTest
   12s
   Build / JDK 11 and Scala 2.13 / testSeparateOffsetsTopic – org.apache.kafka.connect.integration.ExactlyOnceSourceIntegrationTest
   2m 58s
   Build / JDK 11 and Scala 2.13 / testSendOffsetsWithNoConsumerGroupWriteAccess(String).quorum=kraft – kafka.api.AuthorizerIntegrationTest
   13s
   Build / JDK 11 and Scala 2.13 / testConsumptionWithBrokerFailures() – kafka.api.ConsumerBounceTest
   30s
   Build / JDK 11 and Scala 2.13 / testCreateClusterAndCreateListDeleteTopic() – kafka.server.KRaftClusterTest
   ```


-- 
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-unsubscribe@kafka.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [kafka] dajac merged pull request #13603: KAFKA-14869: Bump coordinator value records to flexible versions (KIP…

Posted by "dajac (via GitHub)" <gi...@apache.org>.
dajac merged PR #13603:
URL: https://github.com/apache/kafka/pull/13603


-- 
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-unsubscribe@kafka.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [kafka] dajac commented on pull request #13603: KAFKA-14869: Bump coordinator value records to flexible versions (KIP…

Posted by "dajac (via GitHub)" <gi...@apache.org>.
dajac commented on PR #13603:
URL: https://github.com/apache/kafka/pull/13603#issuecomment-1517975471

   @jeffkbkim Could you please rebase this one?


-- 
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-unsubscribe@kafka.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [kafka] jeffkbkim commented on pull request #13603: KAFKA-14869: Bump coordinator value records to flexible versions (KIP…

Posted by "jeffkbkim (via GitHub)" <gi...@apache.org>.
jeffkbkim commented on PR #13603:
URL: https://github.com/apache/kafka/pull/13603#issuecomment-1516453173

   @dajac 
   ```
   org.apache.kafka.streams.integration.SmokeTestDriverIntegrationTest. shouldWorkWithRebalance
   kafka.api.ConsumerBounceTest.testSubscribeWhenTopicUnavailable()
   ```
   passed locally


-- 
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-unsubscribe@kafka.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org