You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by GitBox <gi...@apache.org> on 2022/04/12 07:15:53 UTC

[GitHub] [flink] syhily opened a new pull request, #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

syhily opened a new pull request, #19433:
URL: https://github.com/apache/flink/pull/19433

   This is a backport PR for #19092


-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] imaffe commented on pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
imaffe commented on PR #19433:
URL: https://github.com/apache/flink/pull/19433#issuecomment-1120614941

   @MartijnVisser  seems this backport PR is ready ? 


-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] syhily commented on a diff in pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
syhily commented on code in PR #19433:
URL: https://github.com/apache/flink/pull/19433#discussion_r861026530


##########
flink-connectors/flink-connector-pulsar/src/test/resources/containers/txnStandalone.conf:
##########
@@ -14,8 +14,7 @@
 
 ### --- General broker settings --- ###
 
-# Zookeeper quorum connection string
-zookeeperServers=
+# Zookeeper quorum connection stringzookeeperServers=

Review Comment:
   Yep. This should be a mistake on my side.



-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] flinkbot commented on pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
flinkbot commented on PR #19433:
URL: https://github.com/apache/flink/pull/19433#issuecomment-1096243899

   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "e5d89c986d70ef2cd5cefbc0c73e380386776f32",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "e5d89c986d70ef2cd5cefbc0c73e380386776f32",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * e5d89c986d70ef2cd5cefbc0c73e380386776f32 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run azure` re-run the last Azure build
   </details>


-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] MartijnVisser merged pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
MartijnVisser merged PR #19433:
URL: https://github.com/apache/flink/pull/19433


-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] syhily commented on pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
syhily commented on PR #19433:
URL: https://github.com/apache/flink/pull/19433#issuecomment-1099954699

   @AHeise This is a backport PR. Can you review it?


-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] AHeise commented on a diff in pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
AHeise commented on code in PR #19433:
URL: https://github.com/apache/flink/pull/19433#discussion_r860530623


##########
flink-connectors/flink-connector-pulsar/src/test/resources/containers/txnStandalone.conf:
##########
@@ -14,8 +14,7 @@
 
 ### --- General broker settings --- ###
 
-# Zookeeper quorum connection string
-zookeeperServers=
+# Zookeeper quorum connection stringzookeeperServers=

Review Comment:
   This looks indeed as an unintended change.



-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] fapaul commented on a diff in pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
fapaul commented on code in PR #19433:
URL: https://github.com/apache/flink/pull/19433#discussion_r859934962


##########
flink-connectors/flink-connector-pulsar/src/main/java/org/apache/flink/connector/pulsar/source/enumerator/subscriber/impl/BasePulsarSubscriber.java:
##########
@@ -63,18 +63,15 @@ protected List<TopicPartition> toTopicPartitions(
                     .map(range -> new TopicPartition(metadata.getName(), -1, range))
                     .collect(toList());
         } else {
-            return IntStream.range(0, metadata.getPartitionSize())
-                    .boxed()
-                    .flatMap(
-                            partitionId ->
-                                    ranges.stream()
-                                            .map(
-                                                    range ->
-                                                            new TopicPartition(
-                                                                    metadata.getName(),
-                                                                    partitionId,
-                                                                    range)))
-                    .collect(toList());
+            List<TopicPartition> partitions = new ArrayList<>();

Review Comment:
   Nit: Why did you change using the stream API to the manual loop?



##########
flink-connectors/flink-connector-pulsar/src/test/resources/containers/txnStandalone.conf:
##########
@@ -14,8 +14,7 @@
 
 ### --- General broker settings --- ###
 
-# Zookeeper quorum connection string
-zookeeperServers=
+# Zookeeper quorum connection stringzookeeperServers=

Review Comment:
   I did not find this change in the original PR, and it looks suspicious.



-- 
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: issues-unsubscribe@flink.apache.org

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


[GitHub] [flink] syhily commented on a diff in pull request #19433: [BK-1.14][FLINK-26645][Connector/pulsar] Support subscribe only one topic partition/

Posted by GitBox <gi...@apache.org>.
syhily commented on code in PR #19433:
URL: https://github.com/apache/flink/pull/19433#discussion_r861027392


##########
flink-connectors/flink-connector-pulsar/src/main/java/org/apache/flink/connector/pulsar/source/enumerator/subscriber/impl/BasePulsarSubscriber.java:
##########
@@ -63,18 +63,15 @@ protected List<TopicPartition> toTopicPartitions(
                     .map(range -> new TopicPartition(metadata.getName(), -1, range))
                     .collect(toList());
         } else {
-            return IntStream.range(0, metadata.getPartitionSize())
-                    .boxed()
-                    .flatMap(
-                            partitionId ->
-                                    ranges.stream()
-                                            .map(
-                                                    range ->
-                                                            new TopicPartition(
-                                                                    metadata.getName(),
-                                                                    partitionId,
-                                                                    range)))
-                    .collect(toList());
+            List<TopicPartition> partitions = new ArrayList<>();

Review Comment:
   This would make the code more readable because the lambda has been formatted in an ugly style.



-- 
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: issues-unsubscribe@flink.apache.org

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