You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@pekko.apache.org by "mdedetrich (via GitHub)" <gi...@apache.org> on 2023/05/10 11:02:12 UTC

[GitHub] [incubator-pekko-connectors-kafka] mdedetrich opened a new pull request, #65: Apply compat changes from latest Pekko

mdedetrich opened a new pull request, #65:
URL: https://github.com/apache/incubator-pekko-connectors-kafka/pull/65

   Self explanatory


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org
For additional commands, e-mail: notifications-help@pekko.apache.org


[GitHub] [incubator-pekko-connectors-kafka] He-Pin commented on a diff in pull request #65: Apply compat changes from latest Pekko

Posted by "He-Pin (via GitHub)" <gi...@apache.org>.
He-Pin commented on code in PR #65:
URL: https://github.com/apache/incubator-pekko-connectors-kafka/pull/65#discussion_r1189982868


##########
core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala:
##########
@@ -24,13 +24,13 @@ import com.typesafe.config.Config
 import org.apache.kafka.clients.producer.{ KafkaProducer, Producer, ProducerConfig }
 import org.apache.kafka.common.serialization.Serializer
 
-import scala.compat.java8.OptionConverters._
 import scala.concurrent.duration._
 import pekko.util.ccompat.JavaConverters._
+import pekko.util.FutureConverters._
 import pekko.util.JavaDurationConverters._
+import pekko.util.OptionConverters._

Review Comment:
   How about run a `sbt sortImports`?



##########
core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala:
##########
@@ -24,13 +24,13 @@ import com.typesafe.config.Config
 import org.apache.kafka.clients.producer.{ KafkaProducer, Producer, ProducerConfig }
 import org.apache.kafka.common.serialization.Serializer
 
-import scala.compat.java8.OptionConverters._
 import scala.concurrent.duration._
 import pekko.util.ccompat.JavaConverters._
+import pekko.util.FutureConverters._
 import pekko.util.JavaDurationConverters._
+import pekko.util.OptionConverters._

Review Comment:
   How about running a `sbt sortImports`?



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org
For additional commands, e-mail: notifications-help@pekko.apache.org


[GitHub] [incubator-pekko-connectors-kafka] mdedetrich merged pull request #65: Apply compat changes from latest Pekko

Posted by "mdedetrich (via GitHub)" <gi...@apache.org>.
mdedetrich merged PR #65:
URL: https://github.com/apache/incubator-pekko-connectors-kafka/pull/65


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org
For additional commands, e-mail: notifications-help@pekko.apache.org


[GitHub] [incubator-pekko-connectors-kafka] mdedetrich commented on a diff in pull request #65: Apply compat changes from latest Pekko

Posted by "mdedetrich (via GitHub)" <gi...@apache.org>.
mdedetrich commented on code in PR #65:
URL: https://github.com/apache/incubator-pekko-connectors-kafka/pull/65#discussion_r1189985009


##########
core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala:
##########
@@ -24,13 +24,13 @@ import com.typesafe.config.Config
 import org.apache.kafka.clients.producer.{ KafkaProducer, Producer, ProducerConfig }
 import org.apache.kafka.common.serialization.Serializer
 
-import scala.compat.java8.OptionConverters._
 import scala.concurrent.duration._
 import pekko.util.ccompat.JavaConverters._
+import pekko.util.FutureConverters._
 import pekko.util.JavaDurationConverters._
+import pekko.util.OptionConverters._

Review Comment:
   Not a bad idea, but honestly I don't want to mess the imports up at the cost of making a ginormous diff. There is definitely a discussion to be had about the general style/ordering of our imports and whether we can automate that with scalafix/sortImports but that is something I want to tackle later and at once and most importantly seperately.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org
For additional commands, e-mail: notifications-help@pekko.apache.org


[GitHub] [incubator-pekko-connectors-kafka] mdedetrich commented on a diff in pull request #65: Apply compat changes from latest Pekko

Posted by "mdedetrich (via GitHub)" <gi...@apache.org>.
mdedetrich commented on code in PR #65:
URL: https://github.com/apache/incubator-pekko-connectors-kafka/pull/65#discussion_r1189985009


##########
core/src/main/scala/org/apache/pekko/kafka/ProducerSettings.scala:
##########
@@ -24,13 +24,13 @@ import com.typesafe.config.Config
 import org.apache.kafka.clients.producer.{ KafkaProducer, Producer, ProducerConfig }
 import org.apache.kafka.common.serialization.Serializer
 
-import scala.compat.java8.OptionConverters._
 import scala.concurrent.duration._
 import pekko.util.ccompat.JavaConverters._
+import pekko.util.FutureConverters._
 import pekko.util.JavaDurationConverters._
+import pekko.util.OptionConverters._

Review Comment:
   Not a bad idea, but honestly I don't want to mess the imports up at the cost of making a ginormous diff. There is definitely a discussion to be had about the general style/ordering of our imports and whether we can automate that with scalafix/sortImports but that is something I want to tackle later and at once.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@pekko.apache.org
For additional commands, e-mail: notifications-help@pekko.apache.org