diff --git a/debezium-api/pom.xml b/debezium-api/pom.xml
index 16b618f635e..12c124b7224 100644
--- a/debezium-api/pom.xml
+++ b/debezium-api/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-assembly-descriptors/pom.xml b/debezium-assembly-descriptors/pom.xml
index d32b8477ec0..a2a4690a354 100644
--- a/debezium-assembly-descriptors/pom.xml
+++ b/debezium-assembly-descriptors/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-bom/pom.xml b/debezium-bom/pom.xml
index 92da82eacc4..21511a3b44e 100644
--- a/debezium-bom/pom.xml
+++ b/debezium-bom/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-build-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-connect-rest-extension/pom.xml b/debezium-connect-rest-extension/pom.xml
index ae28fe84a94..22865b90855 100644
--- a/debezium-connect-rest-extension/pom.xml
+++ b/debezium-connect-rest-extension/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-connector-mongodb/pom.xml b/debezium-connector-mongodb/pom.xml
index b1331bfe348..b91675f1a54 100644
--- a/debezium-connector-mongodb/pom.xml
+++ b/debezium-connector-mongodb/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-connector-mysql/pom.xml b/debezium-connector-mysql/pom.xml
index 0115f422c92..699e1ccb800 100644
--- a/debezium-connector-mysql/pom.xml
+++ b/debezium-connector-mysql/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-connector-oracle/pom.xml b/debezium-connector-oracle/pom.xml
index 90e3e0197e8..bfb3e8af0bc 100644
--- a/debezium-connector-oracle/pom.xml
+++ b/debezium-connector-oracle/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-connector-postgres/pom.xml b/debezium-connector-postgres/pom.xml
index 893ea19b412..3aac3e88add 100644
--- a/debezium-connector-postgres/pom.xml
+++ b/debezium-connector-postgres/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorConfig.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorConfig.java
index ea01ec38075..f77f5808936 100755
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorConfig.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorConfig.java
@@ -54,7 +54,7 @@
import io.debezium.util.Strings;
/**
- * The configuration properties for the {@link YBPostgresConnector}
+ * The configuration properties for the {@link YugabyteDBConnector}
*
* @author Horia Chiorean
*/
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorTask.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorTask.java
index 894c66af6bd..38d961b8b0d 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorTask.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresConnectorTask.java
@@ -195,7 +195,7 @@ public ChangeEventSourceCoordinator st
final PostgresEventMetadataProvider metadataProvider = new PostgresEventMetadataProvider();
SignalProcessor signalProcessor = new SignalProcessor<>(
- YBPostgresConnector.class, connectorConfig, Map.of(),
+ YugabyteDBConnector.class, connectorConfig, Map.of(),
getAvailableSignalChannels(),
DocumentReader.defaultReader(),
previousOffsets);
@@ -235,7 +235,7 @@ public ChangeEventSourceCoordinator st
ChangeEventSourceCoordinator coordinator = new PostgresChangeEventSourceCoordinator(
previousOffsets,
errorHandler,
- YBPostgresConnector.class,
+ YugabyteDBConnector.class,
connectorConfig,
new PostgresChangeEventSourceFactory(
connectorConfig,
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresErrorHandler.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresErrorHandler.java
index d8dc145b1ec..cedccbf43c7 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresErrorHandler.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresErrorHandler.java
@@ -21,7 +21,7 @@
public class PostgresErrorHandler extends ErrorHandler {
public PostgresErrorHandler(PostgresConnectorConfig connectorConfig, ChangeEventQueue> queue, ErrorHandler replacedErrorHandler) {
- super(YBPostgresConnector.class, connectorConfig, queue, replacedErrorHandler);
+ super(YugabyteDBConnector.class, connectorConfig, queue, replacedErrorHandler);
}
@Override
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresSchema.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresSchema.java
index a26c6599588..cc4e29de22d 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresSchema.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresSchema.java
@@ -32,7 +32,7 @@
import io.debezium.spi.topic.TopicNamingStrategy;
/**
- * Component that records the schema information for the {@link YBPostgresConnector}. The schema information contains
+ * Component that records the schema information for the {@link YugabyteDBConnector}. The schema information contains
* the {@link Tables table definitions} and the Kafka Connect {@link #schemaFor(TableId) Schema}s for each table, where the
* {@link Schema} excludes any columns that have been {@link PostgresConnectorConfig#COLUMN_EXCLUDE_LIST specified} in the
* configuration.
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresStreamingChangeEventSource.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresStreamingChangeEventSource.java
index f6c7937cae4..6491ea7c686 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresStreamingChangeEventSource.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/PostgresStreamingChangeEventSource.java
@@ -165,7 +165,7 @@ public void execute(ChangeEventSourceContext context, PostgresPartition partitio
// such that the connection times out. We must enable keep
// alive to ensure that it doesn't time out
ReplicationStream stream = this.replicationStream.get();
- stream.startKeepAlive(Threads.newSingleThreadExecutor(YBPostgresConnector.class, connectorConfig.getLogicalName(), KEEP_ALIVE_THREAD_NAME));
+ stream.startKeepAlive(Threads.newSingleThreadExecutor(YugabyteDBConnector.class, connectorConfig.getLogicalName(), KEEP_ALIVE_THREAD_NAME));
initSchema();
@@ -200,7 +200,7 @@ public void execute(ChangeEventSourceContext context, PostgresPartition partitio
replicationStream.set(replicationConnection.startStreaming(walPosition.getLastEventStoredLsn(), walPosition));
stream = this.replicationStream.get();
- stream.startKeepAlive(Threads.newSingleThreadExecutor(YBPostgresConnector.class, connectorConfig.getLogicalName(), KEEP_ALIVE_THREAD_NAME));
+ stream.startKeepAlive(Threads.newSingleThreadExecutor(YugabyteDBConnector.class, connectorConfig.getLogicalName(), KEEP_ALIVE_THREAD_NAME));
}
} else {
LOGGER.info("Connector config provide.transaction.metadata is set to true. Therefore, skip records filtering in order to ship entire transactions.");
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/ReplicaIdentityMapper.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/ReplicaIdentityMapper.java
index 9b93e4d7520..85d1a2bee27 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/ReplicaIdentityMapper.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/ReplicaIdentityMapper.java
@@ -21,7 +21,7 @@
import io.debezium.relational.TableId;
/**
- * Class that records Replica Identity information for the {@link YBPostgresConnector}
+ * Class that records Replica Identity information for the {@link YugabyteDBConnector}
* @author Ben White, Miguel Sotomayor
*/
@Immutable
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/YBPostgresConnector.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/YugabyteDBConnector.java
similarity index 98%
rename from debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/YBPostgresConnector.java
rename to debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/YugabyteDBConnector.java
index 850d544706f..335d73bfb53 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/YBPostgresConnector.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/YugabyteDBConnector.java
@@ -36,12 +36,12 @@
*
* @author Horia Chiorean
*/
-public class YBPostgresConnector extends RelationalBaseSourceConnector {
+public class YugabyteDBConnector extends RelationalBaseSourceConnector {
- private static final Logger LOGGER = LoggerFactory.getLogger(YBPostgresConnector.class);
+ private static final Logger LOGGER = LoggerFactory.getLogger(YugabyteDBConnector.class);
private Map props;
- public YBPostgresConnector() {
+ public YugabyteDBConnector() {
}
@Override
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/metadata/PostgresConnectorMetadata.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/metadata/PostgresConnectorMetadata.java
index 66801d25874..0f879647393 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/metadata/PostgresConnectorMetadata.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/metadata/PostgresConnectorMetadata.java
@@ -7,7 +7,7 @@
import io.debezium.config.Field;
import io.debezium.connector.postgresql.Module;
-import io.debezium.connector.postgresql.YBPostgresConnector;
+import io.debezium.connector.postgresql.YugabyteDBConnector;
import io.debezium.connector.postgresql.PostgresConnectorConfig;
import io.debezium.metadata.ConnectorDescriptor;
import io.debezium.metadata.ConnectorMetadata;
@@ -16,7 +16,7 @@ public class PostgresConnectorMetadata implements ConnectorMetadata {
@Override
public ConnectorDescriptor getConnectorDescriptor() {
- return new ConnectorDescriptor("postgres", "Debezium PostgreSQL Connector", YBPostgresConnector.class.getName(), Module.version());
+ return new ConnectorDescriptor("postgres", "Debezium PostgreSQL Connector", YugabyteDBConnector.class.getName(), Module.version());
}
@Override
diff --git a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/rest/DebeziumPostgresConnectorResource.java b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/rest/DebeziumPostgresConnectorResource.java
index 1a854745a54..91d52f3eb54 100644
--- a/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/rest/DebeziumPostgresConnectorResource.java
+++ b/debezium-connector-postgres/src/main/java/io/debezium/connector/postgresql/rest/DebeziumPostgresConnectorResource.java
@@ -16,7 +16,7 @@
import javax.ws.rs.Produces;
import javax.ws.rs.core.MediaType;
-import io.debezium.connector.postgresql.YBPostgresConnector;
+import io.debezium.connector.postgresql.YugabyteDBConnector;
import org.apache.kafka.connect.health.ConnectClusterState;
import io.debezium.config.Configuration;
@@ -36,7 +36,7 @@
@Produces(MediaType.APPLICATION_JSON)
@Consumes(MediaType.APPLICATION_JSON)
public class DebeziumPostgresConnectorResource
- implements SchemaResource, ConnectionValidationResource, FilterValidationResource, MetricsResource {
+ implements SchemaResource, ConnectionValidationResource, FilterValidationResource, MetricsResource {
public static final String BASE_PATH = "/debezium/postgres";
public static final String VERSION_ENDPOINT = "/version";
@@ -53,8 +53,8 @@ public String getConnectorVersion() {
}
@Override
- public YBPostgresConnector getConnector() {
- return new YBPostgresConnector();
+ public YugabyteDBConnector getConnector() {
+ return new YugabyteDBConnector();
}
@Override
diff --git a/debezium-connector-postgres/src/main/resources/META-INF/services/org.apache.kafka.connect.source.SourceConnector b/debezium-connector-postgres/src/main/resources/META-INF/services/org.apache.kafka.connect.source.SourceConnector
index 79070ced248..2f31254804d 100644
--- a/debezium-connector-postgres/src/main/resources/META-INF/services/org.apache.kafka.connect.source.SourceConnector
+++ b/debezium-connector-postgres/src/main/resources/META-INF/services/org.apache.kafka.connect.source.SourceConnector
@@ -1 +1 @@
-io.debezium.connector.postgresql.YBPostgresConnector
\ No newline at end of file
+io.debezium.connector.postgresql.YugabyteDBConnector
\ No newline at end of file
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/BlockingSnapshotIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/BlockingSnapshotIT.java
index d48a2653367..f57e9985d0d 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/BlockingSnapshotIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/BlockingSnapshotIT.java
@@ -78,8 +78,8 @@ protected Configuration.Builder mutableConfig(boolean signalTableOnly, boolean s
}
@Override
- protected Class connectorClass() {
- return YBPostgresConnector.class;
+ protected Class connectorClass() {
+ return YugabyteDBConnector.class;
}
@Override
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CloudEventsConverterIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CloudEventsConverterIT.java
index bc1a0dfe143..48ed0108ab7 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CloudEventsConverterIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CloudEventsConverterIT.java
@@ -16,11 +16,11 @@
import io.debezium.jdbc.JdbcConnection;
/**
- * Integration test for {@link io.debezium.converters.CloudEventsConverter} with {@link YBPostgresConnector}
+ * Integration test for {@link io.debezium.converters.CloudEventsConverter} with {@link YugabyteDBConnector}
*
* @author Roman Kudryashov
*/
-public class CloudEventsConverterIT extends AbstractCloudEventsConverterTest {
+public class CloudEventsConverterIT extends AbstractCloudEventsConverterTest {
private static final String SETUP_SCHEMA = "DROP SCHEMA IF EXISTS s1 CASCADE;" +
"CREATE SCHEMA s1;";
@@ -51,8 +51,8 @@ public void beforeEach() throws Exception {
}
@Override
- protected Class getConnectorClass() {
- return YBPostgresConnector.class;
+ protected Class getConnectorClass() {
+ return YugabyteDBConnector.class;
}
@Override
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CustomTestSnapshot.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CustomTestSnapshot.java
index e98884d255b..3b2dd3be192 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CustomTestSnapshot.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/CustomTestSnapshot.java
@@ -16,7 +16,7 @@
import io.debezium.relational.TableId;
/**
- * This is a small class used in YBPostgresConnectorIT to test a custom snapshot
+ * This is a small class used in YugabyteDBConnectorIT to test a custom snapshot
*
* It is tightly coupled to the test there, but needs to be placed here in order
* to allow for class loading to work
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DebeziumEngineIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DebeziumEngineIT.java
index 9fe7a6f8a7e..3fcaf3dfd03 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DebeziumEngineIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DebeziumEngineIT.java
@@ -82,7 +82,7 @@ public void shouldSerializeToJson() throws Exception {
final Properties props = new Properties();
props.putAll(TestHelper.defaultConfig().build().asMap());
props.setProperty("name", "debezium-engine");
- props.setProperty("connector.class", "io.debezium.connector.postgresql.YBPostgresConnector");
+ props.setProperty("connector.class", "io.debezium.connector.postgresql.YugabyteDBConnector");
props.setProperty(StandaloneConfig.OFFSET_STORAGE_FILE_FILENAME_CONFIG,
OFFSET_STORE_PATH.toAbsolutePath().toString());
props.setProperty("offset.flush.interval.ms", "0");
@@ -129,7 +129,7 @@ public void shouldSerializeToAvro() throws Exception {
final Properties props = new Properties();
props.putAll(TestHelper.defaultConfig().build().asMap());
props.setProperty("name", "debezium-engine");
- props.setProperty("connector.class", "io.debezium.connector.postgresql.YBPostgresConnector");
+ props.setProperty("connector.class", "io.debezium.connector.postgresql.YugabyteDBConnector");
props.setProperty(StandaloneConfig.OFFSET_STORAGE_FILE_FILENAME_CONFIG,
OFFSET_STORE_PATH.toAbsolutePath().toString());
props.setProperty("offset.flush.interval.ms", "0");
@@ -169,7 +169,7 @@ public void shouldSerializeToCloudEvents() throws Exception {
final Properties props = new Properties();
props.putAll(TestHelper.defaultConfig().build().asMap());
props.setProperty("name", "debezium-engine");
- props.setProperty("connector.class", "io.debezium.connector.postgresql.YBPostgresConnector");
+ props.setProperty("connector.class", "io.debezium.connector.postgresql.YugabyteDBConnector");
props.setProperty(StandaloneConfig.OFFSET_STORAGE_FILE_FILENAME_CONFIG,
OFFSET_STORE_PATH.toAbsolutePath().toString());
props.setProperty("offset.flush.interval.ms", "0");
@@ -244,7 +244,7 @@ public void testOffsetsCommitAfterStop() throws Exception {
final Properties props = new Properties();
props.putAll(TestHelper.defaultConfig().build().asMap());
props.setProperty("name", "debezium-engine");
- props.setProperty("connector.class", "io.debezium.connector.postgresql.YBPostgresConnector");
+ props.setProperty("connector.class", "io.debezium.connector.postgresql.YugabyteDBConnector");
props.setProperty(StandaloneConfig.OFFSET_STORAGE_FILE_FILENAME_CONFIG,
OFFSET_STORE_PATH.toAbsolutePath().toString());
props.setProperty("offset.flush.interval.ms", "3000");
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DomainTypesIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DomainTypesIT.java
index 08e299268cc..de4d6e1105d 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DomainTypesIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/DomainTypesIT.java
@@ -43,7 +43,7 @@ public void before() throws SQLException {
@Test
@FixFor("DBZ-3657")
public void shouldNotChokeOnDomainTypeInArray() throws Exception {
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "domaintypes")
.build());
@@ -63,7 +63,7 @@ public void shouldNotChokeOnDomainTypeInArray() throws Exception {
@Test
@FixFor("DBZ-3657")
public void shouldExportDomainTypeInArrayAsUnknown() throws Exception {
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "domaintypes")
.with(PostgresConnectorConfig.INCLUDE_UNKNOWN_DATATYPES, true)
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/IncrementalSnapshotIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/IncrementalSnapshotIT.java
index dbd5fa7573e..caa9eba39ce 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/IncrementalSnapshotIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/IncrementalSnapshotIT.java
@@ -41,7 +41,7 @@
import io.debezium.util.Collect;
import io.debezium.util.Testing;
-public class IncrementalSnapshotIT extends AbstractIncrementalSnapshotTest {
+public class IncrementalSnapshotIT extends AbstractIncrementalSnapshotTest {
private static final Logger LOGGER = LoggerFactory.getLogger(IncrementalSnapshotIT.class);
@@ -134,8 +134,8 @@ protected Configuration.Builder mutableConfig(boolean signalTableOnly, boolean s
}
@Override
- protected Class connectorClass() {
- return YBPostgresConnector.class;
+ protected Class connectorClass() {
+ return YugabyteDBConnector.class;
}
@Override
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/LogicalDecodingMessageIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/LogicalDecodingMessageIT.java
index 4fdd7c3d02b..587c08b8010 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/LogicalDecodingMessageIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/LogicalDecodingMessageIT.java
@@ -76,7 +76,7 @@ public void shouldNotConsumeLogicalDecodingMessagesWhenAllPrefixesAreInTheExclud
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.LOGICAL_DECODING_MESSAGE_PREFIX_EXCLUDE_LIST, ".*");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -99,7 +99,7 @@ public void shouldConsumeNonTransactionalLogicalDecodingMessages() throws Except
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig();
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -138,7 +138,7 @@ public void shouldConsumeTransactionalLogicalDecodingMessages() throws Exception
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig();
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -180,7 +180,7 @@ public void shouldApplyBinaryHandlingMode() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.BINARY_HANDLING_MODE, "base64");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -206,7 +206,7 @@ public void shouldNotConsumeLogicalDecodingMessagesWithExcludedPrefixes() throws
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.LOGICAL_DECODING_MESSAGE_PREFIX_EXCLUDE_LIST, "excluded_prefix, prefix:excluded");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -232,7 +232,7 @@ public void shouldOnlyConsumeLogicalDecodingMessagesWithIncludedPrefixes() throw
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.LOGICAL_DECODING_MESSAGE_PREFIX_INCLUDE_LIST, "included_prefix, prefix:included, ano.*er_included");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/NotificationsIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/NotificationsIT.java
index 5c58c04b244..7c443c4f5fa 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/NotificationsIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/NotificationsIT.java
@@ -14,7 +14,7 @@
import io.debezium.config.Configuration;
import io.debezium.pipeline.notification.AbstractNotificationsIT;
-public class NotificationsIT extends AbstractNotificationsIT {
+public class NotificationsIT extends AbstractNotificationsIT {
@Before
public void before() throws SQLException {
@@ -31,8 +31,8 @@ public void after() {
}
@Override
- protected Class connectorClass() {
- return YBPostgresConnector.class;
+ protected Class connectorClass() {
+ return YugabyteDBConnector.class;
}
@Override
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/OutboxEventRouterIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/OutboxEventRouterIT.java
index 3f80d19baba..b1731a3a596 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/OutboxEventRouterIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/OutboxEventRouterIT.java
@@ -19,11 +19,11 @@
import io.debezium.transforms.outbox.AbstractEventRouterTest;
/**
- * Integration test for {@link io.debezium.transforms.outbox.EventRouter} with {@link YBPostgresConnector}
+ * Integration test for {@link io.debezium.transforms.outbox.EventRouter} with {@link YugabyteDBConnector}
*
* @author Renato Mefi (gh@mefi.in)
*/
-public class OutboxEventRouterIT extends AbstractEventRouterTest {
+public class OutboxEventRouterIT extends AbstractEventRouterTest {
private static final String SETUP_OUTBOX_SCHEMA = "DROP SCHEMA IF EXISTS outboxsmtit CASCADE;" +
"CREATE SCHEMA outboxsmtit;";
@@ -47,8 +47,8 @@ public void beforeEach() throws Exception {
}
@Override
- protected Class getConnectorClass() {
- return YBPostgresConnector.class;
+ protected Class getConnectorClass() {
+ return YugabyteDBConnector.class;
}
@Override
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresDefaultValueConverterIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresDefaultValueConverterIT.java
index 49ae37a7524..b54e0e1fbc2 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresDefaultValueConverterIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresDefaultValueConverterIT.java
@@ -52,7 +52,7 @@ public void shouldSetTheNullValueInSnapshot() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted("postgres", TestHelper.TEST_SERVER);
@@ -69,7 +69,7 @@ public void shouldSetTheNullValueInStreaming() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted("postgres", TestHelper.TEST_SERVER);
@@ -99,7 +99,7 @@ public void testShouldHandleDefaultValueFunctionsWithSchemaPrefixes() throws Exc
TestHelper.execute(ddl);
Configuration config = TestHelper.defaultConfig().build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMetricsIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMetricsIT.java
index 7afb9c95624..5cc76aa6c4a 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMetricsIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMetricsIT.java
@@ -59,7 +59,7 @@ public void after() throws Exception {
@Test
public void testLifecycle() throws Exception {
// start connector
- start(YBPostgresConnector.class,
+ start(YugabyteDBConnector.class,
TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.ALWAYS)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
@@ -100,7 +100,7 @@ public void testSnapshotOnlyMetrics() throws Exception {
TestHelper.execute(INIT_STATEMENTS, INSERT_STATEMENTS);
// start connector
- start(YBPostgresConnector.class,
+ start(YugabyteDBConnector.class,
TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
@@ -115,7 +115,7 @@ public void testSnapshotAndStreamingMetrics() throws Exception {
TestHelper.execute(INIT_STATEMENTS, INSERT_STATEMENTS);
// start connector
- start(YBPostgresConnector.class,
+ start(YugabyteDBConnector.class,
TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.ALWAYS)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
@@ -138,7 +138,7 @@ public void testSnapshotAndStreamingWithCustomMetrics() throws Exception {
.with(PostgresConnectorConfig.CUSTOM_METRIC_TAGS, "env=test,bu=bigdata")
.build();
Map customMetricTags = new PostgresConnectorConfig(config).getCustomMetricTags();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertSnapshotWithCustomMetrics(customMetricTags);
assertStreamingWithCustomMetrics(customMetricTags);
@@ -150,7 +150,7 @@ public void testStreamingOnlyMetrics() throws Exception {
TestHelper.execute(INIT_STATEMENTS);
// start connector
- start(YBPostgresConnector.class,
+ start(YugabyteDBConnector.class,
TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
@@ -275,7 +275,7 @@ public void oneRecordInQueue() throws Exception {
.with(PostgresConnectorConfig.MAX_BATCH_SIZE, 1)
.with(PostgresConnectorConfig.POLL_INTERVAL_MS, 100L)
.with(PostgresConnectorConfig.MAX_QUEUE_SIZE_IN_BYTES, 10000L);
- start(YBPostgresConnector.class, configBuilder.build(), loggingCompletion(), null, x -> {
+ start(YugabyteDBConnector.class, configBuilder.build(), loggingCompletion(), null, x -> {
LOGGER.info("Record '{}' arrived", x);
step1.countDown();
try {
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMoneyIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMoneyIT.java
index 38b9058655b..a444e7245b5 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMoneyIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresMoneyIT.java
@@ -51,7 +51,7 @@ public void shouldReceiveChangesForInsertsWithPreciseMode() throws Exception {
Configuration config = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
// insert 2 records for testing
@@ -77,7 +77,7 @@ public void shouldReceiveChangesForInsertsWithStringMode() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.with(PostgresConnectorConfig.DECIMAL_HANDLING_MODE, "string")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
// insert 2 records for testing
@@ -103,7 +103,7 @@ public void shouldReceiveChangesForInsertsWithDoubleMode() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.with(PostgresConnectorConfig.DECIMAL_HANDLING_MODE, "double")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
// insert 2 records for testing
@@ -128,7 +128,7 @@ public void shouldReceiveChangesForInsertNullAndZeroMoney() throws Exception {
Configuration config = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
// insert 2 records for testing
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresReselectColumnsProcessorIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresReselectColumnsProcessorIT.java
index b917a9eb258..db32e16639e 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresReselectColumnsProcessorIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresReselectColumnsProcessorIT.java
@@ -30,7 +30,7 @@
*
* @author Chris Cranford
*/
-public class PostgresReselectColumnsProcessorIT extends AbstractReselectProcessorTest {
+public class PostgresReselectColumnsProcessorIT extends AbstractReselectProcessorTest {
public static final String CREATE_STMT = "DROP SCHEMA IF EXISTS s1 CASCADE;" +
"CREATE SCHEMA s1; ";
@@ -53,8 +53,8 @@ public void afterEach() throws Exception {
}
@Override
- protected Class getConnectorClass() {
- return YBPostgresConnector.class;
+ protected Class getConnectorClass() {
+ return YugabyteDBConnector.class;
}
@Override
@@ -120,7 +120,7 @@ public void testToastColumnReselectedWhenValueIsUnavailable() throws Exception {
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1\\.dbz4321_toast")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingStarted();
final String text = RandomStringUtils.randomAlphabetic(10000);
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresShutdownIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresShutdownIT.java
index 1817e6ea6b8..a1b1adaa23e 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresShutdownIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresShutdownIT.java
@@ -34,7 +34,7 @@
import io.debezium.util.Testing;
/**
- * Integration test for {@link YBPostgresConnector} using an {@link EmbeddedEngine} and Testcontainers infrastructure for when Postgres is shutdown during streaming
+ * Integration test for {@link YugabyteDBConnector} using an {@link EmbeddedEngine} and Testcontainers infrastructure for when Postgres is shutdown during streaming
*/
public class PostgresShutdownIT extends AbstractConnectorTest {
@@ -114,7 +114,7 @@ public void shouldStopOnPostgresFastShutdown() throws Exception {
String initialHeartbeat = postgresConnection.queryAndMap(
"SELECT ts FROM s1.heartbeat;",
postgresConnection.singleResultMapper(rs -> rs.getString("ts"), "Could not fetch keepalive info"));
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted("postgres", TestHelper.TEST_SERVER);
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresSkipMessagesWithoutChangeConfigIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresSkipMessagesWithoutChangeConfigIT.java
index 2bae1d45796..cfe2ccbfdb5 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresSkipMessagesWithoutChangeConfigIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PostgresSkipMessagesWithoutChangeConfigIT.java
@@ -58,7 +58,7 @@ public void shouldSkipEventsWithNoChangeInIncludedColumnsWhenSkipEnabled() throw
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
TestHelper.execute("INSERT INTO updates_test.debezium_test (id,white,black) VALUES (1,1,1);");
@@ -98,7 +98,7 @@ public void shouldSkipEventsWithNoChangeInIncludedColumnsWhenSkipEnabledWithExcl
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
TestHelper.execute("INSERT INTO updates_test.debezium_test (id,white,black) VALUES (1,1,1);");
@@ -136,7 +136,7 @@ public void shouldNotSkipEventsWithNoChangeInIncludedColumnsWhenSkipEnabledButTa
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
TestHelper.execute("INSERT INTO updates_test.debezium_test (id,white,black) VALUES (1,1,1);");
@@ -177,7 +177,7 @@ public void shouldNotSkipEventsWithNoChangeInIncludedColumnsWhenSkipDisabled() t
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
TestHelper.execute("INSERT INTO updates_test.debezium_test (id,white,black) VALUES (1,1,1);");
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PublicGeometryIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PublicGeometryIT.java
index 454e8af3cd6..67a1b27861a 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PublicGeometryIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/PublicGeometryIT.java
@@ -90,7 +90,7 @@ public void shouldReceiveChangesForInsertsWithPostgisTypes() throws Exception {
}
private void setupRecordsProducer(Configuration.Builder config) {
- start(YBPostgresConnector.class, config
+ start(YugabyteDBConnector.class, config
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.build());
assertConnectorIsRunning();
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsSnapshotProducerIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsSnapshotProducerIT.java
index 44146d33241..551504558d8 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsSnapshotProducerIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsSnapshotProducerIT.java
@@ -1218,7 +1218,7 @@ public void shouldIncludePartitionedTableIntoSnapshot() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue())
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.part");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -1256,7 +1256,7 @@ public void shouldGenerateSnapshotWhenSignalDataCollectionIsPresentWithoutTableI
private void buildNoStreamProducer(Configuration.Builder config) {
alterConfig(config);
- start(YBPostgresConnector.class, config
+ start(YugabyteDBConnector.class, config
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY)
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
@@ -1266,7 +1266,7 @@ private void buildNoStreamProducer(Configuration.Builder config) {
private void buildWithStreamProducer(Configuration.Builder config) {
alterConfig(config);
- start(YBPostgresConnector.class, config
+ start(YugabyteDBConnector.class, config
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.ALWAYS)
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsStreamProducerIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsStreamProducerIT.java
index ea4611af835..1967ea0006f 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsStreamProducerIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/RecordsStreamProducerIT.java
@@ -150,7 +150,7 @@ public void before() throws Exception {
private void startConnector(Function customConfig, boolean waitForSnapshot, Predicate isStopRecord)
throws InterruptedException {
- start(YBPostgresConnector.class, new PostgresConnectorConfig(customConfig.apply(TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, new PostgresConnectorConfig(customConfig.apply(TestHelper.defaultConfig()
.with(PostgresConnectorConfig.INCLUDE_UNKNOWN_DATATYPES, false)
.with(PostgresConnectorConfig.SCHEMA_EXCLUDE_LIST, "postgis")
.with(PostgresConnectorConfig.SNAPSHOT_MODE, waitForSnapshot ? SnapshotMode.INITIAL : SnapshotMode.NEVER))
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SignalsIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SignalsIT.java
index c081b44f401..a83df14805f 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SignalsIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SignalsIT.java
@@ -70,7 +70,7 @@ public void signalLog() throws InterruptedException {
.with(PostgresConnectorConfig.SIGNAL_DATA_COLLECTION, "s1.debezium_signal")
.with(CommonConnectorConfig.SIGNAL_POLL_INTERVAL_MS, "500")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.waitForDefaultReplicationSlotBeActive();
@@ -105,7 +105,7 @@ public void signalingDisabled() throws InterruptedException {
.with(CommonConnectorConfig.SIGNAL_POLL_INTERVAL_MS, "500")
.with(CommonConnectorConfig.SIGNAL_ENABLED_CHANNELS, "")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.waitForDefaultReplicationSlotBeActive();
@@ -138,7 +138,7 @@ public void signalSchemaChange() throws InterruptedException {
.with(PostgresConnectorConfig.SIGNAL_DATA_COLLECTION, "s1.debezium_signal")
.with(CommonConnectorConfig.SIGNAL_POLL_INTERVAL_MS, "500")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.waitForDefaultReplicationSlotBeActive();
@@ -218,7 +218,7 @@ public void jmxSignals() throws Exception {
.with(CommonConnectorConfig.SIGNAL_POLL_INTERVAL_MS, "500")
.with(CommonConnectorConfig.SIGNAL_ENABLED_CHANNELS, "jmx")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.waitForDefaultReplicationSlotBeActive();
@@ -244,7 +244,7 @@ public void customAction() throws Exception {
.with(CommonConnectorConfig.SIGNAL_POLL_INTERVAL_MS, "500")
.with(CommonConnectorConfig.SIGNAL_ENABLED_CHANNELS, "jmx")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.waitForDefaultReplicationSlotBeActive();
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SnapshotWithOverridesProducerIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SnapshotWithOverridesProducerIT.java
index 0beef910bdd..0257196eff4 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SnapshotWithOverridesProducerIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/SnapshotWithOverridesProducerIT.java
@@ -86,7 +86,7 @@ public void shouldUseMultipleOverriddenSelectStatementsDuringSnapshotting() thro
}
private void buildProducer(Configuration.Builder config) {
- start(YBPostgresConnector.class, config
+ start(YugabyteDBConnector.class, config
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY)
.build());
assertConnectorIsRunning();
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TablesWithoutPrimaryKeyIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TablesWithoutPrimaryKeyIT.java
index 3a9c451d9f9..b0493525f77 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TablesWithoutPrimaryKeyIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TablesWithoutPrimaryKeyIT.java
@@ -44,7 +44,7 @@ public void before() throws SQLException {
public void shouldProcessFromSnapshot() throws Exception {
TestHelper.execute(STATEMENTS);
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "nopk")
.build());
@@ -66,7 +66,7 @@ public void shouldProcessFromSnapshot() throws Exception {
public void shouldProcessFromSnapshotOld() throws Exception {
TestHelper.execute(STATEMENTS);
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "nopk")
.build());
@@ -86,7 +86,7 @@ public void shouldProcessFromSnapshotOld() throws Exception {
@Test
public void shouldProcessFromStreaming() throws Exception {
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "nopk")
.build());
@@ -125,7 +125,7 @@ public void shouldProcessFromStreaming() throws Exception {
@Test
public void shouldProcessFromStreamingOld() throws Exception {
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "nopk")
.build());
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TransactionMetadataIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TransactionMetadataIT.java
index 3ab3ba1e94c..1674f342822 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TransactionMetadataIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/TransactionMetadataIT.java
@@ -80,7 +80,7 @@ public void transactionMetadata() throws InterruptedException {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.PROVIDE_TRANSACTION_METADATA, true)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.waitForDefaultReplicationSlotBeActive();
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorConfigDefTest.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorConfigDefTest.java
similarity index 93%
rename from debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorConfigDefTest.java
rename to debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorConfigDefTest.java
index 1ae5e9ab5a9..c17ecb4f681 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorConfigDefTest.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorConfigDefTest.java
@@ -12,10 +12,10 @@
import io.debezium.config.ConfigDefinitionMetadataTest;
import io.debezium.config.Configuration;
-public class YBPostgresConnectorConfigDefTest extends ConfigDefinitionMetadataTest {
+public class YugabyteDBConnectorConfigDefTest extends ConfigDefinitionMetadataTest {
- public YBPostgresConnectorConfigDefTest() {
- super(new YBPostgresConnector());
+ public YugabyteDBConnectorConfigDefTest() {
+ super(new YugabyteDBConnector());
}
@Test
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorIT.java
similarity index 96%
rename from debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorIT.java
rename to debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorIT.java
index 6531ed9f732..a85f7f04f7d 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorIT.java
@@ -107,12 +107,12 @@
import org.slf4j.LoggerFactory;
/**
- * Integration test for {@link YBPostgresConnector} using an {@link io.debezium.engine.DebeziumEngine}
+ * Integration test for {@link YugabyteDBConnector} using an {@link io.debezium.engine.DebeziumEngine}
*
* @author Horia Chiorean (hchiorea@redhat.com)
*/
-public class YBPostgresConnectorIT extends AbstractConnectorTest {
- private static final Logger LOGGER = LoggerFactory.getLogger(YBPostgresConnectorIT.class);
+public class YugabyteDBConnectorIT extends AbstractConnectorTest {
+ private static final Logger LOGGER = LoggerFactory.getLogger(YugabyteDBConnectorIT.class);
/*
* Specific tests that need to extend the initial DDL set should do it in a form of
@@ -127,7 +127,7 @@ public class YBPostgresConnectorIT extends AbstractConnectorTest {
"CREATE TABLE s1.a (pk SERIAL, aa integer, PRIMARY KEY(pk));" +
"CREATE TABLE s2.a (pk SERIAL, aa integer, bb varchar(20), PRIMARY KEY(pk));";
protected static final String SETUP_TABLES_STMT = CREATE_TABLES_STMT + INSERT_STMT;
- private YBPostgresConnector connector;
+ private YugabyteDBConnector connector;
@Rule
public final TestRule skipName = new SkipTestDependingOnDecoderPluginNameRule();
@@ -151,7 +151,7 @@ public void after() {
@Test
public void shouldValidateConnectorConfigDef() {
- connector = new YBPostgresConnector();
+ connector = new YugabyteDBConnector();
ConfigDef configDef = connector.config();
assertThat(configDef).isNotNull();
PostgresConnectorConfig.ALL_FIELDS.forEach(this::validateFieldDef);
@@ -164,7 +164,7 @@ public void shouldNotStartWithInvalidConfiguration() throws Exception {
// we expect the engine will log at least one error, so preface it ...
logger.info("Attempting to start the connector with an INVALID configuration, so MULTIPLE error messages & one exceptions will appear in the log");
- start(YBPostgresConnector.class, config, (success, msg, error) -> {
+ start(YugabyteDBConnector.class, config, (success, msg, error) -> {
assertThat(success).isFalse();
assertThat(error).isNotNull();
});
@@ -174,7 +174,7 @@ public void shouldNotStartWithInvalidConfiguration() throws Exception {
@Test
public void shouldValidateMinimalConfiguration() throws Exception {
Configuration config = TestHelper.defaultConfig().build();
- Config validateConfig = new YBPostgresConnector().validate(config.asMap());
+ Config validateConfig = new YugabyteDBConnector().validate(config.asMap());
validateConfig.configValues().forEach(configValue -> assertTrue("Unexpected error for: " + configValue.name(),
configValue.errorMessages().isEmpty()));
}
@@ -193,7 +193,7 @@ public void shouldNotStartWithInvalidSlotConfigAndUserRoles() throws Exception {
.with(PostgresConnectorConfig.SLOT_NAME, ReplicationConnection.Builder.DEFAULT_SLOT_NAME)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning();
Configuration failingConfig = TestHelper.defaultConfig()
@@ -203,7 +203,7 @@ public void shouldNotStartWithInvalidSlotConfigAndUserRoles() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.SLOT_NAME, ReplicationConnection.Builder.DEFAULT_SLOT_NAME)
.build();
- List validatedConfig = new YBPostgresConnector().validate(failingConfig.asMap()).configValues();
+ List validatedConfig = new YugabyteDBConnector().validate(failingConfig.asMap()).configValues();
final List invalidProperties = Collections.singletonList("database.user");
validatedConfig.forEach(
@@ -218,7 +218,7 @@ public void shouldNotStartWithInvalidSlotConfigAndUserRoles() throws Exception {
public void shouldValidateConfiguration() throws Exception {
// use an empty configuration which should be invalid because of the lack of DB connection details
Configuration config = Configuration.create().build();
- YBPostgresConnector connector = new YBPostgresConnector();
+ YugabyteDBConnector connector = new YugabyteDBConnector();
Config validatedConfig = connector.validate(config.asMap());
// validate that the required fields have errors
assertConfigurationErrors(validatedConfig, PostgresConnectorConfig.HOSTNAME, 1);
@@ -263,7 +263,7 @@ public void shouldValidateReplicationSlotName() throws Exception {
Configuration config = Configuration.create()
.with(PostgresConnectorConfig.SLOT_NAME, "xx-aa")
.build();
- YBPostgresConnector connector = new YBPostgresConnector();
+ YugabyteDBConnector connector = new YugabyteDBConnector();
Config validatedConfig = connector.validate(config.asMap());
assertConfigurationErrors(validatedConfig, PostgresConnectorConfig.SLOT_NAME, 1);
@@ -275,7 +275,7 @@ public void shouldSupportSSLParameters() throws Exception {
// SSL is enabled
Configuration config = TestHelper.defaultConfig().with(PostgresConnectorConfig.SSL_MODE,
PostgresConnectorConfig.SecureConnectionMode.REQUIRED).build();
- start(YBPostgresConnector.class, config, (success, msg, error) -> {
+ start(YugabyteDBConnector.class, config, (success, msg, error) -> {
if (TestHelper.shouldSSLConnectionFail()) {
// we expect the task to fail at startup when we're printing the server info
assertThat(success).isFalse();
@@ -301,7 +301,7 @@ public void shouldProduceEventsWithInitialSnapshot() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
// check the records from the snapshot
@@ -320,7 +320,7 @@ public void shouldProduceEventsWithInitialSnapshot() throws Exception {
// start the connector back up and check that a new snapshot has not been performed (we're running initial only mode)
// but the 2 records that we were inserted while we were down will be retrieved
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
assertRecordsAfterInsert(2, 3, 3);
@@ -333,7 +333,7 @@ public void initialSnapshotWithExistingSlot() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
// now stop the connector
stopConnector();
@@ -350,7 +350,7 @@ public void initialSnapshotWithExistingSlot() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilderInitial.build());
+ start(YugabyteDBConnector.class, configBuilderInitial.build());
assertConnectorIsRunning();
assertRecordsFromSnapshot(2, 1, 1);
@@ -361,7 +361,7 @@ public void initialSnapshotWithExistingSlot() throws Exception {
@FixFor("DBZ-1235")
public void shouldUseMillisecondsForTransactionCommitTime() throws InterruptedException {
TestHelper.execute(SETUP_TABLES_STMT);
- start(YBPostgresConnector.class, TestHelper.defaultConfig().build());
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig().build());
assertConnectorIsRunning();
// check records from snapshot
@@ -395,7 +395,7 @@ public void shouldConsumeMessagesFromSnapshot() throws Exception {
.with(PostgresConnectorConfig.MAX_QUEUE_SIZE, recordCount / 2)
.with(PostgresConnectorConfig.MAX_BATCH_SIZE, 10)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -416,7 +416,7 @@ public void shouldConsumeMessagesFromSnapshotOld() throws Exception {
.with(PostgresConnectorConfig.MAX_QUEUE_SIZE, recordCount / 2)
.with(PostgresConnectorConfig.MAX_BATCH_SIZE, 10)
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -447,7 +447,7 @@ public void shouldReceiveChangesForChangePKColumnDefinition() throws Exception {
"CREATE TABLE changepk.test_table (pk SERIAL, text TEXT, PRIMARY KEY(pk));",
"INSERT INTO changepk.test_table(text) VALUES ('insert');");
- start(YBPostgresConnector.class, config.getConfig());
+ start(YugabyteDBConnector.class, config.getConfig());
assertConnectorIsRunning();
@@ -488,7 +488,7 @@ public void shouldReceiveChangesForChangePKColumnDefinition() throws Exception {
+ "ALTER TABLE changepk.test_table ADD PRIMARY KEY(newpk,pk3);"
+ "INSERT INTO changepk.test_table VALUES(5, 'dropandaddpkcol',10)");
- start(YBPostgresConnector.class, config.getConfig());
+ start(YugabyteDBConnector.class, config.getConfig());
records = consumeRecordsByTopic(2);
@@ -548,7 +548,7 @@ public void shouldReceiveChangesForChangeColumnDefault() throws Exception {
final String topicName = topicName("default_change.test_table");
- start(YBPostgresConnector.class, config.getConfig());
+ start(YugabyteDBConnector.class, config.getConfig());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -630,7 +630,7 @@ public void shouldReceiveChangesForChangeColumnDefault() throws Exception {
TestHelper.execute("INSERT INTO default_change.test_table(i, text) VALUES (DEFAULT, DEFAULT);");
- start(YBPostgresConnector.class, config.getConfig());
+ start(YugabyteDBConnector.class, config.getConfig());
assertConnectorIsRunning();
@@ -706,7 +706,7 @@ public void showThatSchemaColumnDefaultMayApplyRetroactively() throws Exception
"CREATE TABLE default_change.test_table (pk SERIAL, i INT DEFAULT 1, text TEXT DEFAULT 'foo', PRIMARY KEY(pk));",
"INSERT INTO default_change.test_table(i, text) VALUES (DEFAULT, DEFAULT);");
- start(YBPostgresConnector.class, config.getConfig());
+ start(YugabyteDBConnector.class, config.getConfig());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -738,7 +738,7 @@ public void showThatSchemaColumnDefaultMayApplyRetroactively() throws Exception
"ALTER TABLE default_change.test_table ADD COLUMN tstz TIMESTAMPTZ DEFAULT '2021-03-20 14:44:28 +1'::TIMESTAMPTZ;",
"INSERT INTO default_change.test_table(i, text, bi, tstz) VALUES (DEFAULT, DEFAULT, DEFAULT, DEFAULT);");
- start(YBPostgresConnector.class, config.getConfig());
+ start(YugabyteDBConnector.class, config.getConfig());
assertConnectorIsRunning();
@@ -810,7 +810,7 @@ public void shouldIgnoreEventsForDeletedTable() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -830,7 +830,7 @@ public void shouldIgnoreEventsForDeletedTable() throws Exception {
TestHelper.execute(INSERT_STMT);
TestHelper.execute("DROP TABLE s1.a");
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -848,7 +848,7 @@ public void shouldNotIgnoreEventsForDeletedTable() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -868,7 +868,7 @@ public void shouldNotIgnoreEventsForDeletedTable() throws Exception {
TestHelper.execute(INSERT_STMT);
TestHelper.execute("DROP TABLE s1.a");
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -886,7 +886,7 @@ public void shouldIgnoreViews() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -907,7 +907,7 @@ public void shouldIgnoreViews() throws Exception {
// start the connector back up and check that a new snapshot has not been performed (we're running initial only mode)
// but the 2 records that we were inserted while we were down will be retrieved
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -923,7 +923,7 @@ public void shouldLimitDecoderLog() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -944,7 +944,7 @@ public void shouldLimitDecoderLog() throws Exception {
// start the connector back up and check that a new snapshot has not been performed (we're running initial only mode)
// but the 2 records that we were inserted while we were down will be retrieved
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -962,7 +962,7 @@ public void shouldExecuteOnConnectStatements() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.ON_CONNECT_STATEMENTS, "INSERT INTO s1.a (aa) VALUES (2); INSERT INTO s2.a (aa, bb) VALUES (2, 'hello;; world');")
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -989,7 +989,7 @@ public void shouldProduceEventsWhenSnapshotsAreNeverAllowed() throws Interrupted
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -1013,7 +1013,7 @@ public void shouldNotProduceEventsWithInitialOnlySnapshot() throws InterruptedEx
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// check the records from the snapshot
@@ -1033,7 +1033,7 @@ public void shouldProduceEventsWhenAlwaysTakingSnapshots() throws InterruptedExc
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.ALWAYS.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -1048,7 +1048,7 @@ public void shouldProduceEventsWhenAlwaysTakingSnapshots() throws InterruptedExc
assertNoRecordsToConsume();
// start the connector back up and check that a new snapshot has been performed
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -1065,7 +1065,7 @@ public void shouldHaveBeforeImageOfUpdatedRow() throws InterruptedException {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -1112,7 +1112,7 @@ public void shouldResumeSnapshotIfFailingMidstream() throws Exception {
fail("A controlled exception was expected....");
}
};
- start(YBPostgresConnector.class, configBuilder.build(), completionCallback, stopOnPKPredicate(2));
+ start(YugabyteDBConnector.class, configBuilder.build(), completionCallback, stopOnPKPredicate(2));
// YB Note: Increasing the wait time since the connector is taking slightly higher time to initialize.
// wait until we know we've raised the exception at startup AND the engine has been shutdown
if (!latch.await(TestHelper.waitTimeForRecords() * 15, TimeUnit.SECONDS)) {
@@ -1128,7 +1128,7 @@ public void shouldResumeSnapshotIfFailingMidstream() throws Exception {
// make sure there are no records to consume
assertNoRecordsToConsume();
// start the connector back up and check that it took another full snapshot since previously it was stopped midstream
- start(YBPostgresConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
+ start(YugabyteDBConnector.class, configBuilder.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE).build());
assertConnectorIsRunning();
// check that the snapshot was recreated
@@ -1152,7 +1152,7 @@ public void shouldRecoverFromRetriableException() throws Exception {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
@@ -1184,7 +1184,7 @@ public void shouldUpdateReplicaIdentity() throws Exception {
.with(PostgresConnectorConfig.REPLICA_IDENTITY_AUTOSET_VALUES, "s1.a:FULL,s2.a:DEFAULT")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1217,7 +1217,7 @@ public void shouldUpdateReplicaIdentityWithRegExp() throws Exception {
.with(PostgresConnectorConfig.REPLICA_IDENTITY_AUTOSET_VALUES, "(.*).a:FULL,s2.*:NOTHING")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1251,7 +1251,7 @@ public void shouldNotUpdateReplicaIdentityWithRegExpDuplicated() throws Exceptio
.with(PostgresConnectorConfig.REPLICA_IDENTITY_AUTOSET_VALUES, "s.*:FULL,s2.*:NOTHING")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1279,7 +1279,7 @@ public void shouldUpdateReplicaIdentityWithOneTable() throws Exception {
.with(PostgresConnectorConfig.REPLICA_IDENTITY_AUTOSET_VALUES, "s1.a:FULL")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1309,7 +1309,7 @@ public void shouldUpdateReplicaIdentityUsingIndex() throws Exception {
.with(PostgresConnectorConfig.REPLICA_IDENTITY_AUTOSET_VALUES, "s1.a:FULL,s2.a:INDEX a_pkey")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1349,7 +1349,7 @@ public void shouldLogOwnershipErrorForReplicaIdentityUpdate() throws Exception {
.with("database.password", "role_2_pass")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1374,7 +1374,7 @@ public void shouldCheckTablesToUpdateReplicaIdentityAreCaptured() throws Excepti
.with(PostgresConnectorConfig.REPLICA_IDENTITY_AUTOSET_VALUES, "s1.a:FULL,s2.b:DEFAULT")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -1424,7 +1424,7 @@ public void shouldTakeExcludeListFiltersIntoAccount() throws Exception {
.with(PostgresConnectorConfig.TABLE_EXCLUDE_LIST, ".+b")
.with(PostgresConnectorConfig.COLUMN_EXCLUDE_LIST, ".+bb");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
// check the records from the snapshot take the filters into account
@@ -1470,7 +1470,7 @@ public void shouldTakeBlacklistFiltersIntoAccount() throws Exception {
.with(PostgresConnectorConfig.TABLE_EXCLUDE_LIST, ".+b")
.with(PostgresConnectorConfig.COLUMN_EXCLUDE_LIST, ".+bb");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
// check the records from the snapshot take the filters into account
@@ -1513,7 +1513,7 @@ public void shouldTakeColumnIncludeListFilterIntoAccount() throws Exception {
.with("column.mask.with.5.chars", ".+cc")
.with(PostgresConnectorConfig.COLUMN_INCLUDE_LIST, ".+aa,.+cc");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(1);
@@ -1542,7 +1542,7 @@ public void shouldRemoveWhiteSpaceChars() throws Exception {
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1")
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, tableWhitelistWithWhitespace);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(2);
@@ -1572,7 +1572,7 @@ public void shouldRemoveWhiteSpaceCharsOld() throws Exception {
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1")
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, tableWhitelistWithWhitespace);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(2);
@@ -1600,7 +1600,7 @@ public void shouldCloseTxAfterTypeQuery() throws Exception {
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.b")
.with(PostgresConnectorConfig.INCLUDE_UNKNOWN_DATATYPES, true);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -1634,7 +1634,7 @@ public void shouldReplaceInvalidTopicNameCharacters() throws Exception {
.with(PostgresConnectorConfig.SCHEMA_INCLUDE_LIST, "s1")
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1\\.dbz_878_some\\|test@data");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(1);
@@ -1661,7 +1661,7 @@ public void shouldNotSendEmptyOffset() throws InterruptedException, SQLException
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.a")
.with(Heartbeat.HEARTBEAT_INTERVAL, 10)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
// Generate empty logical decoding message
@@ -1682,7 +1682,7 @@ public void shouldRegularlyFlushLsn() throws InterruptedException, SQLException
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.a")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
@@ -1727,7 +1727,7 @@ public void shouldRegularlyFlushLsnWithTxMonitoring() throws InterruptedExceptio
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.a")
.with(PostgresConnectorConfig.PROVIDE_TRANSACTION_METADATA, true)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
// there shouldn't be any snapshot records
@@ -1742,7 +1742,7 @@ public void shouldRegularlyFlushLsnWithTxMonitoring() throws InterruptedExceptio
stopConnector();
assertConnectorNotRunning();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
// there shouldn't be any snapshot records, only potentially transaction messages
@@ -1782,7 +1782,7 @@ public void shouldAllowForCustomSnapshot() throws InterruptedException {
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(1);
@@ -1813,7 +1813,7 @@ record = s2recs.get(0);
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
actualRecords = consumeRecordsByTopic(4);
@@ -1836,7 +1836,7 @@ public void shouldAllowForSelectiveSnapshot() throws InterruptedException {
.with(CommonConnectorConfig.SNAPSHOT_MODE_TABLES, "s1.a")
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
/* Snapshot must be taken only for the listed tables */
@@ -1863,7 +1863,7 @@ public void shouldAllowForSelectiveSnapshot() throws InterruptedException {
stopConnector();
/* start the connector back up and make sure snapshot is being taken */
- start(YBPostgresConnector.class, configBuilder
+ start(YugabyteDBConnector.class, configBuilder
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.SNAPSHOT_MODE_TABLES, "s2.a")
.build());
@@ -1892,7 +1892,7 @@ public void shouldAllowForExportedSnapshot() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// Consume records from the snapshot
@@ -1926,7 +1926,7 @@ public void shouldAllowForExportedSnapshot() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
TestHelper.execute(INSERT_STMT);
@@ -1962,7 +1962,7 @@ public void exportedSnapshotShouldNotSkipRecordOfParallelTx() throws Exception {
pgConnection.setAutoCommit(false);
pgConnection.executeWithoutCommitting(INSERT_STMT);
final AtomicBoolean inserted = new AtomicBoolean();
- start(YBPostgresConnector.class, config, loggingCompletion(), x -> false, x -> {
+ start(YugabyteDBConnector.class, config, loggingCompletion(), x -> false, x -> {
if (!inserted.get()) {
TestHelper.execute(INSERT_STMT);
try {
@@ -2011,7 +2011,7 @@ public void exportedSnapshotShouldNotSkipRecordOfParallelTxPgoutput() throws Exc
pgConnection.setAutoCommit(false);
pgConnection.executeWithoutCommitting(INSERT_STMT);
final AtomicBoolean inserted = new AtomicBoolean();
- start(YBPostgresConnector.class, config, loggingCompletion(), x -> false, x -> {
+ start(YugabyteDBConnector.class, config, loggingCompletion(), x -> false, x -> {
if (!inserted.get()) {
TestHelper.execute(INSERT_STMT);
try {
@@ -2051,7 +2051,7 @@ public void shouldPerformSnapshotOnceForInitialOnlySnapshotMode() throws Excepti
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// Lets wait for snapshot to finish before proceeding
@@ -2082,7 +2082,7 @@ public void shouldPerformSnapshotOnceForInitialOnlySnapshotMode() throws Excepti
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForConnectorShutdown("postgres", TestHelper.TEST_SERVER);
@@ -2101,7 +2101,7 @@ public void snapshotInitialOnlyFollowedByNever() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// now stop the connector
stopConnector();
@@ -2115,7 +2115,7 @@ public void snapshotInitialOnlyFollowedByNever() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// Lets wait for snapshot to finish before proceeding
@@ -2133,7 +2133,7 @@ public void snapshotInitialOnlyFollowedByNever() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
assertRecordsAfterInsert(2, 2, 2);
@@ -2149,7 +2149,7 @@ public void shouldResumeStreamingFromSlotPositionForCustomSnapshot() throws Exce
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomStartFromStreamingTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -2172,7 +2172,7 @@ public void shouldResumeStreamingFromSlotPositionForCustomSnapshot() throws Exce
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomStartFromStreamingTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -2210,7 +2210,7 @@ public void customSnapshotterSkipsTablesOnRestart() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.ALWAYS.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -2233,7 +2233,7 @@ public void customSnapshotterSkipsTablesOnRestart() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomPartialTableTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -2276,7 +2276,7 @@ public void customSnapshotterSkipsTablesOnRestartWithConcurrentTx() throws Excep
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.ALWAYS.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -2299,7 +2299,7 @@ public void customSnapshotterSkipsTablesOnRestartWithConcurrentTx() throws Excep
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomPartialTableTestSnapshot.class.getName())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
Awaitility.await()
@@ -2349,7 +2349,7 @@ public void testCustomSnapshotterSnapshotCompleteLifecycleHook() throws Exceptio
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.CUSTOM.getValue())
.with(PostgresConnectorConfig.SNAPSHOT_MODE_CLASS, CustomLifecycleHookTestSnapshot.class.getName())
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -2418,7 +2418,7 @@ public void testStreamingPerformance() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
final long recordsCount = 1000000;
final int batchSize = 1000;
@@ -2459,7 +2459,7 @@ public void testSnapshotPerformance() throws Exception {
batchInsertRecords(recordsCount, batchSize).get();
// start the connector only after we've finished inserting all the records
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
CompletableFuture.runAsync(() -> consumeRecords(recordsCount))
@@ -2482,7 +2482,7 @@ public void testEmptySchemaWarningAfterApplyingFilters() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue())
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "my_products");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForAvailableRecords(10 * (TestHelper.waitTimeForRecords() * 5), TimeUnit.MILLISECONDS);
@@ -2502,7 +2502,7 @@ public void testNoEmptySchemaWarningAfterApplyingFilters() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL_ONLY.getValue());
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForAvailableRecords(100, TimeUnit.MILLISECONDS);
@@ -2523,7 +2523,7 @@ public void testCustomPublicationNameUsed() throws Exception {
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.PUBLICATION_NAME, "cdc");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForAvailableRecords(100, TimeUnit.MILLISECONDS);
@@ -2541,7 +2541,7 @@ public void shouldRewriteIdentityKey() throws InterruptedException {
// rewrite key from table 'a': from {pk} to {pk, aa}
.with(PostgresConnectorConfig.MSG_KEY_COLUMNS, "(.*)1.a:pk,aa");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
waitForSnapshotToBeCompleted();
SourceRecords records = consumeRecordsByTopic(2);
records.recordsForTopic("test_server.s1.a").forEach(record -> {
@@ -2573,14 +2573,14 @@ public void shouldNotIssueWarningForNoMonitoredTablesAfterApplyingFilters() thro
.build();
// Start connector, verify that it does not log no captured tables warning
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForSnapshotToBeCompleted();
SourceRecords records = consumeRecordsByTopic(1);
assertThat(logInterceptor.containsMessage(DatabaseSchema.NO_CAPTURED_DATA_COLLECTIONS_WARNING)).isFalse();
stopConnector();
// Restart connector, verify it does not log no captured tables warning
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning();
assertThat(logInterceptor.containsMessage(DatabaseSchema.NO_CAPTURED_DATA_COLLECTIONS_WARNING)).isFalse();
}
@@ -2598,7 +2598,7 @@ public void shouldClearDatabaseWarnings() throws Exception {
.with(PostgresConnectorConfig.POLL_INTERVAL_MS, "10")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForSnapshotToBeCompleted();
Awaitility.await().atMost(Duration.ofSeconds(TestHelper.waitTimeForRecords() * 6))
.until(() -> logInterceptor.containsMessage("Server-side message: 'Exiting startup callback'"));
@@ -2622,7 +2622,7 @@ public void shouldCreatePublicationWhenReplicationSlotExists() throws Exception
// Start connector with no snapshot; by default replication slot and publication should be created
// Wait until streaming mode begins to proceed
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning();
// Check that publication was created
@@ -2635,7 +2635,7 @@ public void shouldCreatePublicationWhenReplicationSlotExists() throws Exception
// Create log interceptor and restart the connector, should observe publication gets re-created
final LogInterceptor interceptor = new LogInterceptor(PostgresReplicationConnection.class);
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning();
// YB Note: Increasing the wait time.
@@ -2655,7 +2655,7 @@ public void shouldConsumeEventsWithMaskedColumns() throws Exception {
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with("column.mask.with.5.chars", "s2.a.bb");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(2);
@@ -2718,7 +2718,7 @@ public void shouldConsumeEventsWithMaskedHashedColumns() throws Exception {
"CREATE TABLE s2.b (pk SERIAL, bb varchar(255), PRIMARY KEY(pk));");
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with("column.mask.hash.SHA-256.with.salt.CzQMA0cB5K", "s2.a.bb, s2.b.bb");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(2);
@@ -2797,7 +2797,7 @@ public void shouldConsumeEventsWithTruncatedColumns() throws Exception {
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with("column.truncate.to.3.chars", "s2.a.bb");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
SourceRecords actualRecords = consumeRecordsByTopic(2);
@@ -2861,7 +2861,7 @@ public void shouldAckLsnOnSourceByDefault() throws Exception {
.with(PostgresConnectorConfig.SLOT_NAME, ReplicationConnection.Builder.DEFAULT_SLOT_NAME)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, "false");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -2874,7 +2874,7 @@ public void shouldAckLsnOnSourceByDefault() throws Exception {
TestHelper.execute("INSERT INTO s2.a (aa,bb) VALUES (1, 'test');");
TestHelper.execute("UPDATE s2.a SET aa=2, bb='hello' WHERE pk=2;");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -2899,7 +2899,7 @@ public void testYBCustomChangesForUpdate() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s2.a");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForStreamingRunning();
TestHelper.waitFor(Duration.ofSeconds(5));
@@ -2953,7 +2953,7 @@ public void testSkipMessagesWithoutChange(ReplicaIdentityInfo.ReplicaIdentity re
.with(PostgresConnectorConfig.SKIP_MESSAGES_WITHOUT_CHANGE, true)
.with(PostgresConnectorConfig.COLUMN_INCLUDE_LIST, "s2.a.pk,s2.a.aa");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForStreamingRunning();
TestHelper.waitFor(Duration.ofSeconds(5));
@@ -3014,7 +3014,7 @@ public void customYBStructureShouldBePresentInSnapshotRecords() throws Exception
.with(PostgresConnectorConfig.SLOT_NAME, ReplicationConnection.Builder.DEFAULT_SLOT_NAME)
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s2.a");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -3047,7 +3047,7 @@ public void shouldNotAckLsnOnSource() throws Exception {
.with(PostgresConnectorConfig.SLOT_NAME, ReplicationConnection.Builder.DEFAULT_SLOT_NAME)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, "false");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -3062,7 +3062,7 @@ public void shouldNotAckLsnOnSource() throws Exception {
TestHelper.execute("INSERT INTO s2.a (aa,bb) VALUES (1, 'test');");
TestHelper.execute("UPDATE s2.a SET aa=2, bb='hello' WHERE pk=2;");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForStreamingRunning();
@@ -3086,7 +3086,7 @@ public void shouldOutputRecordsInCloudEventsFormat() throws Exception {
.with(CommonConnectorConfig.PROVIDE_TRANSACTION_METADATA, true)
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -3147,7 +3147,7 @@ public void testYBChangesForMultiHostConfiguration() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER)
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s2.a");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForStreamingRunning();
TestHelper.waitFor(Duration.ofSeconds(5));
@@ -3180,7 +3180,7 @@ public void shouldConfigureSubscriptionsForAllTablesByDefault() throws Exception
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.PUBLICATION_NAME, "cdc");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForAvailableRecords(100, TimeUnit.MILLISECONDS);
@@ -3207,7 +3207,7 @@ public void shouldConfigureSubscriptionsFromTableFilters() throws Exception {
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "public.numeric_table,public.text_table,s1.a,s2.a")
.with(PostgresConnectorConfig.PUBLICATION_AUTOCREATE_MODE, PostgresConnectorConfig.AutoCreateMode.FILTERED.getValue());
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForAvailableRecords(100, TimeUnit.MILLISECONDS);
@@ -3243,7 +3243,7 @@ public void shouldThrowWhenAutocreationIsDisabled() throws Exception {
assertEquals(error.getMessage(), "Publication autocreation is disabled, please create one and restart the connector.");
};
- start(YBPostgresConnector.class, configBuilder.build(), cb);
+ start(YugabyteDBConnector.class, configBuilder.build(), cb);
waitForAvailableRecords(100, TimeUnit.MILLISECONDS);
stopConnector();
@@ -3264,7 +3264,7 @@ public void shouldProduceMessagesOnlyForConfiguredTables() throws Exception {
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s2.a")
.with(PostgresConnectorConfig.PUBLICATION_AUTOCREATE_MODE, PostgresConnectorConfig.AutoCreateMode.FILTERED.getValue());
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -3288,7 +3288,7 @@ public void shouldProduceMessagesOnlyForConfiguredTables() throws Exception {
@FixFor("DBZ-2885")
@SkipWhenDecoderPluginNameIsNot(value = SkipWhenDecoderPluginNameIsNot.DecoderPluginName.PGOUTPUT, reason = "Publication configuration only valid for PGOUTPUT decoder")
public void shouldThrowWhenTableFiltersIsEmpty() throws Exception {
- final LogInterceptor logInterceptor = new LogInterceptor(YBPostgresConnectorIT.class);
+ final LogInterceptor logInterceptor = new LogInterceptor(YugabyteDBConnectorIT.class);
TestHelper.dropAllSchemas();
TestHelper.dropPublication("cdc");
@@ -3300,7 +3300,7 @@ public void shouldThrowWhenTableFiltersIsEmpty() throws Exception {
.with(PostgresConnectorConfig.PUBLICATION_AUTOCREATE_MODE, PostgresConnectorConfig.AutoCreateMode.FILTERED.getValue())
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "nonexistent.table");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorNotRunning();
assertTrue(logInterceptor.containsStacktraceElement("No table filters found for filtered publication cdc"));
}
@@ -3320,7 +3320,7 @@ public void shouldUpdatePublicationForConfiguredTables() throws Exception {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE)
.with(PostgresConnectorConfig.PUBLICATION_AUTOCREATE_MODE, PostgresConnectorConfig.AutoCreateMode.FILTERED.getValue());
- start(YBPostgresConnector.class, initalConfigBuilder.build());
+ start(YugabyteDBConnector.class, initalConfigBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -3349,7 +3349,7 @@ public void shouldUpdatePublicationForConfiguredTables() throws Exception {
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.a")
.with(PostgresConnectorConfig.PUBLICATION_AUTOCREATE_MODE, PostgresConnectorConfig.AutoCreateMode.FILTERED.getValue());
- start(YBPostgresConnector.class, updatedConfigBuilder.build());
+ start(YugabyteDBConnector.class, updatedConfigBuilder.build());
assertConnectorIsRunning();
// snapshot record s1.a
@@ -3388,7 +3388,7 @@ public void shouldUpdateExistingPublicationForConfiguredPartitionedTables() thro
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.part")
.with(PostgresConnectorConfig.PUBLICATION_AUTOCREATE_MODE, PostgresConnectorConfig.AutoCreateMode.FILTERED.getValue());
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
waitForSnapshotToBeCompleted();
@@ -3423,7 +3423,7 @@ public void shouldEmitNoEventsForSkippedCreateOperations() throws Exception {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.SKIPPED_OPERATIONS, Envelope.Operation.UPDATE.code())
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
assertNoRecordsToConsume();
@@ -3470,7 +3470,7 @@ public void nonSuperUserSnapshotAndStreaming() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilderInitial.build());
+ start(YugabyteDBConnector.class, configBuilderInitial.build());
assertConnectorIsRunning();
// insert some more records - these should not be part of the snapshot
@@ -3521,7 +3521,7 @@ private List getSequence(SourceRecord record) {
@FixFor("DBZ-2911")
public void shouldHaveLastCommitLsn() throws InterruptedException {
TestHelper.execute(SETUP_TABLES_STMT);
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.PROVIDE_TRANSACTION_METADATA, true)
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.NEVER.getValue())
.build());
@@ -3574,7 +3574,7 @@ public void testCreateNumericReplicationSlotName() throws Exception {
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SLOT_NAME, "12345");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
waitForStreamingRunning();
assertConnectorIsRunning();
}
@@ -3585,7 +3585,7 @@ public void testStreamingWithNumericReplicationSlotName() throws Exception {
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SLOT_NAME, "12345");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
waitForStreamingRunning();
assertConnectorIsRunning();
@@ -3608,7 +3608,7 @@ public void testStreamingWithNumericReplicationSlotName() throws Exception {
public void testShouldNotCloseConnectionFetchingMetadataWithNewDataTypes() throws Exception {
TestHelper.execute(CREATE_TABLES_STMT);
Configuration config = TestHelper.defaultConfig().build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning();
assertConnectorIsRunning();
@@ -3639,7 +3639,7 @@ public void shouldReselectToastColumnsOnPrimaryKeyChange() throws Exception {
TestHelper.execute("INSERT INTO s1.dbz5295 (pk,data,data2) values (1,'" + toastValue1 + "','" + toastValue2 + "');");
Configuration config = TestHelper.defaultConfig().build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning();
SourceRecords records = consumeRecordsByTopic(1);
@@ -3690,7 +3690,7 @@ public void shouldSuppressLoggingOptionalOfExcludedColumns() throws Exception {
Configuration config = TestHelper.defaultConfig()
.with("column.exclude.list", "s1.dbz5783.data")
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
@@ -3709,7 +3709,7 @@ public void shouldSuppressLoggingOptionalOfExcludedColumns() throws Exception {
@FixFor("DBZ-5739")
@SkipWhenDatabaseVersion(check = LESS_THAN, major = 11, reason = "This needs pg_replication_slot_advance which is supported only on Postgres 11+")
public void shouldStopConnectorOnSlotRecreation() throws InterruptedException {
- final LogInterceptor logInterceptor = new LogInterceptor(YBPostgresConnectorIT.class);
+ final LogInterceptor logInterceptor = new LogInterceptor(YugabyteDBConnectorIT.class);
TestHelper.execute(SETUP_TABLES_STMT);
Configuration.Builder configBuilder = TestHelper.defaultConfig()
@@ -3717,7 +3717,7 @@ public void shouldStopConnectorOnSlotRecreation() throws InterruptedException {
.with(CommonConnectorConfig.SNAPSHOT_MODE_TABLES, "s1.a")
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
consumeRecordsByTopic(1);
@@ -3732,7 +3732,7 @@ public void shouldStopConnectorOnSlotRecreation() throws InterruptedException {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.SLOT_SEEK_TO_KNOWN_OFFSET, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
Awaitility.await().atMost(TestHelper.waitTimeForRecords() * 5, TimeUnit.SECONDS)
.until(() -> logInterceptor.containsStacktraceElement("Cannot seek to the last known offset "));
assertConnectorNotRunning();
@@ -3750,7 +3750,7 @@ public void shouldSeekToCorrectOffset() throws InterruptedException {
.with(CommonConnectorConfig.SNAPSHOT_MODE_TABLES, "s1.a")
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.FALSE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
consumeRecordsByTopic(1);
@@ -3765,7 +3765,7 @@ public void shouldSeekToCorrectOffset() throws InterruptedException {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.SLOT_SEEK_TO_KNOWN_OFFSET, Boolean.TRUE);
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
consumeRecordsByTopic(1);
assertConnectorIsRunning();
@@ -3804,7 +3804,7 @@ public void shouldInvokeSnapshotterAbortedMethod() throws Exception {
}
};
- start(YBPostgresConnector.class, configBuilder.build(), completionCallback, stopOnPKPredicate(1));
+ start(YugabyteDBConnector.class, configBuilder.build(), completionCallback, stopOnPKPredicate(1));
// wait until we know we've raised the exception at startup AND the engine has been shutdown
if (!latch.await(TestHelper.waitTimeForRecords() * 5, TimeUnit.SECONDS)) {
@@ -3837,7 +3837,7 @@ public void shouldThrowRightExceptionWhenNoCustomSnapshotClassProvided() {
Configuration config = TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.CUSTOM.getValue())
.build();
- start(YBPostgresConnector.class, config, (success, msg, err) -> {
+ start(YugabyteDBConnector.class, config, (success, msg, err) -> {
error.set(err);
message.set(msg);
status.set(success);
@@ -3868,7 +3868,7 @@ public void shouldIncludeTableWithBackSlashInName() throws Exception {
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.back\\\\slash");
- start(YBPostgresConnector.class, configBuilder.build());
+ start(YugabyteDBConnector.class, configBuilder.build());
assertConnectorIsRunning();
TestHelper.execute("INSERT INTO s1.\"back\\slash\" (aa, bb) VALUES (3, 3);");
@@ -3896,7 +3896,7 @@ public void shouldAddNewFieldToSourceInfo() throws InterruptedException {
"CREATE SCHEMA IF NOT EXISTS s1;",
"CREATE TABLE s1.DBZ6076 (pk SERIAL, aa integer, PRIMARY KEY(pk));",
"INSERT INTO s1.DBZ6076 (aa) VALUES (1);");
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, SnapshotMode.INITIAL.name())
.with(PostgresConnectorConfig.TABLE_INCLUDE_LIST, "s1.DBZ6076")
.with(PostgresConnectorConfig.SOURCE_INFO_STRUCT_MAKER, CustomPostgresSourceInfoStructMaker.class.getName())
@@ -3926,7 +3926,7 @@ public void shouldAddNewFieldToSourceInfo() throws InterruptedException {
@FixFor("DBZ-6076")
public void shouldUseDefaultSourceInfoStructMaker() throws InterruptedException {
TestHelper.execute(SETUP_TABLES_STMT);
- start(YBPostgresConnector.class, TestHelper.defaultConfig()
+ start(YugabyteDBConnector.class, TestHelper.defaultConfig()
.build());
assertConnectorIsRunning();
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorTaskIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorTaskIT.java
similarity index 98%
rename from debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorTaskIT.java
rename to debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorTaskIT.java
index 9f58c6c5ecd..0d06df672f9 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YBPostgresConnectorTaskIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteDBConnectorTaskIT.java
@@ -22,7 +22,7 @@
/**
* Integration test for {@link PostgresConnectorTask} class.
*/
-public class YBPostgresConnectorTaskIT {
+public class YugabyteDBConnectorTaskIT {
@Test
@FixFor("DBZ-519")
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteReplicaIdentityIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteReplicaIdentityIT.java
index a0dcf2832bd..9d92f342bcd 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteReplicaIdentityIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/YugabyteReplicaIdentityIT.java
@@ -39,7 +39,7 @@ public class YugabyteReplicaIdentityIT extends AbstractConnectorTest {
private static final String INSERT_STMT = "INSERT INTO s1.a (aa) VALUES (1);" +
"INSERT INTO s2.a (aa) VALUES (1);";
- private YBPostgresConnector connector;
+ private YugabyteDBConnector connector;
@BeforeClass
public static void beforeClass() throws SQLException {
@@ -68,7 +68,7 @@ public void shouldProduceOldValuesWithReplicaIdentityFull() throws Exception {
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -106,7 +106,7 @@ public void shouldProduceExpectedValuesWithReplicaIdentityDefault() throws Excep
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -148,7 +148,7 @@ public void shouldProduceEventsWithValuesForChangedColumnWithReplicaIdentityChan
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -206,7 +206,7 @@ public void shouldThrowExceptionWithReplicaIdentityNothingOnUpdatesAndDeletes()
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -241,7 +241,7 @@ public void shouldHaveBeforeImageForDeletesForReplicaIdentityFull() throws Excep
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -282,7 +282,7 @@ public void shouldHaveBeforeImageForDeletesForReplicaIdentityDefault() throws Ex
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
@@ -324,7 +324,7 @@ public void shouldHaveBeforeImageForDeletesForReplicaIdentityChange() throws Exc
.with(PostgresConnectorConfig.SNAPSHOT_MODE, PostgresConnectorConfig.SnapshotMode.NEVER.getValue())
.with(PostgresConnectorConfig.DROP_SLOT_ON_STOP, Boolean.TRUE)
.build();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
assertConnectorIsRunning();
// YB Note: Added a wait for replication slot to be active.
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYBPostgresConnectorResourceIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYugabyteDBConnectorResourceIT.java
similarity index 98%
rename from debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYBPostgresConnectorResourceIT.java
rename to debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYugabyteDBConnectorResourceIT.java
index 1f8e74c8086..204e6808262 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYBPostgresConnectorResourceIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYugabyteDBConnectorResourceIT.java
@@ -14,6 +14,7 @@
import java.util.Locale;
import java.util.Map;
+import io.debezium.connector.postgresql.YugabyteDBConnector;
import org.junit.After;
import org.junit.Assume;
import org.junit.Before;
@@ -21,18 +22,17 @@
import org.junit.Test;
import io.debezium.connector.postgresql.Module;
-import io.debezium.connector.postgresql.YBPostgresConnector;
import io.debezium.connector.postgresql.PostgresConnectorConfig;
import io.debezium.testing.testcontainers.Connector;
import io.debezium.testing.testcontainers.ConnectorConfiguration;
import io.debezium.testing.testcontainers.testhelper.RestExtensionTestInfrastructure;
import io.restassured.http.ContentType;
-public class DebeziumYBPostgresConnectorResourceIT {
+public class DebeziumYugabyteDBConnectorResourceIT {
@BeforeClass
public static void checkCondition() {
- Assume.assumeThat("Skipping DebeziumYBPostgresConnectorResourceIT tests when assembly profile is not active!",
+ Assume.assumeThat("Skipping DebeziumYugabyteDBConnectorResourceIT tests when assembly profile is not active!",
System.getProperty("isAssemblyProfileActive", "false"),
is("true"));
}
@@ -84,7 +84,7 @@ public void testInvalidHostnameConnection() {
public void testInvalidConnection() {
given()
.port(RestExtensionTestInfrastructure.getDebeziumContainer().getFirstMappedPort())
- .when().contentType(ContentType.JSON).accept(ContentType.JSON).body("{\"connector.class\": \"" + YBPostgresConnector.class.getName() + "\"}")
+ .when().contentType(ContentType.JSON).accept(ContentType.JSON).body("{\"connector.class\": \"" + YugabyteDBConnector.class.getName() + "\"}")
.put(DebeziumPostgresConnectorResource.BASE_PATH + DebeziumPostgresConnectorResource.VALIDATE_CONNECTION_ENDPOINT)
.then().log().all()
.statusCode(200)
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYBPostgresConnectorResourceNoDatabaseIT.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYugabyteDBConnectorResourceNoDatabaseIT.java
similarity index 91%
rename from debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYBPostgresConnectorResourceNoDatabaseIT.java
rename to debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYugabyteDBConnectorResourceNoDatabaseIT.java
index 8a349a2863d..974b961e5eb 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYBPostgresConnectorResourceNoDatabaseIT.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/rest/DebeziumYugabyteDBConnectorResourceNoDatabaseIT.java
@@ -10,6 +10,7 @@
import static org.hamcrest.CoreMatchers.is;
import static org.hamcrest.Matchers.hasKey;
+import io.debezium.connector.postgresql.YugabyteDBConnector;
import org.junit.After;
import org.junit.Assume;
import org.junit.Before;
@@ -17,14 +18,13 @@
import org.junit.Test;
import io.debezium.connector.postgresql.Module;
-import io.debezium.connector.postgresql.YBPostgresConnector;
import io.debezium.testing.testcontainers.testhelper.RestExtensionTestInfrastructure;
-public class DebeziumYBPostgresConnectorResourceNoDatabaseIT {
+public class DebeziumYugabyteDBConnectorResourceNoDatabaseIT {
@BeforeClass
public static void checkCondition() {
- Assume.assumeThat("Skipping DebeziumYBPostgresConnectorResourceIT tests when assembly profile is not active!",
+ Assume.assumeThat("Skipping DebeziumYugabyteDBConnectorResourceIT tests when assembly profile is not active!",
System.getProperty("isAssemblyProfileActive", "false"),
is("true"));
}
@@ -65,7 +65,7 @@ public void testSchemaEndpoint() {
.body("properties.isEmpty()", is(false))
.body("x-connector-id", is("postgres"))
.body("x-version", is(Module.version()))
- .body("x-className", is(YBPostgresConnector.class.getName()))
+ .body("x-className", is(YugabyteDBConnector.class.getName()))
.body("properties", hasKey("topic.prefix"))
.body("properties", hasKey("plugin.name"))
.body("properties", hasKey("slot.name"))
diff --git a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/transforms/timescaledb/TimescaleDbDatabaseTest.java b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/transforms/timescaledb/TimescaleDbDatabaseTest.java
index 0a34dbdca3d..1d04e06fabd 100644
--- a/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/transforms/timescaledb/TimescaleDbDatabaseTest.java
+++ b/debezium-connector-postgres/src/test/java/io/debezium/connector/postgresql/transforms/timescaledb/TimescaleDbDatabaseTest.java
@@ -9,7 +9,7 @@
import java.sql.SQLException;
-import io.debezium.connector.postgresql.YBPostgresConnector;
+import io.debezium.connector.postgresql.YugabyteDBConnector;
import org.junit.After;
import org.junit.Before;
import org.junit.Test;
@@ -94,7 +94,7 @@ protected void insertData() throws SQLException {
public void shouldTransformChunks() throws Exception {
Testing.Print.enable();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
insertData();
@@ -112,7 +112,7 @@ public void shouldTransformChunks() throws Exception {
public void shouldTransformAggregates() throws Exception {
Testing.Print.enable();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
insertData();
@@ -142,7 +142,7 @@ public void shouldTransformAggregates() throws Exception {
public void shouldTransformCompressedChunks() throws Exception {
Testing.Print.enable();
- start(YBPostgresConnector.class, config);
+ start(YugabyteDBConnector.class, config);
waitForStreamingRunning("postgres", TestHelper.TEST_SERVER);
insertData();
diff --git a/debezium-connector-postgres/src/test/resources/logback-test.xml b/debezium-connector-postgres/src/test/resources/logback-test.xml
index 67df491d802..95faa1e192c 100644
--- a/debezium-connector-postgres/src/test/resources/logback-test.xml
+++ b/debezium-connector-postgres/src/test/resources/logback-test.xml
@@ -33,7 +33,7 @@
additivity="false">
-
+
diff --git a/debezium-connector-sqlserver/pom.xml b/debezium-connector-sqlserver/pom.xml
index 88cfa390913..2086562e102 100644
--- a/debezium-connector-sqlserver/pom.xml
+++ b/debezium-connector-sqlserver/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-core/pom.xml b/debezium-core/pom.xml
index c112243d4a9..aabff12fa9f 100644
--- a/debezium-core/pom.xml
+++ b/debezium-core/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-ddl-parser/pom.xml b/debezium-ddl-parser/pom.xml
index 64ff2292153..90b3139c008 100644
--- a/debezium-ddl-parser/pom.xml
+++ b/debezium-ddl-parser/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-embedded/pom.xml b/debezium-embedded/pom.xml
index 3f5ed4d0c50..c137bea99ab 100644
--- a/debezium-embedded/pom.xml
+++ b/debezium-embedded/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-interceptor/pom.xml b/debezium-interceptor/pom.xml
index 441142a2832..1c8bde902de 100644
--- a/debezium-interceptor/pom.xml
+++ b/debezium-interceptor/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-microbenchmark-oracle/pom.xml b/debezium-microbenchmark-oracle/pom.xml
index 0ee2b841fa5..2fee1d5ad9f 100644
--- a/debezium-microbenchmark-oracle/pom.xml
+++ b/debezium-microbenchmark-oracle/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-microbenchmark/pom.xml b/debezium-microbenchmark/pom.xml
index 80c9d661065..e42fd03a6a2 100644
--- a/debezium-microbenchmark/pom.xml
+++ b/debezium-microbenchmark/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-parent/pom.xml b/debezium-parent/pom.xml
index ea5476f62d7..87eda03a49c 100644
--- a/debezium-parent/pom.xml
+++ b/debezium-parent/pom.xml
@@ -4,7 +4,7 @@
io.debezium
debezium-build-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox-common/deployment/pom.xml b/debezium-quarkus-outbox-common/deployment/pom.xml
index 4a5e0661a5d..7666c570195 100644
--- a/debezium-quarkus-outbox-common/deployment/pom.xml
+++ b/debezium-quarkus-outbox-common/deployment/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-common-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox-common/pom.xml b/debezium-quarkus-outbox-common/pom.xml
index a153bd87f89..20a55ddda00 100644
--- a/debezium-quarkus-outbox-common/pom.xml
+++ b/debezium-quarkus-outbox-common/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
diff --git a/debezium-quarkus-outbox-common/runtime/pom.xml b/debezium-quarkus-outbox-common/runtime/pom.xml
index 69ef6766100..106474a8e8c 100644
--- a/debezium-quarkus-outbox-common/runtime/pom.xml
+++ b/debezium-quarkus-outbox-common/runtime/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-common-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox-reactive/deployment/pom.xml b/debezium-quarkus-outbox-reactive/deployment/pom.xml
index 799e3cc2d97..babab0d005b 100644
--- a/debezium-quarkus-outbox-reactive/deployment/pom.xml
+++ b/debezium-quarkus-outbox-reactive/deployment/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-reactive-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox-reactive/integration-tests/pom.xml b/debezium-quarkus-outbox-reactive/integration-tests/pom.xml
index bd294d8190a..e068ed8c08d 100644
--- a/debezium-quarkus-outbox-reactive/integration-tests/pom.xml
+++ b/debezium-quarkus-outbox-reactive/integration-tests/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-reactive-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox-reactive/pom.xml b/debezium-quarkus-outbox-reactive/pom.xml
index c6c8eda0ddf..bc7926e7691 100644
--- a/debezium-quarkus-outbox-reactive/pom.xml
+++ b/debezium-quarkus-outbox-reactive/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
diff --git a/debezium-quarkus-outbox-reactive/runtime/pom.xml b/debezium-quarkus-outbox-reactive/runtime/pom.xml
index 644dae0621c..3d51fc460bc 100644
--- a/debezium-quarkus-outbox-reactive/runtime/pom.xml
+++ b/debezium-quarkus-outbox-reactive/runtime/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-reactive-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox/deployment/pom.xml b/debezium-quarkus-outbox/deployment/pom.xml
index 35130dbb420..aacec9ac9d9 100644
--- a/debezium-quarkus-outbox/deployment/pom.xml
+++ b/debezium-quarkus-outbox/deployment/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox/integration-tests/pom.xml b/debezium-quarkus-outbox/integration-tests/pom.xml
index 9e658e4bca2..26acfb8181d 100644
--- a/debezium-quarkus-outbox/integration-tests/pom.xml
+++ b/debezium-quarkus-outbox/integration-tests/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-quarkus-outbox/pom.xml b/debezium-quarkus-outbox/pom.xml
index 487a996fe68..36d61f946ae 100644
--- a/debezium-quarkus-outbox/pom.xml
+++ b/debezium-quarkus-outbox/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
diff --git a/debezium-quarkus-outbox/runtime/pom.xml b/debezium-quarkus-outbox/runtime/pom.xml
index a3d926174c3..02ce93f00f1 100644
--- a/debezium-quarkus-outbox/runtime/pom.xml
+++ b/debezium-quarkus-outbox/runtime/pom.xml
@@ -6,7 +6,7 @@
io.debezium
debezium-quarkus-outbox-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-schema-generator/pom.xml b/debezium-schema-generator/pom.xml
index 04d1a784c8c..7a9288a747f 100644
--- a/debezium-schema-generator/pom.xml
+++ b/debezium-schema-generator/pom.xml
@@ -5,7 +5,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
diff --git a/debezium-scripting/debezium-scripting-languages/pom.xml b/debezium-scripting/debezium-scripting-languages/pom.xml
index 3014b278910..c9983eb96c3 100644
--- a/debezium-scripting/debezium-scripting-languages/pom.xml
+++ b/debezium-scripting/debezium-scripting-languages/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-scripting-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-scripting/debezium-scripting/pom.xml b/debezium-scripting/debezium-scripting/pom.xml
index 66af3e26dfb..d5563e6da80 100644
--- a/debezium-scripting/debezium-scripting/pom.xml
+++ b/debezium-scripting/debezium-scripting/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-scripting-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-scripting/pom.xml b/debezium-scripting/pom.xml
index 1f375d4d380..b61f43c6b08 100644
--- a/debezium-scripting/pom.xml
+++ b/debezium-scripting/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-azure-blob/pom.xml b/debezium-storage/debezium-storage-azure-blob/pom.xml
index a67ea8b5c0c..1ed9e55747a 100644
--- a/debezium-storage/debezium-storage-azure-blob/pom.xml
+++ b/debezium-storage/debezium-storage-azure-blob/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-file/pom.xml b/debezium-storage/debezium-storage-file/pom.xml
index 8595a6d60f5..bae852dae56 100644
--- a/debezium-storage/debezium-storage-file/pom.xml
+++ b/debezium-storage/debezium-storage-file/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-jdbc/pom.xml b/debezium-storage/debezium-storage-jdbc/pom.xml
index b7890abc484..b61574fb709 100644
--- a/debezium-storage/debezium-storage-jdbc/pom.xml
+++ b/debezium-storage/debezium-storage-jdbc/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-kafka/pom.xml b/debezium-storage/debezium-storage-kafka/pom.xml
index cd1d91f95a9..6448d2ac00f 100644
--- a/debezium-storage/debezium-storage-kafka/pom.xml
+++ b/debezium-storage/debezium-storage-kafka/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-redis/pom.xml b/debezium-storage/debezium-storage-redis/pom.xml
index dacac03bf8a..9ad8f14a357 100644
--- a/debezium-storage/debezium-storage-redis/pom.xml
+++ b/debezium-storage/debezium-storage-redis/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-rocketmq/pom.xml b/debezium-storage/debezium-storage-rocketmq/pom.xml
index 3f047e6e8af..058919dc9e9 100644
--- a/debezium-storage/debezium-storage-rocketmq/pom.xml
+++ b/debezium-storage/debezium-storage-rocketmq/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
diff --git a/debezium-storage/debezium-storage-s3/pom.xml b/debezium-storage/debezium-storage-s3/pom.xml
index 9990bb646bd..61a3d35b072 100644
--- a/debezium-storage/debezium-storage-s3/pom.xml
+++ b/debezium-storage/debezium-storage-s3/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/debezium-storage-tests/pom.xml b/debezium-storage/debezium-storage-tests/pom.xml
index d1fccf7f987..50976dba89d 100644
--- a/debezium-storage/debezium-storage-tests/pom.xml
+++ b/debezium-storage/debezium-storage-tests/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-storage
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-storage/pom.xml b/debezium-storage/pom.xml
index e6904d17d48..c7fcfc38bdf 100644
--- a/debezium-storage/pom.xml
+++ b/debezium-storage/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/debezium-testing/debezium-testing-system/pom.xml b/debezium-testing/debezium-testing-system/pom.xml
index 4505b7eccf4..fd70339d04b 100644
--- a/debezium-testing/debezium-testing-system/pom.xml
+++ b/debezium-testing/debezium-testing-system/pom.xml
@@ -4,7 +4,7 @@
io.debezium
debezium-testing
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
@@ -126,7 +126,7 @@
ORCLPDB1
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
http://debezium-artifact-server.${ocp.project.debezium}.svc.cluster.local:8080
diff --git a/debezium-testing/debezium-testing-testcontainers/pom.xml b/debezium-testing/debezium-testing-testcontainers/pom.xml
index 44470d695bf..e2656dd0386 100644
--- a/debezium-testing/debezium-testing-testcontainers/pom.xml
+++ b/debezium-testing/debezium-testing-testcontainers/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-testing
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../pom.xml
4.0.0
diff --git a/debezium-testing/pom.xml b/debezium-testing/pom.xml
index 7528354d87b..f6570fb5004 100644
--- a/debezium-testing/pom.xml
+++ b/debezium-testing/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../debezium-parent/pom.xml
4.0.0
diff --git a/documentation/antora.yml b/documentation/antora.yml
index df860db1bd7..6e1792ced49 100644
--- a/documentation/antora.yml
+++ b/documentation/antora.yml
@@ -8,7 +8,7 @@ nav:
asciidoc:
attributes:
- debezium-version: '2.5.2.ybpg.20241-SNAPSHOT.1'
+ debezium-version: 'dz.2.5.2.yb.2024.1-SNAPSHOT'
debezium-kafka-version: '3.6.1'
debezium-docker-label: '2.4'
DockerKafkaConnect: registry.redhat.io/amq7/amq-streams-kafka-28-rhel8:1.8.0
diff --git a/pom.xml b/pom.xml
index b0218a92ea4..fe07e687bf3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -10,7 +10,7 @@
io.debezium
debezium-build-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
Debezium Build Aggregator
Debezium is an open source change data capture platform
pom
diff --git a/support/checkstyle/pom.xml b/support/checkstyle/pom.xml
index 861df66cdc5..ee8f15b33db 100644
--- a/support/checkstyle/pom.xml
+++ b/support/checkstyle/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-build-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../../pom.xml
diff --git a/support/ide-configs/pom.xml b/support/ide-configs/pom.xml
index fab6413f6d2..e5bce3264fd 100644
--- a/support/ide-configs/pom.xml
+++ b/support/ide-configs/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-build-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../../pom.xml
diff --git a/support/revapi/pom.xml b/support/revapi/pom.xml
index 7ea1802fbd6..1c0aa633621 100644
--- a/support/revapi/pom.xml
+++ b/support/revapi/pom.xml
@@ -3,7 +3,7 @@
io.debezium
debezium-build-parent
- 2.5.2.ybpg.20241-SNAPSHOT.1
+ dz.2.5.2.yb.2024.1-SNAPSHOT
../../pom.xml