You signed in with another tab or window. Reload to refresh your session.You signed out in another tab or window. Reload to refresh your session.You switched accounts on another tab or window. Reload to refresh your session.Dismiss alert
2023-08-18 15:49:38,313 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 1 - Preparing
2023-08-18 15:49:38,313 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 2 - Determining captured tables
2023-08-18 15:49:41,525 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 3 - Locking captured tables [TESTDB.LMIS.JC_HWZD]
2023-08-18 15:49:41,556 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 4 - Determining snapshot offset
2023-08-18 15:49:41,608 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 5 - Reading structure of captured tables
2023-08-18 15:49:42,987 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 6 - Persisting schema history
2023-08-18 15:49:43,163 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshot step 7 - Snapshotting data
2023-08-18 15:49:43,163 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Snapshotting contents of 1 tables while still in transaction
2023-08-18 15:49:43,163 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - Exporting data from table 'TESTDB.LMIS.JC_HWZD' (1 of 1 tables)
2023-08-18 15:49:43,163 INFO io.debezium.relational.RelationalSnapshotChangeEventSource [] - For table 'TESTDB.LMIS.JC_HWZD' using select statement: 'SELECT * FROM "LMIS"."JC_HWZD" AS OF SCN 19030388260314'
2023-08-18 15:49:43,341 INFO io.debezium.connector.common.BaseSourceTask [] - 14 records sent during previous 00:00:05.242, last recorded offset: {snapshot=true, scn=19030388260314, snapshot_completed=false}
2023-08-18 15:49:43,342 INFO com.ververica.cdc.debezium.internal.DebeziumChangeFetcher [] - Database snapshot phase can't perform checkpoint, acquired Checkpoint lock.
checkpoint always is IN_PROGRESS
in flink log I get a error
2023-08-18 15:49:36
java.lang.AbstractMethodError
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema$17.convert(RowDataDebeziumDeserializeSchema.java:641)
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema.convertField(RowDataDebeziumDeserializeSchema.java:626)
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema.access$000(RowDataDebeziumDeserializeSchema.java:63)
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema$16.convert(RowDataDebeziumDeserializeSchema.java:611)
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema$17.convert(RowDataDebeziumDeserializeSchema.java:641)
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema.extractAfterRow(RowDataDebeziumDeserializeSchema.java:146)
at com.ververica.cdc.debezium.table.RowDataDebeziumDeserializeSchema.deserialize(RowDataDebeziumDeserializeSchema.java:121)
at com.ververica.cdc.debezium.internal.DebeziumChangeFetcher.handleBatch(DebeziumChangeFetcher.java:229)
at com.ververica.cdc.debezium.internal.DebeziumChangeFetcher.runFetchLoop(DebeziumChangeFetcher.java:151)
at com.ververica.cdc.debezium.DebeziumSourceFunction.run(DebeziumSourceFunction.java:446)
at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:110)
at org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:67)
at org.apache.flink.streaming.runtime.tasks.SourceStreamTask$LegacySourceFunctionThread.run(SourceStreamTask.java:333)
reacted with thumbs up emoji reacted with thumbs down emoji reacted with laugh emoji reacted with hooray emoji reacted with confused emoji reacted with heart emoji reacted with rocket emoji reacted with eyes emoji
-
oracle-cdc 2.2.1
filnk 1.17.1
checkpoint always is IN_PROGRESS
in flink log I get a error
Beta Was this translation helpful? Give feedback.
All reactions