Details
-
Improvement
-
Status: Closed
-
Major
-
Resolution: Fixed
-
None
Description
While working on a project that uses the PubSub connector I found that Google has changed some methods in their API in such a way that it is no longer backwards compatible while doing local unit tests.
I got this error when using their 0.130.0 BOM dependency in my project:
12:10:14,774 [INFO ] ExecutionGraph : 1554: Source: Custom Source -> Map -> Sink: Unnamed (4/8) (5207874dfde44474a75867cfe8353190) switched from RUNNING to FAILED. java.lang.NoSuchMethodError: io.grpc.ManagedChannelBuilder.usePlaintext(Z)Lio/grpc/ManagedChannelBuilder; at org.apache.flink.streaming.connectors.gcp.pubsub.PubSubSink.open(PubSubSink.java:104) at org.apache.flink.api.common.functions.util.FunctionUtils.openFunction(FunctionUtils.java:36) at org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator.open(AbstractUdfStreamOperator.java:102) at org.apache.flink.streaming.api.operators.StreamSink.open(StreamSink.java:48) at org.apache.flink.streaming.runtime.tasks.StreamTask.initializeStateAndOpen(StreamTask.java:990) at org.apache.flink.streaming.runtime.tasks.StreamTask.lambda$beforeInvoke$0(StreamTask.java:453) at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$SynchronizedStreamTaskActionExecutor.runThrowing(StreamTaskActionExecutor.java:94) at org.apache.flink.streaming.runtime.tasks.StreamTask.beforeInvoke(StreamTask.java:448) at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:460) at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:708) at org.apache.flink.runtime.taskmanager.Task.run(Task.java:533) at java.lang.Thread.run(Thread.java:748)
Attachments
Issue Links
- links to