You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by "amin224 (via GitHub)" <gi...@apache.org> on 2023/08/14 08:53:13 UTC

[GitHub] [pulsar] amin224 opened a new issue, #20986: [Bug] Pulsar Source Connector to Postgresql

amin224 opened a new issue, #20986:
URL: https://github.com/apache/pulsar/issues/20986

   ### Search before asking
   
   - [X] I searched in the [issues](https://github.com/apache/pulsar/issues) and found nothing similar.
   
   
   ### Version
   
   OS: Ubtunu 22.04
   Pulsar version: apachepulsar/v3.0.1
   
   ### Minimal reproduce step
   
   I have a running docker container of Pulsar and I am trying to create a source connector to my local machine Postgresql database, but i am getting exceptions.
   
   Note: I made sure I can ping to my local machine from docker container, in addition, telnet to port 5432 and there was **successful connection**.
   
   Steps to reproduce:
   
   
   1. `docker run -it --network host -p 6650:6650 -p 8080:8080 apachepulsar/pulsar-all:3.0.1 bin/pulsar standalone`
   2. `bin/pulsar-admin topics create persistent://public/default/my-topic`
   3. `bin/pulsar-admin schemas upload persistent://public/default/my-topic -f ./connectors/avro-schema2.avsc`
   4. bin/pulsar-admin source create  \
   --source-config-file ./connectors/pulsar-postgres-jdbc-source2.yaml
   
   avro-schema2.avsc:
   ```
   {
     "type": "AVRO",
     "schema": "{\"type\":\"record\",\"name\":\"PulsarPostgresData\",\"fields\":[{\"name\":\"id\",\"type\":[\"null\",\"int\"]},{\"name\":\"name\",\"type\":[\"null\",\"string\"]}]}",
     "properties": {}
   }
   ```
   
   
   pulsar-postgres-jdbc-source.yaml
   ```
   tenant: "public"
   namespace: "default"
   name: "debezium-postgres-source"
   destination-topic-name: "my-topic"
   archive: "connectors/pulsar-io-debezium-postgres-3.0.1.nar"
   parallelism: 1
   
   configs:
     database.hostname: "{MY MACHINE IP}"
     database.port: "5432"
     database.user: "postgres"
     database.password: "{mypassword}"
     database.dbname: "postgres"
     database.server.name: "postgres"
     plugin.name: "pgoutput"
     schema.whitelist: "public"
     table.whitelist: "public.pulsar_postgres_jdbc_sink"
     database.history.pulsar.service.url: "pulsar://127.0.0.1:6650"
   ```
   
   
   
   ### What did you expect to see?
   
   I expected the source connector to be running and extracting data from my database, here is how i created a table and inserted random data:
   
   ```
   create table if not exists pulsar_postgres_jdbc_sink
   (
   id serial PRIMARY KEY,
   name VARCHAR(255) NOT NULL
   );
   ```
   
   
   ```
   INSERT INTO pulsar_postgres_jdbc_sink (name)
   VALUES
       ('Alice'),
       ('Bob'),
       ('Charlie'),
       ('David'),
       ('Eve'),
       ('Frank'),
       ('Grace'),
       ('Helen'),
       ('Ivy'),
       ('Jack');
   ```
   
   ### What did you see instead?
   
   ```
   bin/pulsar-admin sources status \
   >   --tenant public \
   >   --namespace default \
   >   --name debezium-postgres-source
   {
     "numInstances" : 1,
     "numRunning" : 0,
     "instances" : [ {
       "instanceId" : 0,
       "status" : {
         "running" : false,
         "error" : "UNAVAILABLE: io exception",
         "numRestarts" : 0,
         "numReceivedFromSource" : 0,
         "numSystemExceptions" : 0,
         "latestSystemExceptions" : [ ],
         "numSourceExceptions" : 0,
         "latestSourceExceptions" : [ ],
         "numWritten" : 0,
         "lastReceivedTime" : 0,
         "workerId" : "c-standalone-fw-localhost-8080"
       }
     } ]
   }
   ```
   
   ```
   2023-08-11T10:25:14,611+0000 [function-timer-thread-86-1] ERROR org.apache.pulsar.functions.runtime.process.ProcessRuntime - Health check failed for debezium-postgres-source-0
   java.util.concurrent.ExecutionException: io.grpc.StatusRuntimeException: UNAVAILABLE: io exception
   	at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:395) ~[?:?]
   	at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1999) ~[?:?]
   	at org.apache.pulsar.functions.runtime.process.ProcessRuntime.lambda$start$1(ProcessRuntime.java:186) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515) [?:?]
   	at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305) [?:?]
   	at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305) [?:?]
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) [?:?]
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) [?:?]
   	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) [io.netty-netty-common-4.1.68.Final.jar:4.1.68.Final]
   	at java.lang.Thread.run(Thread.java:829) [?:?]
   Caused by: io.grpc.StatusRuntimeException: UNAVAILABLE: io exception
   	at io.grpc.Status.asRuntimeException(Status.java:533) ~[io.grpc-grpc-api-1.33.0.jar:1.33.0]
   	at io.grpc.stub.ClientCalls$UnaryStreamToFuture.onClose(ClientCalls.java:533) ~[io.grpc-grpc-stub-1.33.0.jar:1.33.0]
   	at io.grpc.internal.ClientCallImpl.closeObserver(ClientCallImpl.java:616) ~[io.grpc-grpc-core-1.33.0.jar:1.33.0]
   	at io.grpc.internal.ClientCallImpl.access$300(ClientCallImpl.java:69) ~[io.grpc-grpc-core-1.33.0.jar:1.33.0]
   	at io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1StreamClosed.runInternal(ClientCallImpl.java:802) ~[io.grpc-grpc-core-1.33.0.jar:1.33.0]
   	at io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1StreamClosed.runInContext(ClientCallImpl.java:781) ~[io.grpc-grpc-core-1.33.0.jar:1.33.0]
   	at io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37) ~[io.grpc-grpc-core-1.33.0.jar:1.33.0]
   	at io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123) ~[io.grpc-grpc-core-1.33.0.jar:1.33.0]
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) ~[?:?]
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) ~[?:?]
   	... 1 more
   Caused by: io.grpc.netty.shaded.io.netty.channel.AbstractChannel$AnnotatedConnectException: finishConnect(..) failed: Connection refused: /127.0.0.1:42355
   Caused by: java.net.ConnectException: finishConnect(..) failed: Connection refused
   	at io.grpc.netty.shaded.io.netty.channel.unix.Errors.throwConnectException(Errors.java:124) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.channel.unix.Socket.finishConnect(Socket.java:243) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.channel.epoll.AbstractEpollChannel$AbstractEpollUnsafe.doFinishConnect(AbstractEpollChannel.java:672) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.channel.epoll.AbstractEpollChannel$AbstractEpollUnsafe.finishConnect(AbstractEpollChannel.java:649) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.channel.epoll.AbstractEpollChannel$AbstractEpollUnsafe.epollOutReady(AbstractEpollChannel.java:529) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.channel.epoll.EpollEventLoop.processReady(EpollEventLoop.java:465) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.channel.epoll.EpollEventLoop.run(EpollEventLoop.java:378) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:989) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	at io.grpc.netty.shaded.io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) ~[io.grpc-grpc-netty-shaded-1.33.0.jar:1.33.0]
   	... 1 more
   2023-08-11T10:25:14,615+0000 [function-timer-thread-86-1] ERROR org.apache.pulsar.functions.runtime.process.ProcessRuntime - Extracted Process death exception
   java.lang.RuntimeException: 
   	at org.apache.pulsar.functions.runtime.process.ProcessRuntime.tryExtractingDeathException(ProcessRuntime.java:402) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at org.apache.pulsar.functions.runtime.process.ProcessRuntime.isAlive(ProcessRuntime.java:389) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at org.apache.pulsar.functions.runtime.RuntimeSpawner.lambda$start$0(RuntimeSpawner.java:86) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515) [?:?]
   	at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305) [?:?]
   	at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305) [?:?]
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) [?:?]
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) [?:?]
   	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) [io.netty-netty-common-4.1.68.Final.jar:4.1.68.Final]
   	at java.lang.Thread.run(Thread.java:829) [?:?]
   2023-08-11T10:25:14,616+0000 [function-timer-thread-86-1] ERROR org.apache.pulsar.functions.runtime.RuntimeSpawner - public/default/debezium-postgres-source Function Container is dead with following exception. Restarting.
   java.lang.RuntimeException: 
   	at org.apache.pulsar.functions.runtime.process.ProcessRuntime.tryExtractingDeathException(ProcessRuntime.java:402) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at org.apache.pulsar.functions.runtime.process.ProcessRuntime.isAlive(ProcessRuntime.java:389) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at org.apache.pulsar.functions.runtime.RuntimeSpawner.lambda$start$0(RuntimeSpawner.java:86) ~[org.apache.pulsar-pulsar-functions-runtime-2.9.0.jar:2.9.0]
   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515) [?:?]
   	at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305) [?:?]
   	at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305) [?:?]
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) [?:?]
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) [?:?]
   	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) [io.netty-netty-common-4.1.68.Final.jar:4.1.68.Final]
   	at java.lang.Thread.run(Thread.java:829) [?:?]
   ```
   
   ### Anything else?
   
   _No response_
   
   ### Are you willing to submit a PR?
   
   - [X] I'm willing to submit a PR!


-- 
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: commits-unsubscribe@pulsar.apache.org.apache.org

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


[GitHub] [pulsar] amin224 commented on issue #20986: [Bug] Pulsar Source Connector to Postgresql

Posted by "amin224 (via GitHub)" <gi...@apache.org>.
amin224 commented on issue #20986:
URL: https://github.com/apache/pulsar/issues/20986#issuecomment-1688120852

   While running the source using localrun i got these exceptions instead:
   
   ```
   2023-08-22T12:46:50,931+0000 [function-timer-thread-28-1] ERROR org.apache.pulsar.functions.runtime.RuntimeSpawner - public/default/postgres-source Function Container is dead with following exception. Restarting.
   io.debezium.DebeziumException: Couldn't obtain encoding for database postgres
   	at io.debezium.connector.postgresql.connection.PostgresConnection.getDatabaseCharset(PostgresConnection.java:487) ~[?:?]
   	at io.debezium.connector.postgresql.PostgresConnectorTask.start(PostgresConnectorTask.java:75) ~[?:?]
   	at io.debezium.connector.common.BaseSourceTask.start(BaseSourceTask.java:133) ~[?:?]
   	at org.apache.pulsar.io.kafka.connect.AbstractKafkaConnectSource.open(AbstractKafkaConnectSource.java:162) ~[?:?]
   	at org.apache.pulsar.io.kafka.connect.KafkaConnectSource.open(KafkaConnectSource.java:63) ~[?:?]
   	at org.apache.pulsar.io.debezium.DebeziumSource.open(DebeziumSource.java:114) ~[?:?]
   	at org.apache.pulsar.functions.instance.JavaInstanceRunnable.setupInput(JavaInstanceRunnable.java:858) ~[org.apache.pulsar-pulsar-functions-instance-3.0.1.jar:3.0.1]
   	at org.apache.pulsar.functions.instance.JavaInstanceRunnable.setup(JavaInstanceRunnable.java:253) ~[org.apache.pulsar-pulsar-functions-instance-3.0.1.jar:3.0.1]
   	at org.apache.pulsar.functions.instance.JavaInstanceRunnable.run(JavaInstanceRunnable.java:290) ~[org.apache.pulsar-pulsar-functions-instance-3.0.1.jar:3.0.1]
   	at java.lang.Thread.run(Thread.java:833) ~[?:?]
   Caused by: org.postgresql.util.PSQLException: Connection to localhost:5432 refused. Check that the hostname and port are correct and that the postmaster is accepting TCP/IP connections.
   	at org.postgresql.core.v3.ConnectionFactoryImpl.openConnectionImpl(ConnectionFactoryImpl.java:319) ~[?:?]
   	at org.postgresql.core.ConnectionFactory.openConnection(ConnectionFactory.java:49) ~[?:?]
   	at org.postgresql.jdbc.PgConnection.<init>(PgConnection.java:247) ~[?:?]
   	at org.postgresql.Driver.makeConnection(Driver.java:434) ~[?:?]
   	at org.postgresql.Driver.connect(Driver.java:291) ~[?:?]
   	at io.debezium.jdbc.JdbcConnection.lambda$patternBasedFactory$1(JdbcConnection.java:244) ~[?:?]
   	at io.debezium.jdbc.JdbcConnection.connection(JdbcConnection.java:888) ~[?:?]
   	at io.debezium.jdbc.JdbcConnection.connection(JdbcConnection.java:883) ~[?:?]
   	at io.debezium.connector.postgresql.connection.PostgresConnection.getDatabaseCharset(PostgresConnection.java:484) ~[?:?]
   	... 9 more
   Caused by: java.net.ConnectException: Connection refused
   	at sun.nio.ch.Net.pollConnect(Native Method) ~[?:?]
   	at sun.nio.ch.Net.pollConnectNow(Net.java:672) ~[?:?]
   	at sun.nio.ch.NioSocketImpl.timedFinishConnect(NioSocketImpl.java:542) ~[?:?]
   	at sun.nio.ch.NioSocketImpl.connect(NioSocketImpl.java:597) ~[?:?]
   	at java.net.SocksSocketImpl.connect(SocksSocketImpl.java:327) ~[?:?]
   	at java.net.Socket.connect(Socket.java:633) ~[?:?]
   	at org.postgresql.core.PGStream.createSocket(PGStream.java:241) ~[?:?]
   	at org.postgresql.core.PGStream.<init>(PGStream.java:98) ~[?:?]
   	at org.postgresql.core.v3.ConnectionFactoryImpl.tryConnect(ConnectionFactoryImpl.java:109) ~[?:?]
   	at org.postgresql.core.v3.ConnectionFactoryImpl.openConnectionImpl(ConnectionFactoryImpl.java:235) ~[?:?]
   	at org.postgresql.core.ConnectionFactory.openConnection(ConnectionFactory.java:49) ~[?:?]
   	at org.postgresql.jdbc.PgConnection.<init>(PgConnection.java:247) ~[?:?]
   	at org.postgresql.Driver.makeConnection(Driver.java:434) ~[?:?]
   	at org.postgresql.Driver.connect(Driver.java:291) ~[?:?]
   	at io.debezium.jdbc.JdbcConnection.lambda$patternBasedFactory$1(JdbcConnection.java:244) ~[?:?]
   	at io.debezium.jdbc.JdbcConnection.connection(JdbcConnection.java:888) ~[?:?]
   	at io.debezium.jdbc.JdbcConnection.connection(JdbcConnection.java:883) ~[?:?]
   	at io.debezium.connector.postgresql.connection.PostgresConnection.getDatabaseCharset(PostgresConnection.java:484) ~[?:?]
   	... 9 more
   
   ```


-- 
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: commits-unsubscribe@pulsar.apache.org

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


[GitHub] [pulsar] michaeljmarshall commented on issue #20986: [Bug] Pulsar Source Connector to Postgresql

Posted by "michaeljmarshall (via GitHub)" <gi...@apache.org>.
michaeljmarshall commented on issue #20986:
URL: https://github.com/apache/pulsar/issues/20986#issuecomment-1679372049

   @amin224 - can you find the function's log? That will likely have the details necessary to troubleshoot this issue.


-- 
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: commits-unsubscribe@pulsar.apache.org

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


[GitHub] [pulsar] amin224 commented on issue #20986: [Bug] Pulsar Source Connector to Postgresql

Posted by "amin224 (via GitHub)" <gi...@apache.org>.
amin224 commented on issue #20986:
URL: https://github.com/apache/pulsar/issues/20986#issuecomment-1688236814

   After changing the wal_level = logical in postgresql.conf file the source is running and no exceptions


-- 
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: commits-unsubscribe@pulsar.apache.org

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


[GitHub] [pulsar] amin224 commented on issue #20986: [Bug] Pulsar Source Connector to Postgresql

Posted by "amin224 (via GitHub)" <gi...@apache.org>.
amin224 commented on issue #20986:
URL: https://github.com/apache/pulsar/issues/20986#issuecomment-1688066571

   Hello,
   
   After creating a function to catch the exception logs I noticed these exceptions related to the schema. Do I have to change the schema structure as it is similar to the table structure on my Postgresql.
   
   ```
   using schema:
   "string"","reqId":1143092456697760356, "remote":"localhost/127.0.0.1:6650", "local":"/127.0.0.1:39028"}
   	at java.util.concurrent.CompletableFuture.encodeThrowable(CompletableFuture.java:332) ~[?:?]
   	at java.util.concurrent.CompletableFuture.completeThrowable(CompletableFuture.java:347) ~[?:?]
   	at java.util.concurrent.CompletableFuture$UniRun.tryFire(CompletableFuture.java:781) ~[?:?]
   	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:510) ~[?:?]
   	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:2162) ~[?:?]
   	at org.apache.pulsar.client.impl.ClientCnx.handleError(ClientCnx.java:792) ~[org.apache.pulsar-pulsar-client-original-3.0.1.jar:3.0.1]
   	at org.apache.pulsar.common.protocol.PulsarDecoder.channelRead(PulsarDecoder.java:192) ~[org.apache.pulsar-pulsar-common-3.0.1.jar:3.0.1]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:444) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:420) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:412) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.handler.codec.ByteToMessageDecoder.fireChannelRead(ByteToMessageDecoder.java:346) ~[io.netty-netty-codec-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.handler.codec.ByteToMessageDecoder.channelRead(ByteToMessageDecoder.java:318) ~[io.netty-netty-codec-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:444) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:420) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:412) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.handler.flush.FlushConsolidationHandler.channelRead(FlushConsolidationHandler.java:152) ~[io.netty-netty-handler-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:442) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:420) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:412) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.DefaultChannelPipeline$HeadContext.channelRead(DefaultChannelPipeline.java:1410) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:440) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:420) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.DefaultChannelPipeline.fireChannelRead(DefaultChannelPipeline.java:919) ~[io.netty-netty-transport-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.epoll.AbstractEpollStreamChannel$EpollStreamUnsafe.epollInReady(AbstractEpollStreamChannel.java:800) ~[io.netty-netty-transport-classes-epoll-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.epoll.EpollEventLoop.processReady(EpollEventLoop.java:499) ~[io.netty-netty-transport-classes-epoll-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.channel.epoll.EpollEventLoop.run(EpollEventLoop.java:397) ~[io.netty-netty-transport-classes-epoll-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:997) ~[io.netty-netty-common-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74) ~[io.netty-netty-common-4.1.93.Final.jar:4.1.93.Final]
   	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) ~[io.netty-netty-common-4.1.93.Final.jar:4.1.93.Final]
   	at java.lang.Thread.run(Thread.java:833) ~[?:?]
   Caused by: org.apache.pulsar.client.api.PulsarClientException$IncompatibleSchemaException: {"errorMsg":"org.apache.avro.SchemaValidationException: Unable to read schema: 
   {
     "type" : "record",
     "name" : "PulsarPostgresData",
     "fields" : [ {
       "name" : "id",
       "type" : [ "null", "int" ]
     }, {
       "name" : "name",
       "type" : [ "null", "string" ]
     } ]
   }
   
   ```


-- 
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: commits-unsubscribe@pulsar.apache.org

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


[GitHub] [pulsar] amin224 closed issue #20986: [Bug] Pulsar Source Connector to Postgresql

Posted by "amin224 (via GitHub)" <gi...@apache.org>.
amin224 closed issue #20986: [Bug] Pulsar Source Connector to Postgresql
URL: https://github.com/apache/pulsar/issues/20986


-- 
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: commits-unsubscribe@pulsar.apache.org

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