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/06/13 06:21:41 UTC

Build failed in Jenkins: kafka-0.10.0-jdk7 #220

See <https://builds.apache.org/job/kafka-0.10.0-jdk7/220/display/redirect?page=changes>

Changes:

[me] KAFKA-7009: Suppress the Reflections log warning messages in system

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/>
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/0.10.0^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/0.10.0^{commit} # timeout=10
Checking out Revision 24d0d3351a43f52f6f688143672d7c57c5f19595 (refs/remotes/origin/0.10.0)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 24d0d3351a43f52f6f688143672d7c57c5f19595
Commit message: "KAFKA-7009: Suppress the Reflections log warning messages in system tests"
 > git rev-list --no-walk 5030b5d9d82bb08d520e07c4cd23e23e3caa58af # timeout=10
ERROR: No tool found matching GRADLE_2_4_RC_2_HOME
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-0.10.0-jdk7] $ /bin/bash -xe /tmp/jenkins5790596332948078882.sh
+ rm -rf <https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Support for running Gradle using Java 7 has been deprecated and is scheduled to be removed in Gradle 5.0. Please see https://docs.gradle.org/4.4.1/userguide/java_plugin.html#sec:java_cross_compilation for more details.
Building project 'core' with Scala version 2.10.6
:downloadWrapper

BUILD SUCCESSFUL in 17s
1 actionable task: 1 executed
ERROR: No tool found matching GRADLE_2_4_RC_2_HOME
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-0.10.0-jdk7] $ /bin/bash -xe /tmp/jenkins2196122975119652897.sh
+ export 'GRADLE_OPTS=-Xmx1024m -XX:MaxPermSize=256m'
+ GRADLE_OPTS='-Xmx1024m -XX:MaxPermSize=256m'
+ ./gradlew -Dorg.gradle.project.maxParallelForks=1 clean jarAll testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/2.13/userguide/gradle_daemon.html.
Building project 'core' with Scala version 2.10.6
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:jar_core_2_10
Building project 'core' with Scala version 2.10.6
:kafka-0.10.0-jdk7:clients:compileJavaNote: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

:kafka-0.10.0-jdk7:clients:processResources UP-TO-DATE
:kafka-0.10.0-jdk7:clients:classes
:kafka-0.10.0-jdk7:clients:determineCommitId UP-TO-DATE
:kafka-0.10.0-jdk7:clients:createVersionFile
:kafka-0.10.0-jdk7:clients:jar
:kafka-0.10.0-jdk7:core:compileJava UP-TO-DATE
:kafka-0.10.0-jdk7:core:compileScala
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/api/OffsetCommitRequest.scala>:79: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
            org.apache.kafka.common.requests.OffsetCommitRequest.DEFAULT_TIMESTAMP
                                                                 ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/common/OffsetMetadataAndError.scala>:36: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                             commitTimestamp: Long = org.apache.kafka.common.requests.OffsetCommitRequest.DEFAULT_TIMESTAMP,
                                                                                                          ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/common/OffsetMetadataAndError.scala>:37: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                             expireTimestamp: Long = org.apache.kafka.common.requests.OffsetCommitRequest.DEFAULT_TIMESTAMP) {
                                                                                                          ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/coordinator/GroupMetadataManager.scala>:401: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                          if (value.expireTimestamp == org.apache.kafka.common.requests.OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                                                                            ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:301: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
              if (partitionData.timestamp == OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                                 ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/client/ClientUtils.scala>:93: class ProducerConfig in package producer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.producer.ProducerConfig instead.
    val producerConfig = new ProducerConfig(props)
                             ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/client/ClientUtils.scala>:94: method fetchTopicMetadata in object ClientUtils is deprecated: This method has been deprecated and will be removed in a future release.
    fetchTopicMetadata(topics, brokers, producerConfig, correlationId)
    ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/controller/ControllerChannelManager.scala>:397: constructor UpdateMetadataRequest in class UpdateMetadataRequest is deprecated: see corresponding Javadoc for more information.
            new UpdateMetadataRequest(controllerId, controllerEpoch, liveBrokers.asJava, partitionStates.asJava)
            ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/metrics/KafkaMetricsGroup.scala>:191: object ProducerRequestStatsRegistry in package producer is deprecated: This object has been deprecated and will be removed in a future release.
    ProducerRequestStatsRegistry.removeProducerRequestStats(clientId)
    ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/network/BlockingChannel.scala>:129: method readFromReadableChannel in class NetworkReceive is deprecated: see corresponding Javadoc for more information.
      response.readFromReadableChannel(channel)
               ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:301: value timestamp in class PartitionData is deprecated: see corresponding Javadoc for more information.
              if (partitionData.timestamp == OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:304: value timestamp in class PartitionData is deprecated: see corresponding Javadoc for more information.
                offsetRetention + partitionData.timestamp
                                                ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:43: class OldProducer in package producer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.producer.KafkaProducer instead.
            new OldProducer(getOldProducerProps(config))
                ^
<https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:45: class NewShinyProducer in package producer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.producer.KafkaProducer instead.
            new NewShinyProducer(getNewProducerProps(config))
                ^
14 warnings found
:kafka-0.10.0-jdk7:core:processResources UP-TO-DATE
:kafka-0.10.0-jdk7:core:classes
:kafka-0.10.0-jdk7:clients:compileTestJavaNote: <https://builds.apache.org/job/kafka-0.10.0-jdk7/ws/clients/src/test/java/org/apache/kafka/common/requests/RequestResponseTest.java> uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

:kafka-0.10.0-jdk7:clients:processTestResources
:kafka-0.10.0-jdk7:clients:testClasses
:kafka-0.10.0-jdk7:core:copyDependantLibs
:kafka-0.10.0-jdk7:core:copyDependantTestLibs
:kafka-0.10.0-jdk7:core:jar
:jar_core_2_11
Building project 'core' with Scala version 2.11.8
cache artifact-at-repository.bin (/home/jenkins/.gradle/caches/modules-2/metadata-2.16/artifact-at-repository.bin) is corrupt. Discarding.
:jar_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
A problem occurred configuring project ':core'.
> Could not find a plugin jar in configuration 'scoverage'

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

BUILD FAILED

Total time: 1 mins 59.045 secs
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_2_4_RC_2_HOME
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
ERROR: No tool found matching GRADLE_2_4_RC_2_HOME
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk

Jenkins build is back to normal : kafka-0.10.0-jdk7 #221

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