You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@iceberg.apache.org by GitBox <gi...@apache.org> on 2021/05/24 03:38:07 UTC

[GitHub] [iceberg] xwmr-max opened a new issue #2626: Iceberg Upsert: Iceberg 通过Kafka一次性插入多条主键值相同的数据,数据查询不了

xwmr-max opened a new issue #2626:
URL: https://github.com/apache/iceberg/issues/2626


   java.lang.IllegalArgumentException: Row arity: 3, but serializer arity: 2
           at
   org.apache.flink.table.runtime.typeutils.RowDataSerializer.copy(RowDataSerializer.java:117)
           at
   org.apache.flink.table.runtime.typeutils.RowDataSerializer.copy(RowDataSerializer.java:50)
           at
   org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.pushToOperator(OperatorChain.java:715)
           at
   org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:692)
           at
   org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:672)
           at
   org.apache.flink.streaming.api.operators.CountingOutput.collect(CountingOutput.java:52)
           at
   org.apache.flink.streaming.api.operators.CountingOutput.collect(CountingOutput.java:30)
           at
   org.apache.flink.streaming.api.operators.StreamSourceContexts$ManualWatermarkContext.processAndCollect(StreamSourceContexts.java:305)
           at
   org.apache.flink.streaming.api.operators.StreamSourceContexts$WatermarkContext.collect(StreamSourceContexts.java:394)
           at
   org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction.run(InputFormatSourceFunction.java:94)
           at
   org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:100)
           at
   org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:63)
           at
   org.apache.flink.streaming.runtime.tasks.SourceStreamTask$LegacySourceFunctionThread.run(SourceStreamTask.java:201)
   
   这个报错的意思是:原本的数据是两列,表的schema也是两列,但是现在schema已经变成了三列了
   
   但是当主键不同时候,同一批插入多条数据,是可以进行正常查询的,并且也是可以upsert的


-- 
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



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] xwmr-max closed issue #2626: Iceberg Upsert: Iceberg 通过Kafka一次性插入多条主键值相同的数据,数据查询不了

Posted by GitBox <gi...@apache.org>.
xwmr-max closed issue #2626:
URL: https://github.com/apache/iceberg/issues/2626


   


-- 
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



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org