Skip to content

Releases: apache/flink-cdc

Release-2.2.1

26 Apr 12:42
Compare
Choose a tag to compare

Release Notes

Improvements and Bug fixes

  1. [docs] Update the dependencies version used in docs to 2.2.0
  2. [hotfix][docs] Fix jar link for PolarDB-X docs (#1013)
  3. [docs] Add example for Scan Newly Added tables feature (#1016)
  4. [hotfix][docs] Fix misspell of docs title
  5. [docs][mysql] Add note to make the tableList usage and dependencies clearer (#1037)
  6. [docs] Update the supported sink vendors
  7. [sqlserver] Add more supported(tested) SqlServer versions (#1049)
  8. [oceanbase] Remove useless dependency and code of test (#1046)
  9. [docs][mysql] Fix connector document link error (#1043)
  10. [mysql] Serialize isSuspended flag for MySqlBinlogSplit (#1055)
  11. [common] Apply filter on ResolvedSchema to keep physical columns only (#1097)
  12. [docs][mongodb] Update document about MongoDB database and collection regex filter (#1090)
  13. [mysql] Throw RuntimeException timely in snapshot scan phase (#1099)
  14. [hotfix][tidb] Fix RowKind.INSERT judgement condition (#1104)
  15. [mysql] Catch and hold exception in chunk splitter thread and rethrow in getNext() (#1110)
  16. [mysql] Use the gtid set firstly when compare the binlog offset (#1111)
  17. [mysql] Add heartbeatInterval field to equals() and hashCode() (#1118)

Download

Documentation

Release-2.2.0

27 Mar 13:28
Compare
Choose a tag to compare

Release Notes

Documentation: https://ververica.github.io/flink-cdc-connectors/release-2.2/

Features and Improvements

  1. [docs] Update the supported database vendors and improve the notes.
  2. [docs][mysql][polardbx] Add polardbx tutorials (#1003)
  3. [docs][mysql] Remove redundant docker environment variable in tutorials (#1005)
  4. [cdc-base] Add MySQL Incremental Source to validate the Incremental Snapshot Framework(#776)
  5. [cdc-base] Improve the Incremental Snapshot Interfaces
  6. [cdc-base] The first version of Incremental Snapshot Framework abstraction
  7. [hotfix][docs] Fix markdown title due to typo in readme
  8. [oceanbase] Bump the oblogclient version to 1.0.3 to fix the NPE in oblogclient connection (#998)
  9. [docs] Clarify ownership to comply with ASF trademark policies (#1000)
  10. [build] Decrease the azure job timeout to reasonable 40 minutes (#991)
  11. [hotfix][site] Use Flink with its trademark
  12. [docs] Adopt the full name 'Apache Flink' with its trademark notice (#988)
  13. [hotfix][docs] Update the copyright
  14. [docs][mysql] Correct the jdbc driver version in documentation
  15. [docs] Organize the connector docs in alphabetical order
  16. [docs][tidb] Add tidb cdc connector document
  17. [hotfix][docs] Fix typo in tidb-tutorial.md and tidb-tutorial-zh.md
  18. [mysql] Suspend SourceReader eagerly to reduce restoration time
  19. [docs][oceanbase] Add quickstart tutorials for OceanBase CDC connector
  20. [docs][oceanbase] Add docs for OceanBase CDC connector
  21. [build][oceanbase] Use self-hosted agent for oceanbase cdc tests
  22. [oceanbase] Add OceanBase CDC connector
  23. [tidb] remove useless code.
  24. [test][e2e] Use single fork in tests
  25. [test][e2e] Clean up database resources for every e2e tests.
  26. [e2e] bump flink e2e test version.
  27. [tidb] Add tidb cdc connector e2e test.
  28. [tidb] Add flink1.14 support.
  29. [hotfix][mysql] Avoid schema isn't known error when scanNewlyAddedTable enabled (#965)
  30. [mysql][polardbx] Remove debug print code in PolardbxSourceTCase (#968)
  31. [tidb] Introduce runtime converter to improve the deserialization
  32. [tidb][test] Add timezone tests for tidb
  33. [tidb] Remove useless config options
  34. [docs][site] Add favicon fot website index html
  35. [docs][site] Introduce static index html for the project website (#961)
  36. [mysql] Split snapshot chunks asynchronously (#931)
  37. [docs][tidb] Add index for tidb tutorial docs
  38. [tidb][docs] Add tidb connector tutorial (#938)
  39. [tidb] Add metadata column ITCase and improve the code style
  40. [tidb][test] Fix tikv port conflicts
  41. [tidb] Support metadata column
  42. [tidb][test] Add tidb pipeline in azure CI
  43. [tidb][test] Add TiDBTableSourceFactoryTest and TiDBConnectorITCase
  44. [tidb] Fix tikv.pd.addresses not work and use ResolvedSchema instead of TableSchema.
  45. [tidb] Bump tikv client version to v3.2.0
  46. [tidb] The first draft of tidb cdc connector
  47. [docs] List supported databases in docs (#954)
  48. [mysql] Fallback to build schema by 'desc table' case when parsing DDL failure (#949)
  49. [docs] Fix download url in mongodb tutorial (#951)
  50. [docs] Update DingTalk QR code to English version (#950)
  51. [mongodb] Match multiple database and collection names using a regular expression in MongoDB. (#940)
  52. [mysql] Allow custom JDBC URL parameters in MySQL CDC source (#921)
  53. [mongodb][test] Fix unstable tests of MongoDBConnectorITCase (#944)
  54. [mysql] Improve mysql heartbeat feature and tests
  55. [mysql] Original implementation of mysql heartbeat feature
  56. [common] Update issue templates
  57. [hotfix][mysql] Fix MySqlSourceReader#snapshotState should return unfinishedSplits (#926)
  58. [docs] Fix the outdated link of flink download link (#922)
  59. [hotfix][mysql] Fix the binlog position didn't update when emit DDL (#925)
  60. [mongodb] Correct the TypeInformation argument of DebeziumDeserializationSchema in SourceFuntion (#780)
  61. [common] Allow user to pass custom JsonConverter configs in JsonDebeziumDeserializationSchema (#615)
  62. [mysql] Improve the test to cover table with varbinary primary key (#879)
  63. [mysql] Support primary key with varbinary type (#879)
  64. [format][changelog-json] Remove the support of changelog-json format (#912)
  65. [hotfix][minor] Fix the test code typo
  66. [mysql] Fix ArrayIndexOutOfBoundsException in mysql binlog read phase (#911)
  67. [mongodb][tests] Track MongoDBITCase hang in azure (#881)
  68. [docs] Update the supported flink version mapping (#885)
  69. [common] Fix emitDelay and fetchDelay metrics to be 0L during snapshot phase (#878)
  70. [hotfix][docs][mongodb] Update supported mongodb versions in README.md
  71. [docs][sql-server] Add sqlserver-cdc connector tutorial (#687) This closes #687.
  72. [common] Use ResolvedSchema instead of deprecated TableSchema API (#782)
  73. [docs][sqlserver] Add SqlServer CDC connector document (#705)
  74. [doc][sqlserver] Add SqlServer English tutorial document. (#693)
  75. [common] Make Flink CDC Compatible with Flink 1.14
  76. [build] Bump flink version to 1.13.5
  77. [docs][oracle] Add guidance about oracle CDB database (#792)
  78. [docs] Add connection.pool.size and connect.max-retries option in mysql document (#857)
  79. [sqlserver] Add e2e tests for sqlserver cdc connector (#837)
  80. [hotfix][mysql] Rename method from dispatchHighWatermark to dispatchBinlogEndEvent (#810) This closes #810.
  81. [mysql] Use READ type for all records in snapshot reading (#842)
  82. [mysql] Rewrite the newly added table tests to cover more cases (#777) This closes #777.
  83. [mysql] Improve newly added tables process
  84. [mysql] Support capture newly added tables for existed pipeline
  85. [docs] Fix typo in mongodb-cdc.md (#836)
  86. [mysql] add test to cover the datatype GeomCollection that's synonymous with GeometryCollection for mysql8 (#822)
  87. [sqlserver] Add SqlServer cdc connector (#662)
  88. [build] Remove redundant maven enforce plugin (#794)
  89. [hotfix] Fix MySqlSource comment typo (#793)
  90. [mysql] Support MySQL 5.6 (#396)
  91. [build] Switch to Log4j 2 by default (#791)
  92. [oracle] Fix Oracle numeric types conversion (#560)
  93. [hotfix][mysql] Fix message timestamp of snapshot record to 0L (#752)
  94. [docs] Translate the Chinese FAQ document to English (#737)
  95. [docs] Remove the fixed version of website (#730)
  96. [hotfix][mysql] Set minimum connection pool size to 1 (#692)
  97. [build] Bump log4j2 version to 2.16.0 (#714)
  98. [build] Remove override definition of maven-surefire-plugin in connectors pom (#673)
  99. [docs] Add FAQ for tableList option usage in DataStream API (#634)
  100. [mongodb] Support to connect MongoDB without authentication (#642)
  101. [hotfix] Fix the parameter typo in java doc (#651)
  102. [mysql] Add a method to get MySqlSourceConfigFactory from MySqlSource (#648)
  103. [mysql] Set default driver class name for PooledDataSource (#659)
  104. [mysql] Fix there is duplicate records outputted when keep updating table during snapshot read (#592)
  105. [docs] Improve column name note in oracle cdc document. (#625)
  106. [docs] Add Flink cdc eco-system picture (#623)
  107. [hotfix][docs] Fix typo in oracle-cdc.md (#613)
  108. [docs] Add supported Flink versions for Flink CDC 2.1(#611)
  109. [build] Bump version to 2.2-SNAPSHOT

Download

Contributor List (sorted alphabetically)

  1. Dian Qi
  2. He Wang
  3. Jark Wu
  4. Jiabao Sun
  5. Jingsong Lee
  6. Junwang Zhao
  7. Konstantin Knauf
  8. Leonard Xu
  9. Mustang Kong
  10. Paul Zhang
  11. Qingsheng Ren
  12. Sergey Nuyanzin
  13. Shengkai
  14. Tuple
  15. Xianxun Ye
  16. Xuebing Li
  17. Zongwen Li
  18. camelusluo
  19. eastfisher
  20. ehui
  21. fangpc
  22. gongzhongqiang
  23. hele.kc
  24. hiscat
  25. luoyuxia
  26. paul8263
  27. skylines
  28. szgeqin
  29. taox
  30. tsreaper
  31. wangxiaojing
  32. wysstartgo
  33. yexianxun
  34. 元组

Release-2.1.1

17 Dec 07:15
Compare
Choose a tag to compare

Release Notes

Improvements and Bug fixes

  1. [docs] Remove the fixed version of website (#730)
  2. [hotfix][mysql] Set minimum connection pool size to 1 (#692)
  3. [build] Bump log4j2 version to 2.16.0 (#714) Note: This project only uses log4j2 in test code and won't be influenced by log4shell vulnerability
  4. [build] Remove override definition of maven-surefire-plugin in connectors pom (#673)
  5. [docs] Add FAQ for tableList option usage in DataStream API (#634)
  6. [mongodb] Support to connect MongoDB without authentication (#642)
  7. [hotfix] Fix the parameter typo in java doc (#651)
  8. [mysql] Set default driver class name for PooledDataSource (#659) (#661)
  9. [mysql] Fix there is duplicate records outputted when keep updating table during snapshot read (#592)
  10. [docs] Improve column name note in oracle cdc document (#633)
  11. [docs] Add Flink cdc eco-system picture (#624)
  12. [hotfix][docs] Fix typo in oracle-cdc.md(#616)
  13. [docs] Add supported Flink versions for Flink CDC 2.1(#608)

Download

Documentation

Release-2.1.0

15 Nov 07:15
Compare
Choose a tag to compare

Release Notes

Documentation: https://ververica.github.io/flink-cdc-connectors/release-2.1/

Features and Improvements

  1. [tests] Add end-to-end tests for cdc connector uber jars (#594)
  2. [tests] Upgrade testcontainers dependency to 1.16.2 (#591)
  3. [mysql] Reading a null column with default value defined should return null instead of default value (#555)
  4. [mysql] Optimize the dynamic chunk size calculation for table with dense distribution (#599)
  5. [mongodb] Fix MongoDBConnectorITCase is timeout on Azure (#600)
  6. [hotfix][mysql] Fix number overflow in ObjectUtils.minus (#598)
  7. [mongodb] Fix problem of cannot look up fields on non-struct type (#588)
  8. [hotfix][mongodb] Fix NullPointException when heartbeat option is enabled (#586)
  9. [postgres] Support 'schema-name' metadata column for postgres-cdc connector
  10. [oracle] Support metadata columns for oracle connector
  11. [tests] Split the CI pipeline into multiple stages for better performance (#572)
  12. [hotfix][mongodb] Correct the connection uri building of MongoDB (#568)
  13. [mysql] Skip ddl events in snapshot split normalization (#577)
  14. [mysql] Support dynamic chunk size for evenly distribution table
  15. [mysql][minor] Use 'table.include.list' key instead of legacy key 'table.whitelist' in SnapshotSplitReader
  16. [mysql] Set server time zone information for connection pool factory (#566)
  17. [mysql] Polish binlog offset compare semantic (#543)
  18. [build] Update NOTICE file for sql connector jar (#565)
  19. [postgres] Support metadata columns for postgres-cdc connector (#500)
  20. [debezium] Bump up debezium version to 1.5.4.Final (#554)
  21. [oracle] Shade dependencies for oracle-cdc connector (#519)
  22. [hotfix][docs] Fix the display of github star button
  23. [common] Fix NPE of JsonConverter when job run on cluster(#470)
  24. [mongodb] Support metadata columns for mongodb-cdc connector (#476)
  25. [mysql] Reduce the connection usage in table discovery process
  26. [build] bump maven shade plugin version to 3.2.4
  27. [mysql] Introduce Jdbc connection pools
  28. [mysql] support all mysql data types (#438)
  29. [hotfix][docs] Correct the Kibana link in Oracle connector documentation (#539)
  30. [mysql] Support binlog split with huge snapshot split meta
  31. [mysql] Support tables with different split key
  32. [mysql] Validate the regex pattern of database-name and table-name in table factory (#526)
  33. [build] Add necessary shaded dependencies (#512)
  34. [oracle][test] Fix oracle tests failure in azure due to ORA-01882
  35. [oracle][minor] Fix checkstyle and typo
  36. [oracle] Add docker build 'on-the-fly' and refactor test image
  37. [oracle] Added validator for oracle
  38. [oracle] Updated package naming to com.ververica in oracle connector
  39. [oracle] Fixing unit tests, cleaning up after adding oracle cdc
  40. [oracle] Add oracle cdc connector
  41. [build] Upgrade azure environment from ubuntu-16.04 to ubuntu-18.04 (#517)
  42. [hotfix][mysql] Correct the usage of includeSchemaChanges parameter (#501)
  43. [build] Follow Flink builtin connector shade style (#49)
  44. [mysql] Expose MySqlSource API that supports incremental snapshot (#495)
  45. [mysql] Support metadata columns for mysql-cdc connector (#496)
  46. [common] Support to read tables of inconsistent schema (#494)
  47. [build] Fix maven connection timeout issue in azure CI
  48. [mysql] Support wide table with huge number of columns
  49. [tests] Correct the argument order of assertArrayEqualInOrder/assertArrayEqualAnyOrder
  50. [tests] Introduce assertEqualsInOrder/assertEqualsInAnyOrder methods for test
  51. [tests] Improve the unstable test testStartupFromLatestOffset in MySqlConnectorITCase
  52. [mysql] Fix the restoration failure when checkpoint happened in one MySQL transaction
  53. [mysql] Optimization that skips the binlog read if the low watermark equals high watermark
  54. [mysql] Add source metrics for MySqlParallelSource
  55. [build] Use tools with stable version in building docs
  56. [mysql] Use min/max of split key and row count to describe the distribution of table
  57. [mysql] Fix the ClassCastException in RecordUtils
  58. [mongodb][docs] Add documentation for mongodb-cdc connector (#395)
  59. [mongodb] Remove no need config option prefix 'debezium.' (#420)
  60. [mongodb] Support MongoDB CDC connector (#225)
  61. [common] Shade kafka-related dependency (#386)
  62. [common] Support json deserialization schema
  63. [mysql] Improve the tests code
  64. [mysql] Fix the MySqlSnapshotSplitAssigner may assign duplicate splits
  65. [mysql] Add tests to check mysql-cdc works well under various timezones (#367)
  66. [mysql] Optimize the checkpoint be optional under single parallelism (#365)
  67. [postgres] Fix postgres-cdc connector cannot recognize the optional option 'slot.name'
  68. [mysql] Correct the initial binlog offset for MySqlHybridSplitAssigner
  69. [mysql] Add default value for 'database.history.instance.name' in MySqlParallelSource
  70. [common] Remove useless parameter 'converter.schemas.enable'
  71. [build] Run integration tests for each building
  72. [mysql] Improve the code format in SignalEventDispatcher
  73. [postgres] Fix Validator didn't implement Serializable
  74. [changelog] fix changelog-deserialize exception message typo.
  75. [build] Update issue templates
  76. [docs] Add tutorial about building real-time data lake for MySQL sharding table with Flink CDC (#551)
  77. [docs] Add metadata column example for mysql-cdc and mongodb-cdc connector
  78. [docs] Add checkpoint configuration limitation for Oracle and Postgres connector (#580)
  79. [docs] Fix the link of 'edit on github' on site (#578)
  80. [docs] Use SNAPSHOT version dependency in master documentation (#497)
  81. [docs] Use more generic term 'transaction logs' in README
  82. [docs] Add MySQL HA cluster support explanation
  83. [docs] Update the dependency version to 2.1.0
  84. [docs] Add checkpoint configuration limitation for Oracle and Postgres connector
  85. [docs] Fix the link of 'edit on github' on site (#578)
  86. [docs][oracle] Fix oracle DATE type mapping in documentation (#569)
  87. [docs] Translate "Streaming ETL for MySQL and Postgres with Flink CDC" into Chinese (#550)
  88. [docs] Add GitHub star button to documentation (#547)
  89. [docs] Add Oracle support in README
  90. [docs] Restructure the "tutorials" to "quickstart"
  91. [docs] Add documentation for oracle-cdc (#515)
  92. [docs] Rewrite tutorial doc for mysql-postgres-tutorial (#514)
  93. [docs] Add favicon for docs website (#525)
  94. [docs] Use new MySqlSource API in documentation
  95. [docs] Correct DataStream API usage in document examples
  96. [docs] Use JsonDeserializationSchema as output format in examples
  97. [docs] Update documentation of tutorial
  98. [docs] Add meaningful title for tutorial
  99. [docs] Support build document website locally
  100. [docs] Fix the broken link in readme
  101. [docs] Update the debezium document link to version 1.5
  102. [docs][mysql] Fix LowerCase Class name typo
  103. [docs] Add checkpoint config in document example
  104. [docs] Add FAQ for MySQL 8.0 Public Key Retrieval setting
  105. [docs] Add checkpoint and primary key setting for example in tutorials
  106. [docs] Fix the imports in document demo
  107. [docs] Set the content width of the website
  108. [docs] Update DingTalk group picture size in README.md
  109. [docs] Update the supported connector version and link

Download

Contributor list

Gunnar Morling, Jark Wu, Jiabao Sun, Leonard Xu, MartijnVisser, Marton Balassi, Shengkai, Tamas Kiss, Tamas Zseder, Zongwen Li, dongdongking008, frey66, gongzhongqiang, ili zh, jpatel, lsy, luoyuxia, manmao, mincwang, taox, tuple, wangminchao, yangbin09

Release 2.0.2

23 Sep 13:28
Compare
Choose a tag to compare

Release Notes

Improvements and Bug fixes

  1. [mysql] Fix the MySqlSnapshotSplitAssigner may assign duplicate splits
  2. [mysql] Fix the restoration failure when checkpoint happened in one MySQL transaction
  3. [mysql] Fix the ClassCastException in RecordUtils
  4. [mysql] Optimization that skips the binlog read if the low watermark equals high watermark
  5. [mysql] Support wide table with huge number of columns
  6. [mysql] Use min/max of split key and row count to describe the distribution of table
  7. [mysql] Add source metrics for MySqlParallelSource
  8. [tests] Correct the argument order of assertArrayEqualInOrder/assertArrayEqualAnyOrder
  9. [tests] Introduce assertEqualsInOrder/assertEqualsInAnyOrder methods for test
  10. [tests] Improve the unstable test testStartupFromLatestOffset in MySqlConnectorITCase
  11. [docs] Fix the broken link in readme
  12. [docs] Correct DataStream API usage in document examples
  13. [docs] Support build document website locally
  14. [docs] Update documentation of tutorials
  15. [docs] Add meaningful title for tutorials
  16. [build] Use tools with stable version in building docs
  17. [build] Fix maven connection timeout issue in azure CI

Download

Documentation

Release 2.0.1

27 Aug 11:38
Compare
Choose a tag to compare

Release Notes

Improvements and Bug

  1. [postgres] Fix Validator didn't implement Serializable
  2. [mysql] Correct the initial binlog offset for MySqlHybridSplitAssigner
  3. [mysql] Optimize the checkpoint be optional under single parallelism
  4. [postgres] Fix postgres-cdc connector cannot recognize the optional option 'slot.name'
  5. [mysql] Improve the code format in SignalEventDispatcher
  6. [mysql] Add default value for 'database.history.instance.name' in MySqlParallelSource
  7. [mysql] Add tests to check mysql-cdc works well under various timezones
  8. [common] Remove useless parameter 'converter.schemas.enable'
  9. [build] Run integration tests for each building
  10. [changelog] fix changelog-deserialize exception message typo
  11. [docs] Add FAQ for MySQL 8.0 Public Key Retrieval setting
  12. [docs] Update the debezium document link to version 1.5
  13. [docs] Add checkpoint and primary key setting for example in tutorials

Download

Documentation

Release 2.0.0

11 Aug 07:31
Compare
Choose a tag to compare

Release Notes

Documentation: https://ververica.github.io/flink-cdc-connectors/release-2.0/

Features and Improvements

  1. [mysql] Support MySQL-CDC 2.0 which offers parallel reading, lock-free and checkpoint feature
  2. [mysql] Enable single server id for MySqlParallelSource
  3. [mysql] Keep the global order of between snapshot records and binlog records
  4. [mysql] Support binlog reader merge optimization
  5. [mysql] Support numeric type optimization for split boundary calculation
  6. [mysql] Support table with combined primary key
  7. [mysql] Support latest-offset mode for MySqlParallelSource
  8. [build] Rename group.id and package name from 'com.alibaba.ververica' to 'com.ververica'
  9. [build] Bump flink version to 1.13.1
  10. [mysql] Forbid using problematic startup options earliest-offset/specific-offset/timestamp
  11. [mysql] Validate MySQL server configuration (version, binlog_format, binlog_row_image) before start job
  12. [mysql] Refactor class names to use 'MySql' prefix instead of 'MySQL'
  13. [common] Avoid uncompleted state of schema history when engine stop before checkpoint
  14. [common] Fix schema history run out of memory
  15. [common] Fix ClassCastException in type conversion
  16. [docs] Use sphinx-rtd-theme to manage project documents
  17. [docs] Support versioned documents with RTD(ReadTheDocs)

Upgrade Notes

Please note the following incompatible changes when you're upgrading your existed Flink CDC project.

  • The group.id and package name of Flink CDC has renamed from 'com.alibaba.ververica' to 'com.ververica' for making the project
    more neutral
  • The problematic startup options earliest-offset/specific-offset/timestamp has been disabled until they're correctly supported
  • The class name prefix has changed from 'MySQL' to 'MySql' for better code style.

Download

Release 1.4.0

12 May 04:22
Compare
Choose a tag to compare

Release 1.3.0

29 Mar 11:41
29bfc3b
Compare
Choose a tag to compare

Release Notes

  1. [postgres] Flush LSN offset to PG even if no updates to the monitored tables to avoid infinite WAL segments (#111)
  2. [mysql] Fix NPE when the application started for the first time and captured a empty table (#119)
  3. [debezium] Add source metrics according to FLIP-33

Download

release-1.2.0

27 Feb 15:26
db755cc
Compare
Choose a tag to compare

Release Notes

  1. [common] DebeziumSourceFunction only stores monitored table DDLs which cause error in some situation
  2. [common] offset state missing if no binlog fetched tile checkpoint after restore
  3. [common] Bump up Flink version to 1.12.1
  4. [mysql] Support read from specific MySQL Binlog position
  5. [mysql] Support "initial", "earliest-offset", "latest-offset" startup mode options
  6. [mysql] Support read binlog from specific timestamp
  7. [common] Remove logging security properties
  8. [common] Bump Debezium version to 1.4.1.Final
  9. [postgres] Support 'slot.name' option for postgres-cdc connector
  10. [postgres] Flush LSN offset to PG after checkpoint complete to avoid infinite WAL segments

Download