Release Notes for Debezium 2.2

All notable changes for Debezium releases are documented in this file. Release numbers follow Semantic Versioning.

Release 2.2.1.Final (May 12nd 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.4.0 and has been tested with version 3.4.0 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.1.Final from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.1.Final plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.1.Final connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

There are no breaking changes in this release.

New features

  • log.mining.transaction.retention.hours should reference last offset and not sysdate DBZ-6355

Fixes

  • Toasted varying character array and date array are not correcly processed DBZ-6122

  • Using pg_replication_slot_advance which is not supported by PostgreSQL10. DBZ-6353

  • 'CREATE TABLE t (c NATIONAL CHAR)' parsing failed DBZ-6357

  • Toasted hstore are not correcly processed DBZ-6379

  • Snapshotting does not work for hstore in Map mode DBZ-6384

  • Oracle DDL shrink space for table partition can not be parsed DBZ-6386

  • PostgreSQL connector task fails to resume streaming because replication slot is active DBZ-6396

  • MySql in debezium-parser-ddl :The inserted sql statement reports an error DBZ-6401

  • MongoDB connector crashes on invalid resume token DBZ-6402

  • New SMT HeaderToValue not working DBZ-6411

  • Debezium Server 2.2.0.Final BOM refers to debezium-build-parent 2.2.0-SNAPSHOT DBZ-6437

  • Oracle Connector failed parsing DDL Statement DBZ-6442

  • Oracle DDL shrink space for index partition can not be parsed DBZ-6446

  • Fix existing bug in information schema query in the Spanner connector DBZ-6385

  • change logging level of skip.messages.without.change DBZ-6391

  • Include redo/archive log metadata on ORA-01291 exceptions DBZ-6436

Other changes

  • Base the "replaceable" build numbers in legacy deployment instructions on debezium-build-number attribute DBZ-6371

Release 2.2.0.Final (April 20th 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.4.0 and has been tested with version 3.4.0 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.0.Final from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.0.Final plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.0.Final connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

There are no breaking changes in this release.

New features

  • Describe Postgres example configuration for Debezium Server DBZ-6325

  • Improve messages in Redis sink in case of OOM DBZ-6346

  • Stream shard list for debezium vitess connector DBZ-6356

Fixes

  • If column.include.list/column.exclude.list are used and the target table receives an update for the excluded (or not included) column - such events should be ignored DBZ-2979

  • Connector offsets do not advance on transaction commit with filtered events when LOB enabled DBZ-5395

  • Task failure when index is made on primary columns of table. DBZ-6238

  • Oracle connector doesn’t need to verify redo log when snapshotting only DBZ-6276

  • MySQL connector cannot parse table with SYSTEM VERSIONING DBZ-6331

  • MySql in debezium-parser-ddl does not support with keyword parsing DBZ-6336

  • Duplicate JMX MBean names when multiple vitess tasks running in the same JVM DBZ-6347

  • KafkaSignalThread#SIGNAL_POLL_TIMEOUT_MS option duplicate signal prefix DBZ-6361

Other changes

  • Complete MongoDB incremental snapshotting implementation DBZ-4427

  • Add documentation for the reactive variant of the Quarkus outbox extension DBZ-5859

  • Create an annotation for flaky tests DBZ-6324

  • 2.1.4 post-release documentation fixes DBZ-6351

Release 2.2.0.CR1 (April 14th 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.4.0 and has been tested with version 3.4.0 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.0.CR1 from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.0.CR1 plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.0.CR1 connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

Quarkus was upgraded to version 3. As Quarkus is now based on Jakarta EE 10 the package names has been changed from javax. to jakarta.. If you use Debezium outbox extension or you have dependency on Debezium in your project then it is possible that you’ll either need to update your dependency management or the source code (DBZ-6129).

New features

  • Capture evenents in order across mongodb shards DBZ-5590

  • Pass through configurations for kafka topics/configuration DBZ-6262

  • Enable the docker tag to be configurable in the Spanner connector DBZ-6302

  • Support async producer for Pulsar sink to improve performance DBZ-6319

Fixes

  • Failed retriable operations are retried infinitely DBZ-4488

  • DDL events not stored in schema history topic for excluded tables DBZ-6070

  • Oracle path used current batchSize to calculate end scn is wrong, need to use min batch size DBZ-6155

  • Multiplatform build of example-postres fails DBZ-6258

  • Add protoc version property to postgres connector pom.xml DBZ-6261

  • Postgres connector doesn’t need logical WAL level when snapshotting only DBZ-6265

  • MySQL connector doesn’t need to query binlog when snapshotting only DBZ-6271

  • Table names with spaces are not correctly deserialized when using an Infinispan cache as the transaction buffer DBZ-6273

  • Transaction buffer state can become corrupted when using Infinispan cache with LOBs DBZ-6275

  • DDL statement couldn’t be parsed - Oracle connector 2.1.3.Final DBZ-6314

  • Unparsable DDL statements (MySQL/MariaDB) DBZ-6316

  • Cassandra 3 cannot be built using JDK20 DBZ-6320

Other changes

  • Upgrade dependencies (Quarkus, etc) of Debezium UI DBZ-4109

  • UI- Add the UI to configure the additional properties for a connector DBZ-5365

  • Upgrade UI build to use Debezium 2.2 or latest DBZ-6173

  • Oracle-Connector dbz##user needs more rights DBZ-6198

  • Make quay.io primary image repository DBZ-6216

  • Update config properties in RHEL deployment instructions DBZ-6266

  • Fix errors in downstream Getting Started guide DBZ-6268

  • Address review feedback in downstream RHEL and OCP installation guides DBZ-6272

  • Infinispan cache configuration used by Oracle tests are not compatible with Infinispan 14.0.2 DBZ-6274

  • Remove unused/migrated jobs from upstream repository DBZ-6299

  • Upgrade MySQL JDBC driver to 8.0.32 DBZ-6304

  • Allow specifying docker image reference in MongoDB testcontainers implementation DBZ-6305

  • Use MongoDbContainer instead of MongoDBContainer test containers class in ConnectorConfiguration class DBZ-6306

  • Add documentation for JDBC sink connector DBZ-6310

  • Fix all compliance warnings for Jenkins DBZ-6315

  • Remove outdated information about SYS user accounts with Oracle DBZ-6318

  • Bundle Jolokia with Debezium connect image DBZ-6323

Release 2.2.0.Beta1 (March 31st 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.4.0 and has been tested with version 3.4.0 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.0.Beta1 from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.0.Beta1 plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.0.Beta1 connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

There are no breaking changes in this release.

New features

  • Debezium JDBC Sink Connector DBZ-3647

  • Create an endpoint to update a connector DBZ-5314

  • Refactor snapshotting to use change streams instead of oplog DBZ-5987

  • Update the design for Debezium based connectors Filter step DBZ-6060

  • Connect and stream from sharded clusters through mongos instances DBZ-6170

  • Support Postgres dialect for Spanner Kafka Connector DBZ-6178

  • Support Azure blob storage as Debezium history storage DBZ-6180

  • Support Database role in Connector Config. DBZ-6192

  • Remove duplicated createDdlFilter method from historized connector config DBZ-6197

  • Create new SMT to copy/move header to record value DBZ-6201

  • Add support for columns of type "bytea[]" - array of bytea (byte array) DBZ-6232

  • Support ImageFromDockerfile with Debezium’s testcontainers suite DBZ-6244

  • Expose EmbeddedEngine configurations DBZ-6248

  • RabbitMQ Sink DBZ-6260

Fixes

  • NPE when setting schema.history.internal.store.only.captured.tables.ddl=true DBZ-6072

  • Postgres connector stuck when replication slot does not have confirmed_flush_lsn DBZ-6092

  • java.lang.NullPointerException in MySQL connector with max.queue.size.in.bytes DBZ-6104

  • debezium-connector-mysql failed to parse serveral DDLs of 'CREATE TABLE' DBZ-6124

  • Zerofill property failed for different int types DBZ-6185

  • GRANT DELETE HISTORY couldn’t be parsed in mariadb DBZ-6186

  • ddl parse failed for key partition table DBZ-6188

  • Config options internal.schema.history.internal.ddl.filter not working DBZ-6190

  • Use CHARSET for alterByConvertCharset clause DBZ-6194

  • Data loss upon connector restart DBZ-6204

  • ParsingException: DDL statement couldn’t be parsed DBZ-6217

  • The CHARACTER/CHARACTER(p)/CHARACTER VARYING(p) data types not recognized as JDBC type CHAR DBZ-6221

  • MySQL treats the BOOLEAN synonym differently when processed in snapshot vs streaming phases. DBZ-6225

  • MySQL treats REAL synonym differently when processed in snapshot vs streaming phases. DBZ-6226

  • Spanner Connector - Deadlock in BufferedPublisher when publish gives exception DBZ-6227

  • Publish of sync event fails when message becomes very large. DBZ-6228

  • MySQL treats NCHAR/NVARCHAR differently when processed in snapshot vs streaming phases. DBZ-6231

  • MySQL singleDeleteStatement parser does not support table alias DBZ-6243

  • Testcontainers MongoDbReplicaSetTest failing with MongoDB 4.2 DBZ-6247

  • Wrong error thrown when snapshot.custom_class=custom and no snapshot.custom.class DBZ-6249

  • Missing GEOMETRY keyword which can be used as column name DBZ-6250

  • Postgres connector stuck trying to fallback to restart_lsn when replication slot confirmed_flush_lsn is null. DBZ-6251

  • MariaDB’s UUID column type cannot be parsed when scheme is loaded DBZ-6255

Other changes

  • Document message.key.columns and tombstone events limitations for default REPLICA IDENTITY DBZ-5490

  • Reflect configuration changes for MongoDB connector in documentation DBZ-6090

  • Create Oracle CI workflow DBZ-6115

  • Provide instructions for upgrading from Debezium 1.x to 2.x DBZ-6128

  • Update connector configuration examples in deployment instructions DBZ-6153

  • Insert missing Nebel annotations for Oracle connector FAQ topic DBZ-6215

  • Add metadata for MongoDB change streams topic DBZ-6223

  • Remove incubation notice from Debezium Server page DBZ-6235

  • Ensure correct build for Oracle CI in case of pull request DBZ-6239

  • Fix broken link to Streams documentation in shared deployment files DBZ-6263

  • Update config example in Installing Debezium on OpenShift DBZ-6267

Release 2.2.0.Alpha3 (March 8th 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.4.0 and has been tested with version 3.4.0 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.0.Alpha3 from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.0.Alpha3 plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.0.Alpha3 connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

Debezium was truncating on timezoned types milli/microsecond zeroes regardless of the schema width setting. This is no longer the case and Debezium provides the correct number of trailing zeroes (DBZ-6163).

New features

  • Optionally parallelize initial snapshots DBZ-823

  • Server side database and collection filtering on MongoDB change stream DBZ-5102

  • Create a Datastax connector based on Cassandra connector DBZ-5951

  • Add support for honouring MongoDB read preference in change stream after promotion DBZ-5953

  • Add support for header to all Debezium Server sinks DBZ-6017

  • Add support for surrogate keys for incremental snapshots DBZ-6023

  • Support String type for key in Mongo incremental snapshot DBZ-6116

  • fix typo in sqlserver doc. change "evemts" to "events". DBZ-6123

  • Support change stream filtering using MongoDB’s aggregation pipeline step DBZ-6131

  • Remove hardcoded list of system database exclusions that are not required for change streaming DBZ-6152

Fixes

  • When using snapshot.collection.include.list, relational schema isn’t populated correctly DBZ-3594

  • Debezium UI should use fast-jar again with Quarkus 2.x DBZ-4621

  • GCP Spanner connector start failing when there are multiple indexes on a single column DBZ-6101

  • Negative remaining attempts on MongoDB reconnect case DBZ-6113

  • Tables with spaces or non-ASCII characters in their name are not captured by Oracle because they must be quoted. DBZ-6120

  • Offsets are not advanced in a CDB deployment with low frequency of changes to PDB DBZ-6125

  • Oracle TIMESTAMP WITH TIME ZONE is emitted as GMT during snapshot rather than the specified TZ DBZ-6143

  • Debezium UI E2E Frontend build failing randomly with corrupted Node 16 tar file DBZ-6146

  • Debezium UI SQL Server tests randomly fail due to slow agent start-up DBZ-6149

  • RelationalSnapshotChangeEventSource swallows exception generated during snapshot DBZ-6179

Other changes

  • Remove redundancies between MySqlJdbcContext and MySqlConnection DBZ-4855

  • Refactor connection management for mongodb connector DBZ-6032

  • Conditionalization anomalies in Oracle connector doc DBZ-6073

  • Optimize debezium-testing-system image to build only modules necessary for tests DBZ-6108

  • Migrate system test jobs to gitlab DBZ-6109

  • Remove references to adding configuration settings to a .properties file DBZ-6130

  • Fix Debezium Server Redis random test failures DBZ-6133

  • Allow TestContainers test framework to expose ConnectorConfiguration as JSON DBZ-6136

  • Upgrade impsort-maven-plugin from 1.7.0 to 1.8.0 DBZ-6144

  • Upgrade Quarkus dependencies to 2.16.3.Final DBZ-6150

  • Github workflows not working for Cassandra job (step Build Debezium Connector Cassandra) DBZ-6171

  • Create SSL scenarios for integration tests for MySQL connector DBZ-6184

Release 2.2.0.Alpha2 (February 16th 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.4.0 and has been tested with version 3.4.0 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.0.Alpha2 from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.0.Alpha2 plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.0.Alpha2 connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

Debezium mapped non-ASCII characters into underscores in topic and schema names. This could lead into conflicts in case of names differing with only non-ASCII characters. Debezium now provides a strategy to map the characters uniquely. As by-product it is no longer possible to use sanitize.field.names config option (DBZ-5743).

Debezium Server was extracted from the main repository and is now located and built from its won separate repository. This allowed the build process to include the non-core connectors in the assembly package (DBZ-6049).

SSN field from Oracle connector was propagated as INT32 in the source info block. This could lead to overflows on certain installations so the field is now propagated as INT64 (DBZ-6091).

New features

  • Better control on debezium GTID usage DBZ-2296

  • Adding new option for "ExtractNewRecordState" SMT to exclude unchanged fields DBZ-5283

  • Reactive implementation of Outbox module DBZ-5758

  • Debezium MongoDB connector wizard Filter definition page needs work DBZ-5899

  • Debezium Storage add support for Apache RocketMQ DBZ-5997

  • debezium-server Pulsar support non-default tenant and namespace DBZ-6033

  • Add wallTime in mongodb source info DBZ-6038

  • Vitess: Support Mapping unsigned bigint mysql column type to long DBZ-6043

  • Increase query.fetch.size default to something sensible above zero DBZ-6079

  • Expose sequence field in CloudEvents message id DBZ-6089

  • Reduce verbosity of skipped transactions if transaction has no events relevant to captured tables DBZ-6094

  • Upgrade Kafka client to 3.4.0 DBZ-6102

Fixes

  • Not all connectors are available in debezium server DBZ-4038

  • Property event.processing.failure.handling.mode is not present in MySQL documentation DBZ-4829

  • Data type conversion failed for mysql bigint DBZ-5798

  • ActivateTracingSpan wrong timestamps reported DBZ-5827

  • Unable to specify column or table include list if name contains a backslash \ DBZ-5917

  • debezium-connector-cassandra 2.1.0.Alpha2 plugin can no longer run "out of the box" DBZ-5925

  • MongoDB Incremental Snapshot not Working DBZ-5973

  • Nullable columns marked with "optional: false" in DDL events DBZ-6003

  • Vitess: Handle the shard list difference between current db shards and persisted shards DBZ-6011

  • DDL statement with TokuDB engine specific "CLUSTERING KEY" couldn’t be parsed DBZ-6016

  • DDL parse fail for role revoke with "user-like" role name DBZ-6019

  • DDL parse fail for ALTER USER x DEFAULT ROLE y; DBZ-6020

  • Offsets are not flushed on connect offsets topic when encountering an error on Postgres connector DBZ-6026

  • Unexpected format for TIME column: 8:00 DBZ-6029

  • Oracle does not support compression/logging clauses after an LOB storage clause DBZ-6031

  • Debezium is logging the full message along with the error DBZ-6037

  • Improve resilience during internal schema history recovery from Kafka DBZ-6039

  • Incremental snapshot sends the events from signalling DB to Kafka DBZ-6051

  • Mask password in log statement DBZ-6064

  • Loading Custom offset storage fails with Class not found error DBZ-6075

  • SQL Server tasks fail if the number of databases is smaller than maxTasks DBZ-6084

  • When using LOB support, an UPDATE against multiple rows can lead to inconsistent event data DBZ-6107

Other changes

  • System test-suite ability to prepare OCP environment DBZ-3832

  • TransactionMetadataIT is unstable for Db2 DBZ-5149

  • Update Java Outreach job to use Java 20 DBZ-5825

  • Upgrade to Quarkus 2.16.0.Final DBZ-6005

  • Prepare MongoDB ExtractNewDocumentState SMT doc for downstream GA DBZ-6006

  • SQL Server IncrementalSnapshotWithRecompileIT fails randomly DBZ-6035

  • Remove the redundant "schema.history.internal" from MySqlConnectorConfig DBZ-6040

  • Broken links on FAQ DBZ-6042

  • Upgrade Kafka to 3.3.2 DBZ-6054

  • Upgrade netty version in Pravega to 4.1.86.Final DBZ-6057

  • Return back the driver class option for MySQL connector DBZ-6059

  • Invalid links breaking downstream documentation build DBZ-6069

  • Request SA for UMB DBZ-6077

  • Create certificates for Jenkins for UMB DBZ-6078

  • Request access to cpass UMB topic DBZ-6080

  • Broken debezium-server source file link on docs page DBZ-6111

Release 2.2.0.Alpha1 (January 19th 2023)

Kafka compatibility

This release has been built against Kafka Connect 3.3.1 and has been tested with version 3.3.1 of the Kafka brokers. See the Kafka documentation for compatibility with other versions of Kafka brokers.

Upgrading

Before upgrading any connector, be sure to check the backward-incompatible changes that have been made since the release you were using.

When you decide to upgrade one of these connectors to 2.2.0.Alpha1 from any earlier versions, first check the migration notes for the version you’re using. Gracefully stop the running connector, remove the old plugin files, install the 2.2.0.Alpha1 plugin files, and restart the connector using the same configuration. Upon restart, the 2.2.0.Alpha1 connectors will continue where the previous connector left off. As one might expect, all change events previously written to Kafka by the old connector will not be modified.

If you are using our container images, then please do not forget to pull them fresh from DockerHub.

Breaking changes

ZonedTimestamp strings were sent with fractional second trailing zeroes removed. Current behaviour is to provide the trailing zeroes padded to the length/scale of the source column (DBZ-5996).

New features

  • Remove redundant modifiers of members for interface fields DBZ-2439

  • Allow reading from read-only Oracle standby disaster/recovery DBZ-3866

  • Remove option for specifying driver class from MySQL Connector DBZ-4663

  • Support S3 bucket as Dezbium history store DBZ-5402

  • Update the DBZ-UI documentation page to incorporate the recently added "Custom properties" step details DBZ-5878

  • Support retrying database connection failures during connector start DBZ-5879

  • Add support for Connect Headers to Debezium Server DBZ-5926

  • Sink adapter for Apache RocketMQ DBZ-5962

  • Sink adapter for Infinispan DBZ-5986

  • Add custom Debezium banner to Debezium Server DBZ-6004

  • Postgres LSN check should honor event.processing.failure.handling.mode DBZ-6012

  • Enhance the Spanner connector by adding features and/or solving bugs DBZ-6014

Fixes

  • Debezium is not working with apicurio and custom truststores DBZ-5282

  • Show/Hide password does not work on Connectors View details screen DBZ-5322

  • Snapshotter#snapshotCompleted is invoked regardless of snapshot result DBZ-5852

  • Oracle cannot undo change DBZ-5907

  • Postgresql Data Loss on restarts DBZ-5915

  • Oracle Multithreading lost data DBZ-5945

  • Spanner connector is missing JSR-310 dependency DBZ-5959

  • Truncate records incompatible with ExtractNewRecordState DBZ-5966

  • Computed partition must not be negative DBZ-5967

  • Stream tag images are not published DBZ-5979

  • Table size log message for snapshot.select.statement.overrides tables not correct DBZ-5985

  • NPE in execute snapshot signal with exclude.tables config on giving wrong table name DBZ-5988

  • There is a problem with postgresql connector parsing the boundary value of money type DBZ-5991

  • Log statement for unparseable DDL statement in MySqlDatabaseSchema contains placeholder DBZ-5993

  • Synchronize all actions with core CI & fix GitHub Actions set-output command DBZ-5998

  • Postgresql connector parses the null of the money type into 0 DBZ-6001

  • Run PostgresConnectorIT.shouldReceiveChangesForChangeColumnDefault() failed DBZ-6002

Other changes

  • Plug-in version information duplicated DBZ-4669

  • Move common code in Cassandra connector core module DBZ-5950

  • website-builder image cannot be built DBZ-5971

  • Zookeeper 3.6.3 available only on archive DBZ-5972

  • Jenkins pipelines don’t provide information about FAILURE status DBZ-5974

  • Remove incubating documentation text for MongoDB ExtractNewDocumentState SMT DBZ-5975

  • Use replace rather than replaceAll DBZ-5976

  • Upgrade Apicurio to 2.4.1.Final DBZ-5977

  • Upgrade JDBC driver to 42.5.1 DBZ-5980

  • Update TestContainers to 1.17.6 DBZ-5990

  • Align pipeline tests with new connector pipelines DBZ-5999

  • Db2 incremental snapshot test execution is blocked DBZ-6008