You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@paimon.apache.org by "zhengshubin (via GitHub)" <gi...@apache.org> on 2023/04/10 05:34:34 UTC

[GitHub] [incubator-paimon] zhengshubin opened a new issue, #860: [Bug] CDC Ingestion mysql DATETIME(6) cast error.

zhengshubin opened a new issue, #860:
URL: https://github.com/apache/incubator-paimon/issues/860

   ### Search before asking
   
   - [X] I searched in the [issues](https://github.com/apache/incubator-paimon/issues) and found nothing similar.
   
   
   ### Paimon version
   
   0.4-SNAPSHOT
   
   ### Compute Engine
   
   flink 1.16  
   paimon 0.1-SNAPSHOT  
   mysql 8
   
   ### Minimal reproduce step
   
         MySqlSyncTableAction mySqlSyncTableAction = (MySqlSyncTableAction) action.get();
               StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
               env.setParallelism(4);
               env.enableCheckpointing(10000);
               env.setStateBackend(new HashMapStateBackend());
   
               mySqlSyncTableAction.build(env);
               env.execute(String.format("MySQL-Paimon Table Sync: %s.%s","flink","cdc_test"));
   
   ### What doesn't meet your expectations?
   
   
   java.time.format.DateTimeParseException: Text '1649549400000000' could not be parsed at index 0
   	at java.time.format.DateTimeFormatter.parseResolved0(DateTimeFormatter.java:1949)
   	at java.time.format.DateTimeFormatter.parse(DateTimeFormatter.java:1777)
   	at org.apache.paimon.utils.DateTimeUtils.parseTimestampData(DateTimeUtils.java:382)
   	at org.apache.paimon.utils.TypeUtils.toTimestamp(TypeUtils.java:166)
   	at org.apache.paimon.utils.TypeUtils.castFromString(TypeUtils.java:117)
   	at org.apache.paimon.flink.sink.cdc.CdcRecord.toGenericRow(CdcRecord.java:119)
   	at org.apache.paimon.flink.sink.cdc.SchemaAwareStoreWriteOperator.processRecord(SchemaAwareStoreWriteOperator.java:74)
   	at org.apache.paimon.flink.sink.cdc.SchemaAwareStoreWriteOperator.processRecord(SchemaAwareStoreWriteOperator.java:45)
   	at org.apache.paimon.flink.sink.AbstractStoreWriteOperator.processElement(AbstractStoreWriteOperator.java:123)
   
   ### Anything else?
   
   _No response_
   
   ### Are you willing to submit a PR?
   
   - [ ] 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: issues-unsubscribe@paimon.apache.org.apache.org

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


[GitHub] [incubator-paimon] JingsongLi commented on issue #860: [Bug] CDC Ingestion mysql DATETIME(6) cast error.

Posted by "JingsongLi (via GitHub)" <gi...@apache.org>.
JingsongLi commented on issue #860:
URL: https://github.com/apache/incubator-paimon/issues/860#issuecomment-1508163657

   Thanks @zhengshubin ! Fixing is on the road!


-- 
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@paimon.apache.org

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


[GitHub] [incubator-paimon] JingsongLi commented on issue #860: [Bug] CDC Ingestion mysql DATETIME(6) cast error.

Posted by "JingsongLi (via GitHub)" <gi...@apache.org>.
JingsongLi commented on issue #860:
URL: https://github.com/apache/incubator-paimon/issues/860#issuecomment-1501433281

   CC @tsreaper 


-- 
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@paimon.apache.org

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


[GitHub] [incubator-paimon] zhengshubin commented on issue #860: [Bug] CDC Ingestion mysql DATETIME(6) cast error.

Posted by "zhengshubin (via GitHub)" <gi...@apache.org>.
zhengshubin commented on issue #860:
URL: https://github.com/apache/incubator-paimon/issues/860#issuecomment-1501467119

   If mysql  type is DATETIME(3) , it  also make error:
   Exception in thread "main" java.time.format.DateTimeParseException: Text '2022-04-10 08:10' could not be parsed, unparsed text found at index 10
   	at java.time.format.DateTimeFormatter.parseResolved0(DateTimeFormatter.java:1952)
   	at java.time.format.DateTimeFormatter.parse(DateTimeFormatter.java:1777)
   	at org.apache.paimon.utils.DateTimeUtils.parseTimestampData(DateTimeUtils.java:382)
   	at com.zsb.flink16.Event.main(Event.java:35)
   


-- 
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@paimon.apache.org

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


[GitHub] [incubator-paimon] JingsongLi closed issue #860: [Bug] CDC Ingestion mysql DATETIME(6) cast error.

Posted by "JingsongLi (via GitHub)" <gi...@apache.org>.
JingsongLi closed issue #860: [Bug]  CDC Ingestion   mysql  DATETIME(6) cast  error.
URL: https://github.com/apache/incubator-paimon/issues/860


-- 
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@paimon.apache.org

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