flink-connector-jdbc icon indicating copy to clipboard operation
flink-connector-jdbc copied to clipboard

Apache flink

Results 29 flink-connector-jdbc issues
Sort by recently updated
recently updated
newest added

1. the clickhouse in batch mode ,as sink and source 2. the clickhouse in streaming mode ,as sink

component=Connectors/JDBC

When there is a conflict between a field name and a keyword in a PostgreSQL table, it is necessary to use quotation marks

component=Connectors/JDBC

Remove redundant maven properties with upgrade of flink-connector-parent to 1.1.0

component=JDBC/Core
component=JDBC/Shaded

An SQL Server sink connector may fail with the following exception: ``` java.io.IOException: Writing records to JDBC failed. at org.apache.flink.connector.jdbc.internal.JdbcOutputFormat.writeRecord(JdbcOutputFormat.java:198) at org.apache.flink.connector.jdbc.internal.GenericJdbcSinkFunction.invoke(GenericJdbcSinkFunction.java:57) at org.apache.flink.streaming.api.operators.StreamSink.processElement(StreamSink.java:54) at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.pushToOperator(CopyingChainingOutput.java:82) at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.collect(CopyingChainingOutput.java:68) at org.apache.flink.streaming.api.operators.CountingOutput.collect(CountingOutput.java:62)...

component=JDBC/Core

Bump flink version to 1.20.0 for preparing lineage integration.

component=BuildSystem
component=JDBC/Core

The PR adds Elasticsearch dialect. Important facts: * `x-pack-sql-jdbc` dependency is on Elastic license which is not compatible with Apache license. Therefore: * `x-pack-sql-jdbc` has `provided` scope. * appropriate note...

component=Documentation
component=JDBC/Core

When using PostgreSQL JDBC Catalog an error is thrown if any of the tables has column of type `json` or `jsonb`. ``` java.lang.UnsupportedOperationException: Doesn't support Postgres type 'jsonb' yet ```...

component=JDBC/Postgres

fixes [FLINK-36303](https://issues.apache.org/jira/browse/FLINK-36303)

component=JDBC/Postgres

- Created the module flink-connector-jdbc-architecture to have all tests, we need to add the modules as dependency to validate that module.. - Created the package "org.apache.flink.connector.jdbc.core.util" to have classes of...

component=JDBC/Core