|
24 | 24 | import org.apache.flink.configuration.Configuration;
|
25 | 25 | import org.apache.flink.configuration.ReadableConfig;
|
26 | 26 | import org.apache.flink.connector.base.DeliveryGuarantee;
|
| 27 | +import org.apache.flink.connector.kafka.sink.KafkaPartitioner; |
27 | 28 | import org.apache.flink.streaming.connectors.kafka.config.BoundedMode;
|
28 | 29 | import org.apache.flink.streaming.connectors.kafka.config.StartupMode;
|
29 | 30 | import org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition;
|
30 | 31 | import org.apache.flink.streaming.connectors.kafka.partitioner.FlinkFixedPartitioner;
|
31 |
| -import org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaPartitioner; |
32 | 32 | import org.apache.flink.streaming.connectors.kafka.table.KafkaConnectorOptions.ScanBoundedMode;
|
33 | 33 | import org.apache.flink.streaming.connectors.kafka.table.KafkaConnectorOptions.ScanStartupMode;
|
34 | 34 | import org.apache.flink.streaming.connectors.kafka.table.KafkaConnectorOptions.ValueFieldsStrategy;
|
@@ -386,7 +386,7 @@ public static Properties getKafkaProperties(Map<String, String> tableOptions) {
|
386 | 386 | * The partitioner can be either "fixed", "round-robin" or a customized partitioner full class
|
387 | 387 | * name.
|
388 | 388 | */
|
389 |
| - public static Optional<FlinkKafkaPartitioner<RowData>> getFlinkKafkaPartitioner( |
| 389 | + public static Optional<KafkaPartitioner<RowData>> getFlinkKafkaPartitioner( |
390 | 390 | ReadableConfig tableOptions, ClassLoader classLoader) {
|
391 | 391 | return tableOptions
|
392 | 392 | .getOptional(SINK_PARTITIONER)
|
@@ -465,19 +465,19 @@ private static boolean hasKafkaClientProperties(Map<String, String> tableOptions
|
465 | 465 | }
|
466 | 466 |
|
467 | 467 | /** Returns a class value with the given class name. */
|
468 |
| - private static <T> FlinkKafkaPartitioner<T> initializePartitioner( |
| 468 | + private static <T> KafkaPartitioner<T> initializePartitioner( |
469 | 469 | String name, ClassLoader classLoader) {
|
470 | 470 | try {
|
471 | 471 | Class<?> clazz = Class.forName(name, true, classLoader);
|
472 |
| - if (!FlinkKafkaPartitioner.class.isAssignableFrom(clazz)) { |
| 472 | + if (!KafkaPartitioner.class.isAssignableFrom(clazz)) { |
473 | 473 | throw new ValidationException(
|
474 | 474 | String.format(
|
475 |
| - "Sink partitioner class '%s' should extend from the required class %s", |
476 |
| - name, FlinkKafkaPartitioner.class.getName())); |
| 475 | + "Sink partitioner class '%s' should implement the required class %s", |
| 476 | + name, KafkaPartitioner.class.getName())); |
477 | 477 | }
|
478 | 478 | @SuppressWarnings("unchecked")
|
479 |
| - final FlinkKafkaPartitioner<T> kafkaPartitioner = |
480 |
| - InstantiationUtil.instantiate(name, FlinkKafkaPartitioner.class, classLoader); |
| 479 | + final KafkaPartitioner<T> kafkaPartitioner = |
| 480 | + InstantiationUtil.instantiate(name, KafkaPartitioner.class, classLoader); |
481 | 481 |
|
482 | 482 | return kafkaPartitioner;
|
483 | 483 | } catch (ClassNotFoundException | FlinkException e) {
|
|
0 commit comments