See <https://builds.apache.org/job/Kafka-trunk/392/changes>
Changes:
[jjkoshy] KAFKA-1697; Remove support for producer ack > 1 on the broker;
reviewed by Joel Koshy
------------------------------------------
[...truncated 1373 lines...]
try {
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/coordinator/DelayedJoinGroup.scala>:42:
a pure expression does nothing in statement position; you may be omitting
necessary parentheses
responseCallback
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/server/KafkaServer.scala>:206:
a pure expression does nothing in statement position; you may be omitting
necessary parentheses
ControllerStats.uncleanLeaderElectionRate
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/server/KafkaServer.scala>:207:
a pure expression does nothing in statement position; you may be omitting
necessary parentheses
ControllerStats.leaderElectionTimer
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/utils/Json.scala>:28:
object JSON in package json is deprecated: This object will be removed.
JSON.globalNumberParser = myConversionFunc
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/utils/Json.scala>:37:
object JSON in package json is deprecated: This object will be removed.
JSON.parseFull(input)
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/utils/Utils.scala>:419:
object Pair in object Predef is deprecated: Use built-in tuple syntax or
Tuple2 instead
Pair(s.substring(0,lio).trim, s.substring(lio + 1).trim)
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/consumer/ConsumerConfig.scala>:107:
Reference to uninitialized value fetchWaitMaxMs
require(fetchWaitMaxMs <= socketTimeoutMs, "socket.timeout.ms should always
be at least fetch.wait.max.ms" +
^
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:248:
Reference to uninitialized value replicaFetchWaitMaxMs
require(replicaFetchWaitMaxMs <= replicaSocketTimeoutMs,
"replica.socket.timeout.ms should always be at least replica.fetch.wait.max.ms"
+
^
there were 12 feature warning(s); re-run with -feature for details
12 warnings found
:core:processResources UP-TO-DATE
:core:classes
:core:compileTestJava UP-TO-DATE
:core:compileTestScala
<https://builds.apache.org/job/Kafka-trunk/ws/core/src/test/scala/unit/kafka/server/ServerShutdownTest.scala>:169:
This catches all Throwables. If this is really intended, use `case ex :
Throwable` to clear this warning.
case ex => fail()
^
one warning found
:core:processTestResources UP-TO-DATE
:core:testClasses
:core:test
unit.kafka.KafkaTest > testGetKafkaConfigFromArgs PASSED
unit.kafka.KafkaTest > testGetKafkaConfigFromArgsWrongSetValue PASSED
unit.kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsAtTheEnd PASSED
unit.kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsOnly PASSED
unit.kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsAtTheBegging PASSED
unit.kafka.utils.ByteBoundedBlockingQueueTest > testByteBoundedBlockingQueue
PASSED
unit.kafka.utils.CommandLineUtilsTest > testParseEmptyArg PASSED
unit.kafka.utils.CommandLineUtilsTest > testParseSingleArg PASSED
unit.kafka.utils.CommandLineUtilsTest > testParseArgs PASSED
unit.kafka.consumer.PartitionAssignorTest > testRoundRobinPartitionAssignor
PASSED
unit.kafka.consumer.PartitionAssignorTest > testRangePartitionAssignor PASSED
unit.kafka.common.ConfigTest > testInvalidClientIds PASSED
unit.kafka.common.ConfigTest > testInvalidGroupIds PASSED
unit.kafka.common.TopicTest > testInvalidTopicNames PASSED
kafka.integration.FetcherTest > testFetcher PASSED
kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled
PASSED
kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled
PASSED
kafka.integration.UncleanLeaderElectionTest >
testUncleanLeaderElectionEnabledByTopicOverride PASSED
kafka.integration.UncleanLeaderElectionTest >
testCleanLeaderElectionDisabledByTopicOverride PASSED
kafka.integration.UncleanLeaderElectionTest >
testUncleanLeaderElectionInvalidTopicOverride PASSED
kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh
PASSED
kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow
PASSED
kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh
PASSED
kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow PASSED
kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize PASSED
kafka.integration.PrimitiveApiTest > testEmptyFetchRequest PASSED
kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch PASSED
kafka.integration.PrimitiveApiTest >
testDefaultEncoderProducerAndFetchWithCompression PASSED
kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch PASSED
kafka.integration.PrimitiveApiTest > testMultiProduce PASSED
kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic PASSED
kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests PASSED
kafka.integration.RollingBounceTest > testRollingBounce PASSED
kafka.integration.TopicMetadataTest > testTopicMetadataRequest PASSED
kafka.integration.TopicMetadataTest > testBasicTopicMetadata PASSED
kafka.integration.TopicMetadataTest > testGetAllTopicMetadata PASSED
kafka.integration.TopicMetadataTest > testAutoCreateTopic PASSED
kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED
kafka.zk.ZKEphemeralTest > testEphemeralNodeCleanup PASSED
kafka.message.MessageTest > testFieldValues PASSED
kafka.message.MessageTest > testChecksum PASSED
kafka.message.MessageTest > testEquality PASSED
kafka.message.MessageTest > testIsHashable PASSED
kafka.message.ByteBufferMessageSetTest > testWrittenEqualsRead PASSED
kafka.message.ByteBufferMessageSetTest > testIteratorIsConsistent PASSED
kafka.message.ByteBufferMessageSetTest > testSizeInBytes PASSED
kafka.message.ByteBufferMessageSetTest > testWriteTo PASSED
kafka.message.ByteBufferMessageSetTest > testValidBytes PASSED
kafka.message.ByteBufferMessageSetTest > testValidBytesWithCompression PASSED
kafka.message.ByteBufferMessageSetTest > testEquals PASSED
kafka.message.ByteBufferMessageSetTest > testIterator PASSED
kafka.message.ByteBufferMessageSetTest > testOffsetAssignment PASSED
kafka.message.MessageCompressionTest > testSimpleCompressDecompress PASSED
kafka.network.SocketServerTest > simpleRequest PASSED
kafka.network.SocketServerTest > tooBigRequestIsRejected PASSED
kafka.network.SocketServerTest > testNullResponse PASSED
kafka.network.SocketServerTest > testSocketsCloseOnShutdown PASSED
kafka.network.SocketServerTest > testMaxConnectionsPerIp PASSED
kafka.network.SocketServerTest > testMaxConnectionsPerIPOverrides PASSED
kafka.admin.AddPartitionsTest > testTopicDoesNotExist PASSED
kafka.admin.AddPartitionsTest > testWrongReplicaCount PASSED
kafka.admin.AddPartitionsTest > testIncrementPartitions PASSED
kafka.admin.AddPartitionsTest > testManualAssignmentOfReplicas PASSED
kafka.admin.AddPartitionsTest > testReplicaPlacement PASSED
kafka.admin.DeleteConsumerGroupTest > testGroupWideDeleteInZK PASSED
kafka.admin.DeleteConsumerGroupTest >
testGroupWideDeleteInZKDoesNothingForActiveConsumerGroup PASSED
kafka.admin.DeleteConsumerGroupTest >
testGroupTopicWideDeleteInZKForGroupConsumingOneTopic PASSED
kafka.admin.DeleteConsumerGroupTest >
testGroupTopicWideDeleteInZKForGroupConsumingMultipleTopics PASSED
kafka.admin.DeleteConsumerGroupTest >
testGroupTopicWideDeleteInZKDoesNothingForActiveGroupConsumingMultipleTopics
PASSED
kafka.admin.DeleteConsumerGroupTest > testTopicWideDeleteInZK PASSED
kafka.admin.DeleteConsumerGroupTest >
testConsumptionOnRecreatedTopicAfterTopicWideDeleteInZK PASSED
kafka.admin.TopicCommandTest > testConfigPreservationAcrossPartitionAlteration
PASSED
kafka.admin.AdminTest > testReplicaAssignment PASSED
kafka.admin.AdminTest > testManualReplicaAssignment PASSED
kafka.admin.AdminTest > testTopicCreationInZK PASSED
kafka.admin.AdminTest > testPartitionReassignmentWithLeaderInNewReplicas PASSED
kafka.admin.AdminTest > testPartitionReassignmentWithLeaderNotInNewReplicas
PASSED
kafka.admin.AdminTest > testPartitionReassignmentNonOverlappingReplicas PASSED
kafka.admin.AdminTest > testReassigningNonExistingPartition PASSED
kafka.admin.AdminTest > testResumePartitionReassignmentThatWasCompleted PASSED
kafka.admin.AdminTest > testPreferredReplicaJsonData PASSED
kafka.admin.AdminTest > testBasicPreferredReplicaElection PASSED
kafka.admin.AdminTest > testShutdownBroker PASSED
kafka.admin.AdminTest > testTopicConfigChange PASSED
kafka.admin.DeleteTopicTest > testDeleteTopicWithAllAliveReplicas PASSED
kafka.admin.DeleteTopicTest > testResumeDeleteTopicWithRecoveredFollower PASSED
kafka.admin.DeleteTopicTest > testResumeDeleteTopicOnControllerFailover PASSED
kafka.admin.DeleteTopicTest > testPartitionReassignmentDuringDeleteTopic PASSED
kafka.admin.DeleteTopicTest > testDeleteTopicDuringAddPartition PASSED
kafka.admin.DeleteTopicTest > testAddPartitionDuringDeleteTopic PASSED
kafka.admin.DeleteTopicTest > testRecreateTopicAfterDeletion PASSED
kafka.admin.DeleteTopicTest > testDeleteNonExistingTopic PASSED
kafka.admin.DeleteTopicTest > testDeleteTopicWithCleaner PASSED
kafka.api.ApiUtilsTest > testShortStringNonASCII PASSED
kafka.api.ApiUtilsTest > testShortStringASCII PASSED
kafka.api.ConsumerTest > testSimpleConsumption PASSED
kafka.api.ConsumerTest > testAutoOffsetReset PASSED
kafka.api.ConsumerTest > testSeek PASSED
kafka.api.ConsumerTest > testGroupConsumption PASSED
kafka.api.ConsumerTest > testPositionAndCommit PASSED
kafka.api.ConsumerTest > testPartitionsFor PASSED
kafka.api.ConsumerTest > testConsumptionWithBrokerFailures PASSED
kafka.api.ConsumerTest > testSeekAndCommitWithBrokerFailures PASSED
Setting
GRADLE_2_1_HOME=/x1/jenkins/jenkins-home/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1
Build timed out (after 60 minutes). Marking the build as failed.
Build was aborted
Setting
GRADLE_2_1_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_2.1