Update test catalog data for GHA workflow run 11904731075

Commit: 5f4cbd4aa4
GitHub Run: https://github.com/apache/kafka/actions/runs/11904731075
This commit is contained in:
github-actions[bot] 2024-11-19 06:33:25 +00:00
parent 0c6b8afeba
commit e4a5eb866a
6 changed files with 13 additions and 194 deletions

View File

@ -2760,10 +2760,10 @@ org.apache.kafka.common.TopicPartitionTest:
- testSerializationRoundtrip
- testTopiPartitionSerializationCompatibility
org.apache.kafka.common.UuidTest:
- repetition
- testCompareUuids
- testFromStringWithInvalidInput
- testHashCode
- testRandomUuid
- testSignificantBits
- testStringConversion
- testToArray
@ -3034,21 +3034,10 @@ org.apache.kafka.common.internals.PartitionStatesTest:
- testUpdateAndMoveToEnd
org.apache.kafka.common.internals.SecurityManagerCompatibilityTest:
- testCompositeStrategyCallAsWhenSecurityManagerUnsupported
- testCompositeStrategyCurrentWhenSecurityManagerUnsupported
- testCompositeStrategyDoPrivilegedWhenSecurityManagerUnsupported
- testCompositeStrategyLoadable
- testCompositeStrategyLoadableWhenSecurityManagerRemoved
- testDefaultStrategyCallAsCurrent
- testDefaultStrategyCallAsReturn
- testDefaultStrategyCurrentNull
- testDefaultStrategyDoPrivilegedReturn
- testDefaultStrategyDoPrivilegedThrow
- testDefaultStrategyLoadable
- testLegacyStrategyCallAsThrowsWhenSecurityManagerUnsupported
- testLegacyStrategyCurrentThrowsWhenSecurityManagerUnsupported
- testLegacyStrategyLoadable
- testLegacyStrategyThrowsWhenSecurityManagerRemoved
- testModernStrategyLoadable
- testModernStrategyLoadableWhenSecurityManagerRemoved
org.apache.kafka.common.internals.TopicTest:
- shouldAcceptValidTopicNames
@ -4632,23 +4621,18 @@ org.apache.kafka.common.utils.ByteBufferUnmapperTest:
- testUnmap
org.apache.kafka.common.utils.ByteUtilsTest:
- testCorrectnessReadUnsignedVarint
- testCorrectnessReadUnsignedVarlong
- testCorrectnessWriteUnsignedVarint
- testCorrectnessWriteUnsignedVarlong
- testDouble
- testInvalidVarint
- testInvalidVarlong
- testReadInt
- testReadUnsignedInt
- testReadUnsignedIntLEFromArray
- testReadUnsignedIntLEFromInputStream
- testSizeOfUnsignedVarint
- testSizeOfVarlong
- testUnsignedVarintSerde
- testVarintSerde
- testVarlongSerde
- testWriteUnsignedIntLEToArray
- testWriteUnsignedIntLEToOutputStream
org.apache.kafka.common.utils.BytesTest:
- testIncrement
- testIncrementUpperBoundary

View File

@ -337,8 +337,6 @@ kafka.api.ConsumerBounceTest:
- testClose
- testCloseDuringRebalance
- testConsumerReceivesFatalExceptionWhenGroupPassesMaxSize
- testConsumptionWithBrokerFailures
- testRollingBrokerRestartsWithSmallerMaxGroupSizeConfigDisruptsBigGroup
- testSeekAndCommitWithBrokerFailures
- testSubscribeWhenTopicUnavailable
kafka.api.ConsumerRebootstrapTest:
@ -382,10 +380,6 @@ kafka.api.DelegationTokenEndToEndAuthorizationWithOwnerTest:
- testProduceConsumeViaSubscribe
- testProduceConsumeWithPrefixedAcls
- testProduceConsumeWithWildcardAcls
kafka.api.DescribeAuthorizedOperationsTest:
- testClusterAuthorizedOperations
- testConsumerGroupAuthorizedOperations
- testTopicAuthorizedOperations
kafka.api.EndToEndClusterIdTest:
- testEndToEnd
kafka.api.GroupAuthorizerIntegrationTest:
@ -2069,71 +2063,31 @@ kafka.network.RequestConvertToJsonTest:
- testRequestHeaderNode
- testRequestHeaderNodeWithDeprecatedApiVersion
kafka.network.SocketServerTest:
- closingChannelSendFailure
- closingChannelWithBufferedReceives
- closingChannelWithBufferedReceivesFailedSend
- closingChannelWithCompleteAndIncompleteBufferedReceives
- configureNewConnectionException
- controlThrowable
- idleExpiryWithBufferedReceives
- pollException
- processCompletedReceiveException
- processCompletedSendException
- processDisconnectedException
- processNewResponseException
- remoteCloseSendFailure
- remoteCloseWithBufferedReceives
- remoteCloseWithBufferedReceivesFailedSend
- remoteCloseWithCompleteAndIncompleteBufferedReceives
- remoteCloseWithIncompleteBufferedReceive
- remoteCloseWithoutBufferedReceives
- sendCancelledKeyException
- simpleRequest
- testAcceptorStartOpensPortIfNeeded
- testAuthorizerFailureCausesEnableRequestProcessingFailure
- testBrokerSendAfterChannelClosedUpdatesRequestMetrics
- testClientDisconnectionUpdatesRequestMetrics
- testClientDisconnectionWithOutstandingReceivesProcessedUntilFailedSend
- testClientInformationWithLatestApiVersionsRequest
- testClientInformationWithOldestApiVersionsRequest
- testConnectionDisconnectListenerInvokedOnClose
- testConnectionId
- testConnectionIdReuse
- testConnectionRateLimit
- testConnectionRatePerIp
- testControlPlaneAsPrivilegedListener
- testControlPlaneTakePrecedenceOverInterBrokerListenerAsPrivilegedListener
- testDisabledRequestIsRejected
- testExceptionInAcceptor
- testFailedAcceptorStartupCausesEnableRequestProcessingFailure
- testGracefulClose
- testIdleConnection
- testInterBrokerListenerAsPrivilegedListener
- testLatencyWithBufferedDataAndNoSocketData
- testListenBacklogSize
- testMaxConnectionsPerIp
- testMaxConnectionsPerIpOverrides
- testMetricCollectionAfterShutdown
- testNoOpAction
- testNoOpActionResponseWithThrottledChannelWhereThrottlingAlreadyDone
- testNoOpActionResponseWithThrottledChannelWhereThrottlingInProgress
- testProcessorMetricsTags
- testRequestMetricsAfterStop
- testRequestPerSecAndDeprecatedRequestsPerSecMetrics
- testSaslReauthenticationFailureNoKip152SaslAuthenticate
- testSaslReauthenticationFailureWithKip152SaslAuthenticate
- testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone
- testSendActionResponseWithThrottledChannelWhereThrottlingInProgress
- testServerShutdownWithoutEnable
- testSessionPrincipal
- testSocketsCloseOnShutdown
- testSslSocketServer
- testStagedListenerShutdownWhenConnectionQueueIsFull
- testStagedListenerStartup
- testThrottledSocketsClosedOnShutdown
- testUnmuteChannelWithBufferedReceives
- testZeroMaxConnectionsPerIp
- tooBigRequestIsRejected
kafka.raft.KafkaMetadataLogTest:
- testAdvanceLogStartOffsetAfterCleaning
- testCleanupOlderSnapshots
@ -2264,35 +2218,8 @@ kafka.server.AbstractFetcherThreadTest:
- testUnknownLeaderEpochInTruncation
- testUnknownLeaderEpochWhileFetching
kafka.server.AbstractFetcherThreadWithIbp26Test:
- testConsumerLagRemovedWithPartition
- testCorruptMessage
- testDelay
- testDivergingEpochs
- testFencedFetch
- testFencedOffsetResetAfterOutOfRange
- testFencedTruncation
- testFetcherThreadHandlingPartitionFailureDuringAppending
- testFetcherThreadHandlingPartitionFailureDuringTruncation
- testFollowerFetchOutOfRangeHigh
- testFollowerFetchOutOfRangeLow
- testLeaderEpochChangeDuringFencedFetchEpochsFromLeader
- testLeaderEpochChangeDuringSuccessfulFetchEpochsFromLeader
- testMaybeUpdateTopicIds
- testMetricsRemovedOnShutdown
- testPartitionsInError
- testRetryAfterUnknownLeaderEpochInLatestOffsetFetch
- testSimpleFetch
- testTruncateOnFetchDoesNotProcessPartitionData
- testTruncateToEpochEndOffsetsDuringRemovePartitions
- testTruncateToHighWatermarkDuringRemovePartitions
- testTruncateToHighWatermarkIfLeaderEpochInfoNotAvailable
- testTruncateToHighWatermarkIfLeaderEpochRequestNotSupported
- testTruncation
- testTruncationOnFetchSkippedIfPartitionRemoved
- testTruncationSkippedIfNoEpochChange
- testTruncationThrowsExceptionIfLeaderReturnsPartitionsNotRequestedInFetchEpochs
- testUnknownLeaderEpochInTruncation
- testUnknownLeaderEpochWhileFetching
kafka.server.AddPartitionsToTxnManagerTest:
- testAddPartitionsToTxnHandlerErrorHandling
- testAddPartitionsToTxnManagerMetrics
@ -2341,12 +2268,10 @@ kafka.server.AlterUserScramCredentialsRequestTest:
- testDeleteSomethingThatDoesNotExist
- testMetadataVersionTooLow
kafka.server.ApiVersionManagerTest:
- testApiScope
- testControllerApiIntersection
- testDisabledApis
- testEnvelopeDisabledForKRaftBroker
- testEnvelopeDisabledWhenForwardingManagerEmpty
- testEnvelopeEnabledWhenForwardingManagerPresent
kafka.server.ApiVersionsRequestTest:
- testApiVersionsRequest
- testApiVersionsRequestIncludesUnreleasedApis
@ -2442,7 +2367,6 @@ kafka.server.ClientQuotasRequestTest:
- testAlterClientQuotasRequest
- testAlterClientQuotasRequestValidateOnly
- testAlterIpQuotasRequest
- testClientQuotasForScramUsers
- testClientQuotasSanitized
- testClientQuotasUnsupportedEntityTypes
- testClientQuotasWithDefaultName
@ -2692,7 +2616,6 @@ kafka.server.DynamicBrokerConfigTest:
- testUpdateMetricReportersNoJmxReporter
kafka.server.DynamicBrokerReconfigurationTest:
- testAddRemoveSaslListeners
- testAddRemoveSslListener
- testAdvertisedListenerUpdate
- testConfigDescribeUsingAdminClient
- testConsecutiveConfigChange
@ -2748,7 +2671,6 @@ kafka.server.FetchFromFollowerIntegrationTest:
- testFetchFromFollowerWithRoll
- testFetchFromLeaderWhilePreferredReadReplicaIsUnavailable
- testFollowerCompleteDelayedFetchesOnReplication
- testRackAwareRangeAssignor
kafka.server.FetchRequestDownConversionConfigTest:
- testLatestFetchWithDownConversionDisabled
- testV12WithDownConversionDisabled
@ -3626,10 +3548,6 @@ kafka.server.RequestQuotaTest:
- testResponseThrottleTimeWhenBothProduceAndRequestQuotasViolated
- testUnauthorizedThrottle
- testUnthrottledClient
kafka.server.SaslApiVersionsRequestTest:
- testApiVersionsRequestAfterSaslHandshakeRequest
- testApiVersionsRequestBeforeSaslHandshakeRequest
- testApiVersionsRequestWithUnsupportedVersion
kafka.server.ServerMetricsTest:
- testMetricsConfig
kafka.server.ServerShutdownTest:

View File

@ -84,23 +84,9 @@ org.apache.kafka.controller.ConfigurationControlManagerTest:
- testLegacyAlterConfigs
- testReplay
org.apache.kafka.controller.FeatureControlManagerTest:
- testApplyMetadataVersionChangeRecord
- testCanUpgradeToHigherVersion
- testCanUseSafeDowngradeIfMetadataDidNotChange
- testCanUseUnsafeDowngradeIfMetadataChanged
- testCannotDowngradeBefore3_3_IV0
- testCannotDowngradeToHigherVersion
- testCannotDowngradeToVersionBeforeMinimumSupportedKraftVersion
- testCannotUnsafeDowngradeToHigherVersion
- testCannotUpgradeToLowerVersion
- testCannotUseSafeDowngradeIfMetadataChanged
- testCreateFeatureLevelRecords
- testNoMetadataVersionChangeDuringMigration
- testReplay
- testReplayRecords
- testUnsafeDowngradeIsTemporarilyDisabled
- testUpdateFeatures
- testUpdateFeaturesErrorCases
org.apache.kafka.controller.LogReplayTrackerTest:
- testEmpty
org.apache.kafka.controller.OffsetControlManagerTest:

View File

@ -157,19 +157,13 @@ org.apache.kafka.streams.integration.MetricsIntegrationTest:
org.apache.kafka.streams.integration.MetricsReporterIntegrationTest:
- shouldBeAbleToProvideInitialMetricValueToMetricsReporter
org.apache.kafka.streams.integration.NamedTopologyIntegrationTest:
- shouldAddAndRemoveNamedTopologiesBeforeStartingAndRouteQueriesToCorrectTopology
- shouldAddNamedTopologyToRunningApplicationWithEmptyInitialTopology
- shouldAddNamedTopologyToRunningApplicationWithMultipleInitialNamedTopologies
- shouldAddNamedTopologyToRunningApplicationWithMultipleNodes
- shouldAddNamedTopologyToRunningApplicationWithSingleInitialNamedTopology
- shouldAddToEmptyInitialTopologyRemoveResetOffsetsThenAddSameNamedTopology
- shouldAddToEmptyInitialTopologyRemoveResetOffsetsThenAddSameNamedTopologyWithRepartitioning
- shouldAllowMixedCollectionAndPatternSubscriptionWithMultipleNamedTopologies
- shouldAllowPatternSubscriptionWithMultipleNamedTopologies
- shouldAllowRemovingAndAddingNamedTopologyToRunningApplicationWithMultipleNodesAndResetsOffsets
- shouldPrefixAllInternalTopicNamesWithNamedTopology
- shouldProcessMultipleIdenticalNamedTopologiesWithInMemoryAndPersistentStateStores
- shouldProcessSingleNamedTopologyAndPrefixInternalTopics
- shouldRemoveAndReplaceTopologicallyIncompatibleNamedTopology
org.apache.kafka.streams.integration.OptimizedKTableIntegrationTest:
- shouldApplyUpdatesToStandbyStore

View File

@ -1267,14 +1267,6 @@ org.apache.kafka.streams.kstream.internals.KTableMapValuesTest:
- testQueryableValueGetter
org.apache.kafka.streams.kstream.internals.KTableReduceTest:
- shouldAddAndSubtract
org.apache.kafka.streams.kstream.internals.KTableSourceTest:
- kTableShouldLogAndMeterOnSkippedRecords
- kTableShouldLogOnOutOfOrder
- testKTable
- testKTableSourceEmitOnChange
- testNotSendingOldValue
- testSendingOldValue
- testValueGetter
org.apache.kafka.streams.kstream.internals.KTableTransformValuesTest:
- shouldCalculateCorrectOldValuesIfMaterializedEvenIfStateful
- shouldCalculateCorrectOldValuesIfNotStatefulEvenIfNotMaterialized
@ -2583,80 +2575,13 @@ org.apache.kafka.streams.processor.internals.StreamTaskTest:
- shouldWrapKafkaExceptionsWithStreamsExceptionAndAddContextWhenPunctuatingWallClockTimeTime
- testMetrics
org.apache.kafka.streams.processor.internals.StreamThreadTest:
- shouldAlsoPurgeWhenNothingGetsCommitted
- shouldAlwaysUpdateTasksMetadataAfterChangingState
- shouldCatchHandleCorruptionOnTaskCorruptedExceptionPath
- shouldCatchTaskMigratedExceptionOnOnTaskCorruptedExceptionPath
- shouldCatchTimeoutExceptionFromHandleCorruptionAndInvokeExceptionHandler
- shouldChangeStateAtStartClose
- shouldChangeStateInRebalanceListener
- shouldCheckStateUpdater
- shouldCheckStateUpdaterInBetweenProcessCalls
- shouldCommitAfterCommitInterval
- shouldConstructAdminMetrics
- shouldCreateMetricsAtStartup
- shouldCreateStandbyTask
- shouldEnforceRebalanceWhenScheduledAndNotCurrentlyRebalancing
- shouldEnforceRebalanceWhenTaskCorruptedExceptionIsThrownForAnActiveTask
- shouldGetMainAndRestoreConsumerInstanceId
- shouldGetMainAndRestoreConsumerInstanceIdWithInternalTimeout
- shouldInjectProducerPerThreadUsingClientSupplierOnCreateIfEosV2Enabled
- shouldInjectSharedProducerForAllTasksUsingClientSupplierOnCreateIfEosDisabled
- shouldLogAndRecordSkippedMetricForDeserializationException
- shouldLogAndRecordSkippedRecordsForInvalidTimestamps
- shouldNotBlockWhenPollingInPartitionsAssignedStateWithoutStateUpdater
- shouldNotCauseExceptionIfNothingCommitted
- shouldNotCloseTaskAndRemoveFromTaskManagerIfInvalidPidMappingOccurredInCommitTransactionWhenSuspendingTasks
- shouldNotCloseTaskAndRemoveFromTaskManagerIfPidMappingIsInvalidInCommitTransactionWhenCommitting
- shouldNotCloseTaskAndRemoveFromTaskManagerIfProducerGotFencedInCommitTransactionWhenCommitting
- shouldNotCloseTaskAndRemoveFromTaskManagerIfProducerGotFencedInCommitTransactionWhenSuspendingTasks
- shouldNotCloseTaskAndRemoveFromTaskManagerIfProducerWasFencedWhileProcessing
- shouldNotCloseTaskProducerWhenSuspending
- shouldNotCommitBeforeTheCommitInterval
- shouldNotCommitNonRunningNonRestoringTasks
- shouldNotCreateStandbyTaskIfStateStoresHaveLoggingDisabled
- shouldNotCreateStandbyTaskWithoutStateStores
- shouldNotEnforceRebalanceWhenCurrentlyRebalancing
- shouldNotEnforceRebalanceWhenTaskCorruptedExceptionIsThrownForAnInactiveTask
- shouldNotProcessWhenPartitionRevoked
- shouldNotPurgeBeforeThePurgeInterval
- shouldNotRecordFailedStreamThread
- shouldNotReturnDataAfterTaskMigrated
- shouldNotThrowWhenStandbyTasksAssignedAndNoStateStoresForTopology
- shouldNotUpdateStandbyTaskWhenPaused
- shouldOnlyCompleteShutdownAfterRebalanceNotInProgress
- shouldOnlyShutdownOnce
- shouldProcessWhenPartitionAssigned
- shouldProcessWhenRunning
- shouldProcessWhenStarting
- shouldPunctuateActiveTask
- shouldPunctuateWithTimestampPreservedInProcessorContext
- shouldPurgeAfterPurgeInterval
- shouldRecordCommitLatency
- shouldRecordFailedStreamThread
- shouldRecoverFromInvalidOffsetExceptionOnRestoreAndFinishRestore
- shouldReinitializeRevivedTasksInAnyState
- shouldRespectNumIterationsInMainLoopWithoutProcessingThreads
- shouldRespectPollTimeInPartitionsAssignedStateWithStateUpdater
- shouldResumePollingForPartitionsWithAvailableSpaceBeforePolling
- shouldReturnActiveTaskMetadataWhileRunningState
- shouldReturnErrorIfMainConsumerInstanceIdNotInitialized
- shouldReturnErrorIfProducerInstanceIdNotInitialized
- shouldReturnErrorIfRestoreConsumerInstanceIdNotInitialized
- shouldReturnNullIfMainConsumerTelemetryDisabled
- shouldReturnNullIfProducerTelemetryDisabled
- shouldReturnNullIfRestoreConsumerTelemetryDisabled
- shouldReturnStandbyTaskMetadataWhileRunningState
- shouldShutdownTaskManagerOnClose
- shouldShutdownTaskManagerOnCloseWithoutStart
- shouldThrowTaskMigratedExceptionHandlingRevocation
- shouldThrowTaskMigratedExceptionHandlingTaskLost
- shouldTimeOutOnMainConsumerInstanceId
- shouldTimeOutOnProducerInstanceId
- shouldTimeOutOnRestoreConsumerInstanceId
- shouldTransmitTaskManagerMetrics
- shouldUpdateLagsAfterPolling
- shouldUpdateStandbyTask
org.apache.kafka.streams.processor.internals.StreamThreadTotalBlockedTimeTest:
- shouldComputeTotalBlockedTime
org.apache.kafka.streams.processor.internals.StreamsAssignmentScaleTest:

View File

@ -0,0 +1,12 @@
org.apache.kafka.common.test.junit.AutoQuarantinedTestFilterTest:
- testEmptyCatalog
- testLoadCatalog
- testMissingCatalog
org.apache.kafka.common.test.junit.QuarantinedPostDiscoveryFilterTest:
- testExistingTestFlaky
- testExistingTestNonFlaky
- testNewTest
- testNoCatalogQuarantinedTest
- testQuarantinedExistingTestFlaky
- testQuarantinedExistingTestNonFlaky
- testQuarantinedNewTest