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 12d520c25f3 Update test catalog data for GHA workflow run 12800601275
12d520c25f3 is described below

commit 12d520c25f30244e3d8e59760e86252bca4be00c
Author: github-actions[bot] 
<41898282+github-actions[bot]@users.noreply.github.com>
AuthorDate: Thu Jan 16 04:25:17 2025 +0000

    Update test catalog data for GHA workflow run 12800601275
    
    Commit: 
https://github.com/apache/kafka/commit/c7d3999d4f5f6cbe7bb2be60155ee6e607a7152d
    GitHub Run: https://github.com/apache/kafka/actions/runs/12800601275
---
 test-catalog/streams/tests.yaml |   4 +-
 test-catalog/tools/tests.yaml   | 715 ++++++++++++++++++++++++++++++++++++++++
 2 files changed, 718 insertions(+), 1 deletion(-)

diff --git a/test-catalog/streams/tests.yaml b/test-catalog/streams/tests.yaml
index 037cb9fbeff..3373e183af5 100644
--- a/test-catalog/streams/tests.yaml
+++ b/test-catalog/streams/tests.yaml
@@ -1379,7 +1379,9 @@ 
org.apache.kafka.streams.kstream.internals.SuppressScenarioTest:
 - shouldWorkBeforeGroupBy
 - shouldWorkBeforeJoinLeft
 - shouldWorkBeforeJoinRight
-- shouldWorkWithCogrouped
+- shouldWorkWithCogroupedSessionWindows
+- shouldWorkWithCogroupedSlidingWindows
+- shouldWorkWithCogroupedTimeWindows
 org.apache.kafka.streams.kstream.internals.SuppressTopologyTest:
 - shouldApplyNameToFinalSuppressionNode
 - shouldApplyNameToSuppressionNode
diff --git a/test-catalog/tools/tests.yaml b/test-catalog/tools/tests.yaml
new file mode 100644
index 00000000000..f4430780f34
--- /dev/null
+++ b/test-catalog/tools/tests.yaml
@@ -0,0 +1,715 @@
+org.apache.kafka.tools.AclCommandTest:
+- testAclCliWithAdminAPI
+- testAclCliWithAdminAPIAndBootstrapController
+- testAclCliWithClientId
+- testAclCliWithClientIdAndBootstrapController
+- testAclCliWithMisusingBootstrapControllerToServer
+- testAclCliWithMisusingBootstrapServerToController
+- testAclsOnPrefixedResourcesWithAdminAPI
+- testAclsOnPrefixedResourcesWithAdminAPIAndBootstrapController
+- testExactlyOneAction
+- testInvalidArgs
+- testPatternTypesWithAdminAPI
+- testPatternTypesWithAdminAPIAndBootstrapController
+- testProducerConsumerCliWithAdminAPI
+- testProducerConsumerCliWithAdminAPIAndBootstrapController
+- testUseBootstrapServerOptWithBootstrapControllerOpt
+- testUseConsumerOptWithoutRequiredOpt
+- testUseIdempotentOptWithoutProducerOpt
+- testUseListPrincipalsOptWithoutListOpt
+- testUseProducerOptWithoutTopicOpt
+- testUseWithoutBootstrapServerOptAndBootstrapControllerOpt
+org.apache.kafka.tools.BrokerApiVersionsCommandTest:
+- testAdminSendNoBlock
+- testBrokerApiVersionsCommandOutput
+org.apache.kafka.tools.ClientMetricsCommandTest:
+- testAlter
+- testAlterGenerateName
+- testDelete
+- testDescribe
+- testDescribeAll
+- testList
+- testListFailsWithUnsupportedVersionException
+- testOptionsAlterAllOptionsSucceeds
+- testOptionsAlterGenerateNameSucceeds
+- testOptionsAlterNoNameFails
+- testOptionsAlterWithNameSucceeds
+- testOptionsDeleteNoNameFails
+- testOptionsDeleteWithNameSucceeds
+- testOptionsDescribeNoNameSucceeds
+- testOptionsDescribeWithNameSucceeds
+- testOptionsListSucceeds
+- testOptionsNoActionFails
+org.apache.kafka.tools.ClusterToolTest:
+- testClusterId
+- testClusterIdWithBootstrapController
+- testClusterTooOldToHaveId
+- testLegacyModeClusterCannotUnregisterBroker
+- testListEndpointsArgumentWithBootstrapController
+- testListEndpointsArgumentWithBootstrapServer
+- testListEndpointsWithBootstrapController
+- testListEndpointsWithBootstrapServer
+- testPrintClusterId
+- testUnregister
+- testUnregisterBroker
+- testUnregisterWithBootstrapController
+org.apache.kafka.tools.ConnectPluginPathTest:
+- testListMultipleLocations
+- testListMultiplePluginPaths
+- testListMultipleWorkerConfigs
+- testListNoArguments
+- testListOneLocation
+- testListOnePluginPath
+- testListOneWorkerConfig
+- testNoArguments
+- testSyncManifests
+- testSyncManifestsDryRun
+- testSyncManifestsDryRunReadOnlyLocation
+- testSyncManifestsDryRunReadOnlyManifest
+- testSyncManifestsDryRunReadOnlyMetaInf
+- testSyncManifestsDryRunReadOnlyServices
+- testSyncManifestsKeepNotFound
+org.apache.kafka.tools.ConsoleProducerTest:
+- testBatchSizeNotSetAndMaxPartitionMemoryBytesSet
+- testBatchSizeOverriddenByMaxPartitionMemoryBytesValue
+- testBatchSizeSetAndMaxPartitionMemoryBytesNotSet
+- testBootstrapServerOverride
+- testClientIdOverride
+- testDefaultBatchSize
+- testDefaultClientId
+- testInvalidConfigs
+- testLoopReader
+- testNewReader
+- testParseKeyProp
+- testParseReaderConfigFile
+- testValidConfigsBootstrapServer
+org.apache.kafka.tools.ConsumerPerformanceTest:
+- testClientIdOverride
+- testConfigBootStrapServer
+- testConfigWithUnrecognizedOption
+- testDefaultClientId
+- testDetailedHeaderMatchBody
+- testNonDetailedHeaderMatchBody
+org.apache.kafka.tools.DelegationTokenCommandTest:
+- testDelegationTokenRequests
+org.apache.kafka.tools.DeleteRecordsCommandTest:
+- testCommand
+- testCommandConfigNotExists
+- testOffsetFileNotExists
+- testParse
+- testWrongPartitions
+- testWrongVersion
+org.apache.kafka.tools.EndToEndLatencyTest:
+- shouldFailWhenConsumerRecordsIsEmpty
+- shouldFailWhenProducerAcksAreNotSynchronised
+- shouldFailWhenReceivedMoreThanOneRecord
+- shouldFailWhenSentIsNotEqualToReceived
+- shouldFailWhenSuppliedUnexpectedArgs
+- shouldPassInValidation
+org.apache.kafka.tools.FeatureCommandTest:
+- testDescribeWithKRaft
+- testDescribeWithKRaftAndBootstrapControllers
+- testDowngradeMetadataVersionWithKRaft
+- testDowngradeType
+- testDowngradeWithReleaseVersion
+- testHandleDescribe
+- testHandleDisable
+- testHandleDisableDryRun
+- testHandleDowngrade
+- testHandleDowngradeDryRun
+- testHandleFeatureDependenciesForFeatureWithDependencies
+- testHandleFeatureDependenciesForFeatureWithNoDependencies
+- testHandleFeatureDependenciesForFeatureWithUnknownFeatureVersion
+- testHandleFeatureDependenciesForInvalidVersionFormat
+- testHandleFeatureDependenciesForMultipleFeatures
+- testHandleFeatureDependenciesForUnknownFeature
+- testHandleUpgrade
+- testHandleUpgradeDryRun
+- testHandleVersionMappingWithInvalidReleaseVersion
+- testHandleVersionMappingWithNoReleaseVersion
+- testHandleVersionMappingWithValidReleaseVersion
+- testIncompatibleUpgradeFlags
+- testInvalidReleaseVersion
+- testLevelToString
+- testMetadataVersionsToString
+- testParseNameAndLevel
+- testUpgradeMetadataVersionWithKraft
+- testUpgradeWithReleaseVersion
+org.apache.kafka.tools.GetOffsetShellParsingTest:
+- testInvalidOffset
+- testInvalidTimeValue
+- testPartitionFilterForLowerBound
+- testPartitionFilterForRange
+- testPartitionFilterForSingleIndex
+- testPartitionFilterForUpperBound
+- testPartitionsSetFilter
+- testTopicPartitionFilterComplex
+- testTopicPartitionFilterForInternalTopicName
+- testTopicPartitionFilterForPartitionIndexSpec
+- testTopicPartitionFilterForPartitionLowerBoundSpec
+- testTopicPartitionFilterForPartitionRangeSpec
+- testTopicPartitionFilterForPartitionUpperBoundSpec
+- testTopicPartitionFilterForRegex
+- testTopicPartitionFilterForTopicName
+- testTopicPartitionFilterForTopicNameList
+org.apache.kafka.tools.GetOffsetShellTest:
+- testGetEarliestOffsets
+- testGetLatestOffsets
+- testGetOffsetsByEarliestLocalSpec
+- testGetOffsetsByLatestTieredSpec
+- testGetOffsetsByMaxTimestamp
+- testGetOffsetsByTimestamp
+- testInternalExcluded
+- testNoFilterOptions
+- testNoOffsetIfTimestampGreaterThanLatestRecord
+- testPartitionsArg
+- testPrintHelp
+- testPrintVersion
+- testTopicNameArg
+- testTopicPartitionsArg
+- testTopicPartitionsArgWithInternalExcluded
+- testTopicPartitionsArgWithInternalIncluded
+- testTopicPartitionsFlagWithPartitionsFlagCauseExit
+- testTopicPartitionsFlagWithTopicFlagCauseExit
+- testTopicPartitionsNotFoundForExcludedInternalTopic
+- testTopicPartitionsNotFoundForNonExistentTopic
+- testTopicPartitionsNotFoundForNonMatchingTopicPartitionPattern
+- testTopicPatternArg
+- testTopicPatternArgWithPartitionsArg
+org.apache.kafka.tools.GroupsCommandTest:
+- testGroupCommand
+- testListGroups
+- testListGroupsConsumerFilter
+- testListGroupsEmpty
+- testListGroupsFailsWithException
+- testListGroupsProtocolAndTypeFilter
+- testListGroupsProtocolAndTypeFilterNoMatch
+- testListGroupsProtocolFilter
+- testListGroupsShareFilter
+- testListGroupsTypeFilter
+- testOptionsListConsumerAndProtocolFilterFails
+- testOptionsListConsumerAndShareFilterFails
+- testOptionsListConsumerAndTypeFilterFails
+- testOptionsListConsumerFilterSucceeds
+- testOptionsListInvalidTypeFilterFails
+- testOptionsListProtocolAndTypeFiltersSucceeds
+- testOptionsListProtocolFilterSucceeds
+- testOptionsListShareAndProtocolFilterFails
+- testOptionsListShareAndTypeFilterFails
+- testOptionsListShareFilterSucceeds
+- testOptionsListSucceeds
+- testOptionsListTypeFilterSucceeds
+- testOptionsNoActionFails
+org.apache.kafka.tools.JmxToolTest:
+- allMetrics
+- csvFormat
+- dateFormat
+- filteredMetrics
+- helpOptions
+- kafkaVersion
+- malformedURL
+- missingRequired
+- testDomainNamePattern
+- testDomainNamePatternWithNoAttributes
+- testPropertyListPattern
+- testPropertyListPatternWithNoAttributes
+- testPropertyPattern
+- testPropertyPatternWithNoAttributes
+- testPropertyValuePattern
+- testPropertyValuePatternWithNoAttributes
+- tsvFormat
+- unknownObjectName
+- unrecognizedOption
+org.apache.kafka.tools.LeaderElectionCommandErrorTest:
+- testInvalidBroker
+- testMissingElectionType
+- testMissingTopicPartitionSelection
+- testPartitionWithoutTopic
+- testTopicWithoutPartition
+org.apache.kafka.tools.LeaderElectionCommandTest:
+- testAdminConfigCustomTimeouts
+- testAllTopicPartition
+- testElectionResultOutput
+- testPathToJsonFile
+- testPreferredReplicaElection
+- testTopicDoesNotExist
+- testTopicPartition
+org.apache.kafka.tools.LineMessageReaderTest:
+- testDemarcationsLongerThanOne
+- testHeaderDemarcationCollision
+- testIgnoreErrorInInput
+- testInvalidNullMarker
+- testKeyMissingValue
+- testLineReader
+- testLineReaderHeader
+- testLineReaderHeaderNoKey
+- testLineReaderOnlyValue
+- testMalformedHeaderIgnoreError
+- testMinimalValidInputWithHeaderKeyAndValue
+- testMissingHeaderKeySeparator
+- testMissingKeySeparator
+- testNullMarker
+- testNullMarkerHeaderKeyThrows
+- testNullMarkerWithHeaders
+- 
testParseHeaderEnabledWithCustomDelimiterAndVaryingNumberOfKeyValueHeaderPairs
+org.apache.kafka.tools.LogDirsCommandTest:
+- shouldNotThrowWhenDuplicatedBrokers
+- shouldQueryAllBrokersIfNonSpecified
+- shouldQuerySpecifiedBroker
+- shouldThrowWhenQueryingNonExistentBrokers
+- testLogDirsWithBrokers
+- testLogDirsWithNonExistentTopic
+- testLogDirsWithSpecificTopic
+- testLogDirsWithoutBrokers
+org.apache.kafka.tools.MetadataQuorumCommandErrorTest:
+- testDescribeOptions
+- testPropertiesFileDoesNotExists
+- testRelativeTimeMs
+- testRemoveControllerRequiresControllerDirectoryId
+- testRemoveControllerRequiresControllerId
+org.apache.kafka.tools.MetadataQuorumCommandTest:
+- testCommandConfig
+- testDescribeQuorumReplicationSuccessful
+- testDescribeQuorumStatusSuccessful
+- testHumanReadableOutput
+- testOnlyOneBrokerAndOneController
+org.apache.kafka.tools.MetadataQuorumCommandUnitTest:
+- testAddControllerDryRun
+- testGetControllerAdvertisedListenersWithNoControllerListenerInformation
+- testGetControllerAdvertisedListenersWithNoControllerListenerNames
+- testGetControllerAdvertisedListenersWithRegularListeners
+- 
testGetControllerAdvertisedListenersWithRegularListenersAndAdvertisedListeners
+- testGetControllerId
+- testGetControllerIdWithBrokerProcessRoles
+- testGetControllerIdWithoutId
+- testGetControllerIdWithoutProcessRoles
+- testGetMetadataDirectory
+- testGetMetadataDirectoryFailure
+- testGetMetadataDirectoryFromLogDirs
+- testGetMetadataDirectoryFromMultipleLogDirs
+- testGetMetadataDirectoryId
+- testGetMetadataDirectoryIdWhenThereIsNoDirectory
+- testGetMetadataDirectoryIdWhenThereIsNoId
+- testGetNegativeControllerId
+- testRemoveControllerDryRun
+org.apache.kafka.tools.ProducerPerformanceTest:
+- testClientIdOverride
+- testConfigPostProcessor
+- testDefaultClientId
+- testEnableTransaction
+- testEnableTransactionByProducerProps
+- testEnableTransactionByTransactionDurationMs
+- testEnableTransactionByTransactionId
+- testFractionalThroughput
+- testGenerateMonotonicPayload
+- testGenerateRandomPayloadByPayloadFile
+- testGenerateRandomPayloadByRecordSize
+- testGenerateRandomPayloadException
+- testInvalidConfigPostProcessor
+- testMutuallyExclusiveGroup
+- testNoTransactionRelatedConfigs
+- testNumberOfCallsForSendAndClose
+- testNumberOfFailedSendAndClose
+- testNumberOfSuccessfulSendAndClose
+- testReadPayloadFile
+- testReadProps
+- testStatsCorrectness
+- testStatsInitializationWithLargeNumRecords
+- testUnexpectedArg
+org.apache.kafka.tools.PushHttpMetricsReporterTest:
+- testClientError
+- testConfigureBadUrl
+- testConfigureClose
+- testConfigureMissingPeriod
+- testMetricValues
+- testNoMetrics
+- testServerError
+org.apache.kafka.tools.ReplicaVerificationToolTest:
+- testReplicaBufferVerifyChecksum
+org.apache.kafka.tools.ResetIntegrationTest:
+- shouldAllowGroupProtocolClassic
+- shouldDefaultToClassicGroupProtocol
+- shouldNotAllowToResetWhenInputTopicAbsent
+- shouldNotAllowToResetWhenIntermediateTopicAbsent
+- shouldNotAllowToResetWhenSpecifiedInternalTopicDoesNotExist
+- shouldNotAllowToResetWhenSpecifiedInternalTopicIsNotInternal
+- shouldNotAllowToResetWhileStreamsIsRunning
+- shouldOverwriteGroupProtocolOtherThanClassic
+- testReprocessingByDurationAfterResetWithoutIntermediateUserTopic
+- testReprocessingFromDateTimeAfterResetWithoutIntermediateUserTopic
+- testReprocessingFromFileAfterResetWithoutIntermediateUserTopic
+- testReprocessingFromScratchAfterResetWithIntermediateInternalTopic
+- testReprocessingFromScratchAfterResetWithIntermediateUserTopic
+- testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic
+- testResetWhenInternalTopicsAreSpecified
+- testResetWhenLongSessionTimeoutConfiguredWithForceOption
+org.apache.kafka.tools.ResetIntegrationWithSslTest:
+- testReprocessingFromScratchAfterResetWithIntermediateInternalTopic
+- testReprocessingFromScratchAfterResetWithIntermediateUserTopic
+- testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic
+- testResetWhenInternalTopicsAreSpecified
+org.apache.kafka.tools.ShareConsumerPerformanceTest:
+- testClientIdOverride
+- testConfigBootStrapServer
+- testConfigWithUnrecognizedOption
+- testDefaultClientId
+- testHeaderMatchBody
+org.apache.kafka.tools.StreamsResetterTest:
+- shouldDeleteTopic
+- shouldDetermineInternalTopicBasedOnTopicName1
+- shouldSeekToEndOffset
+- testResetOffsetToSpecificOffsetWhenAfterEndOffset
+- testResetToDatetimeWhenPartitionIsEmptyResetsToLatestOffset
+- testResetToSpecificOffsetWhenAfterEndOffset
+- testResetToSpecificOffsetWhenBeforeBeginningOffset
+- testResetToSpecificOffsetWhenBetweenBeginningAndEndOffset
+- testResetUsingPlanWhenAfterEndOffset
+- testResetUsingPlanWhenBeforeBeginningOffset
+- testResetUsingPlanWhenBetweenBeginningAndEndOffset
+- testShiftOffsetByWhenAfterEndOffset
+- testShiftOffsetByWhenBeforeBeginningOffset
+- testShiftOffsetByWhenBetweenBeginningAndEndOffset
+org.apache.kafka.tools.TopicCommandTest:
+- testAlterAssignment
+- testAlterAssignmentWithMoreAssignmentThanPartitions
+- testAlterAssignmentWithMorePartitionsThanAssignment
+- testAlterPartitionCount
+- testAlterWhenTopicDoesntExist
+- testAlterWhenTopicDoesntExistWithIfExists
+- testAlterWithInvalidPartitionCount
+- testAlterWithUnspecifiedPartitionCount
+- testConfigOptWithBootstrapServers
+- testConfigPreservationAcrossPartitionAlteration
+- testCreate
+- testCreateAlterTopicWithRackAware
+- testCreatePartitionsDoesNotRetryThrottlingQuotaExceededException
+- testCreateTopicDoesNotRetryThrottlingQuotaExceededException
+- testCreateWhenAlreadyExists
+- testCreateWhenAlreadyExistsWithIfNotExists
+- testCreateWithAssignmentAndPartitionCount
+- testCreateWithAssignmentAndReplicationFactor
+- testCreateWithConfigs
+- testCreateWithDefaultPartitions
+- testCreateWithDefaultReplication
+- testCreateWithDefaults
+- testCreateWithInvalidReplicationFactor
+- testCreateWithNegativePartitionCount
+- testCreateWithNegativeReplicationFactor
+- testCreateWithPartitionCountWithoutReplicationFactorShouldSucceed
+- testCreateWithReplicaAssignment
+- testCreateWithReplicationFactorWithoutPartitionCountShouldSucceed
+- testCreateWithTopicNameCollision
+- testCreateWithoutPartitionCountAndReplicationFactorShouldSucceed
+- testDeleteInternalTopic
+- testDeleteTopicDoesNotRetryThrottlingQuotaExceededException
+- testDeleteWhenTopicDoesntExist
+- testDeleteWhenTopicDoesntExistWithIfExists
+- testDescribe
+- testDescribeAndListTopicsWithoutInternalTopics
+- testDescribeAtMinIsrPartitions
+- testDescribeDoesNotFailWhenListingReassignmentIsUnauthorized
+- testDescribeReportOverriddenConfigs
+- testDescribeShouldSucceed
+- testDescribeUnavailablePartitions
+- testDescribeUnderMinIsrPartitions
+- testDescribeUnderMinIsrPartitionsMixed
+- testDescribeUnderReplicatedPartitions
+- testDescribeUnderReplicatedPartitionsWhenReassignmentIsInProgress
+- testDescribeWhenTopicDoesntExist
+- testDescribeWhenTopicDoesntExistWithIfExists
+- testDescribeWithDescribeTopicPartitionsApi
+- testDescribeWithDescribeTopicsApiShouldSucceed
+- testInvalidTopicLevelConfig
+- testIsNotUnderReplicatedWhenAdding
+- testListTopics
+- testListTopicsWithExcludeInternal
+- testListTopicsWithIncludeList
+- testParseAssignment
+- testParseAssignmentDuplicateEntries
+- testParseAssignmentPartitionsOfDifferentSize
+- testTopicDeletion
+- testTopicWithCollidingCharDeletionAndCreateAgain
+org.apache.kafka.tools.TransactionsCommandTest:
+- testDescribeProducersLeader
+- testDescribeProducersPartitionRequired
+- testDescribeProducersSpecificReplica
+- testDescribeProducersTopicRequired
+- testDescribeTransaction
+- testDescribeTransactionsCoordinatorEpochRequiredWithProducerId
+- testDescribeTransactionsPartitionRequired
+- testDescribeTransactionsProducerEpochRequiredWithProducerId
+- testDescribeTransactionsStartOffsetOrProducerIdRequired
+- testDescribeTransactionsTopicRequired
+- testDescribeTransactionsTransactionalIdRequired
+- testFindHangingDoesNotFilterByTransactionInProgressWithDifferentPartitions
+- testFindHangingFilterByTransactionInProgressWithSamePartition
+- testFindHangingLookupTopicAndBrokerId
+- testFindHangingLookupTopicPartitionsForBroker
+- testFindHangingLookupTopicPartitionsForTopic
+- testFindHangingNoMappedTransactionalId
+- testFindHangingRequiresEitherBrokerIdOrTopic
+- testFindHangingRequiresTopicIfPartitionIsSpecified
+- testFindHangingSpecifiedTopicPartition
+- testFindHangingWithNoTransactionDescription
+- testListTransactions
+- testNewBrokerAbortTransaction
+- testOldBrokerAbortTransactionWithUnknownCoordinatorEpoch
+org.apache.kafka.tools.consumer.ConsoleConsumerOptionsTest:
+- groupIdsProvidedInDifferentPlacesMustMatch
+- shouldExitIfFromBeginningAndOffset
+- shouldExitIfNoTopicOrFilterSpecified
+- shouldExitIfPartitionButNoTopic
+- shouldExitIfTopicAndIncludeSpecified
+- shouldExitOnGroupIdAndPartitionGivenTogether
+- shouldExitOnInvalidConfigWithAutoOffsetResetAndConflictingFromBeginning
+- shouldExitOnOffsetWithoutPartition
+- shouldExitOnUnrecognizedNewConsumerOption
+- shouldParseConfigsFromFile
+- shouldParseGroupIdFromBeginningGivenTogether
+- shouldParseIncludeArgument
+- shouldParseValidConsumerConfigWithAutoOffsetResetAndMatchingFromBeginning
+- shouldParseValidConsumerConfigWithAutoOffsetResetEarliest
+- shouldParseValidConsumerConfigWithAutoOffsetResetLatest
+- shouldParseValidConsumerConfigWithNoOffsetReset
+- shouldParseValidConsumerValidConfig
+- shouldParseValidSimpleConsumerValidConfigWithNumericOffset
+- shouldParseValidSimpleConsumerValidConfigWithStringOffset
+- testClientIdOverride
+- testCustomConfigShouldBePassedToConfigureMethod
+- testCustomPropertyShouldBePassedToConfigureMethod
+- testDefaultClientId
+- testParseFormatter
+- testParseOffset
+- testParseTimeoutMs
+org.apache.kafka.tools.consumer.ConsoleConsumerTest:
+- shouldLimitReadsToMaxMessageLimit
+- shouldResetUnConsumedOffsetsBeforeExit
+- shouldSeekWhenOffsetIsSet
+- shouldStopWhenOutputCheckErrorFails
+- shouldThrowTimeoutExceptionWhenTimeoutIsReached
+- shouldWorkWithoutTopicOption
+- testGroupMetadataMessageFormatter
+- testOffsetsMessageFormatter
+- testTransactionLogMessageFormatter
+org.apache.kafka.tools.consumer.ConsoleShareConsumerOptionsTest:
+- groupIdsProvidedInDifferentPlacesMustMatch
+- shouldExitIfNoTopicSpecified
+- shouldExitOnUnrecognizedNewConsumerOption
+- shouldParseConfigsFromFile
+- shouldParseValidConsumerConfigWithSessionTimeout
+- shouldParseValidConsumerValidConfig
+- testClientIdOverride
+- testDefaultClientId
+- testRejectAndReleaseOption
+- testRejectOption
+- testReleaseOption
+org.apache.kafka.tools.consumer.ConsoleShareConsumerTest:
+- shouldLimitReadsToMaxMessageLimit
+- shouldStopWhenOutputCheckErrorFails
+- shouldThrowTimeoutExceptionWhenTimeoutIsReached
+- testRejectMessageOnError
+org.apache.kafka.tools.consumer.DefaultMessageFormatterTest:
+- testDefaultMessageFormatter
+org.apache.kafka.tools.consumer.GroupMetadataMessageFormatterTest:
+- testTransactionLogMessageFormatter
+org.apache.kafka.tools.consumer.NoOpMessageFormatterTest:
+- testNoOpMessageFormatter
+org.apache.kafka.tools.consumer.OffsetMessageFormatterTest:
+- testTransactionLogMessageFormatter
+org.apache.kafka.tools.consumer.TransactionLogMessageFormatterTest:
+- testTransactionLogMessageFormatter
+org.apache.kafka.tools.consumer.group.AuthorizerIntegrationTest:
+- testDescribeGroupCliWithGroupDescribe
+org.apache.kafka.tools.consumer.group.ConsumerGroupCommandTest:
+- testValidateRegexCommandWithInvalidRegex
+- testValidateRegexCommandWithValidRegex
+org.apache.kafka.tools.consumer.group.ConsumerGroupServiceTest:
+- testAdminRequestsForDescribeNegativeOffsets
+- testAdminRequestsForDescribeOffsets
+- testAdminRequestsForResetOffsets
+org.apache.kafka.tools.consumer.group.DeleteConsumerGroupsTest:
+- testDeleteCmdAllGroups
+- testDeleteCmdNonExistingGroup
+- testDeleteCmdWithMixOfSuccessAndError
+- testDeleteEmptyGroup
+- testDeleteNonEmptyGroup
+- testDeleteNonExistingGroup
+- testDeleteWithMixOfSuccessAndError
+- testDeleteWithTopicOption
+- testDeleteWithUnrecognizedNewConsumerOption
+org.apache.kafka.tools.consumer.group.DeleteOffsetsConsumerGroupCommandIntegrationTest:
+- testDeleteOffsetsNonExistingGroup
+- testDeleteOffsetsOfEmptyConsumerGroupWithTopicOnly
+- testDeleteOffsetsOfEmptyConsumerGroupWithTopicPartition
+- testDeleteOffsetsOfEmptyConsumerGroupWithUnknownTopicOnly
+- testDeleteOffsetsOfEmptyConsumerGroupWithUnknownTopicPartition
+- testDeleteOffsetsOfStableConsumerGroupWithTopicOnly
+- testDeleteOffsetsOfStableConsumerGroupWithTopicPartition
+- testDeleteOffsetsOfStableConsumerGroupWithUnknownTopicOnly
+- testDeleteOffsetsOfStableConsumerGroupWithUnknownTopicPartition
+org.apache.kafka.tools.consumer.group.DescribeConsumerGroupTest:
+- testDescribeAllExistingGroups
+- testDescribeExistingGroupWithNoMembers
+- testDescribeExistingGroups
+- testDescribeGroupMemberWithMigration
+- testDescribeGroupMembers
+- testDescribeGroupMembersWithShortInitializationTimeout
+- testDescribeGroupOffsets
+- testDescribeGroupOffsetsWithShortInitializationTimeout
+- testDescribeGroupState
+- testDescribeGroupStateWithShortInitializationTimeout
+- testDescribeGroupWithShortInitializationTimeout
+- testDescribeMembersOfExistingGroup
+- testDescribeMembersOfExistingGroupWithNoMembers
+- testDescribeMembersOfNonExistingGroup
+- testDescribeMembersWithConsumersWithoutAssignedPartitions
+- testDescribeMembersWithMultiPartitionTopicAndMultipleConsumers
+- testDescribeNonExistingGroup
+- testDescribeNonOffsetCommitGroup
+- testDescribeOffsetsOfExistingGroup
+- testDescribeOffsetsOfExistingGroupWithNoMembers
+- testDescribeOffsetsOfNonExistingGroup
+- testDescribeOffsetsWithConsumersWithoutAssignedPartitions
+- testDescribeOffsetsWithMultiPartitionTopicAndMultipleConsumers
+- testDescribeSimpleConsumerGroup
+- testDescribeStateOfExistingGroup
+- testDescribeStateOfExistingGroupWithNoMembers
+- testDescribeStateOfExistingGroupWithNonDefaultAssignor
+- testDescribeStateOfNonExistingGroup
+- testDescribeStateWithConsumersWithoutAssignedPartitions
+- testDescribeStateWithMultiPartitionTopicAndMultipleConsumers
+- testDescribeWithConsumersWithoutAssignedPartitions
+- testDescribeWithMultiPartitionTopicAndMultipleConsumers
+- testDescribeWithMultipleSubActions
+- testDescribeWithStateValue
+- testDescribeWithUnrecognizedNewConsumerOption
+- testPrintVersion
+org.apache.kafka.tools.consumer.group.ListConsumerGroupTest:
+- testListConsumerGroupsWithStates
+- testListConsumerGroupsWithTypesClassicProtocol
+- testListConsumerGroupsWithTypesConsumerProtocol
+- testListConsumerGroupsWithoutFilters
+- testListGroupCommandClassicProtocol
+- testListGroupCommandConsumerProtocol
+- testListWithUnrecognizedNewConsumerOption
+org.apache.kafka.tools.consumer.group.ListConsumerGroupUnitTest:
+- testConsumerGroupStatesFromString
+- testConsumerGroupTypesFromString
+org.apache.kafka.tools.consumer.group.ResetConsumerGroupOffsetTest:
+- testResetOffsetsAllTopicsAllGroups
+- testResetOffsetsByDuration
+- testResetOffsetsByDurationFallbackToLatestWhenNoRecords
+- testResetOffsetsByDurationToEarliest
+- testResetOffsetsExistingTopic
+- testResetOffsetsExistingTopicAllGroups
+- testResetOffsetsExistingTopicSelectedGroups
+- testResetOffsetsExportImportPlan
+- testResetOffsetsExportImportPlanSingleGroupArg
+- testResetOffsetsNotExistingGroup
+- testResetOffsetsShiftByHigherThanLatest
+- testResetOffsetsShiftByLowerThanEarliest
+- testResetOffsetsShiftMinus
+- testResetOffsetsShiftPlus
+- testResetOffsetsToCurrentOffset
+- testResetOffsetsToEarliest
+- testResetOffsetsToEarliestOnOneTopic
+- testResetOffsetsToEarliestOnOneTopicAndPartition
+- testResetOffsetsToEarliestOnTopics
+- testResetOffsetsToEarliestOnTopicsAndPartitions
+- testResetOffsetsToLatest
+- testResetOffsetsToLocalDateTime
+- testResetOffsetsToSpecificOffset
+- testResetOffsetsToZonedDateTime
+- testResetWithUnrecognizedNewConsumerOption
+org.apache.kafka.tools.consumer.group.SaslClientsWithInvalidCredentialsTest:
+- testConsumerGroupServiceWithAuthenticationFailure
+- testConsumerGroupServiceWithAuthenticationSuccess
+org.apache.kafka.tools.consumer.group.ShareGroupCommandTest:
+- testDescribeMembersOfAllExistingGroups
+- testDescribeMembersOfExistingGroup
+- testDescribeNonexistentGroup
+- testDescribeOffsetsOfAllExistingGroups
+- testDescribeOffsetsOfExistingGroup
+- testDescribeShareGroupsInvalidVerboseOption
+- testDescribeShareGroupsOffsetsInvalidVerboseOption
+- testDescribeStateOfExistingGroup
+- testDescribeStatesOfAllExistingGroups
+- testGroupStatesFromString
+- testListShareGroups
+- testListShareGroupsWithStates
+- testListWithUnrecognizedOption
+- testPrintEmptyGroupState
+org.apache.kafka.tools.consumer.group.share.ShareGroupStateMessageFormatterTest:
+- testShareGroupStateMessageFormatter
+- testShareGroupStateMessageFormatterException
+org.apache.kafka.tools.filter.TopicFilterTest:
+- testIncludeLists
+org.apache.kafka.tools.reassign.ReassignPartitionsCommandArgsTest:
+- shouldAllowBootstrapControllerArg
+- shouldAllowThrottleOptionOnExecute
+- shouldCorrectlyParseValidMinimumExecuteOptions
+- shouldCorrectlyParseValidMinimumGenerateOptions
+- shouldCorrectlyParseValidMinimumVerifyOptions
+- shouldFailIfBlankArg
+- shouldFailIfMultipleActions
+- shouldFailIfNoArgs
+- shouldNotAllowBootstrapControllerAndBootstrapServerArg
+- shouldNotAllowBootstrapControllerArgWithUnsupportedAction
+- shouldNotAllowBrokersListWithVerifyOption
+- shouldNotAllowCancelWithoutBootstrapServerOption
+- shouldNotAllowCancelWithoutReassignmentJsonFile
+- shouldNotAllowExecuteWithBrokerList
+- shouldNotAllowExecuteWithTopicsOption
+- shouldNotAllowExecuteWithoutReassignmentOption
+- shouldNotAllowGenerateWithReassignmentOption
+- shouldNotAllowGenerateWithThrottleOption
+- shouldNotAllowGenerateWithoutBrokersAndTopicsOptions
+- shouldNotAllowGenerateWithoutBrokersOption
+- shouldNotAllowGenerateWithoutTopicsOption
+- shouldNotAllowThrottleWithVerifyOption
+- shouldNotAllowTopicsOptionWithVerify
+- shouldNotAllowVerifyWithoutReassignmentOption
+- shouldPrintHelpTextIfHelpArg
+- shouldUseDefaultsIfEnabled
+- testCancelWithPreserveThrottlesOption
+- testList
+- testMissingBootstrapServerArgumentForExecute
+org.apache.kafka.tools.reassign.ReassignPartitionsCommandTest:
+- testAlterLogDirReassignmentThrottle
+- testAlterReassignmentThrottle
+- testCancellationWithAddingReplicaInIsr
+- testCancellationWithBootstrapController
+- testCancellationWithBootstrapServer
+- testGenerateAssignmentWithBootstrapServer
+- testHighWaterMarkAfterPartitionReassignment
+- testLogDirReassignment
+- testProduceAndConsumeWithReassignmentInProgress
+- testReassignment
+- testReassignmentCompletionDuringPartialUpgrade
+- testReassignmentWithAlterPartitionDisabled
+- testThrottledReassignment
+org.apache.kafka.tools.reassign.ReassignPartitionsUnitTest:
+- testAlterReplicaLogDirs
+- testCompareTopicPartitionReplicas
+- testCompareTopicPartitions
+- testCurReassignmentsToString
+- testCurrentPartitionReplicaAssignmentToString
+- testExecuteWithInvalidBrokerIdFails
+- testExecuteWithInvalidPartitionsFails
+- testFindLogDirMoveStates
+- testFindPartitionReassignmentStates
+- testGenerateAssignmentFailsWithoutEnoughReplicas
+- testGenerateAssignmentWithFewerBrokers
+- testGenerateAssignmentWithInconsistentRacks
+- testGenerateAssignmentWithInvalidPartitionsFails
+- testGetBrokerRackInformation
+- testGetReplicaAssignments
+- testModifyBrokerInterBrokerThrottle
+- testModifyLogDirThrottle
+- testModifyTopicThrottles
+- testMoveMap
+- testParseExecuteAssignmentArgs
+- testParseGenerateAssignmentArgs
+- testPartitionReassignStatesToString
+- testPropagateInvalidJsonError
+- testReplicaMoveStatesToString

Reply via email to