See <https://builds.apache.org/job/kafka-0.10.1-jdk7/102/changes>
Changes: [me] MINOR: Update ducktape version to 0.5.3 ------------------------------------------ [...truncated 12370 lines...] val (authorizedRequestInfo, unauthorizedRequestInfo) = offsetRequest.offsetData.asScala.partition { ^ <https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:585: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information. new ListOffsetResponse.PartitionData(Errors.UNKNOWN_TOPIC_OR_PARTITION.code, List[JLong]().asJava) ^ <https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:610: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information. (topicPartition, new ListOffsetResponse.PartitionData(Errors.NONE.code, offsets.map(new JLong(_)).asJava)) ^ <https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:617: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information. (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e).code, List[JLong]().asJava)) ^ <https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:620: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information. (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e).code, List[JLong]().asJava)) ^ <https://builds.apache.org/job/kafka-0.10.1-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:270: class PartitionData in object ListOffsetRequest is deprecated: see corresponding Javadoc for more information. val partitions = Map(topicPartition -> new ListOffsetRequest.PartitionData(earliestOrLatest, 1)) ^ <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>:194: 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>:194: 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 :connect:json:processResources UP-TO-DATE :connect:json:classes :connect:json:copyDependantLibs :connect:json:jar :streams:compileJavaNote: 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.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 org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[0] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[0] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[0] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldBeAbleToQueryState[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > shouldNotMakeStoreAvailableUntilAllStoresAvailable[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > queryOnRebalance[1] PASSED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[1] STARTED org.apache.kafka.streams.integration.QueryableStateIntegrationTest > concurrentAccesses[1] 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.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic STARTED org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic FAILED java.lang.AssertionError: Condition not met within timeout 60000. Did not receive 10 number of records at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:279) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:211) at org.apache.kafka.streams.integration.ResetIntegrationTest.testReprocessingFromScratchAfterResetWithIntermediateUserTopic(ResetIntegrationTest.java:143) org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic STARTED ERROR: Could not install GRADLE_2_4_RC_2_HOME java.lang.NullPointerException at hudson.plugins.toolenv.ToolEnvBuildWrapper$1.buildEnvVars(ToolEnvBuildWrapper.java:46) at hudson.model.AbstractBuild.getEnvironment(AbstractBuild.java:931) at hudson.plugins.git.GitSCM.getParamExpandedRepos(GitSCM.java:404) at hudson.plugins.git.GitSCM.compareRemoteRevisionWithImpl(GitSCM.java:609) at hudson.plugins.git.GitSCM.compareRemoteRevisionWith(GitSCM.java:574) at hudson.scm.SCM.compareRemoteRevisionWith(SCM.java:381) at hudson.scm.SCM.poll(SCM.java:398) at hudson.model.AbstractProject._poll(AbstractProject.java:1446) at hudson.model.AbstractProject.poll(AbstractProject.java:1349) at hudson.triggers.SCMTrigger$Runner.runPolling(SCMTrigger.java:528) at hudson.triggers.SCMTrigger$Runner.run(SCMTrigger.java:557) at hudson.util.SequentialExecutionQueue$QueueEntry.run(SequentialExecutionQueue.java:119) at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) at java.util.concurrent.FutureTask.run(FutureTask.java:266) at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142) at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617) at java.lang.Thread.run(Thread.java:745) 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 Setting GRADLE_2_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.4-rc-2