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/07/19 19:50:11 UTC

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

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

Changes:

[github] KAFKA-3514: Remove min timestamp tracker (#5382)

------------------------------------------
[...truncated 887.72 KB...]
kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > logsShouldNotDivergeOnUncleanLeaderElections STARTED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > logsShouldNotDivergeOnUncleanLeaderElections PASSED

kafka.server.ScramServerStartupTest > testAuthentications STARTED

kafka.server.ScramServerStartupTest > testAuthentications PASSED

kafka.server.MultipleListenersWithAdditionalJaasContextTest > testProduceConsume STARTED

kafka.server.MultipleListenersWithAdditionalJaasContextTest > testProduceConsume PASSED

kafka.server.ReplicationQuotasTest > shouldBootstrapTwoBrokersWithLeaderThrottle STARTED

kafka.server.ReplicationQuotasTest > shouldBootstrapTwoBrokersWithLeaderThrottle PASSED

kafka.server.ReplicationQuotasTest > shouldThrottleOldSegments STARTED

kafka.server.ReplicationQuotasTest > shouldThrottleOldSegments PASSED

kafka.server.ReplicationQuotasTest > shouldBootstrapTwoBrokersWithFollowerThrottle STARTED

kafka.server.ReplicationQuotasTest > shouldBootstrapTwoBrokersWithFollowerThrottle PASSED

kafka.server.EdgeCaseRequestTest > testInvalidApiVersionRequest STARTED

kafka.server.EdgeCaseRequestTest > testInvalidApiVersionRequest PASSED

kafka.server.EdgeCaseRequestTest > testMalformedHeaderRequest STARTED

kafka.server.EdgeCaseRequestTest > testMalformedHeaderRequest PASSED

kafka.server.EdgeCaseRequestTest > testProduceRequestWithNullClientId STARTED

kafka.server.EdgeCaseRequestTest > testProduceRequestWithNullClientId PASSED

kafka.server.EdgeCaseRequestTest > testInvalidApiKeyRequest STARTED

kafka.server.EdgeCaseRequestTest > testInvalidApiKeyRequest PASSED

kafka.server.EdgeCaseRequestTest > testHeaderOnlyRequest STARTED

kafka.server.EdgeCaseRequestTest > testHeaderOnlyRequest PASSED

kafka.server.SaslApiVersionsRequestTest > testApiVersionsRequestWithUnsupportedVersion STARTED

kafka.server.SaslApiVersionsRequestTest > testApiVersionsRequestWithUnsupportedVersion PASSED

kafka.server.SaslApiVersionsRequestTest > testApiVersionsRequestBeforeSaslHandshakeRequest STARTED

kafka.server.SaslApiVersionsRequestTest > testApiVersionsRequestBeforeSaslHandshakeRequest PASSED

kafka.server.SaslApiVersionsRequestTest > testApiVersionsRequestAfterSaslHandshakeRequest STARTED

kafka.server.SaslApiVersionsRequestTest > testApiVersionsRequestAfterSaslHandshakeRequest PASSED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics STARTED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testClusterIdMetric STARTED

kafka.metrics.MetricsTest > testClusterIdMetric PASSED

kafka.metrics.MetricsTest > testControllerMetrics STARTED

kafka.metrics.MetricsTest > testControllerMetrics PASSED

kafka.metrics.MetricsTest > testWindowsStyleTagNames STARTED

kafka.metrics.MetricsTest > testWindowsStyleTagNames PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut PASSED

kafka.metrics.KafkaTimerTest > testKafkaTimer STARTED

kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED

> Task :kafka-trunk-jdk8:core:copyDependantLibs
> Task :kafka-trunk-jdk8:core:jar
> Task :kafka-trunk-jdk8:connect:api:compileJava UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:api:processResources NO-SOURCE
> Task :kafka-trunk-jdk8:connect:api:classes UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:api:copyDependantLibs UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:api:jar UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:json:compileJava UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:json:processResources NO-SOURCE
> Task :kafka-trunk-jdk8:connect:json:classes UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:json:copyDependantLibs UP-TO-DATE
> Task :kafka-trunk-jdk8:connect:json:jar UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:compileJava UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:processResources NO-SOURCE
> Task :kafka-trunk-jdk8:streams:classes UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:copyDependantLibs
> Task :kafka-trunk-jdk8:streams:jar UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:test-utils:compileJava UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:test-utils:processResources NO-SOURCE
> Task :kafka-trunk-jdk8:streams:test-utils:classes UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:test-utils:copyDependantLibs
> Task :kafka-trunk-jdk8:streams:test-utils:jar UP-TO-DATE

> Task :kafka-trunk-jdk8:streams:compileTestJava
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/processor/internals/InternalTopologyBuilderTest.java>:169: warning: non-varargs call of varargs method with inexact argument type for last parameter;
        builder.addProcessor("processor", new MockProcessorSupplier(), null);
                                                                       ^
  cast to String for a varargs call
  cast to String[] for a non-varargs call and to suppress this warning
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/processor/internals/InternalTopologyBuilderTest.java>:200: warning: non-varargs call of varargs method with inexact argument type for last parameter;
        builder.addSink("sink", "topic", null, null, null, null);
                                                           ^
  cast to String for a varargs call
  cast to String[] for a non-varargs call and to suppress this warning
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/TopologyTest.java>:190: warning: non-varargs call of varargs method with inexact argument type for last parameter;
            topology.addProcessor("processor", new MockProcessorSupplier(), null);
                                                                            ^
  cast to String for a varargs call
  cast to String[] for a non-varargs call and to suppress this warning
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/TopologyTest.java>:230: warning: non-varargs call of varargs method with inexact argument type for last parameter;
            topology.addSink("sink", "topic-2", null);
                                                ^
  cast to String for a varargs call
  cast to String[] for a non-varargs call and to suppress this warning
Note: Some input files use or override 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.
4 warnings

> Task :kafka-trunk-jdk8:streams:processTestResources UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:testClasses
> Task :kafka-trunk-jdk8:streams:streams-scala:compileJava NO-SOURCE

> Task :kafka-trunk-jdk8:streams:streams-scala:compileScala
Pruning sources from previous analysis, due to incompatible CompileSetup.

> Task :kafka-trunk-jdk8:streams:streams-scala:processResources NO-SOURCE
> Task :kafka-trunk-jdk8:streams:streams-scala:classes
> Task :kafka-trunk-jdk8:streams:streams-scala:checkstyleMain NO-SOURCE
> Task :kafka-trunk-jdk8:streams:streams-scala:compileTestJava NO-SOURCE

> Task :kafka-trunk-jdk8:streams:streams-scala:compileTestScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/TopologyTest.scala>:118: local val wordCounts in method getTopologyJava is never used
      val wordCounts: KTableJ[String, java.lang.Long] = grouped.count()
          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/TopologyTest.scala>:139: local val clicksPerRegion in method getTopologyScala is never used
      val clicksPerRegion: KTable[String, Long] =
          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/TopologyTest.scala>:183: local val clicksPerRegion in method getTopologyJava is never used
      val clicksPerRegion: KTableJ[String, JLong] = clicksByRegion
          ^
three warnings found

> Task :kafka-trunk-jdk8:streams:streams-scala:processTestResources UP-TO-DATE
> Task :kafka-trunk-jdk8:streams:streams-scala:testClasses
> Task :kafka-trunk-jdk8:streams:streams-scala:checkstyleTest NO-SOURCE
> Task :kafka-trunk-jdk8:streams:streams-scala:findbugsMain

> Task :kafka-trunk-jdk8:streams:streams-scala:test

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionJava STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegionJava FAILED
    kafka.zookeeper.ZooKeeperClientTimeoutException: Timed out waiting for connection while in state: CONNECTING
        at kafka.zookeeper.ZooKeeperClient.$anonfun$waitUntilConnected$3(ZooKeeperClient.scala:225)
        at scala.runtime.java8.JFunction0$mcV$sp.apply(JFunction0$mcV$sp.java:12)
        at kafka.utils.CoreUtils$.inLock(CoreUtils.scala:251)
        at kafka.zookeeper.ZooKeeperClient.waitUntilConnected(ZooKeeperClient.scala:221)
        at kafka.zookeeper.ZooKeeperClient.<init>(ZooKeeperClient.scala:95)
        at kafka.zk.KafkaZkClient$.apply(KafkaZkClient.scala:1581)
        at kafka.zk.KafkaZkClient.apply(KafkaZkClient.scala)
        at org.apache.kafka.streams.integration.utils.KafkaEmbedded.createZkClient(KafkaEmbedded.java:181)
        at org.apache.kafka.streams.integration.utils.KafkaEmbedded.createTopic(KafkaEmbedded.java:174)
        at org.apache.kafka.streams.integration.utils.EmbeddedKafkaCluster.createTopic(EmbeddedKafkaCluster.java:205)
        at org.apache.kafka.streams.integration.utils.EmbeddedKafkaCluster.createTopic(EmbeddedKafkaCluster.java:179)
        at org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes.startKafkaCluster(StreamToTableJoinScalaIntegrationTestImplicitSerdes.scala:59)

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegion STARTED

org.apache.kafka.streams.scala.StreamToTableJoinScalaIntegrationTestImplicitSerdes > testShouldCountClicksPerRegion PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaJoin PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaSimple PASSED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaAggregate PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsMaterialized PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWordsJava PASSED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords STARTED

org.apache.kafka.streams.scala.WordCountTest > testShouldCountWords PASSED

8 tests completed, 1 failed

> Task :kafka-trunk-jdk8:streams:streams-scala:test FAILED
> Task :testScala_2_12 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-trunk-jdk8:streams:streams-scala:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/streams-scala/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 4h 14m 41s
26 actionable tasks: 18 executed, 8 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[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 2 files 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.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/streams/streams-scala/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=2f6240ac944f2a55ece50a179b79f4e2ee63a621, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2805
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user github@alasdairhodge.co.uk

Jenkins build is back to normal : kafka-trunk-jdk8 #2809

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