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 422e219fa04 Update test catalog data for GHA workflow run 13535642170
422e219fa04 is described below

commit 422e219fa04aa8f0e9540b69a59046a8f7e13aeb
Author: github-actions[bot] 
<41898282+github-actions[bot]@users.noreply.github.com>
AuthorDate: Wed Feb 26 06:44:00 2025 +0000

    Update test catalog data for GHA workflow run 13535642170
    
    Commit: 
https://github.com/apache/kafka/commit/f20f2994928fbae53541a2b821515427ee2679a2
    GitHub Run: https://github.com/apache/kafka/actions/runs/13535642170
---
 test-catalog/core/tests.yaml    |  8 ++++++++
 test-catalog/raft/tests.yaml    |  7 +++++++
 test-catalog/streams/tests.yaml | 14 +++-----------
 3 files changed, 18 insertions(+), 11 deletions(-)

diff --git a/test-catalog/core/tests.yaml b/test-catalog/core/tests.yaml
index f1fbd09e36e..198298cda5a 100644
--- a/test-catalog/core/tests.yaml
+++ b/test-catalog/core/tests.yaml
@@ -1752,6 +1752,8 @@ kafka.log.UnifiedLogTest:
 - testIncrementLocalLogStartOffsetAfterLocalLogDeletion
 - testIndexResizingAtTruncation
 - testInitializationOfProducerSnapshotsUpgradePath
+- testInvalidLeaderEpoch
+- testInvalidMemoryRecords
 - testLastStableOffsetDoesNotExceedLogStartOffsetAfterSegmentDeletion
 - testLastStableOffsetDoesNotExceedLogStartOffsetMidSegment
 - testLastStableOffsetWithMixedProducerData
@@ -1791,6 +1793,7 @@ kafka.log.UnifiedLogTest:
 - testProducerIdMapTruncateTo
 - testProducerIdMapTruncateToWithNoSnapshots
 - testProducerSnapshotAfterSegmentRollOnAppend
+- testRandomRecords
 - testReadAtLogGap
 - testReadCommittedWithConcurrentHighWatermarkUpdates
 - testReadOutOfRange
@@ -2074,8 +2077,12 @@ kafka.raft.KafkaMetadataLogTest:
 - testDeleteNonExistentSnapshot
 - testDeleteSnapshots
 - testDoesntTruncateFully
+- testEmptyAppendNotAllowed
 - testHighWatermarkOffsetMetadata
+- testInvalidLeaderEpoch
+- testInvalidMemoryRecords
 - testMaxBatchSize
+- testRandomRecords
 - testReadMissingSnapshot
 - testSegmentsLessThanLatestSnapshot
 - testSnapshotDeletionWithInvalidSnapshotState
@@ -2164,6 +2171,7 @@ kafka.server.AbstractFetcherThreadTest:
 - testMetricsRemovedOnShutdown
 - testParameterizedLeaderEpochChangeDuringFetchEpochsFromLeader
 - testPartitionsInError
+- testReplicateBatchesUpToLeaderEpoch
 - testRetryAfterUnknownLeaderEpochInLatestOffsetFetch
 - testSimpleFetch
 - testTruncateOnFetchDoesNotProcessPartitionData
diff --git a/test-catalog/raft/tests.yaml b/test-catalog/raft/tests.yaml
index 245369a4a60..f07031a520e 100644
--- a/test-catalog/raft/tests.yaml
+++ b/test-catalog/raft/tests.yaml
@@ -108,6 +108,10 @@ org.apache.kafka.raft.KafkaNetworkChannelTest:
 org.apache.kafka.raft.KafkaRaftClientDriverTest:
 - testShutdown
 - testUncaughtException
+org.apache.kafka.raft.KafkaRaftClientFetchTest:
+- testInvalidMemoryRecords
+- testRandomRecords
+- testReplicationOfHigherPartitionLeaderEpoch
 org.apache.kafka.raft.KafkaRaftClientPreVoteTest:
 - testFollowerGrantsPreVoteIfHasNotFetchedYet
 - testHandleInvalidPreVoteRequestWithOlderEpoch
@@ -390,8 +394,11 @@ org.apache.kafka.raft.MockLogTest:
 - testEmptyAppendNotAllowed
 - testEndOffsetForEpoch
 - testFailToIncreaseLogStartPastHighWatermark
+- testInvalidLeaderEpoch
+- testInvalidMemoryRecords
 - testMetadataValidation
 - testMonotonicEpochStartOffset
+- testRandomRecords
 - testReadMissingSnapshot
 - testReadOutOfRangeOffset
 - testReadRecords
diff --git a/test-catalog/streams/tests.yaml b/test-catalog/streams/tests.yaml
index 7c59d3d4dec..8b5b8f70710 100644
--- a/test-catalog/streams/tests.yaml
+++ b/test-catalog/streams/tests.yaml
@@ -2734,12 +2734,6 @@ 
org.apache.kafka.streams.processor.internals.StreamsMetadataStateTest:
 org.apache.kafka.streams.processor.internals.StreamsPartitionAssignorTest:
 - shouldAddUserDefinedEndPointToSubscription
 - shouldAssignEvenlyAcrossConsumersOneClientMultipleThreads
-- shouldDownGradeSubscriptionToVersion1
-- shouldDownGradeSubscriptionToVersion2For0101
-- shouldDownGradeSubscriptionToVersion2For0102
-- shouldDownGradeSubscriptionToVersion2For0110
-- shouldDownGradeSubscriptionToVersion2For10
-- shouldDownGradeSubscriptionToVersion2For11
 - shouldEncodeAssignmentErrorIfV1SubscriptionAndFutureSubscriptionIsMixed
 - shouldEncodeAssignmentErrorIfV2SubscriptionAndFutureSubscriptionIsMixed
 - shouldEncodeMissingSourceTopicError
@@ -2764,20 +2758,20 @@ 
org.apache.kafka.streams.processor.internals.StreamsPartitionAssignorTest:
 - shouldReturnLowestAssignmentVersionForDifferentSubscriptionVersionsV1V3
 - shouldReturnLowestAssignmentVersionForDifferentSubscriptionVersionsV2V3
 - shouldSkipListOffsetsRequestForNewlyCreatedChangelogTopics
+- shouldSupportOnlyCooperativeRebalancingProtocol
 - shouldThrowExceptionIfApplicationServerConfigIsNotHostPortPair
 - shouldThrowExceptionIfApplicationServerConfigPortIsNotAnInteger
 - shouldThrowIllegalStateExceptionIfAnyPartitionsMissingFromChangelogEndOffsets
 - shouldThrowIllegalStateExceptionIfAnyTopicsMissingFromChangelogEndOffsets
 - shouldThrowKafkaExceptionIfReferenceContainerConfigIsNotTaskManagerInstance
 - shouldThrowKafkaExceptionIfReferenceContainerNotConfigured
+- shouldThrowOnEagerSubscription
 - shouldThrowTaskAssignmentExceptionWhenUnableToResolvePartitionCount
 - shouldThrowTimeoutExceptionWhenCreatingChangelogTopicsTimesOut
 - shouldThrowTimeoutExceptionWhenCreatingRepartitionTopicsTimesOut
 - shouldTriggerImmediateRebalanceOnHostInfoChange
 - shouldTriggerImmediateRebalanceOnTasksRevoked
 - shouldUpdateClusterMetadataAndHostInfoOnAssignment
-- shouldUseCooperativeRebalancingProtocol
-- shouldUseEagerRebalancingProtocol
 - testAssignBasic
 - testAssignEmptyMetadata
 - testAssignWithInternalTopicThatsSourceIsAnotherInternalTopic
@@ -2792,7 +2786,6 @@ 
org.apache.kafka.streams.processor.internals.StreamsPartitionAssignorTest:
 - testAssignWithStates
 - testClientTags
 - testCooperativeSubscription
-- testEagerSubscription
 - testOnAssignment
 - testUniqueField
 - testUniqueFieldOverflow
@@ -3129,8 +3122,7 @@ 
org.apache.kafka.streams.processor.internals.assignment.AssignmentInfoTest:
 - shouldUseLatestSupportedVersionByDefault
 
org.apache.kafka.streams.processor.internals.assignment.AssignorConfigurationTest:
 - configsShouldRejectZeroWarmups
-- configuredMetadataVersionShouldSupportAllUpgradeFromVersions
-- rebalanceProtocolShouldSupportAllUpgradeFromVersions
+- shouldSupportAllUpgradeFromVersionsFromCooperativeRebalancingOn
 org.apache.kafka.streams.processor.internals.assignment.ClientStateTest:
 - previousStateConstructorShouldCreateAValidObject
 - shouldAddActiveTasksToBothAssignedAndActive

Reply via email to