See <https://builds.apache.org/job/kafka-trunk-jdk7/1591/changes>
Changes: [wangguoz] HOTFIX: do not call partitioner if num partitions is non-positive ------------------------------------------ [...truncated 3972 lines...] <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/admin/AclCommand.scala>:248: method readLine in class DeprecatedConsole is deprecated: Use the method in scala.io.StdIn Console.readLine().equalsIgnoreCase("y") ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/admin/TopicCommand.scala>:361: method readLine in class DeprecatedConsole is deprecated: Use the method in scala.io.StdIn if (!Console.readLine().equalsIgnoreCase("y")) { ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/client/ClientUtils.scala>:93: class ProducerConfig 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.ProducerConfig instead. val producerConfig = new ProducerConfig(props) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/client/ClientUtils.scala>:94: method fetchTopicMetadata in object ClientUtils is deprecated: This method has been deprecated and will be removed in a future release. fetchTopicMetadata(topics, brokers, producerConfig, correlationId) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/controller/ControllerChannelManager.scala>:393: constructor UpdateMetadataRequest in class UpdateMetadataRequest is deprecated: see corresponding Javadoc for more information. new UpdateMetadataRequest(controllerId, controllerEpoch, liveBrokers.asJava, partitionStates.asJava) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/metrics/KafkaMetricsGroup.scala>:191: object ProducerRequestStatsRegistry in package producer is deprecated: This object has been deprecated and will be removed in a future release. ProducerRequestStatsRegistry.removeProducerRequestStats(clientId) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/network/BlockingChannel.scala>:129: method readFromReadableChannel in class NetworkReceive is deprecated: see corresponding Javadoc for more information. response.readFromReadableChannel(channel) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:310: value timestamp in class PartitionData is deprecated: see corresponding Javadoc for more information. if (partitionData.timestamp == OffsetCommitRequest.DEFAULT_TIMESTAMP) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:313: value timestamp in class PartitionData is deprecated: see corresponding Javadoc for more information. offsetRetention + partitionData.timestamp ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:552: method offsetData in class ListOffsetRequest is deprecated: see corresponding Javadoc for more information. val (authorizedRequestInfo, unauthorizedRequestInfo) = offsetRequest.offsetData.asScala.partition { ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:552: class PartitionData in object ListOffsetRequest is deprecated: see corresponding Javadoc for more information. val (authorizedRequestInfo, unauthorizedRequestInfo) = offsetRequest.offsetData.asScala.partition { ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:557: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information. new ListOffsetResponse.PartitionData(Errors.TOPIC_AUTHORIZATION_FAILED.code, List[JLong]().asJava) ^ <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:582: 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-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:589: 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-trunk-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:592: 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-trunk-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-trunk-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-trunk-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-trunk-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-trunk-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-trunk-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)) ^ 27 warnings found :kafka-trunk-jdk7:core:processResources UP-TO-DATE :kafka-trunk-jdk7:core:classes :kafka-trunk-jdk7:core:checkstyleMain :kafka-trunk-jdk7:core:compileTestJava UP-TO-DATE :kafka-trunk-jdk7:core:compileTestScala <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:186: 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-trunk-jdk7/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:186: 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-trunk-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-trunk-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 :kafka-trunk-jdk7:core:processTestResources UP-TO-DATE :kafka-trunk-jdk7:core:testClasses :kafka-trunk-jdk7:core:checkstyleTest UP-TO-DATE :kafka-trunk-jdk7:core:test integration.kafka.api.GroupCoordinatorIntegrationTest > testGroupCoordinatorPropagatesOfffsetsTopicCompressionCodec STARTED integration.kafka.api.GroupCoordinatorIntegrationTest > testGroupCoordinatorPropagatesOfffsetsTopicCompressionCodec PASSED unit.kafka.server.ApiVersionsTest > testApiVersions STARTED unit.kafka.server.ApiVersionsTest > testApiVersions PASSED kafka.integration.FetcherTest > testFetcher STARTED kafka.integration.FetcherTest > testFetcher PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled STARTED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled PASSED kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride STARTED kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled STARTED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride STARTED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride PASSED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride STARTED kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride PASSED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow STARTED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow PASSED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow STARTED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow PASSED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh STARTED kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh PASSED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh STARTED kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh PASSED kafka.integration.PlaintextTopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack STARTED kafka.integration.PlaintextTopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack PASSED kafka.integration.PlaintextTopicMetadataTest > testAutoCreateTopicWithCollision STARTED kafka.integration.PlaintextTopicMetadataTest > testAutoCreateTopicWithCollision PASSED kafka.integration.PlaintextTopicMetadataTest > testAliveBrokerListWithNoTopics STARTED kafka.integration.PlaintextTopicMetadataTest > testAliveBrokerListWithNoTopics PASSED kafka.integration.PlaintextTopicMetadataTest > testAutoCreateTopic STARTED kafka.integration.PlaintextTopicMetadataTest > testAutoCreateTopic PASSED kafka.integration.PlaintextTopicMetadataTest > testGetAllTopicMetadata STARTED kafka.integration.PlaintextTopicMetadataTest > testGetAllTopicMetadata PASSED kafka.integration.PlaintextTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup STARTED kafka.integration.PlaintextTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup PASSED kafka.integration.PlaintextTopicMetadataTest > testBasicTopicMetadata STARTED kafka.integration.PlaintextTopicMetadataTest > testBasicTopicMetadata PASSED kafka.integration.PlaintextTopicMetadataTest > testAutoCreateTopicWithInvalidReplication STARTED kafka.integration.PlaintextTopicMetadataTest > testAutoCreateTopicWithInvalidReplication PASSED kafka.integration.PlaintextTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterABrokerShutdown STARTED kafka.integration.PlaintextTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterABrokerShutdown PASSED kafka.integration.PrimitiveApiTest > testMultiProduce STARTED kafka.integration.PrimitiveApiTest > testMultiProduce PASSED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch STARTED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch PASSED kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize STARTED kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize PASSED kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests STARTED kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests PASSED kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch STARTED kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch PASSED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression STARTED kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression PASSED kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic STARTED kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic PASSED kafka.integration.PrimitiveApiTest > testEmptyFetchRequest STARTED kafka.integration.PrimitiveApiTest > testEmptyFetchRequest PASSED kafka.integration.SaslSslTopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack STARTED kafka.integration.SaslSslTopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack PASSED kafka.integration.SaslSslTopicMetadataTest > testAutoCreateTopicWithCollision STARTED kafka.integration.SaslSslTopicMetadataTest > testAutoCreateTopicWithCollision PASSED kafka.integration.SaslSslTopicMetadataTest > testAliveBrokerListWithNoTopics STARTED kafka.integration.SaslSslTopicMetadataTest > testAliveBrokerListWithNoTopics PASSED kafka.integration.SaslSslTopicMetadataTest > testAutoCreateTopic STARTED kafka.integration.SaslSslTopicMetadataTest > testAutoCreateTopic PASSED kafka.integration.SaslSslTopicMetadataTest > testGetAllTopicMetadata STARTED kafka.integration.SaslSslTopicMetadataTest > testGetAllTopicMetadata PASSED kafka.integration.SaslSslTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup STARTED kafka.integration.SaslSslTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup PASSED kafka.integration.SaslSslTopicMetadataTest > testBasicTopicMetadata STARTED kafka.integration.SaslSslTopicMetadataTest > testBasicTopicMetadata PASSED kafka.integration.SaslSslTopicMetadataTest > testAutoCreateTopicWithInvalidReplication STARTED kafka.integration.SaslSslTopicMetadataTest > testAutoCreateTopicWithInvalidReplication PASSED kafka.integration.SaslSslTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterABrokerShutdown STARTED kafka.integration.SaslSslTopicMetadataTest > testAliveBrokersListWithNoTopicsAfterABrokerShutdown PASSED kafka.integration.SaslPlaintextTopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack STARTED kafka.integration.SaslPlaintextTopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack PASSED kafka.integration.SaslPlaintextTopicMetadataTest > testAutoCreateTopicWithCollision STARTED Build timed out (after 240 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