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/10/11 17:35:43 UTC

Build failed in Jenkins: kafka-2.1-jdk8 #17

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

Changes:

[rajinisivaram] KAFKA-7475 - capture remote address on connection authetication errors,

------------------------------------------
[...truncated 2.80 MB...]
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/examples/src/main/java/org/apache/kafka/streams/examples/pageview/PageViewUntypedDemo.java>:38: warning: [deprecation] Serialized in org.apache.kafka.streams.kstream has been deprecated
import org.apache.kafka.streams.kstream.Serialized;
                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/examples/src/main/java/org/apache/kafka/streams/examples/pageview/PageViewTypedDemo.java>:36: warning: [deprecation] Serialized in org.apache.kafka.streams.kstream has been deprecated
import org.apache.kafka.streams.kstream.Serialized;
                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/examples/src/main/java/org/apache/kafka/streams/examples/pageview/PageViewUntypedDemo.java>:90: warning: [deprecation] Serialized in org.apache.kafka.streams.kstream has been deprecated
            .groupByKey(Serialized.with(Serdes.String(), jsonSerde))
                        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/examples/src/main/java/org/apache/kafka/streams/examples/pageview/PageViewUntypedDemo.java>:90: warning: [deprecation] groupByKey(Serialized<K,V>) in KStream has been deprecated
            .groupByKey(Serialized.with(Serdes.String(), jsonSerde))
            ^
  where K,V are type-variables:
    K extends Object declared in interface KStream
    V extends Object declared in interface KStream
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/examples/src/main/java/org/apache/kafka/streams/examples/pageview/PageViewTypedDemo.java>:209: warning: [deprecation] Serialized in org.apache.kafka.streams.kstream has been deprecated
            .groupByKey(Serialized.with(Serdes.String(), new JSONSerde<>()))
                        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/examples/src/main/java/org/apache/kafka/streams/examples/pageview/PageViewTypedDemo.java>:209: warning: [deprecation] groupByKey(Serialized<K,V>) in KStream has been deprecated
            .groupByKey(Serialized.with(Serdes.String(), new JSONSerde<>()))
            ^
  where K,V are type-variables:
    K extends Object declared in interface KStream
    V extends Object declared in interface KStream
6 warnings

> Task :streams:examples:processResources NO-SOURCE
> Task :streams:examples:classes
> Task :streams:examples:checkstyleMain
> Task :streams:examples:compileTestJava
> Task :streams:examples:processTestResources NO-SOURCE
> Task :streams:examples:testClasses
> Task :streams:examples:checkstyleTest
> Task :streams:examples:spotbugsMain

> Task :streams:examples:test

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test STARTED

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test PASSED

> Task :spotlessScala UP-TO-DATE
> Task :spotlessScalaCheck UP-TO-DATE
> Task :streams:streams-scala:compileJava NO-SOURCE

> Task :streams:streams-scala:compileScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala>:382: method groupByKey in trait KStream is deprecated: see corresponding Javadoc for more information.
    inner.groupByKey(serialized)
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala>:416: method groupBy in trait KStream is deprecated: see corresponding Javadoc for more information.
    inner.groupBy(selector.asKeyValueMapper, serialized)
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KTable.scala>:224: method groupBy in trait KTable is deprecated: see corresponding Javadoc for more information.
    inner.groupBy(selector.asKeyValueMapper, serialized)
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/Serialized.scala>:34: class Serialized in package kstream is deprecated: see corresponding Javadoc for more information.
  def `with`[K, V](implicit keySerde: Serde[K], valueSerde: Serde[V]): SerializedJ[K, V] =
                                                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/package.scala>:23: class Serialized in package kstream is deprecated: see corresponding Javadoc for more information.
  type Serialized[K, V] = org.apache.kafka.streams.kstream.Serialized[K, V]
                                                           ^
5 warnings found

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

> Task :streams:streams-scala:compileTestScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/StreamToTableJoinScalaIntegrationTestImplicitSerdes.scala>:125: method groupByKey in trait KStream is deprecated: see corresponding Javadoc for more information.
      .groupByKey(Serialized.`with`(Serdes.String, Serdes.JavaLong))
       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/TopologyTest.scala>:194: method groupByKey in trait KStream is deprecated: see corresponding Javadoc for more information.
        .groupByKey(Serialized.`with`[String, JLong])
         ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/kstream/SerializedTest.scala>:34: class SerializedInternal in package internals is deprecated: see corresponding Javadoc for more information.
    val internalSerialized = new SerializedInternal(serialized)
                                 ^
three warnings found

> Task :streams:streams-scala:processTestResources UP-TO-DATE
> Task :streams:streams-scala:testClasses
> Task :streams:streams-scala:checkstyleTest NO-SOURCE
> Task :streams:streams-scala:spotbugsMain

> Task :streams:streams-scala:test

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records FAILED
    java.lang.NullPointerException

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store PASSED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes STARTED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.SerializedTest > Create a Serialized should create a Serialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.SerializedTest > Create a Serialized should create a Serialized with Serdes 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.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform STARTED

org.apache.kafka.streams.scala.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform 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

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

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

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

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

32 tests completed, 1 failed

> Task :streams:streams-scala:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':streams:streams-scala:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.1-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 37m 55s
130 actionable tasks: 102 executed, 28 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-2.1-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
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=e31b8441c90a2a3c6978f59631abc6dc7cad5756, workspace=<https://builds.apache.org/job/kafka-2.1-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #16
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 rajinisivaram@googlemail.com

Jenkins build is back to normal : kafka-2.1-jdk8 #19

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


Build failed in Jenkins: kafka-2.1-jdk8 #18

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

Changes:

[rajinisivaram] KAFKA-6863 Kafka clients should try to use multiple DNS resolved IP

------------------------------------------
[...truncated 456.92 KB...]
  found:    StoreBuilder<S>
  where S is a type-variable:
    S extends StateStore declared in class TableSourceNode
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/graph/TableSourceNode.java>:133: warning: [unchecked] unchecked conversion
            this.consumedInternal = consumedInternal;
                                    ^
  required: ConsumedInternal<K,V>
  found:    ConsumedInternal
  where K,V are type-variables:
    K extends Object declared in class TableSourceNodeBuilder
    V extends Object declared in class TableSourceNodeBuilder
37 warnings

> Task :kafka-2.1-jdk8:streams:processResources NO-SOURCE
> Task :kafka-2.1-jdk8:streams:classes
> Task :kafka-2.1-jdk8:streams:copyDependantLibs
> Task :kafka-2.1-jdk8:streams:jar
> Task :kafka-2.1-jdk8:streams:test-utils:compileJava
> Task :kafka-2.1-jdk8:streams:test-utils:processResources NO-SOURCE
> Task :kafka-2.1-jdk8:streams:test-utils:classes
> Task :kafka-2.1-jdk8:streams:test-utils:copyDependantLibs
> Task :kafka-2.1-jdk8:streams:test-utils:jar

> Task :kafka-2.1-jdk8:streams:compileTestJava
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/processor/internals/InternalTopologyBuilderTest.java>:173: 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-2.1-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/processor/internals/InternalTopologyBuilderTest.java>:204: 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
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.
2 warnings

> Task :kafka-2.1-jdk8:streams:processTestResources
> Task :kafka-2.1-jdk8:streams:testClasses
> Task :kafka-2.1-jdk8:streams:streams-scala:compileJava NO-SOURCE

> Task :kafka-2.1-jdk8:streams:streams-scala:compileScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala>:382: method groupByKey in trait KStream is deprecated: see corresponding Javadoc for more information.
    inner.groupByKey(serialized)
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KStream.scala>:416: method groupBy in trait KStream is deprecated: see corresponding Javadoc for more information.
    inner.groupBy(selector.asKeyValueMapper, serialized)
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/KTable.scala>:224: method groupBy in trait KTable is deprecated: see corresponding Javadoc for more information.
    inner.groupBy(selector.asKeyValueMapper, serialized)
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/Serialized.scala>:34: class Serialized in package kstream is deprecated: see corresponding Javadoc for more information.
  def `with`[K, V](implicit keySerde: Serde[K], valueSerde: Serde[V]): SerializedJ[K, V] =
                                                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/main/scala/org/apache/kafka/streams/scala/kstream/package.scala>:23: class Serialized in package kstream is deprecated: see corresponding Javadoc for more information.
  type Serialized[K, V] = org.apache.kafka.streams.kstream.Serialized[K, V]
                                                           ^
5 warnings found

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

> Task :kafka-2.1-jdk8:streams:streams-scala:compileTestScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/StreamToTableJoinScalaIntegrationTestImplicitSerdes.scala>:125: method groupByKey in trait KStream is deprecated: see corresponding Javadoc for more information.
      .groupByKey(Serialized.`with`(Serdes.String, Serdes.JavaLong))
       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/TopologyTest.scala>:194: method groupByKey in trait KStream is deprecated: see corresponding Javadoc for more information.
        .groupByKey(Serialized.`with`[String, JLong])
         ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/streams/streams-scala/src/test/scala/org/apache/kafka/streams/scala/kstream/SerializedTest.scala>:34: class SerializedInternal in package internals is deprecated: see corresponding Javadoc for more information.
    val internalSerialized = new SerializedInternal(serialized)
                                 ^
three warnings found

> Task :kafka-2.1-jdk8:streams:streams-scala:processTestResources
> Task :kafka-2.1-jdk8:streams:streams-scala:testClasses
> Task :kafka-2.1-jdk8:streams:streams-scala:checkstyleTest NO-SOURCE
> Task :kafka-2.1-jdk8:streams:streams-scala:spotbugsMain

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

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

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.TopologyTest > shouldBuildIdenticalTopologyInJavaNScalaTransform STARTED

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

org.apache.kafka.streams.scala.kstream.SerializedTest > Create a Serialized should create a Serialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.SerializedTest > Create a Serialized should create a Serialized with Serdes PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialized should create a Materialized with Serdes PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a store name should create a Materialized with Serdes and a store name PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a window store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a key value store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier STARTED

org.apache.kafka.streams.scala.kstream.MaterializedTest > Create a Materialize with a session store supplier should create a Materialized with Serdes and a store supplier PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced should create a Produced with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ProducedTest > Create a Produced with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filter a KStream should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > filterNot a KStream should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > foreach a KStream should run foreach actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > peek a KStream should run peek actions on records PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > selectKey a KStream should select a new key PASSED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KStreamTest > join 2 KStreams should join correctly records FAILED
    java.lang.NullPointerException

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filter a KTable should filter records satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > filterNot a KTable should filter records not satisfying the predicate PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables should join correctly records PASSED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store STARTED

org.apache.kafka.streams.scala.kstream.KTableTest > join 2 KTables with a Materialized should join correctly records and state store PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed should create a Consumed with Serdes PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor and resetPolicy should create a Consumed with Serdes, timestampExtractor and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with timestampExtractor should create a Consumed with Serdes and timestampExtractor PASSED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy STARTED

org.apache.kafka.streams.scala.kstream.ConsumedTest > Create a Consumed with resetPolicy should create a Consumed with Serdes and resetPolicy PASSED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes STARTED

org.apache.kafka.streams.scala.kstream.JoinedTest > Create a Joined should create a Joined with Serdes PASSED

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

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

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

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

32 tests completed, 1 failed

> Task :kafka-2.1-jdk8:streams:streams-scala:test FAILED
> Task :testScala_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-2.1-jdk8:streams:streams-scala:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.1-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 1h 49m 37s
26 actionable tasks: 4 executed, 22 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-2.1-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
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=9369ccac2031456305ae459bb7858c02c7cc15d7, workspace=<https://builds.apache.org/job/kafka-2.1-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #16
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 rajinisivaram@googlemail.com