Skip to content
This commit does not belong to any branch on this repository, and may belong to a fork outside of the repository.

Commit c3bcbda

Browse files
committedMar 15, 2025
[FLINK-36245][FOLLOWUP] Remove the @deprecated for ArrowSourceFunction and SinkFunction
1 parent a0f07fe commit c3bcbda

File tree

4 files changed

+5
-2
lines changed

4 files changed

+5
-2
lines changed
 

‎flink-python/src/main/java/org/apache/flink/table/runtime/arrow/sources/ArrowSourceFunction.java

Lines changed: 0 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -63,7 +63,6 @@
6363
* @deprecated This class is based on the {@link SourceFunction} API, which is due to be removed.
6464
* Use the new {@link org.apache.flink.api.connector.source.Source} API instead.
6565
*/
66-
@Deprecated
6766
@Internal
6867
public class ArrowSourceFunction extends RichParallelSourceFunction<RowData>
6968
implements ResultTypeQueryable<RowData>, CheckpointedFunction {

‎flink-runtime/src/main/java/org/apache/flink/streaming/api/datastream/DataStream.java

Lines changed: 4 additions & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -864,7 +864,11 @@ protected DataStream<T> setConnectionType(StreamPartitioner<T> partitioner) {
864864
*
865865
* @param sinkFunction The object containing the sink's invoke function.
866866
* @return The closed DataStream.
867+
* @deprecated This method relies on the {@link SinkFunction} API, which is due to be removed.
868+
* Use the {@link #sinkTo(Sink)} method based on the new {@link
869+
* org.apache.flink.api.connector.sink2.Sink} API instead.
867870
*/
871+
@Deprecated
868872
public DataStreamSink<T> addSink(SinkFunction<T> sinkFunction) {
869873

870874
// read the output type of the input Transform to coax out errors about MissingTypeInfo

‎flink-runtime/src/main/java/org/apache/flink/streaming/api/datastream/KeyedStream.java

Lines changed: 1 addition & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -301,6 +301,7 @@ protected <R> SingleOutputStreamOperator<R> doTransform(
301301
}
302302

303303
@Override
304+
@Deprecated
304305
public DataStreamSink<T> addSink(SinkFunction<T> sinkFunction) {
305306
DataStreamSink<T> result = super.addSink(sinkFunction);
306307
result.getLegacyTransformation().setStateKeySelector(keySelector);

‎flink-runtime/src/main/java/org/apache/flink/streaming/api/functions/sink/legacy/SinkFunction.java

Lines changed: 0 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -32,7 +32,6 @@
3232
* org.apache.flink.api.connector.sink2.Sink} interface instead.
3333
*/
3434
@Internal
35-
@Deprecated
3635
public interface SinkFunction<IN> extends Function, Serializable {
3736

3837
/**

0 commit comments

Comments
 (0)
Please sign in to comment.