Skip to content

Commit

Permalink
[FLINK-32031] Flink GCP Connector having issues with Conscrypt library
Browse files Browse the repository at this point in the history
  • Loading branch information
jayadeep-jayaraman authored and MartijnVisser committed Jul 3, 2023
1 parent d7ed02b commit 4fdaca7
Show file tree
Hide file tree
Showing 4 changed files with 117 additions and 2 deletions.
28 changes: 28 additions & 0 deletions .idea/vcs.xml

Some generated files are not rendered by default. Learn more about how customized files appear on GitHub.

Original file line number Diff line number Diff line change
Expand Up @@ -94,7 +94,7 @@ public void deleteTopic(TopicName topicName) throws IOException {
LOG.info("DeleteTopic {} first delete old subscriptions.", topicName);
adminClient
.listTopicSubscriptions(topicName)
.iterateAllAsProjectSubscriptionName()
.iterateAll()
.forEach(subscriptionAdminClient::deleteSubscription);
LOG.info("DeleteTopic {}", topicName);
adminClient.deleteTopic(topicName);
Expand Down
87 changes: 87 additions & 0 deletions flink-connector-gcp-pubsub/pom.xml
Original file line number Diff line number Diff line change
Expand Up @@ -76,6 +76,93 @@ under the License.
<scope>test</scope>
</dependency>

<dependency>
<groupId>io.grpc</groupId>
<artifactId>grpc-auth</artifactId>
<!-- Version is pulled from google-cloud-bom (loaded via the libraries-bom) -->
</dependency>

<dependency>
<groupId>io.grpc</groupId>
<artifactId>grpc-netty</artifactId>
<!-- Version is pulled from google-cloud-bom (loaded via the libraries-bom) -->
</dependency>

<!-- For dependency convergence -->
<dependency>
<groupId>com.google.cloud</groupId>
<artifactId>google-cloud-core</artifactId>
<exclusions>
<exclusion>
<groupId>com.google.api</groupId>
<artifactId>gax</artifactId>
</exclusion>
<exclusion>
<groupId>com.google.guava</groupId>
<artifactId>guava</artifactId>
</exclusion>
<exclusion>
<groupId>com.google.http-client</groupId>
<artifactId>google-http-client</artifactId>
</exclusion>
</exclusions>
</dependency>
<!-- For dependency convergence -->
<dependency>
<groupId>com.google.api</groupId>
<artifactId>gax</artifactId>
<version>2.18.7</version>
<exclusions>
<exclusion>
<groupId>io.opencensus</groupId>
<artifactId>opencensus-api</artifactId>
</exclusion>
</exclusions>
</dependency>
<!-- For dependency convergence -->
<dependency>
<groupId>com.google.guava</groupId>
<artifactId>guava</artifactId>
<version>31.1-jre</version>
<exclusions>
<exclusion>
<groupId>org.checkerframework</groupId>
<artifactId>checker-qual</artifactId>
</exclusion>
</exclusions>
</dependency>

<!-- For dependency convergence -->
<dependency>
<groupId>com.google.http-client</groupId>
<artifactId>google-http-client</artifactId>
<version>1.42.2</version>
<exclusions>
<exclusion>
<groupId>org.apache.httpcomponents</groupId>
<artifactId>httpclient</artifactId>
</exclusion>
</exclusions>
</dependency>

<!-- For dependency convergence -->
<dependency>
<groupId>org.apache.httpcomponents</groupId>
<artifactId>httpclient</artifactId>
<version>4.5.13</version>
<exclusions>
<exclusion>
<groupId>org.apache.httpcomponents</groupId>
<artifactId>httpcore</artifactId>
</exclusion>
</exclusions>
</dependency>

<dependency>
<groupId>io.grpc</groupId>
<artifactId>grpc-netty-shaded</artifactId>
<!-- Version is pulled from google-cloud-bom (loaded via the libraries-bom) -->
</dependency>
<!-- ArchUit test dependencies -->

<dependency>
Expand Down
2 changes: 1 addition & 1 deletion pom.xml
Original file line number Diff line number Diff line change
Expand Up @@ -50,7 +50,7 @@ under the License.

<properties>
<flink.version>1.17.0</flink.version>
<google-cloud-libraries-bom.version>8.1.0</google-cloud-libraries-bom.version>
<google-cloud-libraries-bom.version>26.1.0</google-cloud-libraries-bom.version>

<junit5.version>5.9.1</junit5.version>
<assertj.version>3.23.1</assertj.version>
Expand Down

0 comments on commit 4fdaca7

Please sign in to comment.