You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@streampipes.apache.org by GitBox <gi...@apache.org> on 2022/11/26 13:33:16 UTC

[GitHub] [streampipes] dominikriemer opened a new issue, #359: Exception during save in MYSQl Sink with Timestamp value

dominikriemer opened a new issue, #359:
URL: https://github.com/apache/streampipes/issues/359

   Starting the mysql sink together with the random adapter 
   the pipeline is starting without errors but throws an exception during save
   
   
   ```
   
   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)
   
   ```
   
   
   
   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.
   
   
   
   Imported from Jira [STREAMPIPES-163](https://issues.apache.org/jira/browse/STREAMPIPES-163). Original Jira may contain additional context.
   Reported by: micklich.


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

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


[GitHub] [streampipes] dominikriemer closed issue #359: Exception during save in MYSQl Sink with Timestamp value

Posted by GitBox <gi...@apache.org>.
dominikriemer closed issue #359: Exception during save in MYSQl Sink with Timestamp value
URL: https://github.com/apache/streampipes/issues/359


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

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