Class ArrowSourceFunction
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction<org.apache.flink.table.data.RowData>
-
- org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction
-
- All Implemented Interfaces:
Serializable
,org.apache.flink.api.common.functions.Function
,org.apache.flink.api.common.functions.RichFunction
,org.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.table.data.RowData>
,org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
,org.apache.flink.streaming.api.functions.source.legacy.ParallelSourceFunction<org.apache.flink.table.data.RowData>
,org.apache.flink.streaming.api.functions.source.legacy.SourceFunction<org.apache.flink.table.data.RowData>
@Deprecated @Internal public class ArrowSourceFunction extends org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction<org.apache.flink.table.data.RowData> implements org.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.table.data.RowData>, org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
Deprecated.This class is based on theSourceFunction
API, which is due to be removed. Use the newSource
API instead.An ArrowSourceFunction
which takes the serialized arrow record batch data as input.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction
org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext<T extends Object>
-
-
Method Summary
All Methods Instance Methods Concrete Methods Deprecated Methods Modifier and Type Method Description void
cancel()
Deprecated.void
close()
Deprecated.org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.table.data.RowData>
getProducedType()
Deprecated.void
initializeState(org.apache.flink.runtime.state.FunctionInitializationContext context)
Deprecated.void
open(org.apache.flink.api.common.functions.OpenContext openContext)
Deprecated.void
run(org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext<org.apache.flink.table.data.RowData> ctx)
Deprecated.void
snapshotState(org.apache.flink.runtime.state.FunctionSnapshotContext context)
Deprecated.
-
-
-
Method Detail
-
open
public void open(org.apache.flink.api.common.functions.OpenContext openContext) throws Exception
Deprecated.- Specified by:
open
in interfaceorg.apache.flink.api.common.functions.RichFunction
- Overrides:
open
in classorg.apache.flink.api.common.functions.AbstractRichFunction
- Throws:
Exception
-
close
public void close() throws Exception
Deprecated.- Specified by:
close
in interfaceorg.apache.flink.api.common.functions.RichFunction
- Overrides:
close
in classorg.apache.flink.api.common.functions.AbstractRichFunction
- Throws:
Exception
-
initializeState
public void initializeState(org.apache.flink.runtime.state.FunctionInitializationContext context) throws Exception
Deprecated.- Specified by:
initializeState
in interfaceorg.apache.flink.streaming.api.checkpoint.CheckpointedFunction
- Throws:
Exception
-
snapshotState
public void snapshotState(org.apache.flink.runtime.state.FunctionSnapshotContext context) throws Exception
Deprecated.- Specified by:
snapshotState
in interfaceorg.apache.flink.streaming.api.checkpoint.CheckpointedFunction
- Throws:
Exception
-
run
public void run(org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext<org.apache.flink.table.data.RowData> ctx) throws Exception
Deprecated.- Specified by:
run
in interfaceorg.apache.flink.streaming.api.functions.source.legacy.SourceFunction<org.apache.flink.table.data.RowData>
- Throws:
Exception
-
cancel
public void cancel()
Deprecated.- Specified by:
cancel
in interfaceorg.apache.flink.streaming.api.functions.source.legacy.SourceFunction<org.apache.flink.table.data.RowData>
-
getProducedType
public org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.table.data.RowData> getProducedType()
Deprecated.- Specified by:
getProducedType
in interfaceorg.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.table.data.RowData>
-
-