SourceFunction
API, which is due to be
removed. Use the new Source
API instead.@Deprecated @Internal public class ArrowSourceFunction extends org.apache.flink.streaming.api.functions.source.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
SourceFunction
which takes the serialized arrow record batch data as input.限定符和类型 | 方法和说明 |
---|---|
void |
cancel()
已过时。
|
void |
close()
已过时。
|
org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.table.data.RowData> |
getProducedType()
已过时。
|
void |
initializeState(org.apache.flink.runtime.state.FunctionInitializationContext context)
已过时。
|
void |
open(org.apache.flink.api.common.functions.OpenContext openContext)
已过时。
|
void |
run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<org.apache.flink.table.data.RowData> ctx)
已过时。
|
void |
snapshotState(org.apache.flink.runtime.state.FunctionSnapshotContext context)
已过时。
|
public void open(org.apache.flink.api.common.functions.OpenContext openContext) throws Exception
open
在接口中 org.apache.flink.api.common.functions.RichFunction
Exception
public void close() throws Exception
close
在接口中 org.apache.flink.api.common.functions.RichFunction
close
在类中 org.apache.flink.api.common.functions.AbstractRichFunction
Exception
public void initializeState(org.apache.flink.runtime.state.FunctionInitializationContext context) throws Exception
initializeState
在接口中 org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
Exception
public void snapshotState(org.apache.flink.runtime.state.FunctionSnapshotContext context) throws Exception
snapshotState
在接口中 org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
Exception
public void run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<org.apache.flink.table.data.RowData> ctx) throws Exception
run
在接口中 org.apache.flink.streaming.api.functions.source.SourceFunction<org.apache.flink.table.data.RowData>
Exception
public void cancel()
cancel
在接口中 org.apache.flink.streaming.api.functions.source.SourceFunction<org.apache.flink.table.data.RowData>
public org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.table.data.RowData> getProducedType()
getProducedType
在接口中 org.apache.flink.api.java.typeutils.ResultTypeQueryable<org.apache.flink.table.data.RowData>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.