Uploaded image for project: 'StreamPipes'
  1. StreamPipes
  2. STREAMPIPES-163

Exception during save in MYSQl Sink with Timestamp value

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Fixed
    • None
    • 0.68.0
    • None
    • None

    Description

      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.

      Attachments

        Activity

          People

            Unassigned Unassigned
            micklich Florian Micklich
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: