Modifier and Type | Method and Description |
---|---|
Set<TableId> |
JdbcConnection.readAllTableNames(String[] tableTypes)
Get the identifiers of all available tables.
|
Set<TableId> |
JdbcConnection.readTableNames(String databaseCatalog,
String schemaNamePattern,
String tableNamePattern,
String[] tableTypes)
Get the identifiers of the tables.
|
Modifier and Type | Method and Description |
---|---|
protected List<String> |
JdbcConnection.readPrimaryKeyNames(DatabaseMetaData metadata,
TableId id) |
protected List<String> |
JdbcConnection.readPrimaryKeyOrUniqueIndexNames(DatabaseMetaData metadata,
TableId id) |
protected Optional<ColumnEditor> |
JdbcConnection.readTableColumn(ResultSet columnMetadata,
TableId tableId,
Tables.ColumnNameFilter columnFilter)
Returns a
ColumnEditor representing the current record of the given result set of column metadata, if
included in column.include.list. |
List<String> |
JdbcConnection.readTableUniqueIndices(DatabaseMetaData metadata,
TableId id) |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotChangeEventSourceMetrics.rowsScanned(TableId tableId,
long numRows) |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotProgressListener.rowsScanned(TableId tableId,
long numRows) |
Modifier and Type | Field and Description |
---|---|
private TableId |
ChangeTable.changeTableId |
private TableId |
TableSchema.id |
private TableId |
TableImpl.id |
private TableId |
TableEditorImpl.id |
private TableId |
NoOpTableEditorImpl.id |
private TableId |
ChangeTable.sourceTableId |
private TableId |
ColumnId.tableId |
Modifier and Type | Field and Description |
---|---|
Set<TableId> |
RelationalSnapshotChangeEventSource.RelationalSnapshotContext.capturedTables |
private EventDispatcher<TableId> |
RelationalSnapshotChangeEventSource.dispatcher |
private Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.tableExclusions |
private Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.tableInclusions |
private TopicSelector<TableId> |
RelationalDatabaseSchema.topicSelector |
private ConcurrentMap<TableId,Table> |
Tables.TablesById.values |
private Set<TableId> |
Tables.TableIds.values |
private ConcurrentMap<TableId,TableSchema> |
RelationalDatabaseSchema.SchemasByTableId.values |
Modifier and Type | Method and Description |
---|---|
TableId |
ChangeTable.getChangeTableId() |
TableId |
ChangeTable.getSourceTableId() |
TableId |
TableSchema.id() |
TableId |
TableImpl.id() |
TableId |
Table.id()
Get the identifier for this table.
|
static TableId |
TableId.parse(String str)
Parse the supplied string, extracting up to the first 3 parts into a TableID.
|
protected static TableId |
TableId.parse(String[] parts,
int numParts,
boolean useCatalogBeforeSchema)
Parse the supplied string, extracting up to the first 3 parts into a TableID.
|
static TableId |
TableId.parse(String str,
boolean useCatalogBeforeSchema)
Parse the supplied string, extracting up to the first 3 parts into a TableID.
|
TableId |
TableEditorImpl.tableId() |
TableId |
TableEditor.tableId()
Get the identifier for this table.
|
TableId |
NoOpTableEditorImpl.tableId() |
TableId |
ColumnId.tableId()
Get the identifier for the table that owns this column.
|
TableId |
TableId.toLowercase() |
private TableId |
Tables.TablesById.toLowerCaseIfNeeded(TableId tableId) |
private TableId |
Tables.TableIds.toLowerCaseIfNeeded(TableId tableId) |
private TableId |
RelationalDatabaseSchema.SchemasByTableId.toLowerCaseIfNeeded(TableId tableId) |
Modifier and Type | Method and Description |
---|---|
Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.build()
|
private Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.buildStartingFromDbFilter(Predicate<String> dbFilter,
Predicate<String> schemaFilter,
Predicate<TableId> tableFilter) |
private Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.buildStartingFromSchemaFilter(Predicate<String> schemaFilter,
Predicate<TableId> tableFilter) |
Set<TableId> |
Tables.drainChanges() |
(package private) Set<Map.Entry<TableId,Table>> |
Tables.TablesById.entrySet() |
static Map<TableId,Predicate<Column>> |
ColumnId.filter(String columnExcludeList)
Create the map of predicate functions that specify which columns are to be included.
|
protected abstract Set<TableId> |
RelationalSnapshotChangeEventSource.getAllTableIds(RelationalSnapshotChangeEventSource.RelationalSnapshotContext snapshotContext)
Returns all candidate tables; the current filter configuration will be applied to the result set, resulting in
the effective set of captured tables.
|
Map<TableId,String> |
RelationalDatabaseConnectorConfig.getSnapshotSelectOverridesByTable()
Returns any SELECT overrides, if present.
|
Set<TableId> |
Tables.TablesById.ids() |
private Set<TableId> |
RelationalSnapshotChangeEventSource.sort(Set<TableId> capturedTables) |
Set<TableId> |
Tables.tableIds()
Get the set of
TableId s for which there is a Schema . |
Set<TableId> |
RelationalDatabaseSchema.tableIds()
Returns the set of table ids included in the current filter configuration.
|
Set<TableId> |
Tables.TableIds.toSet() |
private Stream<TableId> |
RelationalSnapshotChangeEventSource.toTableIds(Set<TableId> tableIds,
Pattern pattern) |
Modifier and Type | Method and Description |
---|---|
void |
Tables.TableIds.add(TableId tableId) |
private static String |
ColumnId.columnId(TableId tableId,
String columnName) |
int |
TableId.compareTo(TableId that) |
int |
TableId.compareToIgnoreCase(TableId that) |
protected ValueConverter[] |
TableSchemaBuilder.convertersForColumns(org.apache.kafka.connect.data.Schema schema,
TableId tableId,
List<Column> columns,
ColumnMappers mappers)
Obtain the array of converters for each column in a row.
|
protected StructGenerator |
TableSchemaBuilder.createKeyGenerator(org.apache.kafka.connect.data.Schema schema,
TableId columnSetName,
List<Column> columns)
Creates the function that produces a Kafka Connect key object for a row of data.
|
protected ValueConverter |
TableSchemaBuilder.createValueConverterFor(TableId tableId,
Column column,
org.apache.kafka.connect.data.Field fieldDefn)
Create a
ValueConverter that can be used to convert row values for the given column into the Kafka Connect value
object described by the field definition . |
protected StructGenerator |
TableSchemaBuilder.createValueGenerator(org.apache.kafka.connect.data.Schema schema,
TableId tableId,
List<Column> columns,
Tables.ColumnNameFilter filter,
ColumnMappers mappers)
Creates the function that produces a Kafka Connect value object for a row of data.
|
private Optional<String> |
RelationalSnapshotChangeEventSource.determineSnapshotSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext snapshotContext,
TableId tableId)
Returns a valid query string for the specified table, either given by the user via snapshot select overrides or
defaulting to a statement provided by the DB-specific change event source.
|
TableEditor |
Tables.editOrCreateTable(TableId tableId)
Obtain an editor for the table with the given ID.
|
TableEditor |
Tables.editTable(TableId tableId)
Obtain an editor for the table with the given ID.
|
protected String |
RelationalSnapshotChangeEventSource.enhanceOverriddenSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext snapshotContext,
String overriddenSelect,
TableId tableId)
This method is overridden for Oracle to implement "as of SCN" predicate
|
Table |
Tables.forTable(TableId tableId)
Obtain the definition of the identified table.
|
private String |
CustomConverterRegistry.fullColumnName(TableId table,
Column column) |
Table |
Tables.TablesById.get(TableId tableId) |
TableSchema |
RelationalDatabaseSchema.SchemasByTableId.get(TableId tableId) |
protected ChangeRecordEmitter |
RelationalSnapshotChangeEventSource.getChangeRecordEmitter(AbstractSnapshotChangeEventSource.SnapshotContext snapshotContext,
TableId tableId,
Object[] row)
Returns a
ChangeRecordEmitter producing the change records for the given table row. |
protected abstract Optional<String> |
RelationalSnapshotChangeEventSource.getSnapshotSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext snapshotContext,
TableId tableId)
Returns the SELECT statement to be used for scanning the given table or empty value if
the table will be streamed from but not snapshotted
|
Optional<ValueConverter> |
CustomConverterRegistry.getValueConverter(TableId table,
Column column)
Obtain a pre-registered converter for a given column.
|
boolean |
Tables.TableFilter.isIncluded(TableId tableId)
Determines whether the given table should be included in the current
DatabaseSchema . |
static TableEditor |
TableEditor.noOp(TableId id)
Create a new editor that does nothing.
|
Table |
Tables.overwriteTable(TableId tableId,
List<Column> columnDefs,
List<String> primaryKeyColumnNames,
String defaultCharsetName)
Add or update the definition for the identified table.
|
Table |
Tables.TablesById.put(TableId tableId,
Table updated) |
TableSchema |
RelationalDatabaseSchema.SchemasByTableId.put(TableId tableId,
TableSchema updated) |
Optional<org.apache.kafka.connect.data.SchemaBuilder> |
CustomConverterRegistry.registerConverterFor(TableId table,
Column column)
Create and register a converter for a given database column.
|
Table |
Tables.TablesById.remove(TableId tableId) |
TableSchema |
RelationalDatabaseSchema.SchemasByTableId.remove(TableId tableId) |
protected void |
RelationalDatabaseSchema.removeSchema(TableId id) |
Table |
Tables.removeTable(TableId tableId)
Remove the definition of the identified table.
|
Table |
Tables.renameTable(TableId existingTableId,
TableId newTableId)
Rename an existing table.
|
TableSchema |
RelationalDatabaseSchema.schemaFor(TableId id)
Get the
Schema information for the table with the given identifier, if that table exists and
is included by the filter configuration. |
Table |
RelationalDatabaseSchema.tableFor(TableId id)
Get the
Table meta-data for the table with the given identifier, if that table exists and is
included by the filter configuration |
TableEditor |
TableEditorImpl.tableId(TableId id) |
TableEditor |
TableEditor.tableId(TableId tableId)
Set the table identifier.
|
TableEditor |
NoOpTableEditorImpl.tableId(TableId id) |
private String |
TableSchemaBuilder.tableSchemaName(TableId tableId)
Returns the type schema name for the given table.
|
private TableId |
Tables.TablesById.toLowerCaseIfNeeded(TableId tableId) |
private TableId |
Tables.TableIds.toLowerCaseIfNeeded(TableId tableId) |
private TableId |
RelationalDatabaseSchema.SchemasByTableId.toLowerCaseIfNeeded(TableId tableId) |
String |
Selectors.TableIdToStringMapper.toString(TableId tableId) |
Table |
Tables.updateTable(TableId tableId,
Function<Table,Table> changer)
Add or update the definition for the identified table.
|
private ValueConverter |
TableSchemaBuilder.wrapInMappingConverterIfNeeded(ColumnMappers mappers,
TableId tableId,
Column column,
ValueConverter converter) |
Modifier and Type | Method and Description |
---|---|
private Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.buildStartingFromDbFilter(Predicate<String> dbFilter,
Predicate<String> schemaFilter,
Predicate<TableId> tableFilter) |
private Predicate<TableId> |
Selectors.TableSelectionPredicateBuilder.buildStartingFromSchemaFilter(Predicate<String> schemaFilter,
Predicate<TableId> tableFilter) |
(package private) void |
Tables.TablesById.forEach(BiConsumer<? super TableId,? super Table> action) |
static Tables.TableFilter |
Tables.TableFilter.fromPredicate(Predicate<TableId> predicate)
Creates a
Tables.TableFilter from the given predicate. |
private Set<TableId> |
RelationalSnapshotChangeEventSource.sort(Set<TableId> capturedTables) |
private Stream<TableId> |
RelationalSnapshotChangeEventSource.toTableIds(Set<TableId> tableIds,
Pattern pattern) |
Constructor and Description |
---|
ChangeTable(String captureInstance,
TableId sourceTableId,
TableId changeTableId,
int changeTableObjectId)
Creates an object that represents a source table's change table.
|
ColumnId(TableId tableId,
String columnName)
Create a new column identifier.
|
TableImpl(TableId id,
List<Column> sortedColumns,
List<String> pkColumnNames,
String defaultCharsetName) |
TableSchema(TableId id,
org.apache.kafka.connect.data.Schema keySchema,
StructGenerator keyGenerator,
Envelope envelopeSchema,
org.apache.kafka.connect.data.Schema valueSchema,
StructGenerator valueGenerator)
Create an instance with the specified
Schema s for the keys and values, and the functions that generate the
key and value for a given row of data. |
Modifier and Type | Field and Description |
---|---|
private TableId |
DdlParserListener.TableAlteredEvent.previousTableId |
private TableId |
DdlParserListener.TableEvent.tableId |
private TableId |
DdlParserListener.TableIndexEvent.tableId |
Modifier and Type | Method and Description |
---|---|
protected TableId |
LegacyDdlParser.parseQualifiedTableName(TokenStream.Marker start)
Parse the next tokens for a possibly qualified table name.
|
TableId |
DdlParserListener.TableAlteredEvent.previousTableId()
If the table was renamed, then get the old identifier of the table before it was renamed.
|
TableId |
AbstractDdlParser.resolveTableId(String schemaName,
String tableName)
Create a
TableId from the supplied schema and table names. |
TableId |
DdlParserListener.TableEvent.tableId()
Get the identifier of the primary table affected by this event.
|
TableId |
DdlParserListener.TableIndexEvent.tableId()
Get the identifier of the table to which the index applies.
|
Modifier and Type | Method and Description |
---|---|
protected List<TableId> |
LegacyDdlParser.parseQualifiedTableNames(TokenStream.Marker start)
Parse the next tokens for one or more comma-separated qualified table names.
|
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractDdlParser.signalAlterTable(TableId id,
TableId previousId,
String statement)
Signal an alter table event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalAlterTable(TableId id,
TableId previousId,
TokenStream.Marker statementStart)
Signal an alter table event to all listeners.
|
protected void |
AbstractDdlParser.signalAlterView(TableId id,
TableId previousId,
String statement)
Signal an alter view event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalAlterView(TableId id,
TableId previousId,
TokenStream.Marker statementStart)
Signal an alter view event to all listeners.
|
protected void |
AbstractDdlParser.signalCreateIndex(String indexName,
TableId id,
String statement)
Signal a create index event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalCreateIndex(String indexName,
TableId id,
TokenStream.Marker statementStart)
Signal a create index event to all listeners.
|
protected void |
AbstractDdlParser.signalCreateTable(TableId id,
String statement)
Signal a create table event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalCreateTable(TableId id,
TokenStream.Marker statementStart)
Signal a create table event to all listeners.
|
protected void |
AbstractDdlParser.signalCreateView(TableId id,
String statement)
Signal a create view event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalCreateView(TableId id,
TokenStream.Marker statementStart)
Signal a create view event to all listeners.
|
protected void |
AbstractDdlParser.signalDropIndex(String indexName,
TableId id,
String statement)
Signal a drop index event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalDropIndex(String indexName,
TableId id,
TokenStream.Marker statementStart)
Signal a drop index event to all listeners.
|
protected void |
AbstractDdlParser.signalDropTable(TableId id,
String statement)
Signal a drop table event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalDropTable(TableId id,
TokenStream.Marker statementStart)
Signal a drop table event to all listeners.
|
protected void |
AbstractDdlParser.signalDropView(TableId id,
String statement)
Signal a drop view event to ddl changes listener.
|
protected void |
LegacyDdlParser.signalDropView(TableId id,
TokenStream.Marker statementStart)
Signal a drop view event to all listeners.
|
protected void |
AbstractDdlParser.signalTruncateTable(TableId id,
String statement)
Signal a truncate table event to ddl changes listener.
|
Modifier and Type | Method and Description |
---|---|
private void |
DdlChanges.addTable(Set<TableId> tables,
DdlParserListener.Event event) |
boolean |
DdlChanges.anyMatch(Predicate<String> databaseFilter,
Predicate<TableId> tableFilter) |
void |
DdlChanges.DatabaseStatementConsumer.consume(String databaseName,
Set<TableId> tableList,
List<String> ddlStatements) |
void |
DdlChanges.DatabaseStatementStringConsumer.consume(String databaseName,
Set<TableId> tableList,
String ddlStatements) |
Constructor and Description |
---|
TableAlteredEvent(TableId tableId,
TableId previousTableId,
String ddlStatement,
boolean isView) |
TableCreatedEvent(TableId tableId,
String ddlStatement,
boolean isView) |
TableDroppedEvent(TableId tableId,
String ddlStatement,
boolean isView) |
TableEvent(DdlParserListener.EventType type,
TableId tableId,
String ddlStatement,
boolean isView) |
TableIndexCreatedEvent(String indexName,
TableId tableId,
String ddlStatement) |
TableIndexDroppedEvent(String indexName,
TableId tableId,
String ddlStatement) |
TableIndexEvent(DdlParserListener.EventType type,
String indexName,
TableId tableId,
String ddlStatement) |
TableTruncatedEvent(TableId tableId,
String ddlStatement,
boolean isView) |
Modifier and Type | Field and Description |
---|---|
private TableId |
TableChanges.TableChange.id |
Modifier and Type | Method and Description |
---|---|
TableId |
TableChanges.TableChange.getId() |
Modifier and Type | Method and Description |
---|---|
private static Table |
JsonTableChangeSerializer.fromDocument(TableId id,
Document document) |
Modifier and Type | Field and Description |
---|---|
protected BiPredicate<TableId,Column> |
ColumnMappers.MapperRule.predicate |
Modifier and Type | Method and Description |
---|---|
private TableId |
ColumnMappers.Builder.mappedTableId(TableId tableId) |
Modifier and Type | Method and Description |
---|---|
String |
ColumnMappers.Builder.fullyQualifiedColumnDatatype(TableId tableId,
Column column) |
String |
ColumnMappers.Builder.fullyQualifiedColumnName(TableId tableId,
Column column) |
String |
ColumnMappers.Builder.mappedTableColumnDatatype(TableId tableId,
Column column) |
String |
ColumnMappers.Builder.mappedTableColumnName(TableId tableId,
Column column) |
private TableId |
ColumnMappers.Builder.mappedTableId(TableId tableId) |
ColumnMapper |
ColumnMappers.mapperFor(TableId tableId,
Column column)
Get the value mapping function for the given column.
|
ValueConverter |
ColumnMappers.mappingConverterFor(TableId tableId,
Column column)
Get the value mapping function for the given column.
|
protected boolean |
ColumnMappers.MapperRule.matches(TableId tableId,
Column column) |
Constructor and Description |
---|
MapperRule(BiPredicate<TableId,Column> predicate,
ColumnMapper mapper) |
Copyright © 2020 JBoss by Red Hat. All rights reserved.