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 76cf237de0a Update test catalog data for GHA workflow run 12784178607
76cf237de0a is described below

commit 76cf237de0a38fe983c6cc85583701e5ff5bad98
Author: github-actions[bot] 
<41898282+github-actions[bot]@users.noreply.github.com>
AuthorDate: Wed Jan 15 10:49:11 2025 +0000

    Update test catalog data for GHA workflow run 12784178607
    
    Commit: 
https://github.com/apache/kafka/commit/ae661dec3466839573ba7822b76e158d245e4f96
    GitHub Run: https://github.com/apache/kafka/actions/runs/12784178607
---
 test-catalog/connect/runtime/tests.yaml             |  1 +
 test-catalog/core/tests.yaml                        | 17 +++++------------
 test-catalog/raft/tests.yaml                        | 11 -----------
 test-catalog/share/tests.yaml                       |  4 ++++
 test-catalog/streams/tests.yaml                     |  3 +--
 test-catalog/test-common/test-common-api/tests.yaml |  1 +
 6 files changed, 12 insertions(+), 25 deletions(-)

diff --git a/test-catalog/connect/runtime/tests.yaml 
b/test-catalog/connect/runtime/tests.yaml
index e88160d7886..c1d0a22beb7 100644
--- a/test-catalog/connect/runtime/tests.yaml
+++ b/test-catalog/connect/runtime/tests.yaml
@@ -920,6 +920,7 @@ org.apache.kafka.connect.runtime.isolation.PluginDescTest:
 - testPluginDescWithSystemClassLoader
 - testRegularPluginDesc
 org.apache.kafka.connect.runtime.isolation.PluginScannerTest:
+- testClasspathPluginIsAlsoLoadedInIsolation
 - testNonVersionedPluginHasUndefinedVersion
 - testScanningEmptyPluginPath
 - testScanningInvalidUberJar
diff --git a/test-catalog/core/tests.yaml b/test-catalog/core/tests.yaml
index 3233572af41..3ca06586ad1 100644
--- a/test-catalog/core/tests.yaml
+++ b/test-catalog/core/tests.yaml
@@ -2755,7 +2755,6 @@ kafka.server.KafkaApisTest:
 - shouldRespondWithUnknownTopicWhenPartitionIsNotHosted
 - testAddPartitionsToTxnOperationNotAttempted
 - testAddPartitionsToTxnWithInvalidPartition
-- testAlterClientQuotasWithAuthorizer
 - testAlterConfigsClientMetrics
 - testAlterConfigsWithAuthorizer
 - testAlterReplicaLogDirs
@@ -2768,9 +2767,6 @@ kafka.server.KafkaApisTest:
 - testConsumerGroupHeartbeatRequestAuthorizationFailed
 - testConsumerGroupHeartbeatRequestFutureFailed
 - testConsumerGroupHeartbeatReturnsUnsupportedVersion
-- testCreateTopicsWithAuthorizer
-- testDeleteTopicsByIdAuthorization
-- testDeleteTopicsByNameAuthorization
 - testDescribeClusterRequest
 - testDescribeConfigsClientMetrics
 - testDescribeConfigsConsumerGroup
@@ -2918,15 +2914,8 @@ kafka.server.KafkaApisTest:
 - testProduceResponseReplicaManagerLookupErrorOnNotLeaderOrFollower
 - testPushTelemetry
 - testPushTelemetryWithException
-- testRaftShouldAlwaysForwardAlterClientQuotasRequest
 - testRaftShouldAlwaysForwardCreateAcls
-- testRaftShouldAlwaysForwardCreatePartitionsRequest
-- testRaftShouldAlwaysForwardCreateTopicsRequest
 - testRaftShouldAlwaysForwardDeleteAcls
-- testRaftShouldAlwaysForwardDeleteTopicsRequest
-- testRaftShouldAlwaysForwardElectLeaders
-- testRaftShouldAlwaysForwardUpdateFeatures
-- testRaftShouldNeverHandleAlterPartitionRequest
 - testReadCommittedConsumerListOffsetLatest
 - testReadShareGroupStateAuthorizationFailed
 - testReadShareGroupStateSuccess
@@ -3426,7 +3415,7 @@ kafka.server.ShareFetchAcknowledgeRequestTest:
 - testShareAcknowledgeRequestSuccessAccept
 - testShareAcknowledgeRequestSuccessReject
 - testShareAcknowledgeRequestSuccessRelease
-- testShareFetchBrokerRespectsPartitionsSizeLimit
+- testShareFetchBrokerDoesNotRespectPartitionsSizeLimit
 - testShareFetchInitialEpochWithAcknowledgements
 - testShareFetchRequestForgetTopicPartitions
 - testShareFetchRequestInvalidShareSessionEpoch
@@ -3549,10 +3538,14 @@ kafka.server.share.DelayedShareFetchTest:
 - testForceCompleteTriggersDelayedActionsQueue
 - testLocksReleasedAcquireException
 - testLocksReleasedForCompletedFetch
+- testPartitionMaxBytesFromUniformStrategyInCombineLogReadResponse
+- testPartitionMaxBytesFromUniformStrategyWhenAllPartitionsAreAcquirable
+- testPartitionMaxBytesFromUniformStrategyWhenFewPartitionsAreAcquirable
 - testReplicaManagerFetchShouldHappenOnComplete
 - testToCompleteAnAlreadyCompletedFuture
 - testTryCompleteWhenMinBytesNotSatisfiedOnFirstFetch
 - testTryCompleteWhenMinBytesNotSatisfiedOnSubsequentFetch
+- testTryCompleteWhenPartitionMaxBytesStrategyThrowsException
 kafka.server.share.ShareFetchUtilsTest:
 - testProcessFetchResponse
 - testProcessFetchResponseWhenNoRecordsAreAcquired
diff --git a/test-catalog/raft/tests.yaml b/test-catalog/raft/tests.yaml
index b378cad2e7f..3b476b53b5b 100644
--- a/test-catalog/raft/tests.yaml
+++ b/test-catalog/raft/tests.yaml
@@ -457,14 +457,6 @@ org.apache.kafka.raft.QuorumStateTest:
 - testUnattachedVotedToUnattachedHigherEpoch
 - testUnattachedVotedToUnattachedSameEpoch
 - testUnattachedVotedToUnattachedVotedSameEpoch
-org.apache.kafka.raft.RaftEventSimulationTest:
-- canElectInitialLeader
-- canElectNewLeaderAfterOldLeaderFailure
-- canElectNewLeaderAfterOldLeaderPartitionedAway
-- canMakeProgressAfterBackToBackLeaderFailures
-- canMakeProgressIfMajorityIsReachable
-- canRecoverAfterAllNodesKilled
-- canRecoverFromSingleNodeCommittedDataLoss
 org.apache.kafka.raft.RaftUtilTest:
 - testErrorResponse
 - testFetchRequestV17Compatibility
@@ -587,10 +579,7 @@ org.apache.kafka.raft.internals.RecordsIteratorTest:
 - testControlRecordIterationWithKraftVersion0
 - testControlRecordIterationWithKraftVersion1
 - testControlRecordTypeValues
-- testCrcValidation
 - testEmptyRecords
-- testFileRecords
-- testMemoryRecords
 - testWithAllSupportedControlRecords
 org.apache.kafka.raft.internals.ThresholdPurgatoryTest:
 - testCompleteAll
diff --git a/test-catalog/share/tests.yaml b/test-catalog/share/tests.yaml
index 505afc9d04b..a62aab9f050 100644
--- a/test-catalog/share/tests.yaml
+++ b/test-catalog/share/tests.yaml
@@ -2,6 +2,10 @@ org.apache.kafka.server.share.CachedSharePartitionTest:
 - testCachedSharePartitionEqualsAndHashCode
 org.apache.kafka.server.share.fetch.DelayedShareFetchKeyTest:
 - testDelayedShareFetchEqualsAndHashcode
+org.apache.kafka.server.share.fetch.PartitionMaxBytesStrategyTest:
+- testCheckValidArguments
+- testConstructor
+- testUniformStrategy
 org.apache.kafka.server.share.fetch.ShareFetchTest:
 - testErrorInAllPartitions
 - testErrorInAllPartitionsWithMultipleTopicIdPartitions
diff --git a/test-catalog/streams/tests.yaml b/test-catalog/streams/tests.yaml
index 3f557b17726..037cb9fbeff 100644
--- a/test-catalog/streams/tests.yaml
+++ b/test-catalog/streams/tests.yaml
@@ -1548,8 +1548,6 @@ 
org.apache.kafka.streams.kstream.internals.graph.StreamsGraphTest:
 - shouldNotOptimizeWithValueOrKeyChangingOperatorsAfterInitialKeyChange
 - shouldNotThrowNPEWithMergeNodes
 - shouldOptimizeSeveralMergeNodesWithCommonKeyChangingParent
-org.apache.kafka.streams.kstream.internals.graph.TableProcessorNodeTest:
-- shouldConvertToStringWithNullStoreBuilder
 org.apache.kafka.streams.kstream.internals.graph.TableSourceNodeTest:
 - shouldConnectStateStoreToChangelogTopic
 - shouldConnectStateStoreToInputTopicIfInputTopicIsUsedAsChangelog
@@ -2260,6 +2258,7 @@ 
org.apache.kafka.streams.processor.internals.RecordCollectorTest:
 - shouldSendToSpecificPartition
 - shouldSendWithNoPartition
 - shouldSendWithPartitioner
+- shouldSwallowTransactionAbortedExceptionAndNotCallProductionExceptionHandler
 - shouldThrowIfTopicIsUnknownOnSendWithPartitioner
 - shouldThrowInformativeStreamsExceptionOnKafkaExceptionFromStreamPartitioner
 - shouldThrowInformativeStreamsExceptionOnKeyAndNullValueClassCastException
diff --git a/test-catalog/test-common/test-common-api/tests.yaml 
b/test-catalog/test-common/test-common-api/tests.yaml
index b6fcd47bdb2..844ad96a055 100644
--- a/test-catalog/test-common/test-common-api/tests.yaml
+++ b/test-catalog/test-common/test-common-api/tests.yaml
@@ -11,6 +11,7 @@ org.apache.kafka.common.test.api.ClusterTestExtensionsTest:
 - testClusterTestWithDisksPerBroker
 - testClusterTests
 - testControllerListenerName
+- testControllerRestart
 - testCreateDefaultProducerAndConsumer
 - testCreateProducerAndConsumer
 - testCreateTopic

Reply via email to