mirror of https://github.com/apache/kafka.git
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:
parent
0c6b8afeba
commit
e4a5eb866a
|
@ -2760,10 +2760,10 @@ org.apache.kafka.common.TopicPartitionTest:
|
||||||
- testSerializationRoundtrip
|
- testSerializationRoundtrip
|
||||||
- testTopiPartitionSerializationCompatibility
|
- testTopiPartitionSerializationCompatibility
|
||||||
org.apache.kafka.common.UuidTest:
|
org.apache.kafka.common.UuidTest:
|
||||||
- repetition
|
|
||||||
- testCompareUuids
|
- testCompareUuids
|
||||||
- testFromStringWithInvalidInput
|
- testFromStringWithInvalidInput
|
||||||
- testHashCode
|
- testHashCode
|
||||||
|
- testRandomUuid
|
||||||
- testSignificantBits
|
- testSignificantBits
|
||||||
- testStringConversion
|
- testStringConversion
|
||||||
- testToArray
|
- testToArray
|
||||||
|
@ -3034,21 +3034,10 @@ org.apache.kafka.common.internals.PartitionStatesTest:
|
||||||
- testUpdateAndMoveToEnd
|
- testUpdateAndMoveToEnd
|
||||||
org.apache.kafka.common.internals.SecurityManagerCompatibilityTest:
|
org.apache.kafka.common.internals.SecurityManagerCompatibilityTest:
|
||||||
- testCompositeStrategyCallAsWhenSecurityManagerUnsupported
|
- testCompositeStrategyCallAsWhenSecurityManagerUnsupported
|
||||||
- testCompositeStrategyCurrentWhenSecurityManagerUnsupported
|
|
||||||
- testCompositeStrategyDoPrivilegedWhenSecurityManagerUnsupported
|
|
||||||
- testCompositeStrategyLoadable
|
|
||||||
- testCompositeStrategyLoadableWhenSecurityManagerRemoved
|
|
||||||
- testDefaultStrategyCallAsCurrent
|
- testDefaultStrategyCallAsCurrent
|
||||||
- testDefaultStrategyCallAsReturn
|
|
||||||
- testDefaultStrategyCurrentNull
|
- testDefaultStrategyCurrentNull
|
||||||
- testDefaultStrategyDoPrivilegedReturn
|
- testDefaultStrategyDoPrivilegedReturn
|
||||||
- testDefaultStrategyDoPrivilegedThrow
|
|
||||||
- testDefaultStrategyLoadable
|
|
||||||
- testLegacyStrategyCallAsThrowsWhenSecurityManagerUnsupported
|
|
||||||
- testLegacyStrategyCurrentThrowsWhenSecurityManagerUnsupported
|
|
||||||
- testLegacyStrategyLoadable
|
|
||||||
- testLegacyStrategyThrowsWhenSecurityManagerRemoved
|
- testLegacyStrategyThrowsWhenSecurityManagerRemoved
|
||||||
- testModernStrategyLoadable
|
|
||||||
- testModernStrategyLoadableWhenSecurityManagerRemoved
|
- testModernStrategyLoadableWhenSecurityManagerRemoved
|
||||||
org.apache.kafka.common.internals.TopicTest:
|
org.apache.kafka.common.internals.TopicTest:
|
||||||
- shouldAcceptValidTopicNames
|
- shouldAcceptValidTopicNames
|
||||||
|
@ -4632,23 +4621,18 @@ org.apache.kafka.common.utils.ByteBufferUnmapperTest:
|
||||||
- testUnmap
|
- testUnmap
|
||||||
org.apache.kafka.common.utils.ByteUtilsTest:
|
org.apache.kafka.common.utils.ByteUtilsTest:
|
||||||
- testCorrectnessReadUnsignedVarint
|
- testCorrectnessReadUnsignedVarint
|
||||||
- testCorrectnessReadUnsignedVarlong
|
|
||||||
- testCorrectnessWriteUnsignedVarint
|
- testCorrectnessWriteUnsignedVarint
|
||||||
- testCorrectnessWriteUnsignedVarlong
|
|
||||||
- testDouble
|
|
||||||
- testInvalidVarint
|
- testInvalidVarint
|
||||||
- testInvalidVarlong
|
- testInvalidVarlong
|
||||||
- testReadInt
|
- testReadInt
|
||||||
- testReadUnsignedInt
|
- testReadUnsignedInt
|
||||||
- testReadUnsignedIntLEFromArray
|
- testReadUnsignedIntLEFromArray
|
||||||
- testReadUnsignedIntLEFromInputStream
|
|
||||||
- testSizeOfUnsignedVarint
|
- testSizeOfUnsignedVarint
|
||||||
- testSizeOfVarlong
|
- testSizeOfVarlong
|
||||||
- testUnsignedVarintSerde
|
- testUnsignedVarintSerde
|
||||||
- testVarintSerde
|
- testVarintSerde
|
||||||
- testVarlongSerde
|
- testVarlongSerde
|
||||||
- testWriteUnsignedIntLEToArray
|
- testWriteUnsignedIntLEToArray
|
||||||
- testWriteUnsignedIntLEToOutputStream
|
|
||||||
org.apache.kafka.common.utils.BytesTest:
|
org.apache.kafka.common.utils.BytesTest:
|
||||||
- testIncrement
|
- testIncrement
|
||||||
- testIncrementUpperBoundary
|
- testIncrementUpperBoundary
|
||||||
|
|
|
@ -337,8 +337,6 @@ kafka.api.ConsumerBounceTest:
|
||||||
- testClose
|
- testClose
|
||||||
- testCloseDuringRebalance
|
- testCloseDuringRebalance
|
||||||
- testConsumerReceivesFatalExceptionWhenGroupPassesMaxSize
|
- testConsumerReceivesFatalExceptionWhenGroupPassesMaxSize
|
||||||
- testConsumptionWithBrokerFailures
|
|
||||||
- testRollingBrokerRestartsWithSmallerMaxGroupSizeConfigDisruptsBigGroup
|
|
||||||
- testSeekAndCommitWithBrokerFailures
|
- testSeekAndCommitWithBrokerFailures
|
||||||
- testSubscribeWhenTopicUnavailable
|
- testSubscribeWhenTopicUnavailable
|
||||||
kafka.api.ConsumerRebootstrapTest:
|
kafka.api.ConsumerRebootstrapTest:
|
||||||
|
@ -382,10 +380,6 @@ kafka.api.DelegationTokenEndToEndAuthorizationWithOwnerTest:
|
||||||
- testProduceConsumeViaSubscribe
|
- testProduceConsumeViaSubscribe
|
||||||
- testProduceConsumeWithPrefixedAcls
|
- testProduceConsumeWithPrefixedAcls
|
||||||
- testProduceConsumeWithWildcardAcls
|
- testProduceConsumeWithWildcardAcls
|
||||||
kafka.api.DescribeAuthorizedOperationsTest:
|
|
||||||
- testClusterAuthorizedOperations
|
|
||||||
- testConsumerGroupAuthorizedOperations
|
|
||||||
- testTopicAuthorizedOperations
|
|
||||||
kafka.api.EndToEndClusterIdTest:
|
kafka.api.EndToEndClusterIdTest:
|
||||||
- testEndToEnd
|
- testEndToEnd
|
||||||
kafka.api.GroupAuthorizerIntegrationTest:
|
kafka.api.GroupAuthorizerIntegrationTest:
|
||||||
|
@ -2069,71 +2063,31 @@ kafka.network.RequestConvertToJsonTest:
|
||||||
- testRequestHeaderNode
|
- testRequestHeaderNode
|
||||||
- testRequestHeaderNodeWithDeprecatedApiVersion
|
- testRequestHeaderNodeWithDeprecatedApiVersion
|
||||||
kafka.network.SocketServerTest:
|
kafka.network.SocketServerTest:
|
||||||
- closingChannelSendFailure
|
|
||||||
- closingChannelWithBufferedReceives
|
|
||||||
- closingChannelWithBufferedReceivesFailedSend
|
|
||||||
- closingChannelWithCompleteAndIncompleteBufferedReceives
|
|
||||||
- configureNewConnectionException
|
|
||||||
- controlThrowable
|
- controlThrowable
|
||||||
- idleExpiryWithBufferedReceives
|
|
||||||
- pollException
|
|
||||||
- processCompletedReceiveException
|
|
||||||
- processCompletedSendException
|
|
||||||
- processDisconnectedException
|
|
||||||
- processNewResponseException
|
|
||||||
- remoteCloseSendFailure
|
- remoteCloseSendFailure
|
||||||
- remoteCloseWithBufferedReceives
|
|
||||||
- remoteCloseWithBufferedReceivesFailedSend
|
- remoteCloseWithBufferedReceivesFailedSend
|
||||||
- remoteCloseWithCompleteAndIncompleteBufferedReceives
|
|
||||||
- remoteCloseWithIncompleteBufferedReceive
|
|
||||||
- remoteCloseWithoutBufferedReceives
|
|
||||||
- sendCancelledKeyException
|
|
||||||
- simpleRequest
|
- simpleRequest
|
||||||
- testAcceptorStartOpensPortIfNeeded
|
|
||||||
- testAuthorizerFailureCausesEnableRequestProcessingFailure
|
- testAuthorizerFailureCausesEnableRequestProcessingFailure
|
||||||
- testBrokerSendAfterChannelClosedUpdatesRequestMetrics
|
- testBrokerSendAfterChannelClosedUpdatesRequestMetrics
|
||||||
- testClientDisconnectionUpdatesRequestMetrics
|
- testClientDisconnectionUpdatesRequestMetrics
|
||||||
- testClientDisconnectionWithOutstandingReceivesProcessedUntilFailedSend
|
- testClientDisconnectionWithOutstandingReceivesProcessedUntilFailedSend
|
||||||
- testClientInformationWithLatestApiVersionsRequest
|
|
||||||
- testClientInformationWithOldestApiVersionsRequest
|
- testClientInformationWithOldestApiVersionsRequest
|
||||||
- testConnectionDisconnectListenerInvokedOnClose
|
- testConnectionDisconnectListenerInvokedOnClose
|
||||||
- testConnectionId
|
- testConnectionId
|
||||||
- testConnectionIdReuse
|
- testConnectionIdReuse
|
||||||
- testConnectionRateLimit
|
|
||||||
- testConnectionRatePerIp
|
|
||||||
- testControlPlaneAsPrivilegedListener
|
|
||||||
- testControlPlaneTakePrecedenceOverInterBrokerListenerAsPrivilegedListener
|
- testControlPlaneTakePrecedenceOverInterBrokerListenerAsPrivilegedListener
|
||||||
- testDisabledRequestIsRejected
|
|
||||||
- testExceptionInAcceptor
|
- testExceptionInAcceptor
|
||||||
- testFailedAcceptorStartupCausesEnableRequestProcessingFailure
|
|
||||||
- testGracefulClose
|
- testGracefulClose
|
||||||
- testIdleConnection
|
- testIdleConnection
|
||||||
- testInterBrokerListenerAsPrivilegedListener
|
|
||||||
- testLatencyWithBufferedDataAndNoSocketData
|
- testLatencyWithBufferedDataAndNoSocketData
|
||||||
- testListenBacklogSize
|
|
||||||
- testMaxConnectionsPerIp
|
- testMaxConnectionsPerIp
|
||||||
- testMaxConnectionsPerIpOverrides
|
|
||||||
- testMetricCollectionAfterShutdown
|
|
||||||
- testNoOpAction
|
- testNoOpAction
|
||||||
- testNoOpActionResponseWithThrottledChannelWhereThrottlingAlreadyDone
|
|
||||||
- testNoOpActionResponseWithThrottledChannelWhereThrottlingInProgress
|
|
||||||
- testProcessorMetricsTags
|
- testProcessorMetricsTags
|
||||||
- testRequestMetricsAfterStop
|
- testRequestMetricsAfterStop
|
||||||
- testRequestPerSecAndDeprecatedRequestsPerSecMetrics
|
- testRequestPerSecAndDeprecatedRequestsPerSecMetrics
|
||||||
- testSaslReauthenticationFailureNoKip152SaslAuthenticate
|
- testSaslReauthenticationFailureNoKip152SaslAuthenticate
|
||||||
- testSaslReauthenticationFailureWithKip152SaslAuthenticate
|
|
||||||
- testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone
|
- testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone
|
||||||
- testSendActionResponseWithThrottledChannelWhereThrottlingInProgress
|
- testSendActionResponseWithThrottledChannelWhereThrottlingInProgress
|
||||||
- testServerShutdownWithoutEnable
|
|
||||||
- testSessionPrincipal
|
|
||||||
- testSocketsCloseOnShutdown
|
|
||||||
- testSslSocketServer
|
|
||||||
- testStagedListenerShutdownWhenConnectionQueueIsFull
|
|
||||||
- testStagedListenerStartup
|
|
||||||
- testThrottledSocketsClosedOnShutdown
|
|
||||||
- testUnmuteChannelWithBufferedReceives
|
|
||||||
- testZeroMaxConnectionsPerIp
|
|
||||||
- tooBigRequestIsRejected
|
|
||||||
kafka.raft.KafkaMetadataLogTest:
|
kafka.raft.KafkaMetadataLogTest:
|
||||||
- testAdvanceLogStartOffsetAfterCleaning
|
- testAdvanceLogStartOffsetAfterCleaning
|
||||||
- testCleanupOlderSnapshots
|
- testCleanupOlderSnapshots
|
||||||
|
@ -2264,35 +2218,8 @@ kafka.server.AbstractFetcherThreadTest:
|
||||||
- testUnknownLeaderEpochInTruncation
|
- testUnknownLeaderEpochInTruncation
|
||||||
- testUnknownLeaderEpochWhileFetching
|
- testUnknownLeaderEpochWhileFetching
|
||||||
kafka.server.AbstractFetcherThreadWithIbp26Test:
|
kafka.server.AbstractFetcherThreadWithIbp26Test:
|
||||||
- testConsumerLagRemovedWithPartition
|
|
||||||
- testCorruptMessage
|
|
||||||
- testDelay
|
|
||||||
- testDivergingEpochs
|
|
||||||
- testFencedFetch
|
|
||||||
- testFencedOffsetResetAfterOutOfRange
|
|
||||||
- testFencedTruncation
|
|
||||||
- testFetcherThreadHandlingPartitionFailureDuringAppending
|
|
||||||
- testFetcherThreadHandlingPartitionFailureDuringTruncation
|
|
||||||
- testFollowerFetchOutOfRangeHigh
|
|
||||||
- testFollowerFetchOutOfRangeLow
|
|
||||||
- testLeaderEpochChangeDuringFencedFetchEpochsFromLeader
|
|
||||||
- testLeaderEpochChangeDuringSuccessfulFetchEpochsFromLeader
|
|
||||||
- testMaybeUpdateTopicIds
|
|
||||||
- testMetricsRemovedOnShutdown
|
|
||||||
- testPartitionsInError
|
|
||||||
- testRetryAfterUnknownLeaderEpochInLatestOffsetFetch
|
|
||||||
- testSimpleFetch
|
- testSimpleFetch
|
||||||
- testTruncateOnFetchDoesNotProcessPartitionData
|
|
||||||
- testTruncateToEpochEndOffsetsDuringRemovePartitions
|
|
||||||
- testTruncateToHighWatermarkDuringRemovePartitions
|
|
||||||
- testTruncateToHighWatermarkIfLeaderEpochInfoNotAvailable
|
- testTruncateToHighWatermarkIfLeaderEpochInfoNotAvailable
|
||||||
- testTruncateToHighWatermarkIfLeaderEpochRequestNotSupported
|
|
||||||
- testTruncation
|
|
||||||
- testTruncationOnFetchSkippedIfPartitionRemoved
|
|
||||||
- testTruncationSkippedIfNoEpochChange
|
|
||||||
- testTruncationThrowsExceptionIfLeaderReturnsPartitionsNotRequestedInFetchEpochs
|
|
||||||
- testUnknownLeaderEpochInTruncation
|
|
||||||
- testUnknownLeaderEpochWhileFetching
|
|
||||||
kafka.server.AddPartitionsToTxnManagerTest:
|
kafka.server.AddPartitionsToTxnManagerTest:
|
||||||
- testAddPartitionsToTxnHandlerErrorHandling
|
- testAddPartitionsToTxnHandlerErrorHandling
|
||||||
- testAddPartitionsToTxnManagerMetrics
|
- testAddPartitionsToTxnManagerMetrics
|
||||||
|
@ -2341,12 +2268,10 @@ kafka.server.AlterUserScramCredentialsRequestTest:
|
||||||
- testDeleteSomethingThatDoesNotExist
|
- testDeleteSomethingThatDoesNotExist
|
||||||
- testMetadataVersionTooLow
|
- testMetadataVersionTooLow
|
||||||
kafka.server.ApiVersionManagerTest:
|
kafka.server.ApiVersionManagerTest:
|
||||||
- testApiScope
|
|
||||||
- testControllerApiIntersection
|
- testControllerApiIntersection
|
||||||
- testDisabledApis
|
- testDisabledApis
|
||||||
- testEnvelopeDisabledForKRaftBroker
|
- testEnvelopeDisabledForKRaftBroker
|
||||||
- testEnvelopeDisabledWhenForwardingManagerEmpty
|
- testEnvelopeDisabledWhenForwardingManagerEmpty
|
||||||
- testEnvelopeEnabledWhenForwardingManagerPresent
|
|
||||||
kafka.server.ApiVersionsRequestTest:
|
kafka.server.ApiVersionsRequestTest:
|
||||||
- testApiVersionsRequest
|
- testApiVersionsRequest
|
||||||
- testApiVersionsRequestIncludesUnreleasedApis
|
- testApiVersionsRequestIncludesUnreleasedApis
|
||||||
|
@ -2442,7 +2367,6 @@ kafka.server.ClientQuotasRequestTest:
|
||||||
- testAlterClientQuotasRequest
|
- testAlterClientQuotasRequest
|
||||||
- testAlterClientQuotasRequestValidateOnly
|
- testAlterClientQuotasRequestValidateOnly
|
||||||
- testAlterIpQuotasRequest
|
- testAlterIpQuotasRequest
|
||||||
- testClientQuotasForScramUsers
|
|
||||||
- testClientQuotasSanitized
|
- testClientQuotasSanitized
|
||||||
- testClientQuotasUnsupportedEntityTypes
|
- testClientQuotasUnsupportedEntityTypes
|
||||||
- testClientQuotasWithDefaultName
|
- testClientQuotasWithDefaultName
|
||||||
|
@ -2692,7 +2616,6 @@ kafka.server.DynamicBrokerConfigTest:
|
||||||
- testUpdateMetricReportersNoJmxReporter
|
- testUpdateMetricReportersNoJmxReporter
|
||||||
kafka.server.DynamicBrokerReconfigurationTest:
|
kafka.server.DynamicBrokerReconfigurationTest:
|
||||||
- testAddRemoveSaslListeners
|
- testAddRemoveSaslListeners
|
||||||
- testAddRemoveSslListener
|
|
||||||
- testAdvertisedListenerUpdate
|
- testAdvertisedListenerUpdate
|
||||||
- testConfigDescribeUsingAdminClient
|
- testConfigDescribeUsingAdminClient
|
||||||
- testConsecutiveConfigChange
|
- testConsecutiveConfigChange
|
||||||
|
@ -2748,7 +2671,6 @@ kafka.server.FetchFromFollowerIntegrationTest:
|
||||||
- testFetchFromFollowerWithRoll
|
- testFetchFromFollowerWithRoll
|
||||||
- testFetchFromLeaderWhilePreferredReadReplicaIsUnavailable
|
- testFetchFromLeaderWhilePreferredReadReplicaIsUnavailable
|
||||||
- testFollowerCompleteDelayedFetchesOnReplication
|
- testFollowerCompleteDelayedFetchesOnReplication
|
||||||
- testRackAwareRangeAssignor
|
|
||||||
kafka.server.FetchRequestDownConversionConfigTest:
|
kafka.server.FetchRequestDownConversionConfigTest:
|
||||||
- testLatestFetchWithDownConversionDisabled
|
- testLatestFetchWithDownConversionDisabled
|
||||||
- testV12WithDownConversionDisabled
|
- testV12WithDownConversionDisabled
|
||||||
|
@ -3626,10 +3548,6 @@ kafka.server.RequestQuotaTest:
|
||||||
- testResponseThrottleTimeWhenBothProduceAndRequestQuotasViolated
|
- testResponseThrottleTimeWhenBothProduceAndRequestQuotasViolated
|
||||||
- testUnauthorizedThrottle
|
- testUnauthorizedThrottle
|
||||||
- testUnthrottledClient
|
- testUnthrottledClient
|
||||||
kafka.server.SaslApiVersionsRequestTest:
|
|
||||||
- testApiVersionsRequestAfterSaslHandshakeRequest
|
|
||||||
- testApiVersionsRequestBeforeSaslHandshakeRequest
|
|
||||||
- testApiVersionsRequestWithUnsupportedVersion
|
|
||||||
kafka.server.ServerMetricsTest:
|
kafka.server.ServerMetricsTest:
|
||||||
- testMetricsConfig
|
- testMetricsConfig
|
||||||
kafka.server.ServerShutdownTest:
|
kafka.server.ServerShutdownTest:
|
||||||
|
|
|
@ -84,23 +84,9 @@ org.apache.kafka.controller.ConfigurationControlManagerTest:
|
||||||
- testLegacyAlterConfigs
|
- testLegacyAlterConfigs
|
||||||
- testReplay
|
- testReplay
|
||||||
org.apache.kafka.controller.FeatureControlManagerTest:
|
org.apache.kafka.controller.FeatureControlManagerTest:
|
||||||
- testApplyMetadataVersionChangeRecord
|
|
||||||
- testCanUpgradeToHigherVersion
|
|
||||||
- testCanUseSafeDowngradeIfMetadataDidNotChange
|
|
||||||
- testCanUseUnsafeDowngradeIfMetadataChanged
|
|
||||||
- testCannotDowngradeBefore3_3_IV0
|
|
||||||
- testCannotDowngradeToHigherVersion
|
|
||||||
- testCannotDowngradeToVersionBeforeMinimumSupportedKraftVersion
|
|
||||||
- testCannotUnsafeDowngradeToHigherVersion
|
|
||||||
- testCannotUpgradeToLowerVersion
|
|
||||||
- testCannotUseSafeDowngradeIfMetadataChanged
|
|
||||||
- testCreateFeatureLevelRecords
|
|
||||||
- testNoMetadataVersionChangeDuringMigration
|
- testNoMetadataVersionChangeDuringMigration
|
||||||
- testReplay
|
|
||||||
- testReplayRecords
|
- testReplayRecords
|
||||||
- testUnsafeDowngradeIsTemporarilyDisabled
|
|
||||||
- testUpdateFeatures
|
- testUpdateFeatures
|
||||||
- testUpdateFeaturesErrorCases
|
|
||||||
org.apache.kafka.controller.LogReplayTrackerTest:
|
org.apache.kafka.controller.LogReplayTrackerTest:
|
||||||
- testEmpty
|
- testEmpty
|
||||||
org.apache.kafka.controller.OffsetControlManagerTest:
|
org.apache.kafka.controller.OffsetControlManagerTest:
|
||||||
|
|
|
@ -157,19 +157,13 @@ org.apache.kafka.streams.integration.MetricsIntegrationTest:
|
||||||
org.apache.kafka.streams.integration.MetricsReporterIntegrationTest:
|
org.apache.kafka.streams.integration.MetricsReporterIntegrationTest:
|
||||||
- shouldBeAbleToProvideInitialMetricValueToMetricsReporter
|
- shouldBeAbleToProvideInitialMetricValueToMetricsReporter
|
||||||
org.apache.kafka.streams.integration.NamedTopologyIntegrationTest:
|
org.apache.kafka.streams.integration.NamedTopologyIntegrationTest:
|
||||||
- shouldAddAndRemoveNamedTopologiesBeforeStartingAndRouteQueriesToCorrectTopology
|
|
||||||
- shouldAddNamedTopologyToRunningApplicationWithEmptyInitialTopology
|
- shouldAddNamedTopologyToRunningApplicationWithEmptyInitialTopology
|
||||||
- shouldAddNamedTopologyToRunningApplicationWithMultipleInitialNamedTopologies
|
|
||||||
- shouldAddNamedTopologyToRunningApplicationWithMultipleNodes
|
|
||||||
- shouldAddNamedTopologyToRunningApplicationWithSingleInitialNamedTopology
|
|
||||||
- shouldAddToEmptyInitialTopologyRemoveResetOffsetsThenAddSameNamedTopology
|
- shouldAddToEmptyInitialTopologyRemoveResetOffsetsThenAddSameNamedTopology
|
||||||
- shouldAddToEmptyInitialTopologyRemoveResetOffsetsThenAddSameNamedTopologyWithRepartitioning
|
- shouldAddToEmptyInitialTopologyRemoveResetOffsetsThenAddSameNamedTopologyWithRepartitioning
|
||||||
- shouldAllowMixedCollectionAndPatternSubscriptionWithMultipleNamedTopologies
|
- shouldAllowMixedCollectionAndPatternSubscriptionWithMultipleNamedTopologies
|
||||||
- shouldAllowPatternSubscriptionWithMultipleNamedTopologies
|
- shouldAllowPatternSubscriptionWithMultipleNamedTopologies
|
||||||
- shouldAllowRemovingAndAddingNamedTopologyToRunningApplicationWithMultipleNodesAndResetsOffsets
|
- shouldAllowRemovingAndAddingNamedTopologyToRunningApplicationWithMultipleNodesAndResetsOffsets
|
||||||
- shouldPrefixAllInternalTopicNamesWithNamedTopology
|
- shouldPrefixAllInternalTopicNamesWithNamedTopology
|
||||||
- shouldProcessMultipleIdenticalNamedTopologiesWithInMemoryAndPersistentStateStores
|
|
||||||
- shouldProcessSingleNamedTopologyAndPrefixInternalTopics
|
|
||||||
- shouldRemoveAndReplaceTopologicallyIncompatibleNamedTopology
|
- shouldRemoveAndReplaceTopologicallyIncompatibleNamedTopology
|
||||||
org.apache.kafka.streams.integration.OptimizedKTableIntegrationTest:
|
org.apache.kafka.streams.integration.OptimizedKTableIntegrationTest:
|
||||||
- shouldApplyUpdatesToStandbyStore
|
- shouldApplyUpdatesToStandbyStore
|
||||||
|
|
|
@ -1267,14 +1267,6 @@ org.apache.kafka.streams.kstream.internals.KTableMapValuesTest:
|
||||||
- testQueryableValueGetter
|
- testQueryableValueGetter
|
||||||
org.apache.kafka.streams.kstream.internals.KTableReduceTest:
|
org.apache.kafka.streams.kstream.internals.KTableReduceTest:
|
||||||
- shouldAddAndSubtract
|
- shouldAddAndSubtract
|
||||||
org.apache.kafka.streams.kstream.internals.KTableSourceTest:
|
|
||||||
- kTableShouldLogAndMeterOnSkippedRecords
|
|
||||||
- kTableShouldLogOnOutOfOrder
|
|
||||||
- testKTable
|
|
||||||
- testKTableSourceEmitOnChange
|
|
||||||
- testNotSendingOldValue
|
|
||||||
- testSendingOldValue
|
|
||||||
- testValueGetter
|
|
||||||
org.apache.kafka.streams.kstream.internals.KTableTransformValuesTest:
|
org.apache.kafka.streams.kstream.internals.KTableTransformValuesTest:
|
||||||
- shouldCalculateCorrectOldValuesIfMaterializedEvenIfStateful
|
- shouldCalculateCorrectOldValuesIfMaterializedEvenIfStateful
|
||||||
- shouldCalculateCorrectOldValuesIfNotStatefulEvenIfNotMaterialized
|
- shouldCalculateCorrectOldValuesIfNotStatefulEvenIfNotMaterialized
|
||||||
|
@ -2583,80 +2575,13 @@ org.apache.kafka.streams.processor.internals.StreamTaskTest:
|
||||||
- shouldWrapKafkaExceptionsWithStreamsExceptionAndAddContextWhenPunctuatingWallClockTimeTime
|
- shouldWrapKafkaExceptionsWithStreamsExceptionAndAddContextWhenPunctuatingWallClockTimeTime
|
||||||
- testMetrics
|
- testMetrics
|
||||||
org.apache.kafka.streams.processor.internals.StreamThreadTest:
|
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
|
- shouldInjectProducerPerThreadUsingClientSupplierOnCreateIfEosV2Enabled
|
||||||
- shouldInjectSharedProducerForAllTasksUsingClientSupplierOnCreateIfEosDisabled
|
|
||||||
- shouldLogAndRecordSkippedMetricForDeserializationException
|
|
||||||
- shouldLogAndRecordSkippedRecordsForInvalidTimestamps
|
- shouldLogAndRecordSkippedRecordsForInvalidTimestamps
|
||||||
- shouldNotBlockWhenPollingInPartitionsAssignedStateWithoutStateUpdater
|
|
||||||
- shouldNotCauseExceptionIfNothingCommitted
|
|
||||||
- shouldNotCloseTaskAndRemoveFromTaskManagerIfInvalidPidMappingOccurredInCommitTransactionWhenSuspendingTasks
|
|
||||||
- shouldNotCloseTaskAndRemoveFromTaskManagerIfPidMappingIsInvalidInCommitTransactionWhenCommitting
|
|
||||||
- shouldNotCloseTaskAndRemoveFromTaskManagerIfProducerGotFencedInCommitTransactionWhenCommitting
|
|
||||||
- shouldNotCloseTaskAndRemoveFromTaskManagerIfProducerGotFencedInCommitTransactionWhenSuspendingTasks
|
|
||||||
- shouldNotCloseTaskAndRemoveFromTaskManagerIfProducerWasFencedWhileProcessing
|
|
||||||
- shouldNotCloseTaskProducerWhenSuspending
|
|
||||||
- shouldNotCommitBeforeTheCommitInterval
|
|
||||||
- shouldNotCommitNonRunningNonRestoringTasks
|
- shouldNotCommitNonRunningNonRestoringTasks
|
||||||
- shouldNotCreateStandbyTaskIfStateStoresHaveLoggingDisabled
|
|
||||||
- shouldNotCreateStandbyTaskWithoutStateStores
|
|
||||||
- shouldNotEnforceRebalanceWhenCurrentlyRebalancing
|
|
||||||
- shouldNotEnforceRebalanceWhenTaskCorruptedExceptionIsThrownForAnInactiveTask
|
|
||||||
- shouldNotProcessWhenPartitionRevoked
|
|
||||||
- shouldNotPurgeBeforeThePurgeInterval
|
- shouldNotPurgeBeforeThePurgeInterval
|
||||||
- shouldNotRecordFailedStreamThread
|
|
||||||
- shouldNotReturnDataAfterTaskMigrated
|
|
||||||
- shouldNotThrowWhenStandbyTasksAssignedAndNoStateStoresForTopology
|
|
||||||
- shouldNotUpdateStandbyTaskWhenPaused
|
|
||||||
- shouldOnlyCompleteShutdownAfterRebalanceNotInProgress
|
|
||||||
- shouldOnlyShutdownOnce
|
|
||||||
- shouldProcessWhenPartitionAssigned
|
|
||||||
- shouldProcessWhenRunning
|
|
||||||
- shouldProcessWhenStarting
|
|
||||||
- shouldPunctuateActiveTask
|
|
||||||
- shouldPunctuateWithTimestampPreservedInProcessorContext
|
- shouldPunctuateWithTimestampPreservedInProcessorContext
|
||||||
- shouldPurgeAfterPurgeInterval
|
|
||||||
- shouldRecordCommitLatency
|
|
||||||
- shouldRecordFailedStreamThread
|
|
||||||
- shouldRecoverFromInvalidOffsetExceptionOnRestoreAndFinishRestore
|
|
||||||
- shouldReinitializeRevivedTasksInAnyState
|
|
||||||
- shouldRespectNumIterationsInMainLoopWithoutProcessingThreads
|
|
||||||
- shouldRespectPollTimeInPartitionsAssignedStateWithStateUpdater
|
|
||||||
- shouldResumePollingForPartitionsWithAvailableSpaceBeforePolling
|
|
||||||
- shouldReturnActiveTaskMetadataWhileRunningState
|
|
||||||
- shouldReturnErrorIfMainConsumerInstanceIdNotInitialized
|
|
||||||
- shouldReturnErrorIfProducerInstanceIdNotInitialized
|
|
||||||
- shouldReturnErrorIfRestoreConsumerInstanceIdNotInitialized
|
|
||||||
- shouldReturnNullIfMainConsumerTelemetryDisabled
|
|
||||||
- shouldReturnNullIfProducerTelemetryDisabled
|
|
||||||
- shouldReturnNullIfRestoreConsumerTelemetryDisabled
|
|
||||||
- shouldReturnStandbyTaskMetadataWhileRunningState
|
- shouldReturnStandbyTaskMetadataWhileRunningState
|
||||||
- shouldShutdownTaskManagerOnClose
|
|
||||||
- shouldShutdownTaskManagerOnCloseWithoutStart
|
|
||||||
- shouldThrowTaskMigratedExceptionHandlingRevocation
|
|
||||||
- shouldThrowTaskMigratedExceptionHandlingTaskLost
|
|
||||||
- shouldTimeOutOnMainConsumerInstanceId
|
|
||||||
- shouldTimeOutOnProducerInstanceId
|
|
||||||
- shouldTimeOutOnRestoreConsumerInstanceId
|
|
||||||
- shouldTransmitTaskManagerMetrics
|
|
||||||
- shouldUpdateLagsAfterPolling
|
- shouldUpdateLagsAfterPolling
|
||||||
- shouldUpdateStandbyTask
|
|
||||||
org.apache.kafka.streams.processor.internals.StreamThreadTotalBlockedTimeTest:
|
org.apache.kafka.streams.processor.internals.StreamThreadTotalBlockedTimeTest:
|
||||||
- shouldComputeTotalBlockedTime
|
- shouldComputeTotalBlockedTime
|
||||||
org.apache.kafka.streams.processor.internals.StreamsAssignmentScaleTest:
|
org.apache.kafka.streams.processor.internals.StreamsAssignmentScaleTest:
|
||||||
|
|
|
@ -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
|
Loading…
Reference in New Issue