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 2015/07/23 18:39:34 UTC

Build failed in Jenkins: KafkaPreCommit #161

See <https://builds.apache.org/job/KafkaPreCommit/161/changes>

Changes:

[cshapi] KAFKA-2344; kafka-merge-pr improvements

[cshapi] KAFKA-2355;  Add an unit test to validate the deletion of a partition marked as deleted; patched by Edward Ribeiro, reviewed by Ashish Singh, Ismael Juma and Grant Henke

------------------------------------------
Started by an SCM change
Building remotely on ubuntu3 (Ubuntu ubuntu legacy-ubuntu) in workspace <https://builds.apache.org/job/KafkaPreCommit/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://git-wip-us.apache.org/repos/asf/kafka.git # timeout=10
Fetching upstream changes from https://git-wip-us.apache.org/repos/asf/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://git-wip-us.apache.org/repos/asf/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 66c8647d85f801893b9f882a7ad49242cef683fd (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 66c8647d85f801893b9f882a7ad49242cef683fd
 > git rev-list fd3b4cc41e9249ec6848cde8137691d32b2e79e5 # timeout=10
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1
[KafkaPreCommit] $ /bin/bash -xe /tmp/hudson578566261504390339.sh
+ /home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: http://gradle.org/docs/2.1/userguide/gradle_daemon.html.
Building project 'core' with Scala version 2.10.5
:downloadWrapper UP-TO-DATE

BUILD SUCCESSFUL

Total time: 12.992 secs
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1
[KafkaPreCommit] $ /bin/bash -xe /tmp/hudson4806820590641038165.sh
+ ./gradlew -PscalaVersion=2.10.1 test
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: http://gradle.org/docs/2.4/userguide/gradle_daemon.html.

FAILURE: Build failed with an exception.

* What went wrong:
Could not open buildscript class cache for settings file '/x1/jenkins/jenkins-slave/workspace/KafkaPreCommit/settings.gradle' (/home/jenkins/.gradle/caches/2.4/scripts/settings_azpqlzkn71yz2ostwvxkk46wf/SettingsScript/buildscript).
> Timeout waiting to lock buildscript class cache for settings file '/x1/jenkins/jenkins-slave/workspace/KafkaPreCommit/settings.gradle' (/home/jenkins/.gradle/caches/2.4/scripts/settings_azpqlzkn71yz2ostwvxkk46wf/SettingsScript/buildscript). It is currently in use by another Gradle instance.
  Owner PID: unknown
  Our PID: 10478
  Owner Operation: unknown
  Our operation: Initialize cache
  Lock file: /home/jenkins/.gradle/caches/2.4/scripts/settings_azpqlzkn71yz2ostwvxkk46wf/SettingsScript/buildscript/cache.properties.lock

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output.

BUILD FAILED

Total time: 1 mins 2.809 secs
Build step 'Execute shell' marked build as failure
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1

Re: Build failed in Jenkins: KafkaPreCommit #161

Posted by Ismael Juma <is...@juma.me.uk>.
On Thu, Jul 23, 2015 at 6:39 PM, Ashish Singh <as...@cloudera.com> wrote:

> Isamel, thats true. It will be nice to see this fixed, however as we are
> now moving to Github PRs should we start using travis CI?
>

We are currently using Jenkins for PR builds:

https://builds.apache.org/job/kafka-trunk-git-pr/

It would be good to experiment with Travis if someone has the time and
interest. As I understand, it can be problematic if the test suite takes
too long or uses a lot of CPU, although Apache did buy additional capacity:

https://blogs.apache.org/infra/entry/apache_gains_additional_travis_ci

I didn't want to change everything at once, so I thought that keeping
Jenkins for the initial phase would be the prudent thing to do.

Best,
Ismael

Re: Build failed in Jenkins: KafkaPreCommit #161

Posted by Ashish Singh <as...@cloudera.com>.
Isamel, thats true. It will be nice to see this fixed, however as we are
now moving to Github PRs should we start using travis CI?

On Thu, Jul 23, 2015 at 9:51 AM, Ismael Juma <is...@juma.me.uk> wrote:

> On Thu, Jul 23, 2015 at 5:39 PM, Apache Jenkins Server <
> jenkins@builds.apache.org> wrote:
> >
> > BUILD FAILED
> >
>
> This build job seems to be failing almost every time:
>
> https://builds.apache.org/job/KafkaPreCommit/
>
> Also, it seems to be running at a similar time as:
>
> https://builds.apache.org/job/Kafka-trunk/
>
> I think the idea was for it to run against JIRA patches, but it seems to me
> that it's actually running after new commits are pushed to trunk.
>
> Best,
> Ismael
>



-- 

Regards,
Ashish

Re: Build failed in Jenkins: KafkaPreCommit #161

Posted by Ismael Juma <is...@juma.me.uk>.
On Thu, Jul 23, 2015 at 5:39 PM, Apache Jenkins Server <
jenkins@builds.apache.org> wrote:
>
> BUILD FAILED
>

This build job seems to be failing almost every time:

https://builds.apache.org/job/KafkaPreCommit/

Also, it seems to be running at a similar time as:

https://builds.apache.org/job/Kafka-trunk/

I think the idea was for it to run against JIRA patches, but it seems to me
that it's actually running after new commits are pushed to trunk.

Best,
Ismael

Jenkins build is back to normal : KafkaPreCommit #164

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/KafkaPreCommit/164/changes>


Build failed in Jenkins: KafkaPreCommit #163

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/KafkaPreCommit/163/changes>

Changes:

[wangguoz] KAFKA-2348; Drop support for Scala 2.9

------------------------------------------
Started by an SCM change
Building remotely on ubuntu3 (Ubuntu ubuntu legacy-ubuntu) in workspace <https://builds.apache.org/job/KafkaPreCommit/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://git-wip-us.apache.org/repos/asf/kafka.git # timeout=10
Fetching upstream changes from https://git-wip-us.apache.org/repos/asf/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://git-wip-us.apache.org/repos/asf/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision fd3a3cd59539a741b6d3c830870dae1d5a5f93b5 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f fd3a3cd59539a741b6d3c830870dae1d5a5f93b5
 > git rev-list 520a8135f4820ee92e63427c5dbb2d5356e6a473 # timeout=10
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1
[KafkaPreCommit] $ /bin/bash -xe /tmp/hudson5812825175467945284.sh
+ /home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: http://gradle.org/docs/2.1/userguide/gradle_daemon.html.
Building project 'core' with Scala version 2.10.5
:downloadWrapper UP-TO-DATE

BUILD SUCCESSFUL

Total time: 13.077 secs
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1
[KafkaPreCommit] $ /bin/bash -xe /tmp/hudson9059387518674775750.sh
+ ./gradlew -PscalaVersion=2.10.1 test
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: http://gradle.org/docs/2.4/userguide/gradle_daemon.html.

FAILURE: Build failed with an exception.

* What went wrong:
Could not open buildscript class cache for settings file '/x1/jenkins/jenkins-slave/workspace/KafkaPreCommit/settings.gradle' (/home/jenkins/.gradle/caches/2.4/scripts/settings_azpqlzkn71yz2ostwvxkk46wf/SettingsScript/buildscript).
> Timeout waiting to lock buildscript class cache for settings file '/x1/jenkins/jenkins-slave/workspace/KafkaPreCommit/settings.gradle' (/home/jenkins/.gradle/caches/2.4/scripts/settings_azpqlzkn71yz2ostwvxkk46wf/SettingsScript/buildscript). It is currently in use by another Gradle instance.
  Owner PID: unknown
  Our PID: 10878
  Owner Operation: unknown
  Our operation: Initialize cache
  Lock file: /home/jenkins/.gradle/caches/2.4/scripts/settings_azpqlzkn71yz2ostwvxkk46wf/SettingsScript/buildscript/cache.properties.lock

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output.

BUILD FAILED

Total time: 1 mins 2.681 secs
Build step 'Execute shell' marked build as failure
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1

Build failed in Jenkins: KafkaPreCommit #162

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/KafkaPreCommit/162/changes>

Changes:

[wangguoz] KAFKA-2353; SocketServer catch exception and close connection properly; reviewed by Gwen Shapira, Ismael Juma and Guozhang Wang

------------------------------------------
[...truncated 1349 lines...]
kafka.log.BrokerCompressionTest > testBrokerSideCompression[17] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[18] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[19] PASSED

kafka.log.LogManagerTest > testGetNonExistentLog PASSED

kafka.log.LogManagerTest > testCleanupExpiredSegments PASSED

kafka.log.LogManagerTest > testCleanupSegmentsToMaintainSize PASSED

kafka.log.LogManagerTest > testCreateLog PASSED

kafka.log.LogManagerTest > testTimeBasedFlush PASSED

kafka.log.LogManagerTest > testLeastLoadedAssignment PASSED

kafka.log.LogManagerTest > testTwoLogManagersUsingSameDirFails PASSED

kafka.log.LogManagerTest > testCheckpointRecoveryPoints PASSED

kafka.log.LogManagerTest > testRecoveryDirectoryMappingWithTrailingSlash PASSED

kafka.log.LogManagerTest > testRecoveryDirectoryMappingWithRelativeDirectory PASSED

kafka.cluster.BrokerEndPointTest > testSerDe PASSED

kafka.cluster.BrokerEndPointTest > testHashAndEquals PASSED

kafka.cluster.BrokerEndPointTest > testFromJSON PASSED

kafka.cluster.BrokerEndPointTest > testFromOldJSON PASSED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromURI PASSED

kafka.cluster.BrokerEndPointTest > testEndpointFromURI PASSED

kafka.consumer.ConsumerIteratorTest > testConsumerIteratorDeduplicationDeepIterator PASSED

kafka.consumer.ConsumerIteratorTest > testConsumerIteratorDecodingFailure PASSED

kafka.consumer.ZookeeperConsumerConnectorTest > testCompression PASSED

kafka.consumer.ZookeeperConsumerConnectorTest > testLeaderSelectionForPartition PASSED

kafka.consumer.ZookeeperConsumerConnectorTest > testConsumerRebalanceListener PASSED

kafka.consumer.ZookeeperConsumerConnectorTest > testBasic PASSED

kafka.consumer.ZookeeperConsumerConnectorTest > testCompressionSetConsumption PASSED

kafka.consumer.ZookeeperConsumerConnectorTest > testConsumerDecoder PASSED

kafka.consumer.TopicFilterTest > testWildcardTopicCountGetTopicCountMapEscapeJson PASSED

kafka.consumer.TopicFilterTest > testWhitelists PASSED

kafka.consumer.TopicFilterTest > testBlacklists PASSED

kafka.consumer.PartitionAssignorTest > testRoundRobinPartitionAssignor PASSED

kafka.consumer.PartitionAssignorTest > testRangePartitionAssignor PASSED

kafka.consumer.MetricsTest > testMetricsReporterAfterDeletingTopic PASSED

kafka.consumer.MetricsTest > testMetricsLeak PASSED

kafka.common.TopicTest > testTopicHasCollision PASSED

kafka.common.TopicTest > testTopicHasCollisionChars PASSED

kafka.common.TopicTest > testInvalidTopicNames PASSED

kafka.common.ConfigTest > testInvalidClientIds PASSED

kafka.common.ConfigTest > testInvalidGroupIds PASSED

kafka.zk.ZKEphemeralTest > testEphemeralNodeCleanup PASSED

kafka.zk.ZKPathTest > testCreatePersistentSequentialThrowsException PASSED

kafka.zk.ZKPathTest > testCreatePersistentSequentialExists PASSED

kafka.zk.ZKPathTest > testCreateEphemeralPathThrowsException PASSED

kafka.zk.ZKPathTest > testCreateEphemeralPathExists PASSED

kafka.zk.ZKPathTest > testCreatePersistentPathThrowsException PASSED

kafka.zk.ZKPathTest > testCreatePersistentPath PASSED

kafka.zk.ZKPathTest > testMakeSurePersistsPathExistsThrowsException PASSED

kafka.zk.ZKPathTest > testMakeSurePersistsPathExists PASSED

kafka.server.ReplicaManagerTest > testIllegalRequiredAcks PASSED

kafka.server.ReplicaManagerTest > testHighwaterMarkRelativeDirectoryMapping PASSED

kafka.server.ReplicaManagerTest > testHighWaterMarkDirectoryMapping PASSED

kafka.server.IsrExpirationTest > testIsrExpirationForSlowFollowers PASSED

kafka.server.IsrExpirationTest > testIsrExpirationForStuckFollowers PASSED

kafka.server.IsrExpirationTest > testIsrExpirationIfNoFetchRequestMade PASSED

kafka.server.SimpleFetchTest > testReadFromLog PASSED

kafka.server.ServerGenerateBrokerIdTest > testAutoGenerateBrokerId PASSED

kafka.server.ServerGenerateBrokerIdTest > testUserConfigAndGeneratedBrokerId PASSED

kafka.server.ServerGenerateBrokerIdTest > testMultipleLogDirsMetaProps PASSED

kafka.server.ServerGenerateBrokerIdTest > testConsistentBrokerIdFromUserConfigAndMetaProps PASSED

kafka.server.ServerShutdownTest > testConsecutiveShutdown PASSED

kafka.server.ServerShutdownTest > testCleanShutdown PASSED

kafka.server.ServerShutdownTest > testCleanShutdownAfterFailedStartup PASSED

kafka.server.ServerShutdownTest > testCleanShutdownWithDeleteTopicEnabled PASSED

kafka.server.KafkaConfigTest > testLogRollTimeBothMsAndHoursProvided PASSED

kafka.server.KafkaConfigTest > testLogRollTimeNoConfigProvided PASSED

kafka.server.KafkaConfigTest > testVersionConfiguration PASSED

kafka.server.KafkaConfigTest > testListenerDefaults PASSED

kafka.server.KafkaConfigTest > testUncleanElectionDisabled PASSED

kafka.server.KafkaConfigTest > testUncleanElectionEnabled PASSED

kafka.server.KafkaConfigTest > testAdvertisePortDefault PASSED

kafka.server.KafkaConfigTest > testLogRetentionValid PASSED

kafka.server.KafkaConfigTest > testLogRetentionTimeNoConfigProvided PASSED

kafka.server.KafkaConfigTest > testAdvertiseConfigured PASSED

kafka.server.KafkaConfigTest > testAdvertiseDefaults PASSED

kafka.server.KafkaConfigTest > testLogRetentionTimeHoursProvided PASSED

kafka.server.KafkaConfigTest > testLogRetentionTimeMsProvided PASSED

kafka.server.KafkaConfigTest > testLogRetentionTimeBothMinutesAndHoursProvided PASSED

kafka.server.KafkaConfigTest > testDuplicateListeners PASSED

kafka.server.KafkaConfigTest > testLogRetentionTimeMinutesProvided PASSED

kafka.server.KafkaConfigTest > testBadListenerProtocol PASSED

kafka.server.KafkaConfigTest > testAdvertiseHostNameDefault PASSED

kafka.server.KafkaConfigTest > testUncleanLeaderElectionDefault PASSED

kafka.server.KafkaConfigTest > testUncleanElectionInvalid PASSED

kafka.server.KafkaConfigTest > testLogRetentionTimeBothMinutesAndMsProvided PASSED

kafka.server.KafkaConfigTest > testValidCompressionType PASSED

kafka.server.KafkaConfigTest > testInvalidCompressionType PASSED

kafka.server.KafkaConfigTest > testLogRollTimeMsProvided PASSED

kafka.server.KafkaConfigTest > testLogRetentionUnlimited PASSED

kafka.server.KafkaConfigTest > testDefaultCompressionType PASSED

kafka.server.OffsetCommitTest > testUpdateOffsets PASSED

kafka.server.OffsetCommitTest > testCommitAndFetchOffsets PASSED

kafka.server.OffsetCommitTest > testLargeMetadataPayload PASSED

kafka.server.OffsetCommitTest > testOffsetExpiration PASSED

kafka.server.OffsetCommitTest > testNonExistingTopicOffsetCommit PASSED

kafka.server.LogOffsetTest > testEmptyLogsGetOffsets PASSED

kafka.server.LogOffsetTest > testGetOffsetsBeforeEarliestTime PASSED

kafka.server.LogOffsetTest > testGetOffsetsBeforeLatestTime PASSED

kafka.server.LogOffsetTest > testGetOffsetsForUnknownTopic PASSED

kafka.server.LogOffsetTest > testGetOffsetsBeforeNow PASSED

kafka.server.AdvertiseBrokerTest > testBrokerAdvertiseToZK PASSED

kafka.server.KafkaConfigConfigDefTest > testFromPropsEmpty PASSED

kafka.server.KafkaConfigConfigDefTest > testFromPropsToProps PASSED

kafka.server.KafkaConfigConfigDefTest > testFromPropsInvalid PASSED

kafka.server.KafkaConfigConfigDefTest > testSpecificProperties PASSED

kafka.server.ServerStartupTest > testBrokerCreatesZKChroot PASSED

kafka.server.ServerStartupTest > testConflictBrokerRegistration PASSED

kafka.server.DelayedOperationTest > testRequestSatisfaction PASSED

kafka.server.DelayedOperationTest > testRequestPurge PASSED

kafka.server.DelayedOperationTest > testRequestExpiry PASSED

kafka.server.LeaderElectionTest > testLeaderElectionWithStaleControllerEpoch PASSED

kafka.server.LeaderElectionTest > testLeaderElectionAndEpoch PASSED

kafka.server.DynamicConfigChangeTest > testConfigChange PASSED

kafka.server.DynamicConfigChangeTest > testConfigChangeOnNonExistingTopic PASSED

kafka.server.HighwatermarkPersistenceTest > testHighWatermarkPersistenceMultiplePartitions PASSED

kafka.server.HighwatermarkPersistenceTest > testHighWatermarkPersistenceSinglePartition PASSED

kafka.server.ReplicaFetchTest > testReplicaFetcherThread PASSED

kafka.server.LogRecoveryTest > testHWCheckpointNoFailuresSingleLogSegment PASSED
:core:test FAILED

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output.

BUILD FAILED

Total time: 17 mins 15.708 secs
Build step 'Execute shell' marked build as failure
Setting GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1