mumrah commented on PR #17788:
URL: https://github.com/apache/kafka/pull/17788#issuecomment-2474414294

   Here's what the catalog diff will be with this PR:
   
   ```
   diff --git a/test-catalog/clients/tests.yaml 
b/test-catalog/clients/tests.yaml
   index 4b39d4f069..51d7850671 100644
   --- a/test-catalog/clients/tests.yaml
   +++ b/test-catalog/clients/tests.yaml
   @@ -816,12 +816,12 @@ 
org.apache.kafka.clients.consumer.OffsetAndMetadataTest:
    - testInvalidNegativeOffset
    - testSerializationRoundtrip
    org.apache.kafka.clients.consumer.RangeAssignorTest:
   -- rackConfig
    - testCoPartitionedAssignmentWithSameSubscription
    - testMultipleConsumersMixedTopics
    - testOneConsumerMultipleTopics
    - testOneConsumerNoTopic
    - testOneConsumerNonexistentTopic
   +- testOneConsumerOneTopic
    - testOneStaticConsumerAndOneDynamicConsumerTwoTopicsSixPartitions
    - testOnlyAssignsPartitionsFromSubscribedTopics
    - testRackAwareAssignmentWithCoPartitioning
   @@ -3230,7 +3230,9 @@ org.apache.kafka.common.metrics.stats.RateTest:
    - testRateIsConsistentAfterTheFirstWindow
    - testRateWithNoPriorAvailableSamples
    org.apache.kafka.common.metrics.stats.SampledStatTest:
   -- Sample
   +- testSampleIsKeptIfOverlaps
   +- testSampleIsKeptIfOverlapsAndExtra
   +- testSampleIsPurgedIfDoesntOverlap
    org.apache.kafka.common.network.ChannelBuildersTest:
    - testChannelBuilderConfigs
    - testCreateConfigurableKafkaPrincipalBuilder
   @@ -3353,7 +3355,7 @@ 
org.apache.kafka.common.network.SslTransportTls12Tls13Test:
    - testCiphersSuiteForTls12FailsForTls13
    - testCiphersSuiteForTls13
    org.apache.kafka.common.network.SslVersionsTransportLayerTest:
   -- tlsServerProtocol
   +- testTlsDefaults
    org.apache.kafka.common.network.Tls12SelectorTest:
    - registerFailure
    - testBytesBufferedChannelAfterMute
   @@ -3616,7 +3618,7 @@ org.apache.kafka.common.record.FileRecordsTest:
    - testTruncateNotCalledIfSizeIsBiggerThanTargetSize
    - testTruncateNotCalledIfSizeIsSameAsTargetSize
    org.apache.kafka.common.record.LazyDownConversionRecordsTest:
   -- compressionType
   +- testConversion
    - testConversionOfCommitMarker
    org.apache.kafka.common.record.LegacyRecordTest:
    - testChecksum
   diff --git a/test-catalog/storage/tests.yaml 
b/test-catalog/storage/tests.yaml
   index 8a26477731..f978d606d9 100644
   --- a/test-catalog/storage/tests.yaml
   +++ b/test-catalog/storage/tests.yaml
   @@ -27,8 +27,8 @@ 
org.apache.kafka.server.log.remote.metadata.storage.RemoteLogLeaderEpochStateTes
    - testListAllRemoteLogSegmentsShouldReturnSortedSegments
    - testListAllRemoteLogSegmentsShouldThrowErrorForUnknownSegmentId
    
org.apache.kafka.server.log.remote.metadata.storage.RemoteLogMetadataCacheTest:
   -- isInitialized
    - testCacheAddMetadataOnInvalidArgs
   +- testCacheUpdateMetadataOnInvalidArgs
    - testDropEventOnInvalidStateTransition
    
org.apache.kafka.server.log.remote.metadata.storage.RemoteLogMetadataFormatterTest:
    - testFormat
   diff --git a/test-catalog/streams/integration-tests/tests.yaml 
b/test-catalog/streams/integration-tests/tests.yaml
   index 318a98c716..cade38190f 100644
   --- a/test-catalog/streams/integration-tests/tests.yaml
   +++ b/test-catalog/streams/integration-tests/tests.yaml
   @@ -142,9 +142,10 @@ 
org.apache.kafka.streams.integration.KTableSourceTopicRestartIntegrationTest:
    
org.apache.kafka.streams.integration.KafkaStreamsCloseOptionsIntegrationTest:
    - testCloseOptions
    org.apache.kafka.streams.integration.KafkaStreamsTelemetryIntegrationTest:
   -- Correct
   -- End
   -- Streams
   +- passedMetricsShouldNotLeakIntoClientMetrics
   +- shouldPassCorrectMetricsDynamicInstances
   +- shouldPassMetrics
   +- shouldPushMetricsToBroker
    org.apache.kafka.streams.integration.LagFetchIntegrationTest:
    - shouldFetchLagsDuringRebalancingWithNoOptimization
    - shouldFetchLagsDuringRebalancingWithOptimization
   diff --git a/test-catalog/streams/test-utils/tests.yaml 
b/test-catalog/streams/test-utils/tests.yaml
   index 626d4ec93c..6361f616c6 100644
   --- a/test-catalog/streams/test-utils/tests.yaml
   +++ b/test-catalog/streams/test-utils/tests.yaml
   @@ -155,7 +155,7 @@ 
org.apache.kafka.streams.test.MockProcessorContextAPITest:
    - shouldCaptureRecordsOutputToChildByName
    - shouldStoreAndReturnStateStores
    org.apache.kafka.streams.test.MockProcessorContextStateStoreTest:
   -- builder
   +- shouldEitherInitOrThrow
    org.apache.kafka.streams.test.TestRecordTest:
    - testConsumerRecord
    - testEqualsAndHashCode
   diff --git a/test-catalog/streams/tests.yaml 
b/test-catalog/streams/tests.yaml
   index 51a6115e96..59347bc0cf 100644
   --- a/test-catalog/streams/tests.yaml
   +++ b/test-catalog/streams/tests.yaml
   @@ -421,10 +421,14 @@ 
org.apache.kafka.streams.internals.metrics.ClientMetricsTest:
    - shouldAddVersionMetric
    - shouldGetFailedStreamThreadsSensor
    
org.apache.kafka.streams.internals.metrics.StreamsClientMetricsDelegatingReporterTest:
   -- Should
   +- metricRemoval
   +- shouldInitMetrics
   +- shouldRegisterCorrectMetrics
    
org.apache.kafka.streams.internals.metrics.StreamsThreadMetricsDelegatingReporterTest:
   -- Init
   -- Should
   +- shouldInitMetrics
   +- shouldNotRegisterMetricsWithoutThreadIdTag
   +- shouldRegisterMetrics
   +- shouldRemoveMetrics
    org.apache.kafka.streams.kstream.JoinWindowsTest:
    - afterShouldNotModifyGrace
    - beforeShouldNotModifyGrace
   @@ -1105,7 +1109,8 @@ 
org.apache.kafka.streams.kstream.internals.KStreamMapValuesTest:
    - testFlatMapValues
    - testMapValuesWithKeys
    org.apache.kafka.streams.kstream.internals.KStreamNewProcessorApiTest:
   -- Should
   +- shouldGetStateStoreWithConnectedStoreProvider
   +- shouldGetStateStoreWithStreamBuilder
    org.apache.kafka.streams.kstream.internals.KStreamPeekTest:
    - shouldNotAllowNullAction
    - shouldObserveStreamElements
   @@ -3548,9 +3553,9 @@ org.apache.kafka.streams.query.PositionTest:
    - shouldNotMatchOnUnEqual
    - shouldUpdateComponentMonotonically
    org.apache.kafka.streams.query.StateQueryResultTest:
   -- More
   -- Valid
   -- Zero
   +- getOnlyPartitionResultMultipleResults
   +- getOnlyPartitionResultNoResultsTest
   +- getOnlyPartitionResultWithSingleResultTest
    org.apache.kafka.streams.query.VersionedKeyQueryTest:
    - shouldThrowNPEWithNullAsOftimestamp
    - shouldThrowNPEWithNullKey
   ```


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: [email protected]

For queries about this service, please contact Infrastructure at:
[email protected]

Reply via email to