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 2016/09/21 22:10:44 UTC

Build failed in Jenkins: kafka-0.10.1-jdk7 #3

See <https://builds.apache.org/job/kafka-0.10.1-jdk7/3/changes>

Changes:

[wangguoz] MINOR: add javadoc comment to PersistenKeyValueFactory.enableCaching

[wangguoz] MINOR: remove unused code from InternalTopicManager

------------------------------------------
[...truncated 12031 lines...]
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:271: constructor ListOffsetRequest in class ListOffsetRequest is deprecated: see corresponding Javadoc for more information.
        (new ListOffsetRequest(consumerId, partitions.asJava), 0)
         ^
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:281: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
          partitionData.offsets.get(0)
                        ^
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:298: method fromReplica in object FetchRequest is deprecated: see corresponding Javadoc for more information.
      else JFetchRequest.fromReplica(replicaId, maxWait, minBytes, requestMap)
                         ^
<https://builds.apache.org/job/kafka-0.10.1-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.1-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))
                ^
24 warnings found
:core:processResources UP-TO-DATE
:core:classes
:core:copyDependantLibs
:core:jar
:examples:compileJava
:examples:processResources UP-TO-DATE
:examples:classes
:examples:checkstyleMain
:examples:compileTestJava UP-TO-DATE
:examples:processTestResources UP-TO-DATE
:examples:testClasses UP-TO-DATE
:examples:checkstyleTest UP-TO-DATE
:examples:test UP-TO-DATE
:log4j-appender:compileJava
:log4j-appender:processResources UP-TO-DATE
:log4j-appender:classes
:log4j-appender:checkstyleMain
:log4j-appender:compileTestJava
:log4j-appender:processTestResources UP-TO-DATE
:log4j-appender:testClasses
:log4j-appender:checkstyleTest
:log4j-appender:test

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testLog4jAppends PASSED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs STARTED

org.apache.kafka.log4jappender.KafkaLog4jAppenderTest > testKafkaLog4jConfigs PASSED
:core:compileTestJava UP-TO-DATE
:core:compileTestScala
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:186: constructor ListOffsetRequest in class ListOffsetRequest is deprecated: see corresponding Javadoc for more information.
    new requests.ListOffsetRequest(Map(tp -> new ListOffsetRequest.PartitionData(0, 100)).asJava)
    ^
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:186: class PartitionData in object ListOffsetRequest is deprecated: see corresponding Javadoc for more information.
    new requests.ListOffsetRequest(Map(tp -> new ListOffsetRequest.PartitionData(0, 100)).asJava)
                                                                   ^
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/test/scala/unit/kafka/metrics/MetricsTest.scala>:88: method createAndShutdownStep in class MetricsTest is deprecated: This test has been deprecated and it will be removed in a future release
    createAndShutdownStep("group0", "consumer0", "producer0")
    ^
<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/test/scala/unit/kafka/server/FetchRequestTest.scala>:158: constructor FetchRequest in class FetchRequest is deprecated: see corresponding Javadoc for more information.
    val fetchRequest = new FetchRequest(Int.MaxValue, 0, createPartitionMap(maxPartitionBytes, Seq(topicPartition)))
                       ^
four warnings found
:core:processTestResources UP-TO-DATE
:core:testClasses
:connect:api:compileJava
:connect:api:processResources UP-TO-DATE
:connect:api:classes
:connect:api:copyDependantLibs
:connect:api:jar
:connect:json:compileJava
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/core/jackson-databind/2.6.3/jackson-databind-2.6.3.pom
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/jackson-parent/2.6.1/jackson-parent-2.6.1.pom
Download https://repo1.maven.org/maven2/com/fasterxml/oss-parent/23/oss-parent-23.pom
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/core/jackson-annotations/2.6.0/jackson-annotations-2.6.0.pom
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/core/jackson-core/2.6.3/jackson-core-2.6.3.pom
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/core/jackson-databind/2.6.3/jackson-databind-2.6.3.jar
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/core/jackson-annotations/2.6.0/jackson-annotations-2.6.0.jar
Download https://repo1.maven.org/maven2/com/fasterxml/jackson/core/jackson-core/2.6.3/jackson-core-2.6.3.jar
:connect:json:processResources UP-TO-DATE
:connect:json:classes
:connect:json:copyDependantLibs
:connect:json:jar
:streams:compileJava
Download https://repo1.maven.org/maven2/org/rocksdb/rocksdbjni/4.9.0/rocksdbjni-4.9.0.pom
Download https://repo1.maven.org/maven2/org/rocksdb/rocksdbjni/4.9.0/rocksdbjni-4.9.0.jar
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.
:streams:processResources UP-TO-DATE
:streams:classes
:streams:checkstyleMain
:streams:compileTestJava<https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/streams/src/test/java/org/apache/kafka/streams/kstream/internals/KStreamImplTest.java>:203: warning: non-varargs call of varargs method with inexact argument type for last parameter;
        testStream.branch(null);
                          ^
  cast to Predicate<String,String> for a varargs call
  cast to Predicate<String,String>[] for a non-varargs call and to suppress this warning
Note: <https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/streams/src/test/java/org/apache/kafka/streams/processor/internals/StreamsMetadataStateTest.java> uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.
1 warning

:streams:processTestResources
:streams:testClasses
:streams:checkstyleTest
:streams:test

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactTopicsForStateChangelogs STARTED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactTopicsForStateChangelogs PASSED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldUseCompactAndDeleteForWindowStoreChangelogs STARTED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldUseCompactAndDeleteForWindowStoreChangelogs PASSED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[0] STARTED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[0] PASSED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[1] STARTED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations[1] PASSED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[0] STARTED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[0] PASSED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[1] STARTED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegion[1] PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterReset STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterReset PASSED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduce STARTED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduce PASSED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduceWindowed STARTED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduceWindowed PASSED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testShouldReadFromRegexAndNamedTopics STARTED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testShouldReadFromRegexAndNamedTopics PASSED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenCreated STARTED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenCreated PASSED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testMultipleConsumersCanReadFromPartitionedTopic STARTED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testMultipleConsumersCanReadFromPartitionedTopic PASSED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenDeleted STARTED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenDeleted PASSED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testNoMessagesSentExceptionFromOverlappingPatterns STARTED

org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testNoMessagesSentExceptionFromOverlappingPatterns PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce[0] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce[0] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate[0] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate[0] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount[0] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount[0] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey[0] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey[0] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed[0] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed[0] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed[0] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed[0] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce[1] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce[1] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate[1] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate[1] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount[1] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount[1] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey[1] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey[1] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed[1] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed[1] PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed[1] STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed[1] PASSED

org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[0] STARTED

org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[0] PASSED

org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[1] STARTED

org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput[1] PASSED

org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[0] STARTED

org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[0] PASSED

org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[0] STARTED

org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[0] PASSED

org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[0] STARTED
ERROR: Could not install GRADLE_2_4_RC_2_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_2_4_RC_2_HOME
java.lang.NullPointerException
Build timed out (after 180 minutes). Marking the build as failed.
Build was aborted
Recording test results
Setting GRADLE_2_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.4-rc-2
:streams:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':streams:test'.
> Process 'Gradle Test Executor 4' finished with non-zero exit value 143

* 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: 2 hrs 59 mins 12.184 secs
Setting GRADLE_2_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.4-rc-2

Jenkins build is back to normal : kafka-0.10.1-jdk7 #4

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-0.10.1-jdk7/4/changes>