This is an automated email from the ASF dual-hosted git repository.
github-bot pushed a commit to branch test-catalog
in repository https://gitbox.apache.org/repos/asf/kafka.git
The following commit(s) were added to refs/heads/test-catalog by this push:
new 6f546f031e2 Update test catalog data for GHA workflow run 13995388831
6f546f031e2 is described below
commit 6f546f031e27b2d8ca928a9e6de40c0f78b8f566
Author: github-actions[bot]
<41898282+github-actions[bot]@users.noreply.github.com>
AuthorDate: Fri Mar 21 18:23:20 2025 +0000
Update test catalog data for GHA workflow run 13995388831
Commit:
https://github.com/apache/kafka/commit/ec12d360a1ad21229a125153f0982d68fed06aa8
GitHub Run: https://github.com/apache/kafka/actions/runs/13995388831
---
.../clients/clients-integration-tests/tests.yaml | 2 +-
test-catalog/core/tests.yaml | 385 ++-------------------
2 files changed, 24 insertions(+), 363 deletions(-)
diff --git a/test-catalog/clients/clients-integration-tests/tests.yaml
b/test-catalog/clients/clients-integration-tests/tests.yaml
index a04bce1e26a..b37a1a10b08 100644
--- a/test-catalog/clients/clients-integration-tests/tests.yaml
+++ b/test-catalog/clients/clients-integration-tests/tests.yaml
@@ -31,7 +31,7 @@ org.apache.kafka.clients.admin.StaticBrokerConfigTest:
- testTopicConfigsGetImpactedIfStaticConfigsAddToBroker
- testTopicConfigsGetImpactedIfStaticConfigsAddToController
org.apache.kafka.clients.consumer.ConsumerIntegrationTest:
-- testAsyncConsumerWithOldGroupCoordinator
+- testAsyncConsumerWithConsumerProtocolDisabled
- testFetchPartitionsAfterFailedListenerWithGroupProtocolClassic
- testFetchPartitionsAfterFailedListenerWithGroupProtocolConsumer
- testFetchPartitionsWithAlwaysFailedListenerWithGroupProtocolClassic
diff --git a/test-catalog/core/tests.yaml b/test-catalog/core/tests.yaml
index 352ff4072ea..fa8362e49e8 100644
--- a/test-catalog/core/tests.yaml
+++ b/test-catalog/core/tests.yaml
@@ -809,331 +809,6 @@ kafka.coordinator.group.CoordinatorPartitionWriterTest:
- testRegisterDeregisterListener
- testWriteRecords
- testWriteRecordsWithFailure
-kafka.coordinator.group.GroupCoordinatorAdapterTest:
-- testCommitOffsets
-- testCommitTransactionalOffsets
-- testConsumerGroupDescribe
-- testDeleteGroups
-- testDeleteOffsetsWithGroupLevelError
-- testDescribeGroup
-- testDescribeShareGroupOffsets
-- testFetchAllOffsets
-- testFetchOffsets
-- testHeartbeat
-- testJoinConsumerGroup
-- testJoinGroup
-- testJoinShareGroup
-- testListGroups
-- testOnTransactionCompletedWithUnexpectedException
-- testShareGroupDescribe
-- testStreamsGroupHeartbeat
-- testSyncGroup
-kafka.coordinator.group.GroupCoordinatorConcurrencyTest:
-- testConcurrentGoodPathSequence
-- testConcurrentJoinGroupEnforceGroupMaxSize
-- testConcurrentRandomSequence
-- testConcurrentTxnGoodPathSequence
-kafka.coordinator.group.GroupCoordinatorTest:
-- shouldDelayInitialRebalanceByGroupInitialRebalanceDelayOnEmptyGroup
-- shouldDelayRebalanceUptoRebalanceTimeout
-- shouldGetDifferentStaticMemberIdAfterEachRejoin
-- shouldResetRebalanceDelayWhenNewMemberJoinsGroupInInitialRebalance
-- staticMemberCommitOffsetWithInvalidMemberId
-- staticMemberFenceDuplicateRejoinedFollower
-- staticMemberFenceDuplicateRejoiningFollowerAfterMemberIdChanged
-- staticMemberFenceDuplicateSyncingFollowerAfterMemberIdChanged
-- staticMemberHeartbeatLeaderWithInvalidMemberId
-- staticMemberJoinAsFirstMember
-- staticMemberJoinWithUnknownInstanceIdAndKnownMemberId
-- staticMemberReJoinWithExplicitUnknownMemberId
-- staticMemberReJoinWithIllegalStateAsUnknownMember
-- staticMemberRejoinAsFollowerWithKnownMemberIdAndNoProtocolChange
-- staticMemberRejoinAsFollowerWithMismatchedMemberId
-- staticMemberRejoinAsFollowerWithUnknownMemberId
-- staticMemberRejoinAsLeaderWithMismatchedMemberId
-- staticMemberRejoinWithFollowerIdAndChangeOfProtocol
--
staticMemberRejoinWithKnownLeaderIdToTriggerRebalanceAndFollowerWithChangeOfProtocol
-- staticMemberRejoinWithKnownMemberId
-- staticMemberRejoinWithLeaderIdAndKnownMemberId
-- staticMemberRejoinWithLeaderIdAndUnexpectedDeadGroup
-- staticMemberRejoinWithLeaderIdAndUnexpectedEmptyGroup
-- staticMemberRejoinWithLeaderIdAndUnknownMemberId
--
staticMemberRejoinWithUnknownMemberIdAndChangeOfProtocolWhileSelectProtocolUnchanged
--
staticMemberRejoinWithUnknownMemberIdAndChangeOfProtocolWhileSelectProtocolUnchangedPersistenceFailure
--
staticMemberRejoinWithUnknownMemberIdAndChangeOfProtocolWithSelectedProtocolChanged
-- staticMemberRejoinWithUpdatedSessionAndRebalanceTimeoutsAndPersistChange
--
staticMemberRejoinWithUpdatedSessionAndRebalanceTimeoutsButCannotPersistChange
-- staticMemberSyncAsLeaderWithInvalidMemberId
-- testBasicFetchTxnOffsets
-- testBatchLeaveDeadGroup
-- testCommitAndFetchOffsetsWithEmptyGroup
-- testCommitMaintainsSession
-- testCommitOffsetFromUnknownGroup
-- testCommitOffsetInCompletingRebalance
-- testCommitOffsetInCompletingRebalanceFromIllegalGeneration
-- testCommitOffsetInCompletingRebalanceFromUnknownMemberId
-- testCommitOffsetWithDefaultGeneration
-- testCommitOffsetsAfterGroupIsEmpty
-- testCompleteHeartbeatWithGroupDead
-- testCompleteHeartbeatWithMemberAlreadyRemoved
-- testDeleteEmptyGroup
-- testDeleteEmptyGroupWithStoredOffsets
-- testDeleteGroupWithInvalidGroupId
-- testDeleteGroupWithWrongCoordinator
-- testDeleteNonEmptyGroup
-- testDeleteOffsetOfConsumerGroupWithUnparsableProtocol
-- testDeleteOffsetOfDeadConsumerGroup
-- testDeleteOffsetOfEmptyConsumerGroup
-- testDeleteOffsetOfEmptyNonConsumerGroup
-- testDeleteOffsetOfNonEmptyNonConsumerGroup
-- testDeleteOffsetOfNonExistingGroup
-- testDeleteOffsetOfStableConsumerGroup
-- testDescribeGroupInactiveGroup
-- testDescribeGroupRebalancing
-- testDescribeGroupStableForDynamicMember
-- testDescribeGroupStableForStaticMember
-- testDescribeGroupWrongCoordinator
-- testDynamicMembersCanReJoinGroupWithMaxSizeWhileRebalancing
-- testDynamicMembersJoinGroupWithMaxSize
-- testDynamicMembersJoinGroupWithMaxSizeAndRequiredKnownMember
-- testFetchAllOffsets
-- testFetchOffsetForUnknownPartition
-- testFetchOffsetNotCoordinatorForGroup
-- testFetchOffsets
-- testFetchPendingTxnOffsetsWithAbort
-- testFetchPendingTxnOffsetsWithCommit
-- testFetchTxnOffsetsIgnoreSpuriousCommit
-- testFetchTxnOffsetsMultipleProducersOneGroup
-- testFetchTxnOffsetsOneProducerMultipleGroups
-- testFetchTxnOffsetsWithAbort
-- testGenerationIdIncrementsOnRebalance
-- testHeartbeatDeadGroup
-- testHeartbeatDuringRebalanceCausesRebalanceInProgress
-- testHeartbeatEmptyGroup
-- testHeartbeatIllegalGeneration
-- testHeartbeatMaintainsSession
-- testHeartbeatRebalanceInProgress
-- testHeartbeatUnknownConsumerExistingGroup
-- testHeartbeatUnknownGroup
-- testHeartbeatWrongCoordinator
-- testInvalidGroupId
-- testJoinGroupCompletionWhenPendingMemberJoins
-- testJoinGroupCompletionWhenPendingMemberTimesOut
-- testJoinGroupFromUnchangedFollowerDoesNotRebalance
-- testJoinGroupFromUnchangedLeaderShouldRebalance
-- testJoinGroupInconsistentGroupProtocol
-- testJoinGroupInconsistentProtocolType
-- testJoinGroupProtocolTypeIsNotProvidedWhenAnErrorOccurs
-- testJoinGroupReturnsTheProtocolType
-- testJoinGroupSecondJoinInconsistentProtocol
-- testJoinGroupSessionTimeoutTooLarge
-- testJoinGroupSessionTimeoutTooSmall
-- testJoinGroupShouldReceiveErrorIfGroupOverMaxSize
-- testJoinGroupUnknownConsumerExistingGroup
-- testJoinGroupUnknownConsumerNewDeadGroup
-- testJoinGroupUnknownConsumerNewGroup
-- testJoinGroupWithEmptyGroupProtocol
-- testJoinGroupWithEmptyProtocolType
-- testJoinGroupWrongCoordinator
-- testLastJoiningMembersAreKickedOutWhenReJoiningGroupWithMaxSize
-- testLeaderFailToRejoinBeforeFinalRebalanceTimeoutWithLongSessionTimeout
-- testLeaderFailureInSyncGroup
-- testLeaderRejoinBeforeFinalRebalanceTimeoutWithLongSessionTimeout
-- testLeaveGroupStaticMemberWithUnknownMemberId
-- testLeaveGroupUnknownConsumerExistingGroup
-- testLeaveGroupUnknownGroup
-- testLeaveGroupWithFencedInstanceId
-- testLeaveGroupWrongCoordinator
-- testListGroupsIncludesRebalancingGroups
-- testListGroupsIncludesStableGroups
-- testListGroupsWithStates
-- testListGroupsWithTypes
-- testManualCommitOffsetShouldNotValidateMemberIdAndInstanceId
-- testNewMemberFailureAfterJoinGroupCompletion
-- testNewMemberFailureAfterSyncGroupCompletion
-- testNewMemberJoinExpiration
-- testNewMemberTimeoutCompletion
-- testOffsetCommitDeadGroup
-- testOffsetsRetentionMsIntegerOverflow
-- testPendingMemberBatchLeaveGroup
-- testPendingMembersLeavesGroup
-- testRebalanceCompletesBeforeMemberJoins
-- testRebalanceDoesNotTimeOutWhenAllSyncAreReceived
-- testRebalanceTimesOutWhenSyncRequestIsNotReceived
-- testRebalanceTimesOutWhenSyncRequestIsNotReceivedFromFollowers
-- testRebalanceTimesOutWhenSyncRequestIsNotReceivedFromLeaders
-- testRequestHandlingWhileLoadingInProgress
-- testSecondMemberPartiallyJoinAndTimeout
-- testSessionTimeout
-- testSessionTimeoutDuringRebalance
-- testSingleLeaveDeadGroup
-- testStaticMemberFollowerFailToRejoinBeforeRebalanceTimeout
-- testStaticMemberLeaderFailToRejoinBeforeRebalanceTimeout
-- testStaticMembersFencedInstanceBatchLeaveGroup
-- testStaticMembersJoinGroupWithMaxSize
-- testStaticMembersUnknownGroupBatchLeaveGroup
-- testStaticMembersUnknownInstanceBatchLeaveGroup
-- testStaticMembersValidBatchLeaveGroup
-- testStaticMembersWrongCoordinatorBatchLeaveGroup
-- testSyncDeadGroup
-- testSyncGroupEmptyAssignment
-- testSyncGroupFollowerAfterLeader
-- testSyncGroupFromIllegalGeneration
-- testSyncGroupFromUnknownGroup
-- testSyncGroupFromUnknownMember
-- testSyncGroupLeaderAfterFollower
-- testSyncGroupNotCoordinator
-- testSyncGroupReturnsAnErrorWhenProtocolNameIsInconsistent
-- testSyncGroupReturnsAnErrorWhenProtocolTypeIsInconsistent
-- testSyncGroupSucceedWhenProtocolTypeAndNameAreConsistent
-- testSyncGroupSucceedWhenProtocolTypeAndNameAreNotProvided
-- testTxnCommitOffsetWithFencedInstanceId
-- testTxnCommitOffsetWithIllegalGeneration
-- testTxnCommitOffsetWithInvalidMemberId
-- testTxnCommitOffsetWithKnownMemberId
-- testTxnCommitOffsetWithLegalGeneration
-- testTxnOffsetMetadataTooLarge
-- testValidHeartbeat
-- testValidJoinGroup
-- testValidLeaveGroup
-- testVerificationErrorsForTxnOffsetCommits
-kafka.coordinator.group.GroupMetadataManagerTest:
-- testAddGroup
-- testCommitOffset
-- testCommitOffsetFailure
-- testCommitOffsetPartialFailure
-- testCommitOffsetWhenCoordinatorHasMoved
-- testCurrentStateTimestampForAllVersions
-- testDeserializeFutureGroupMetadataValue
-- testDeserializeFutureOffsetCommitValue
-- testDeserializeHighestSupportedGroupMetadataValueVersion
-- testDeserializeHighestSupportedOffsetCommitValueVersion
-- testDoNotLoadAbortedTransactionalOffsetCommits
-- testExpireGroupWithOffsetsOnly
-- testExpireOffset
-- testGroupLoadWithConsumerAndTransactionalOffsetCommitsConsumerWins
-- testGroupLoadWithConsumerAndTransactionalOffsetCommitsTransactionWins
-- testGroupLoadedWithPendingCommits
-- testGroupMetadataKey
-- testGroupMetadataRemoval
-- testGroupMetadataRemovalWithLogAppendTime
-- testGroupNotExists
-- testLoadConsumerGroup
-- testLoadConsumerGroupWithFaultyConsumerProtocol
-- testLoadEmptyConsumerGroup
-- testLoadEmptyGroupWithOffsets
-- testLoadGroupAndOffsetsFromDifferentSegments
-- testLoadGroupAndOffsetsWithCorruptedLog
-- testLoadGroupWithLargeGroupMetadataRecord
-- testLoadGroupWithTombstone
-- testLoadGroupsAndOffsetsWillIgnoreUnknownMessage
-- testLoadOffsetFromOldCommit
-- testLoadOffsetWithExplicitRetention
-- testLoadOffsetsAndGroup
-- testLoadOffsetsAndGroupIgnored
-- testLoadOffsetsWithEmptyControlBatch
-- testLoadOffsetsWithTombstones
-- testLoadOffsetsWithoutGroup
-- testLoadTransactionalOffsetCommitsFromMultipleProducers
-- testLoadTransactionalOffsetsWithoutGroup
-- testLoadWithCommittedAndAbortedAndPendingTransactionalOffsetCommits
-- testLoadWithCommittedAndAbortedTransactionalOffsetCommits
-- testLogInfoFromCleanupGroupMetadata
-- testMetrics
-- testOffsetCommitKey
-- testOffsetExpirationOfActiveGroupSemantics
-- testOffsetExpirationOfSimpleConsumer
-- testOffsetExpirationSemantics
-- testOffsetMetadataTooLarge
-- testOffsetMetadataTooLargePartialFailure
-- testOffsetWriteAfterGroupRemoved
-- testPartitionLoadMetric
-- testReadFromOldGroupMetadata
-- testReadMessageKeyCanReadUnknownMessage
-- testSerdeOffsetCommitValue
-- testSerdeOffsetCommitValueWithExpireTimestamp
-- testSerializeGroupMetadataValueToHighestNonFlexibleVersion
-- testSerializeOffsetCommitValueToHighestNonFlexibleVersion
-- testShouldThrowExceptionForUnsupportedGroupMetadataVersion
-- testStoreEmptyGroup
-- testStoreEmptySimpleGroup
-- testStoreGroupErrorMapping
-- testStoreNonEmptyGroup
-- testStoreNonEmptyGroupWhenCoordinatorHasMoved
-- testTransactionalCommitOffsetAborted
-- testTransactionalCommitOffsetAppendFailure
-- testTransactionalCommitOffsetCommitted
-- testTransactionalCommitOffsetWithOffsetMetadataTooLargePartialFailure
-- testUnloadOffsetsAndGroup
-- testUnloadOffsetsAndGroupIgnored
-- testUnloadOffsetsAndGroupIgnoredAfterStopReplica
-- testloadGroupWithStaticMember
-kafka.coordinator.group.GroupMetadataTest:
-- testAwaitingRebalanceToAwaitingRebalanceIllegalTransition
-- testAwaitingRebalanceToPreparingRebalanceTransition
-- testAwaitingRebalanceToStableTransition
-- testCanAddAndRemovePendingSyncMember
-- testCanRebalanceWhenCompletingRebalance
-- testCanRebalanceWhenStable
-- testCannotAddPendingMemberIfStable
-- testCannotAddPendingSyncOfUnknownMember
-- testCannotAddStaticMemberIfAlreadyPresent
-- testCannotRebalanceWhenDead
-- testCannotRebalanceWhenPreparingRebalance
-- testCannotRemovePendingSyncOfUnknownMember
-- testConsumerBeatsTransactionalOffsetCommit
-- testDeadToAwaitingRebalanceIllegalTransition
-- testDeadToDeadIllegalTransition
-- testDeadToPreparingRebalanceIllegalTransition
-- testDeadToStableIllegalTransition
-- testEmptyToAwaitingRebalanceIllegalTransition
-- testEmptyToDeadTransition
-- testEmptyToStableIllegalTransition
-- testFailedTxnOffsetCommitLeavesNoPendingState
-- testHasPendingNonTxnOffsets
-- testHasPendingTxnOffsets
-- testInitNextGeneration
-- testInitNextGenerationEmptyGroup
-- testInvokeJoinCallback
-- testInvokeJoinCallbackFails
-- testInvokeSyncCallback
-- testInvokeSyncCallbackFails
-- testNewGenerationClearsPendingSyncMembers
-- testNotInvokeJoinCallback
-- testNotInvokeSyncCallback
-- testOffsetCommit
-- testOffsetCommitFailure
-- testOffsetCommitFailureWithAnotherPending
-- testOffsetCommitWithAnotherPending
-- testOffsetRemovalDuringTransitionFromEmptyToNonEmpty
-- testPreparingRebalanceToDeadTransition
-- testPreparingRebalanceToEmptyTransition
-- testPreparingRebalanceToPreparingRebalanceIllegalTransition
-- testPreparingRebalanceToStableIllegalTransition
-- testRemovalFromPendingAfterMemberIsStable
-- testRemovalFromPendingSyncWhenMemberIsRemoved
-- testRemovalFromPendingWhenMemberIsRemoved
-- testReplaceGroupInstance
-- testReplaceGroupInstanceWithNonExistingMember
-- testSelectProtocol
-- testSelectProtocolChoosesCompatibleProtocol
-- testSelectProtocolRaisesIfNoMembers
-- testStableToDeadTransition
-- testStableToPreparingRebalanceTransition
-- testStableToStableIllegalTransition
-- testSubscribedTopics
-- testSubscribedTopicsNonConsumerGroup
-- testSupportsProtocols
-- testTransactionBeatsConsumerOffsetCommit
-- testTransactionalCommitIsAbortedAndConsumerCommitWins
-- testUpdateMember
-kafka.coordinator.group.MemberMetadataTest:
-- testHasValidGroupInstanceId
-- testMatchesSupportedProtocols
-- testMetadata
-- testMetadataRaisesOnUnsupportedProtocol
-- testVoteForPreferredProtocol
-- testVoteRaisesOnNoSupportedProtocols
kafka.coordinator.transaction.ProducerIntegrationTest:
- testTransactionWithAndWithoutSend
- testTransactionWithInvalidSendAndEndTxnRequestSent
@@ -2370,9 +2045,8 @@ kafka.server.DelegationTokenRequestsTest:
kafka.server.DelegationTokenRequestsWithDisableTokenFeatureTest:
- testDelegationTokenRequests
kafka.server.DeleteGroupsRequestTest:
-- testDeleteGroupsWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testDeleteGroupsWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testDeleteGroupsWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testDeleteGroupsWithNewConsumerGroupProtocol
+- testDeleteGroupsWithOldConsumerGroupProtocol
kafka.server.DeleteRecordsRequestTest:
- testDeleteRecordsHappyCase
- testErrorWhenDeletingRecordsWithInvalidOffset
@@ -2387,8 +2061,7 @@ kafka.server.DescribeClusterRequestTest:
- testDescribeClusterRequestExcludingClusterAuthorizedOperations
- testDescribeClusterRequestIncludingClusterAuthorizedOperations
kafka.server.DescribeGroupsRequestTest:
-- testDescribeGroupsWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testDescribeGroupsWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testDescribeGroupsWithOldConsumerGroupProtocol
kafka.server.DescribeLogDirsRequestTest:
- testDescribeLogDirsRequest
kafka.server.DescribeQuorumRequestTest:
@@ -2543,8 +2216,7 @@ kafka.server.GssapiAuthenticationTest:
- testServerAuthenticationFailure
- testServerNotFoundInKerberosDatabase
kafka.server.HeartbeatRequestTest:
-- testHeartbeatWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testHeartbeatWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testHeartbeatWithOldConsumerGroupProtocol
kafka.server.HighwatermarkPersistenceTest:
- testHighWatermarkPersistenceMultiplePartitions
- testHighWatermarkPersistenceSinglePartition
@@ -2554,8 +2226,7 @@ kafka.server.IsrExpirationTest:
- testIsrExpirationForStuckFollowers
- testIsrExpirationIfNoFetchRequestMade
kafka.server.JoinGroupRequestTest:
-- testJoinGroupWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testJoinGroupWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testJoinGroupWithOldConsumerGroupProtocol
kafka.server.KRaftClusterTest:
- testAbandonedFutureReplicaRecovered_mainReplicaInOfflineLogDir
- testAbandonedFutureReplicaRecovered_mainReplicaInOnlineLogDir
@@ -2684,7 +2355,6 @@ kafka.server.KafkaApisTest:
- testHandleOffsetFetchWithMultipleGroups
- testHandleOffsetFetchWithSingleGroup
- testHandleOffsetFetchWithUnauthorizedTopicAndTopLevelError
-- testHandleShareAcknowledgeNewGroupCoordinatorDisabled
- testHandleShareAcknowledgeRequestAcknowledgeThrowsError
- testHandleShareAcknowledgeRequestBatchValidationError
- testHandleShareAcknowledgeRequestGroupAuthorizationError
@@ -2698,7 +2368,6 @@ kafka.server.KafkaApisTest:
- testHandleShareFetchFetchMessagesReturnErrorCode
- testHandleShareFetchFromShareFetchRequestErrorTopicsInRequest
- testHandleShareFetchFromShareFetchRequestWithErroneousPartitions
-- testHandleShareFetchNewGroupCoordinatorDisabled
- testHandleShareFetchRequestAcknowledgeThrowsException
- testHandleShareFetchRequestErrorInReadingPartition
- testHandleShareFetchRequestFetchAndAcknowledgeThrowsException
@@ -2720,9 +2389,8 @@ kafka.server.KafkaApisTest:
- testHandleTxnOffsetCommitRequest
- testHandleTxnOffsetCommitRequestFutureFailed
- testHandleTxnOffsetCommitRequestTopicsAndPartitionsValidation
-- testHandleWriteTxnMarkersRequestWithNewGroupCoordinator
-- testHandleWriteTxnMarkersRequestWithNewGroupCoordinatorErrorTranslation
-- testHandleWriteTxnMarkersRequestWithOldGroupCoordinator
+- testHandleWriteTxnMarkersRequest
+- testHandleWriteTxnMarkersRequestErrorTranslation
- testIncrementalAlterConfigsWithAuthorizer
- testIncrementalClientMetricAlterConfigs
- testIncrementalConsumerGroupAlterConfigs
@@ -2962,9 +2630,8 @@ kafka.server.LeaveGroupRequestTest:
- testLeaveGroupWithOldConsumerGroupProtocolAndNewGroupCoordinator
- testLeaveGroupWithOldConsumerGroupProtocolAndOldGroupCoordinator
kafka.server.ListGroupsRequestTest:
-- testListGroupsWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testListGroupsWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testListGroupsWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testListGroupsWithNewConsumerGroupProtocol
+- testListGroupsWithOldConsumerGroupProtocol
kafka.server.ListOffsetsRequestTest:
- testCurrentEpochValidation
- testListOffsetsErrorCodes
@@ -3053,23 +2720,18 @@ kafka.server.NodeToControllerRequestThreadTest:
- testThreadNotStarted
- testUnsupportedVersionHandling
kafka.server.OffsetCommitRequestTest:
-- testOffsetCommitWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testOffsetCommitWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testOffsetCommitWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testOffsetCommitWithNewConsumerGroupProtocol
+- testOffsetCommitWithOldConsumerGroupProtocol
kafka.server.OffsetDeleteRequestTest:
-- testOffsetDeleteWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testOffsetDeleteWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testOffsetDeleteWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testOffsetDeleteWithNewConsumerGroupProtocol
+- testOffsetDeleteWithOldConsumerGroupProtocol
kafka.server.OffsetFetchRequestTest:
-- testMultiGroupsOffsetFetchWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testMultiGroupsOffsetFetchWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testMultiGroupsOffsetFetchWithOldConsumerGroupProtocolAndOldGroupCoordinator
--
testSingleGroupAllOffsetFetchWithNewConsumerGroupProtocolAndNewGroupCoordinator
--
testSingleGroupAllOffsetFetchWithOldConsumerGroupProtocolAndNewGroupCoordinator
--
testSingleGroupAllOffsetFetchWithOldConsumerGroupProtocolAndOldGroupCoordinator
-- testSingleGroupOffsetFetchWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testSingleGroupOffsetFetchWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testSingleGroupOffsetFetchWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testMultiGroupsOffsetFetchWithNewConsumerGroupProtocol
+- testMultiGroupsOffsetFetchWithOldConsumerGroupProtocol
+- testSingleGroupAllOffsetFetchWithNewConsumerGroupProtocol
+- testSingleGroupAllOffsetFetchWithOldConsumerGroupProtocol
+- testSingleGroupOffsetFetchWithNewConsumerGroupProtocol
+- testSingleGroupOffsetFetchWithOldConsumerGroupProtocol
kafka.server.OffsetsForLeaderEpochRequestTest:
- testCurrentEpochValidation
- testOffsetsForLeaderEpochErrorCodes
@@ -3190,6 +2852,7 @@ kafka.server.ReplicaManagerTest:
- testInconsistentIdReturnsError
- testMaybeAddLogDirFetchers
- testMaybeAddLogDirFetchersPausingCleaning
+- testMonitorableReplicaSelector
- testNotCallStopPartitionsForNonTieredTopics
- testOffsetOutOfRangeExceptionWhenFetchMessages
- testOffsetOutOfRangeExceptionWhenReadFromLog
@@ -3294,8 +2957,7 @@ kafka.server.ShareGroupHeartbeatRequestTest:
kafka.server.StrictControllerMutationQuotaTest:
- testControllerMutationQuotaViolation
kafka.server.SyncGroupRequestTest:
-- testSyncGroupWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testSyncGroupWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testSyncGroupWithOldConsumerGroupProtocol
kafka.server.ThrottledChannelExpirationTest:
- testCallbackInvocationAfterExpiration
kafka.server.TierStateMachineTest:
@@ -3303,9 +2965,8 @@ kafka.server.TierStateMachineTest:
- testFollowerFetchMovedToTieredStore
- testFollowerFetchOffsetOutOfRangeWithTieredStore
kafka.server.TxnOffsetCommitRequestTest:
-- testTxnOffsetCommitWithNewConsumerGroupProtocolAndNewGroupCoordinator
-- testTxnOffsetCommitWithOldConsumerGroupProtocolAndNewGroupCoordinator
-- testTxnOffsetCommitWithOldConsumerGroupProtocolAndOldGroupCoordinator
+- testTxnOffsetCommitWithNewConsumerGroupProtocol
+- testTxnOffsetCommitWithOldConsumerGroupProtocol
kafka.server.epoch.LeaderEpochFileCacheTest:
- shouldAddEpochAndMessageOffsetToCache
- shouldClearAllEntries