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 2018/01/17 00:17:46 UTC

Build failed in Jenkins: kafka-trunk-jdk8 #2331

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

Changes:

[wangguoz] MINOR: Fix typo (#4426)

[wangguoz] KAFKA-4218: Enable access to key in ValueTransformer and ValueMapper

------------------------------------------
[...truncated 1.84 MB...]

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldSuccessfullyReInitializeStateStores STARTED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldSuccessfullyReInitializeStateStores PASSED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldThrowIllegalArgumentExceptionOnRegisterWhenStoreHasAlreadyBeenRegistered STARTED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldThrowIllegalArgumentExceptionOnRegisterWhenStoreHasAlreadyBeenRegistered PASSED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldRestoreStoreWithSinglePutRestoreSpecification STARTED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldRestoreStoreWithSinglePutRestoreSpecification PASSED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldNotChangeOffsetsIfAckedOffsetsIsNull STARTED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldNotChangeOffsetsIfAckedOffsetsIsNull PASSED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldThrowIllegalArgumentExceptionIfStoreNameIsSameAsCheckpointFileName STARTED

org.apache.kafka.streams.processor.internals.ProcessorStateManagerTest > shouldThrowIllegalArgumentExceptionIfStoreNameIsSameAsCheckpointFileName PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldCloseStateManagerWithOffsets STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldCloseStateManagerWithOffsets PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldProcessRecordsForTopic STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldProcessRecordsForTopic PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldInitializeProcessorTopology STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldInitializeProcessorTopology PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldInitializeContext STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldInitializeContext PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldCheckpointOffsetsWhenStateIsFlushed STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldCheckpointOffsetsWhenStateIsFlushed PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldThrowStreamsExceptionWhenKeyDeserializationFails STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldThrowStreamsExceptionWhenKeyDeserializationFails PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldInitializeStateManager STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldInitializeStateManager PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldProcessRecordsForOtherTopic STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldProcessRecordsForOtherTopic PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldNotThrowStreamsExceptionWhenValueDeserializationFails STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldNotThrowStreamsExceptionWhenValueDeserializationFails PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldThrowStreamsExceptionWhenValueDeserializationFails STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldThrowStreamsExceptionWhenValueDeserializationFails PASSED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldNotThrowStreamsExceptionWhenKeyDeserializationFailsWithSkipHandler STARTED

org.apache.kafka.streams.processor.internals.GlobalStateTaskTest > shouldNotThrowStreamsExceptionWhenKeyDeserializationFailsWithSkipHandler PASSED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testThroughputMetrics STARTED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testThroughputMetrics PASSED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testLatencyMetrics STARTED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testLatencyMetrics PASSED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testRemoveSensor STARTED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testRemoveSensor PASSED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testRemoveNullSensor STARTED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testRemoveNullSensor PASSED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testNullMetrics STARTED

org.apache.kafka.streams.processor.internals.StreamsMetricsImplTest > testNullMetrics PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldDieOnInvalidOffsetException STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldDieOnInvalidOffsetException PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldStayDeadAfterTwoCloses STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldStayDeadAfterTwoCloses PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldTransitionToRunningOnStart STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldTransitionToRunningOnStart PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldCloseStateStoresOnClose STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldCloseStateStoresOnClose PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldBeRunningAfterSuccessfulStart STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldBeRunningAfterSuccessfulStart PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldTransitionToDeadOnClose STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldTransitionToDeadOnClose PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldStopRunningWhenClosedByUser STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldStopRunningWhenClosedByUser PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldThrowStreamsExceptionOnStartupIfThereIsAStreamsException STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldThrowStreamsExceptionOnStartupIfThereIsAStreamsException PASSED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldThrowStreamsExceptionOnStartupIfExceptionOccurred STARTED

org.apache.kafka.streams.processor.internals.GlobalStreamThreadTest > shouldThrowStreamsExceptionOnStartupIfExceptionOccurred PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanUpTaskStateDirectoriesThatAreNotCurrentlyLocked STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanUpTaskStateDirectoriesThatAreNotCurrentlyLocked PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateBaseDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateBaseDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldThrowProcessorStateException STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldThrowProcessorStateException PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockMulitpleTaskDirectories STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockMulitpleTaskDirectories PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateDirectoriesIfParentDoesntExist STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateDirectoriesIfParentDoesntExist PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldUnlockGlobalStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldUnlockGlobalStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldListAllTaskDirectories STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldListAllTaskDirectories PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanupStateDirectoriesWhenLastModifiedIsLessThanNowMinusCleanupDelay STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanupStateDirectoriesWhenLastModifiedIsLessThanNowMinusCleanupDelay PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotLockStateDirLockedByAnotherThread STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotLockStateDirLockedByAnotherThread PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockTaskStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockTaskStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotUnLockStateDirLockedByAnotherThread STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotUnLockStateDirLockedByAnotherThread PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockGlobalStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldLockGlobalStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanupAllTaskDirectoriesIncludingGlobalOne STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCleanupAllTaskDirectoriesIncludingGlobalOne PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotLockDeletedDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotLockDeletedDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateTaskStateDirectory STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldCreateTaskStateDirectory PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotRemoveNonTaskDirectoriesAndFiles STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldNotRemoveNonTaskDirectoriesAndFiles PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldBeTrueIfAlreadyHoldsLock STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldBeTrueIfAlreadyHoldsLock PASSED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldReleaseTaskStateDirectoryLock STARTED

org.apache.kafka.streams.processor.internals.StateDirectoryTest > shouldReleaseTaskStateDirectoryLock PASSED

org.apache.kafka.streams.processor.WallclockTimestampExtractorTest > extractSystemTimestamp STARTED

org.apache.kafka.streams.processor.WallclockTimestampExtractorTest > extractSystemTimestamp PASSED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > usePreviousTimeOnInvalidTimestamp STARTED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > usePreviousTimeOnInvalidTimestamp PASSED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > shouldThrowStreamsException STARTED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > shouldThrowStreamsException PASSED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > extractMetadataTimestamp STARTED

org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestampTest > extractMetadataTimestamp PASSED

1838 tests completed, 12 failed
:streams:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':streams:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/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

BUILD FAILED in 1h 54m 32s
52 actionable tasks: 44 executed, 8 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 5 files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/clients/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/examples/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/log4j-appender/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=bcc712b45820da74b44209857ebbf7b9d59e0ed7, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2330
Recording test results
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk8 #2333

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

Changes:

[wangguoz] KAFKA-6328: Sort node groups considering global stores in

------------------------------------------
[...truncated 7.68 MB...]

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-780443661009837827: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testAcceptAppendWithSequenceGapsOnReplica STARTED

kafka.log.ProducerStateManagerTest > testAcceptAppendWithSequenceGapsOnReplica FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-8668216773049665914: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testOldEpochForControlRecord STARTED

kafka.log.ProducerStateManagerTest > testOldEpochForControlRecord FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-4894412274386277004: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testTruncateAndReloadRemovesOutOfRangeSnapshots STARTED

kafka.log.ProducerStateManagerTest > testTruncateAndReloadRemovesOutOfRangeSnapshots FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-3046891870806134494: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testStartOffset STARTED

kafka.log.ProducerStateManagerTest > testStartOffset FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-2004858623984427968: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testProducerSequenceInvalidWrapAround STARTED

kafka.log.ProducerStateManagerTest > testProducerSequenceInvalidWrapAround FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-1057965904923305075: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testTruncateHead STARTED

kafka.log.ProducerStateManagerTest > testTruncateHead FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-7668808456777059617: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testNonTransactionalAppendWithOngoingTransaction STARTED

kafka.log.ProducerStateManagerTest > testNonTransactionalAppendWithOngoingTransaction FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-5651665245333490619: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

kafka.log.ProducerStateManagerTest > testSkipSnapshotIfOffsetUnchanged STARTED

kafka.log.ProducerStateManagerTest > testSkipSnapshotIfOffsetUnchanged FAILED
    java.lang.RuntimeException: Failed to create a temp dir
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:176)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.log.ProducerStateManagerTest.setUp(ProducerStateManagerTest.scala:46)

        Caused by:
        java.nio.file.FileSystemException: /tmp/kafka-5676531440312284546: No space left on device
            at sun.nio.fs.UnixException.translateToIOException(UnixException.java:91)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:102)
            at sun.nio.fs.UnixException.rethrowAsIOException(UnixException.java:107)
            at sun.nio.fs.UnixFileSystemProvider.createDirectory(UnixFileSystemProvider.java:384)
            at java.nio.file.Files.createDirectory(Files.java:674)
            at java.nio.file.TempFileHelper.create(TempFileHelper.java:136)
            at java.nio.file.TempFileHelper.createTempDirectory(TempFileHelper.java:173)
            at java.nio.file.Files.createTempDirectory(Files.java:991)
            at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:174)
            ... 4 more

1793 tests completed, 1014 failed, 6 skipped
:kafka-trunk-jdk8:core:test FAILED
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-trunk-jdk8:core:test'.
> java.io.IOException: No space left on device

* 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

BUILD FAILED in 18m 24s
16 actionable tasks: 15 executed, 1 up-to-date

FAILURE: Build failed with an exception.

* What went wrong:
Could not add entry ':core:test' to cache taskHistory.bin (<https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle/4.4.1/taskHistory/taskHistory.bin).>
> java.io.IOException: No space left on device

* 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

BUILD FAILED in 18m 25s
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 1 file in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=2771f52ea7070a3147058e0d6661e0a7e4158161, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2330
Recording test results
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk8 #2332

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

Changes:

[wangguoz] MINOR: Improve Join integration test coverage, PART II

------------------------------------------
[...truncated 3.90 MB...]

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigRegexRouter PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigSetSchemaMetadata STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigSetSchemaMetadata PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigTimestampConverter STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigTimestampConverter PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigHoistField STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigHoistField PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigMaskField STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigMaskField PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigInsertField STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigInsertField PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigFlatten STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigFlatten PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigReplaceField STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigReplaceField PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigTimestampRouter STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigTimestampRouter PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigValueToKey STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigValueToKey PASSED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigExtractField STARTED

org.apache.kafka.connect.runtime.TransformationConfigTest > testEmbeddedConfigExtractField PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > unconfiguredTransform STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > unconfiguredTransform PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > multipleTransformsOneDangling STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > multipleTransformsOneDangling PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > misconfiguredTransform STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > misconfiguredTransform PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > noTransforms STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > noTransforms PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > danglingTransformAlias STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > danglingTransformAlias PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > multipleTransforms STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > multipleTransforms PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > singleTransform STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > singleTransform PASSED

org.apache.kafka.connect.runtime.ConnectorConfigTest > wrongTransformationType STARTED

org.apache.kafka.connect.runtime.ConnectorConfigTest > wrongTransformationType PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testPutConnectorConfig STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testPutConnectorConfig PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testPutTaskConfigs STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testPutTaskConfigs PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateConnectorFailedBasicValidation STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateConnectorFailedBasicValidation PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateConnectorFailedCustomValidation STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateConnectorFailedCustomValidation PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateConnectorAlreadyExists STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateConnectorAlreadyExists PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testDestroyConnector STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testDestroyConnector PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartConnector STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartConnector PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartTask STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartTask PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testAccessors STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testAccessors PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateSourceConnector STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateSourceConnector PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateSinkConnector STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateSinkConnector PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartConnectorFailureOnStart STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartConnectorFailureOnStart PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartTaskFailureOnStart STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testRestartTaskFailureOnStart PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateAndStop STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCreateAndStop PASSED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCorruptConfig STARTED

org.apache.kafka.connect.runtime.standalone.StandaloneHerderTest > testCorruptConfig PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testGettingGroupMultipleTimes STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testGettingGroupMultipleTimes PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testCreatingTags STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testCreatingTags PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testMetricGroupIdWithoutTags STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testMetricGroupIdWithoutTags PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testCreatingTagsWithOddNumberOfTags STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testCreatingTagsWithOddNumberOfTags PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testGettingGroupWithOddNumberOfTags STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testGettingGroupWithOddNumberOfTags PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testMetricGroupIdIdentity STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testMetricGroupIdIdentity PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testRecreateWithoutClose STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testRecreateWithoutClose PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testGettingGroupWithTags STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testGettingGroupWithTags PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testRecreateWithClose STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testRecreateWithClose PASSED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testKafkaMetricsNotNull STARTED

org.apache.kafka.connect.runtime.ConnectMetricsTest > testKafkaMetricsNotNull PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectSchemaless STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectSchemaless PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testToConnectNull STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testToConnectNull PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectBadSchema STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectBadSchema PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectNull STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectNull PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testToConnect STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testToConnect PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnect STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnect PASSED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectInvalidValue STARTED

org.apache.kafka.connect.converters.ByteArrayConverterTest > testFromConnectInvalidValue PASSED

281 tests completed, 1 failed
:connect:runtime:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':connect:runtime:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk8/ws/connect/runtime/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

BUILD FAILED in 1h 26m 32s
97 actionable tasks: 94 executed, 3 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 11 files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/clients/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/connect/api/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/connect/file/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/connect/json/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/connect/runtime/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/examples/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/jmh-benchmarks/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/log4j-appender/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/tools/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=8ded496c9be619fe29d00b406b3c1e094abc202c, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2330
Recording test results
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
Not sending mail to unregistered user wangguoz@gmail.com