You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by GitBox <gi...@apache.org> on 2019/10/30 13:26:05 UTC

[GitHub] [pulsar] tuteng commented on issue #5474: Support CDC Connector for MongoDB

tuteng commented on issue #5474: Support CDC Connector for MongoDB
URL: https://github.com/apache/pulsar/issues/5474#issuecomment-547901366
 
 
   Yes, Debezium has already supported MongoDB. That should be easy to add support to Mongo in pulsar-io, you can refer to https://github.com/apache/pulsar/blob/master/pulsar-io/debezium/postgres/src/main/java/org/apache/pulsar/io/debezium/postgres/DebeziumPostgresSource.java
   ```
   package org.apache.pulsar.io.debezium.postgres;
   
   import java.util.Map;
   
   import org.apache.kafka.connect.runtime.TaskConfig;
   import org.apache.pulsar.io.debezium.DebeziumSource;
   
   
   /**
    * A pulsar source that runs debezium postgres source
    */
   public class DebeziumPostgresSource extends DebeziumSource {
       static private final String DEFAULT_TASK = "io.debezium.connector.postgresql.PostgresConnectorTask";
   
       @Override
       public void setDbConnectorTask(Map<String, Object> config) throws Exception {
           throwExceptionIfConfigNotMatch(config, TaskConfig.TASK_CLASS_CONFIG, DEFAULT_TASK);
       }
   }
   ```
   , but we haven't had time to add this recently, if you are interested, you can try 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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services