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/27 01:19:32 UTC

Build failed in Jenkins: kafka-1.0-jdk7 #250

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

Changes:

[matthias] KAFKA-7534: Error in flush calling close may prevent underlying store 

[mjsax] MINOR: Increase timeout and add more context to error message (#5840)

------------------------------------------
[...truncated 1.45 MB...]
    public void writeAsText(final String filePath,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:269: warning: [deprecation] writeAsText(String,Serde<K>,Serde<V>) in KStream has been deprecated
    public void writeAsText(final String filePath,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:262: warning: [deprecation] writeAsText(String,String) in KStream has been deprecated
    public void writeAsText(final String filePath,
                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:256: warning: [deprecation] writeAsText(String) in KStream has been deprecated
    public void writeAsText(final String filePath) {
                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:237: warning: [deprecation] print(KeyValueMapper<? super K,? super V,String>,Serde<K>,Serde<V>,String) in KStream has been deprecated
    public void print(final KeyValueMapper<? super K, ? super V, String> mapper,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:229: warning: [deprecation] print(KeyValueMapper<? super K,? super V,String>,Serde<K>,Serde<V>) in KStream has been deprecated
    public void print(final KeyValueMapper<? super K, ? super V, String> mapper,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:222: warning: [deprecation] print(KeyValueMapper<? super K,? super V,String>,String) in KStream has been deprecated
    public void print(final KeyValueMapper<? super K, ? super V, String> mapper,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:216: warning: [deprecation] print(KeyValueMapper<? super K,? super V,String>) in KStream has been deprecated
    public void print(final KeyValueMapper<? super K, ? super V, String> mapper) {
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:208: warning: [deprecation] print(Serde<K>,Serde<V>,String) in KStream has been deprecated
    public void print(final Serde<K> keySerde,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:201: warning: [deprecation] print(Serde<K>,Serde<V>) in KStream has been deprecated
    public void print(final Serde<K> keySerde,
                ^
  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-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:195: warning: [deprecation] print(String) in KStream has been deprecated
    public void print(final String label) {
                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KStreamImpl.java>:189: warning: [deprecation] print() in KStream has been deprecated
    public void print() {
                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:130: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,StateStoreSupplier<KeyValueStore>) in KGroupedTable has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,StateStoreSupplier<KeyValueStore>)
    K extends Object declared in interface KGroupedTable
    V extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:104: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,Serde<VR>) in KGroupedTable has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,Serde<VR>)
    K extends Object declared in interface KGroupedTable
    V extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:93: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,Serde<VR>,String) in KGroupedTable has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,Serde<VR>,String)
    K extends Object declared in interface KGroupedTable
    V extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:113: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,String) in KGroupedTable has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Aggregator<? super K,? super V,VR>,String)
    K extends Object declared in interface KGroupedTable
    V extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:235: warning: [deprecation] reduce(Reducer<V>,Reducer<V>,StateStoreSupplier<KeyValueStore>) in KGroupedTable has been deprecated
    public KTable<K, V> reduce(final Reducer<V> adder,
                        ^
  where V,K are type-variables:
    V extends Object declared in interface KGroupedTable
    K extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:205: warning: [deprecation] reduce(Reducer<V>,Reducer<V>,String) in KGroupedTable has been deprecated
    public KTable<K, V> reduce(final Reducer<V> adder,
                        ^
  where V,K are type-variables:
    V extends Object declared in interface KGroupedTable
    K extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:289: warning: [deprecation] count(StateStoreSupplier<KeyValueStore>) in KGroupedTable has been deprecated
    public KTable<K, Long> count(final org.apache.kafka.streams.processor.StateStoreSupplier<KeyValueStore> storeSupplier) {
                           ^
  where K is a type-variable:
    K extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedTableImpl.java>:247: warning: [deprecation] count(String) in KGroupedTable has been deprecated
    public KTable<K, Long> count(final String queryableStoreName) {
                           ^
  where K is a type-variable:
    K extends Object declared in interface KGroupedTable
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:349: warning: [deprecation] <T>aggregate(Initializer<T>,Aggregator<? super K,? super V,T>,Merger<? super K,T>,SessionWindows,Serde<T>,StateStoreSupplier<SessionStore>) in KGroupedStream has been deprecated
    public <T> KTable<Windowed<K>, T> aggregate(final Initializer<T> initializer,
                                      ^
  where T,K,V are type-variables:
    T extends Object declared in method <T>aggregate(Initializer<T>,Aggregator<? super K,? super V,T>,Merger<? super K,T>,SessionWindows,Serde<T>,StateStoreSupplier<SessionStore>)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:334: warning: [deprecation] <T>aggregate(Initializer<T>,Aggregator<? super K,? super V,T>,Merger<? super K,T>,SessionWindows,Serde<T>) in KGroupedStream has been deprecated
    public <T> KTable<Windowed<K>, T> aggregate(final Initializer<T> initializer,
                                      ^
  where T,K,V are type-variables:
    T extends Object declared in method <T>aggregate(Initializer<T>,Aggregator<? super K,? super V,T>,Merger<? super K,T>,SessionWindows,Serde<T>)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:314: warning: [deprecation] <T>aggregate(Initializer<T>,Aggregator<? super K,? super V,T>,Merger<? super K,T>,SessionWindows,Serde<T>,String) in KGroupedStream has been deprecated
    public <T> KTable<Windowed<K>, T> aggregate(final Initializer<T> initializer,
                                      ^
  where T,K,V are type-variables:
    T extends Object declared in method <T>aggregate(Initializer<T>,Aggregator<? super K,? super V,T>,Merger<? super K,T>,SessionWindows,Serde<T>,String)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:243: warning: [deprecation] <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,StateStoreSupplier<WindowStore>) in KGroupedStream has been deprecated
    public <W extends Window, T> KTable<Windowed<K>, T> aggregate(final Initializer<T> initializer,
                                                        ^
  where W,VR,K,V are type-variables:
    W extends Window declared in method <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,StateStoreSupplier<WindowStore>)
    VR extends Object declared in method <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,StateStoreSupplier<WindowStore>)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:231: warning: [deprecation] <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,Serde<VR>) in KGroupedStream has been deprecated
    public <W extends Window, T> KTable<Windowed<K>, T> aggregate(final Initializer<T> initializer,
                                                        ^
  where W,VR,K,V are type-variables:
    W extends Window declared in method <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,Serde<VR>)
    VR extends Object declared in method <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,Serde<VR>)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:220: warning: [deprecation] <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,Serde<VR>,String) in KGroupedStream has been deprecated
    public <W extends Window, T> KTable<Windowed<K>, T> aggregate(final Initializer<T> initializer,
                                                        ^
  where W,VR,K,V are type-variables:
    W extends Window declared in method <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,Serde<VR>,String)
    VR extends Object declared in method <W,VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Windows<W>,Serde<VR>,String)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:206: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,StateStoreSupplier<KeyValueStore>) in KGroupedStream has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,StateStoreSupplier<KeyValueStore>)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:198: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Serde<VR>) in KGroupedStream has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Serde<VR>)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:152: warning: [deprecation] <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Serde<VR>,String) in KGroupedStream has been deprecated
    public <T> KTable<K, T> aggregate(final Initializer<T> initializer,
                            ^
  where VR,K,V are type-variables:
    VR extends Object declared in method <VR>aggregate(Initializer<VR>,Aggregator<? super K,? super V,VR>,Serde<VR>,String)
    K extends Object declared in interface KGroupedStream
    V extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:447: warning: [deprecation] reduce(Reducer<V>,SessionWindows,StateStoreSupplier<SessionStore>) in KGroupedStream has been deprecated
    public KTable<Windowed<K>, V> reduce(final Reducer<V> reducer,
                                  ^
  where V,K are type-variables:
    V extends Object declared in interface KGroupedStream
    K extends Object declared in interface KGroupedStream
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/main/java/org/apache/kafka/streams/kstream/internals/KGroupedStreamImpl.java>:439: warning: [deprecation] reduce(Reducer<V>,SessionWindows) in KGroupedStream has been deprecated
    public KTable<Windowed<K>, V> reduce(final Reducer<V> reducer,
                                  ^
  where V,K are type-variables:
    V extends Object declared in interface KGroupedStream
    K extends Object declared in interface KGroupedStream
Note: Some input files additionally use or override a deprecated API.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.
100 warnings

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

> Task :streams:compileTestJava
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/test/java/org/apache/kafka/streams/state/internals/CachingKeyValueStoreTest.java>:116: error: cannot find symbol
            context = new InternalMockProcessorContext(null, null, null, (RecordCollector) null, cache);
                          ^
  symbol:   class InternalMockProcessorContext
  location: class CachingKeyValueStoreTest
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/streams/src/test/java/org/apache/kafka/streams/state/internals/CachingKeyValueStoreTest.java>:117: error: constructor ProcessorRecordContext in class ProcessorRecordContext cannot be applied to given types;
            context.setRecordContext(new ProcessorRecordContext(10, 0, 0, topic, null));
                                     ^
  required: long,long,int,String
  found: int,int,int,String,<null>
  reason: actual and formal argument lists differ in length
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 errors

> Task :streams:compileTestJava FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':streams:compileTestJava'.
> Compilation failed; see the compiler error output for details.

* 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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
See https://docs.gradle.org/4.8.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 17m 23s
52 actionable tasks: 27 executed, 25 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-1.0-jdk7/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 4 files in <https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/clients/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/examples/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/log4j-appender/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=175a9309b1417f6eb44bc484417f5a474142997d, workspace=<https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #249
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

Jenkins build is back to normal : kafka-1.0-jdk7 #252

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


Build failed in Jenkins: kafka-1.0-jdk7 #251

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

Changes:

[matthias] HOTFIX: fix broken build

------------------------------------------
[...truncated 378.29 KB...]
kafka.cluster.BrokerEndPointTest > testFromJsonV3 PASSED

kafka.cluster.ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark STARTED

kafka.cluster.ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark PASSED

kafka.cluster.ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization STARTED

kafka.cluster.ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization PASSED

kafka.cluster.ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark STARTED

kafka.cluster.ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark PASSED

kafka.cluster.PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset STARTED

kafka.cluster.PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset PASSED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException STARTED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException PASSED

kafka.cluster.PartitionTest > testGetReplica STARTED

kafka.cluster.PartitionTest > testGetReplica PASSED

kafka.security.auth.ZkAuthorizationTest > testIsZkSecurityEnabled STARTED

kafka.security.auth.ZkAuthorizationTest > testIsZkSecurityEnabled PASSED

kafka.security.auth.ZkAuthorizationTest > testZkUtils STARTED

kafka.security.auth.ZkAuthorizationTest > testZkUtils PASSED

kafka.security.auth.ZkAuthorizationTest > testZkAntiMigration STARTED

kafka.security.auth.ZkAuthorizationTest > testZkAntiMigration PASSED

kafka.security.auth.ZkAuthorizationTest > testZkMigration STARTED

kafka.security.auth.ZkAuthorizationTest > testZkMigration PASSED

kafka.security.auth.ZkAuthorizationTest > testChroot STARTED

kafka.security.auth.ZkAuthorizationTest > testChroot PASSED

kafka.security.auth.ZkAuthorizationTest > testDelete STARTED

kafka.security.auth.ZkAuthorizationTest > testDelete PASSED

kafka.security.auth.ZkAuthorizationTest > testDeleteRecursive STARTED

kafka.security.auth.ZkAuthorizationTest > testDeleteRecursive PASSED

kafka.security.auth.AclTest > testAclJsonConversion STARTED

kafka.security.auth.AclTest > testAclJsonConversion PASSED

kafka.security.auth.OperationTest > testJavaConversions STARTED

kafka.security.auth.OperationTest > testJavaConversions PASSED

kafka.security.auth.ResourceTypeTest > testJavaConversions STARTED

kafka.security.auth.ResourceTypeTest > testJavaConversions PASSED

kafka.security.auth.ResourceTypeTest > testFromString STARTED

kafka.security.auth.ResourceTypeTest > testFromString PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAllAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAllAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testLocalConcurrentModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testLocalConcurrentModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyDeletionOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyDeletionOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFound STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFound PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAclInheritance STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAclInheritance PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAclManagementAPIs STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAclManagementAPIs PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWildCardAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWildCardAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testTopicAcl STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testTopicAcl PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserHasAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserHasAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDenyTakesPrecedence STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDenyTakesPrecedence PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFoundOverride STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFoundOverride PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testLoadCache STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testLoadCache PASSED

kafka.security.auth.PermissionTypeTest > testJavaConversions STARTED

kafka.security.auth.PermissionTypeTest > testJavaConversions PASSED

kafka.security.auth.PermissionTypeTest > testFromString STARTED

kafka.security.auth.PermissionTypeTest > testFromString PASSED

kafka.message.MessageTest > testChecksum STARTED

kafka.message.MessageTest > testChecksum PASSED

kafka.message.MessageTest > testInvalidTimestamp STARTED

kafka.message.MessageTest > testInvalidTimestamp PASSED

kafka.message.MessageTest > testIsHashable STARTED

kafka.message.MessageTest > testIsHashable PASSED

kafka.message.MessageTest > testInvalidTimestampAndMagicValueCombination STARTED

kafka.message.MessageTest > testInvalidTimestampAndMagicValueCombination PASSED

kafka.message.MessageTest > testExceptionMapping STARTED

kafka.message.MessageTest > testExceptionMapping PASSED

kafka.message.MessageTest > testFieldValues STARTED

kafka.message.MessageTest > testFieldValues PASSED

kafka.message.MessageTest > testInvalidMagicByte STARTED

kafka.message.MessageTest > testInvalidMagicByte PASSED

kafka.message.MessageTest > testEquality STARTED

kafka.message.MessageTest > testEquality PASSED

kafka.message.MessageCompressionTest > testCompressSize STARTED

kafka.message.MessageCompressionTest > testCompressSize PASSED

kafka.message.MessageCompressionTest > testSimpleCompressDecompress STARTED

kafka.message.MessageCompressionTest > testSimpleCompressDecompress PASSED

kafka.message.ByteBufferMessageSetTest > testMessageWithProvidedOffsetSeq STARTED

kafka.message.ByteBufferMessageSetTest > testMessageWithProvidedOffsetSeq PASSED

kafka.message.ByteBufferMessageSetTest > testValidBytes STARTED

kafka.message.ByteBufferMessageSetTest > testValidBytes PASSED

kafka.message.ByteBufferMessageSetTest > testValidBytesWithCompression STARTED

kafka.message.ByteBufferMessageSetTest > testValidBytesWithCompression PASSED

kafka.message.ByteBufferMessageSetTest > testWriteToChannelThatConsumesPartially STARTED

kafka.message.ByteBufferMessageSetTest > testWriteToChannelThatConsumesPartially PASSED

kafka.message.ByteBufferMessageSetTest > testIteratorIsConsistent STARTED

kafka.message.ByteBufferMessageSetTest > testIteratorIsConsistent PASSED

kafka.message.ByteBufferMessageSetTest > testWrittenEqualsRead STARTED

kafka.message.ByteBufferMessageSetTest > testWrittenEqualsRead PASSED

kafka.message.ByteBufferMessageSetTest > testWriteTo STARTED

kafka.message.ByteBufferMessageSetTest > testWriteTo PASSED

kafka.message.ByteBufferMessageSetTest > testEquals STARTED

kafka.message.ByteBufferMessageSetTest > testEquals PASSED

kafka.message.ByteBufferMessageSetTest > testSizeInBytes STARTED

kafka.message.ByteBufferMessageSetTest > testSizeInBytes PASSED

kafka.message.ByteBufferMessageSetTest > testIterator STARTED

kafka.message.ByteBufferMessageSetTest > testIterator PASSED

1654 tests completed, 1 failed, 4 skipped

> Task :kafka-1.0-jdk7:core:test FAILED
> Task :test_core_2_11 FAILED

FAILURE: Build failed with an exception.

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 5.0.
See https://docs.gradle.org/4.8.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 13m 12s
20 actionable tasks: 8 executed, 12 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-1.0-jdk7/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 1 file in <https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/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=11e84e7d07e3feee8a46310962f895a273d3ed09, workspace=<https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #249
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