You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by jk...@apache.org on 2015/01/30 05:12:00 UTC

kafka git commit: KAFKA-1760 Follow-up: fix compilation issue with Scala 2.11

Repository: kafka
Updated Branches:
  refs/heads/trunk 0699ff2ce -> 75a286e43


KAFKA-1760 Follow-up: fix compilation issue with Scala 2.11


Project: http://git-wip-us.apache.org/repos/asf/kafka/repo
Commit: http://git-wip-us.apache.org/repos/asf/kafka/commit/75a286e4
Tree: http://git-wip-us.apache.org/repos/asf/kafka/tree/75a286e4
Diff: http://git-wip-us.apache.org/repos/asf/kafka/diff/75a286e4

Branch: refs/heads/trunk
Commit: 75a286e4308831203cc7e1d4748bdab504e8a1f3
Parents: 0699ff2
Author: Jay Kreps <ja...@gmail.com>
Authored: Thu Jan 29 20:09:36 2015 -0800
Committer: Jay Kreps <ja...@gmail.com>
Committed: Thu Jan 29 20:09:36 2015 -0800

----------------------------------------------------------------------
 core/src/main/scala/kafka/server/KafkaApis.scala | 5 +++--
 1 file changed, 3 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kafka/blob/75a286e4/core/src/main/scala/kafka/server/KafkaApis.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/kafka/server/KafkaApis.scala b/core/src/main/scala/kafka/server/KafkaApis.scala
index 48bc435..f2b027b 100644
--- a/core/src/main/scala/kafka/server/KafkaApis.scala
+++ b/core/src/main/scala/kafka/server/KafkaApis.scala
@@ -455,12 +455,13 @@ class KafkaApis(val requestChannel: RequestChannel,
   }
 
   def handleJoinGroupRequest(request: RequestChannel.Request) {
+    import JavaConversions._
     val joinGroupReq = request.requestObj.asInstanceOf[JoinGroupRequestAndHeader]
-    val topics = JavaConversions.asScalaIterable(joinGroupReq.body.topics()).toSet
+    val topics = joinGroupReq.body.topics().toSet
     val partitions = this.replicaManager.logManager.allLogs.filter(log => topics.contains(log.topicAndPartition.topic))
     val partitionList = partitions.map(_.topicAndPartition).map(tp => new org.apache.kafka.common.TopicPartition(tp.topic, tp.partition)).toBuffer
     this.consumerGroupGenerationId += 1
-    val response = new JoinGroupResponse(ErrorMapping.NoError, this.consumerGroupGenerationId, joinGroupReq.body.consumerId, JavaConversions.asJavaList(partitionList))
+    val response = new JoinGroupResponse(ErrorMapping.NoError, this.consumerGroupGenerationId, joinGroupReq.body.consumerId, partitionList)
     val send = new BoundedByteBufferSend(new JoinGroupResponseAndHeader(joinGroupReq.correlationId, response))
     requestChannel.sendResponse(new RequestChannel.Response(request, send))
   }