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 f652011bcf4 Update test catalog data for GHA workflow run 20268561989
f652011bcf4 is described below

commit f652011bcf430bec4a1ae5590be25d4ee06af44c
Author: github-actions[bot] 
<41898282+github-actions[bot]@users.noreply.github.com>
AuthorDate: Tue Dec 16 15:17:09 2025 +0000

    Update test catalog data for GHA workflow run 20268561989
    
    Commit: 
https://github.com/apache/kafka/commit/bf91c079936fe1706564fc33a850eaf3dd7be3f4
    GitHub Run: https://github.com/apache/kafka/actions/runs/20268561989
---
 test-catalog/core/tests.yaml     | 45 ---------------------------------------
 test-catalog/metadata/tests.yaml |  2 ++
 test-catalog/raft/tests.yaml     | 46 ++++++++++++++++++++++++++++++++++++++++
 test-catalog/storage/tests.yaml  |  5 +----
 4 files changed, 49 insertions(+), 49 deletions(-)

diff --git a/test-catalog/core/tests.yaml b/test-catalog/core/tests.yaml
index aae3d332e1b..cf27a623698 100644
--- a/test-catalog/core/tests.yaml
+++ b/test-catalog/core/tests.yaml
@@ -1423,51 +1423,6 @@ kafka.network.SocketServerTest:
 kafka.raft.DefaultExternalKRaftMetricsTest:
 - testDefaultExternalKRaftMetrics
 - testEmptyDefaultExternalKRaftMetrics
-kafka.raft.KafkaMetadataLogTest:
-- testAdvanceLogStartOffsetAfterCleaning
-- testCleanupOlderSnapshots
-- testCleanupPartialSnapshots
-- testConfig
-- testCreateExistingSnapshot
-- testCreateReplicatedLogTruncatesFully
-- testCreateSnapshot
-- testCreateSnapshotBeforeLogStartOffset
-- testCreateSnapshotDivergingEpoch
-- testCreateSnapshotFromEndOffset
-- testCreateSnapshotInMiddleOfBatch
-- testCreateSnapshotLaterThanHighWatermark
-- testCreateSnapshotMuchLaterEpoch
-- testCreateSnapshotOlderEpoch
-- testCreateSnapshotWithMissingEpoch
-- testDeleteNonExistentSnapshot
-- testDeleteSnapshots
-- testDoesntTruncateFully
-- testEmptyAppendNotAllowed
-- testHighWatermarkOffsetMetadata
-- testInvalidLeaderEpoch
-- testInvalidMemoryRecords
-- testMaxBatchSize
-- testRandomRecords
-- testReadMissingSnapshot
-- testSegmentMsConfigIsSetInMetadataLog
-- testSegmentsLessThanLatestSnapshot
-- testSnapshotDeletionWithInvalidSnapshotState
-- testSoftRetentionLimit
-- testStartupWithInvalidSnapshotState
-- testTopicId
-- testTruncateBelowHighWatermark
-- testTruncateFullyToLatestSnapshot
-- testTruncateWillRemoveOlderSnapshot
-- testUnexpectedAppendOffset
-- testValidateEpochGreaterThanLastKnownEpoch
-- testValidateEpochLessThanFirstEpochInLog
-- testValidateEpochLessThanOldestSnapshotEpoch
-- testValidateOffsetEqualToOldestSnapshotOffset
-- testValidateOffsetGreatThanEndOffset
-- testValidateOffsetLessThanLEO
-- testValidateOffsetLessThanOldestSnapshotOffset
-- testValidateUnknownEpochLessThanLastKnownGreaterThanOldestSnapshot
-- testValidateValidEpochAndOffset
 kafka.raft.RaftManagerTest:
 - testLogDirLockWhenBrokerOnlyWithSeparateMetadataDir
 - testLogDirLockWhenControllerOnly
diff --git a/test-catalog/metadata/tests.yaml b/test-catalog/metadata/tests.yaml
index b89b4e865e2..cdff3b4f4a0 100644
--- a/test-catalog/metadata/tests.yaml
+++ b/test-catalog/metadata/tests.yaml
@@ -481,6 +481,8 @@ org.apache.kafka.image.TopicsImageTest:
 - testImage1RoundTrip
 - testImage2RoundTrip
 - testLocalReassignmentChanges
+- testPartitionReplicas
+- testPartitionReplicasWithEmptyImage
 - testTopicDeltaElectionStatsWithEmptyImage
 - testTopicDeltaElectionStatsWithNonEmptyImage
 - testTopicIdToNameView
diff --git a/test-catalog/raft/tests.yaml b/test-catalog/raft/tests.yaml
index 0fedcb2f021..f3f89fd8147 100644
--- a/test-catalog/raft/tests.yaml
+++ b/test-catalog/raft/tests.yaml
@@ -692,6 +692,52 @@ 
org.apache.kafka.raft.internals.KRaftControlRecordStateMachineTest:
 - testUpdateWithSnapshot
 - testUpdateWithSnapshotAndLogOverride
 - testUpdateWithoutSnapshot
+org.apache.kafka.raft.internals.KafkaRaftLogTest:
+- testAdvanceLogStartOffsetAfterCleaning
+- testCleanupOlderSnapshots
+- testCleanupPartialSnapshots
+- testConfig
+- testCreateExistingSnapshot
+- testCreateRaftLogTruncatesFully
+- testCreateSnapshot
+- testCreateSnapshotBeforeLogStartOffset
+- testCreateSnapshotDivergingEpoch
+- testCreateSnapshotFromEndOffset
+- testCreateSnapshotInMiddleOfBatch
+- testCreateSnapshotLaterThanHighWatermark
+- testCreateSnapshotMuchLaterEpoch
+- testCreateSnapshotOlderEpoch
+- testCreateSnapshotWithMissingEpoch
+- testDeleteNonExistentSnapshot
+- testDeleteSnapshots
+- testDoesntTruncateFully
+- testEmptyAppendNotAllowed
+- testHighWatermarkOffsetMetadata
+- testInvalidLeaderEpoch
+- testInvalidMemoryRecords
+- testMaxBatchSize
+- testRandomRecords
+- testReadMissingSnapshot
+- testReadMissingSnapshotFile
+- testSegmentMsConfigIsSetInMetadataLog
+- testSegmentsLessThanLatestSnapshot
+- testSnapshotDeletionWithInvalidSnapshotState
+- testSoftRetentionLimit
+- testStartupWithInvalidSnapshotState
+- testTopicId
+- testTruncateBelowHighWatermark
+- testTruncateFullyToLatestSnapshot
+- testTruncateWillRemoveOlderSnapshot
+- testUnexpectedAppendOffset
+- testValidateEpochGreaterThanLastKnownEpoch
+- testValidateEpochLessThanFirstEpochInLog
+- testValidateEpochLessThanOldestSnapshotEpoch
+- testValidateOffsetEqualToOldestSnapshotOffset
+- testValidateOffsetGreatThanEndOffset
+- testValidateOffsetLessThanLEO
+- testValidateOffsetLessThanOldestSnapshotOffset
+- testValidateUnknownEpochLessThanLastKnownGreaterThanOldestSnapshot
+- testValidateValidEpochAndOffset
 org.apache.kafka.raft.internals.KafkaRaftMetricsTest:
 - shouldRecordLatency
 - shouldRecordLogEnd
diff --git a/test-catalog/storage/tests.yaml b/test-catalog/storage/tests.yaml
index ea8d3f43dfb..a4c7833fd7d 100644
--- a/test-catalog/storage/tests.yaml
+++ b/test-catalog/storage/tests.yaml
@@ -292,10 +292,7 @@ org.apache.kafka.storage.internals.log.LogConcurrencyTest:
 - testUncommittedDataNotConsumed
 - testUncommittedDataNotConsumedFrequentSegmentRolls
 org.apache.kafka.storage.internals.log.LogManagerTest:
-- testIsStrayKraftMissingTopicId
-- testIsStrayKraftReplicaInImage
-- testIsStrayKraftReplicaInImageWithRemoteReplicas
-- testIsStrayKraftReplicaWithEmptyImage
+- testIsStrayReplica
 - testWaitForAllToComplete
 org.apache.kafka.storage.internals.log.LogOffsetMetadataTest:
 - testMessageOffsetOnly

Reply via email to