You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kafka.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2019/11/23 00:45:52 UTC

Build failed in Jenkins: kafka-trunk-jdk11 #980

See <https://builds.apache.org/job/kafka-trunk-jdk11/980/display/redirect?page=changes>

Changes:

[github] MINOR: Fix producer timeouts in log divergence test (#7728)

[vvcephei] MINOR: Updated StreamTableJoinIntegrationTest to use TTD (#7722)


------------------------------------------
[...truncated 2.76 MB...]
org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfMergerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeCount STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeCount PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeAggregated STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeAggregated PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldCountSessionWindowedWithCachingEnabled STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldCountSessionWindowedWithCachingEnabled PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnCountIfMaterializedIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnCountIfMaterializedIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfAggregatorIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfAggregatorIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnReduceIfReducerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnReduceIfReducerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldAggregateSessionWindowed STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldAggregateSessionWindowed PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldReduceWindowed STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldReduceWindowed PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfAggregatorIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfAggregatorIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldCountSessionWindowedWithCachingDisabled STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldCountSessionWindowedWithCachingDisabled PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfInitializerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfInitializerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfMergerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfMergerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedReduceIfMaterializedIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedReduceIfMaterializedIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeReduced STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeReduced PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowIsWithinThisWindow STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowIsWithinThisWindow PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldNotOverlapIfOtherWindowIsBeforeThisWindow STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldNotOverlapIfOtherWindowIsBeforeThisWindow PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > cannotCompareSessionWindowWithDifferentWindowType STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > cannotCompareSessionWindowWithDifferentWindowType PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowContainsThisWindow STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowContainsThisWindow PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowStartIsWithinThisWindow STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowStartIsWithinThisWindow PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowEndIsWithinThisWindow STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldOverlapIfOtherWindowEndIsWithinThisWindow PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldNotOverlapIsOtherWindowIsAfterThisWindow STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowTest > shouldNotOverlapIsOtherWindowIsAfterThisWindow PASSED

org.apache.kafka.streams.kstream.internals.WindowedStreamPartitionerTest > testCopartitioning STARTED

org.apache.kafka.streams.kstream.internals.WindowedStreamPartitionerTest > testCopartitioning PASSED

org.apache.kafka.streams.kstream.internals.KTableMapKeysTest > testMapKeysConvertingToStream STARTED

org.apache.kafka.streams.kstream.internals.KTableMapKeysTest > testMapKeysConvertingToStream PASSED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testMap STARTED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testMap PASSED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testTypeVariance STARTED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testTypeVariance PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > untilShouldSetGraceDuration STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > untilShouldSetGraceDuration PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > gracePeriodShouldEnforceBoundaries STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > gracePeriodShouldEnforceBoundaries PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > endTimeShouldNotBeBeforeStart STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > endTimeShouldNotBeBeforeStart PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > validWindows STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > validWindows PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > startTimeShouldNotBeAfterEnd STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > startTimeShouldNotBeAfterEnd PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > equalsAndHashcodeShouldBeValidForPositiveCases STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > equalsAndHashcodeShouldBeValidForPositiveCases PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > retentionTimeMustNoBeSmallerThanWindowSize STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > retentionTimeMustNoBeSmallerThanWindowSize PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > equalsAndHashcodeShouldBeValidForNegativeCases STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > equalsAndHashcodeShouldBeValidForNegativeCases PASSED

org.apache.kafka.streams.kstream.JoinWindowsTest > timeDifferenceMustNotBeNegative STARTED

org.apache.kafka.streams.kstream.JoinWindowsTest > timeDifferenceMustNotBeNegative PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > retentionTimeShouldBeGapIfGapIsLargerThanDefaultRetentionTime STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > retentionTimeShouldBeGapIfGapIsLargerThanDefaultRetentionTime PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > gracePeriodShouldEnforceBoundaries STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > gracePeriodShouldEnforceBoundaries PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > shouldSetWindowGap STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > shouldSetWindowGap PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > retentionTimeMustNotBeNegative STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > retentionTimeMustNotBeNegative PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > shouldSetWindowGraceTime STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > shouldSetWindowGraceTime PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > windowSizeMustNotBeZero STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > windowSizeMustNotBeZero PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > equalsAndHashcodeShouldBeValidForPositiveCases STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > equalsAndHashcodeShouldBeValidForPositiveCases PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > windowSizeMustNotBeNegative STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > windowSizeMustNotBeNegative PASSED

org.apache.kafka.streams.kstream.SessionWindowsTest > equalsAndHashcodeShouldBeValidForNegativeCases STARTED

org.apache.kafka.streams.kstream.SessionWindowsTest > equalsAndHashcodeShouldBeValidForNegativeCases PASSED

org.apache.kafka.streams.kstream.WindowTest > shouldThrowIfEndIsSmallerThanStart STARTED

org.apache.kafka.streams.kstream.WindowTest > shouldThrowIfEndIsSmallerThanStart PASSED

org.apache.kafka.streams.kstream.WindowTest > shouldNotBeEqualIfDifferentWindowType STARTED

org.apache.kafka.streams.kstream.WindowTest > shouldNotBeEqualIfDifferentWindowType PASSED

org.apache.kafka.streams.kstream.WindowTest > shouldBeEqualIfStartAndEndSame STARTED

org.apache.kafka.streams.kstream.WindowTest > shouldBeEqualIfStartAndEndSame PASSED

org.apache.kafka.streams.kstream.WindowTest > shouldNotBeEqualIfNull STARTED

org.apache.kafka.streams.kstream.WindowTest > shouldNotBeEqualIfNull PASSED

org.apache.kafka.streams.kstream.WindowTest > shouldThrowIfStartIsNegative STARTED

org.apache.kafka.streams.kstream.WindowTest > shouldThrowIfStartIsNegative PASSED

org.apache.kafka.streams.kstream.WindowTest > shouldNotBeEqualIfStartOrEndIsDifferent STARTED

org.apache.kafka.streams.kstream.WindowTest > shouldNotBeEqualIfStartOrEndIsDifferent PASSED

org.apache.kafka.streams.kstream.MaterializedTest > shouldNotAllowInvalidTopicNames STARTED

org.apache.kafka.streams.kstream.MaterializedTest > shouldNotAllowInvalidTopicNames PASSED

org.apache.kafka.streams.kstream.MaterializedTest > shouldThrowNullPointerIfKeyValueBytesStoreSupplierIsNull STARTED

org.apache.kafka.streams.kstream.MaterializedTest > shouldThrowNullPointerIfKeyValueBytesStoreSupplierIsNull PASSED

org.apache.kafka.streams.kstream.MaterializedTest > shouldAllowValidTopicNamesAsStoreName STARTED

org.apache.kafka.streams.kstream.MaterializedTest > shouldAllowValidTopicNamesAsStoreName PASSED

org.apache.kafka.streams.kstream.MaterializedTest > shouldThrowNullPointerIfSessionBytesStoreSupplierIsNull STARTED

org.apache.kafka.streams.kstream.MaterializedTest > shouldThrowNullPointerIfSessionBytesStoreSupplierIsNull PASSED

org.apache.kafka.streams.kstream.MaterializedTest > shouldThrowNullPointerIfWindowBytesStoreSupplierIsNull STARTED

org.apache.kafka.streams.kstream.MaterializedTest > shouldThrowNullPointerIfWindowBytesStoreSupplierIsNull PASSED
streams-3: SMOKE-TEST-CLIENT-CLOSED
streams-5: SMOKE-TEST-CLIENT-CLOSED
streams-1: SMOKE-TEST-CLIENT-CLOSED
streams-0: SMOKE-TEST-CLIENT-CLOSED
streams-4: SMOKE-TEST-CLIENT-CLOSED
streams-2: SMOKE-TEST-CLIENT-CLOSED
streams-6: SMOKE-TEST-CLIENT-CLOSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.0/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 3h 2m 38s
205 actionable tasks: 176 executed, 29 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user noreply@github.com

Jenkins build is back to normal : kafka-trunk-jdk11 #982

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/982/display/redirect?page=changes>


Build failed in Jenkins: kafka-trunk-jdk11 #981

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/981/display/redirect?page=changes>

Changes:

[github] KAFKA-9123 Test a large number of replicas (#7621)


------------------------------------------
[...truncated 2.75 MB...]

org.apache.kafka.connect.transforms.RegexRouterTest > identity PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > addPrefix STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > addPrefix PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > addSuffix STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > addSuffix PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > slice STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > slice PASSED

org.apache.kafka.connect.transforms.RegexRouterTest > staticReplacement STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > staticReplacement PASSED

org.apache.kafka.connect.transforms.MaskFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.MaskFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.MaskFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.MaskFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testKey STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testKey PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat PASSED

> Task :connect:mirror-client:test

org.apache.kafka.connect.mirror.MirrorClientTest > upstreamClustersTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > upstreamClustersTest PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > countHopsForTopicTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > countHopsForTopicTest PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > testIsHeartbeatTopic STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > testIsHeartbeatTopic PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > testIsCheckpointTopic STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > testIsCheckpointTopic PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > remoteTopicsTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > remoteTopicsTest PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > heartbeatTopicsTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > heartbeatTopicsTest PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > remoteTopicsSeparatorTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > remoteTopicsSeparatorTest PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > checkpointsTopicsTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > checkpointsTopicsTest PASSED

org.apache.kafka.connect.mirror.MirrorClientTest > replicationHopsTest STARTED

org.apache.kafka.connect.mirror.MirrorClientTest > replicationHopsTest PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.0/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 3h 16m 51s
205 actionable tasks: 176 executed, 29 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user noreply@github.com