You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@streampipes.apache.org by "Dominik Riemer (Jira)" <ji...@apache.org> on 2022/11/26 13:34:00 UTC

[jira] [Commented] (STREAMPIPES-163) Exception during save in MYSQl Sink with Timestamp value

    [ https://issues.apache.org/jira/browse/STREAMPIPES-163?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=17639049#comment-17639049 ] 

Dominik Riemer commented on STREAMPIPES-163:
--------------------------------------------

This issue has been migrated to https://github.com/apache/streampipes/issues/359

> Exception during save in MYSQl Sink with Timestamp value
> --------------------------------------------------------
>
>                 Key: STREAMPIPES-163
>                 URL: https://issues.apache.org/jira/browse/STREAMPIPES-163
>             Project: StreamPipes
>          Issue Type: Bug
>            Reporter: Florian Micklich
>            Priority: Major
>             Fix For: 0.68.0
>
>
> Starting the mysql sink together with the random adapter 
> the pipeline is starting without errors but throws an exception during save
> {code:java}
> com.mysql.cj.jdbc.exceptions.MysqlDataTruncation: Data truncation: Incorrect datetime value: '1592423739000' for column 'timestamp' at row 1
> 	at com.mysql.cj.jdbc.exceptions.SQLExceptionsMapping.translateException(SQLExceptionsMapping.java:104)
> 	at com.mysql.cj.jdbc.StatementImpl.executeInternal(StatementImpl.java:782)
> 	at com.mysql.cj.jdbc.StatementImpl.execute(StatementImpl.java:666)
> 	at org.apache.streampipes.sinks.databases.jvm.mysql.Mysql.save(Mysql.java:153)
> 	at org.apache.streampipes.sinks.databases.jvm.mysql.Mysql.onEvent(Mysql.java:69)
> 	at org.apache.streampipes.wrapper.standalone.runtime.StandaloneEventSinkRuntime.process(StandaloneEventSinkRuntime.java:50)
> 	at org.apache.streampipes.wrapper.standalone.routing.StandaloneSpInputCollector.send(StandaloneSpInputCollector.java:54)
> 	at org.apache.streampipes.wrapper.standalone.routing.StandaloneSpInputCollector.lambda$onEvent$0(StandaloneSpInputCollector.java:48)
> 	at java.util.concurrent.ConcurrentHashMap.forEach(ConcurrentHashMap.java:1597)
> 	at org.apache.streampipes.wrapper.standalone.routing.StandaloneSpInputCollector.onEvent(StandaloneSpInputCollector.java:48)
> 	at org.apache.streampipes.wrapper.standalone.routing.StandaloneSpInputCollector.onEvent(StandaloneSpInputCollector.java:29)
> 	at org.apache.streampipes.messaging.kafka.SpKafkaConsumer.run(SpKafkaConsumer.java:101)
> 	at java.lang.Thread.run(Thread.java:748)
> {code}
> Validation error but has to be handeled not only in the mysql sink
> In this case using datetime domain and UNIX timestamp has to be transfered in correct way.



--
This message was sent by Atlassian Jira
(v8.20.10#820010)