You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@openwhisk.apache.org by gi...@git.apache.org on 2017/06/27 18:50:40 UTC

[GitHub] rabbah commented on a change in pull request #2414: SPI approach for pluggable implementations

rabbah commented on a change in pull request #2414: SPI approach for pluggable implementations
URL: https://github.com/apache/incubator-openwhisk/pull/2414#discussion_r124363687
 
 

 ##########
 File path: common/scala/src/main/scala/whisk/connector/kafka/KafkaProducerConnector.scala
 ##########
 @@ -20,22 +20,21 @@ package whisk.connector.kafka
 import java.util.Properties
 import java.util.UUID
 
-import scala.concurrent.ExecutionContext
-import scala.concurrent.Future
-import scala.util.Failure
-import scala.util.Success
-
 import org.apache.kafka.clients.producer.KafkaProducer
 import org.apache.kafka.clients.producer.ProducerConfig
 import org.apache.kafka.clients.producer.ProducerRecord
 import org.apache.kafka.clients.producer.RecordMetadata
 import org.apache.kafka.common.serialization.StringSerializer
-
 import whisk.common.Counter
 import whisk.common.Logging
 import whisk.core.connector.Message
 import whisk.core.connector.MessageProducer
 
+import scala.concurrent.ExecutionContext
 
 Review comment:
   this file is unchanged just reorg of imports, drop it?
 
----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services