public class StreamingMonitorFunction extends org.apache.flink.streaming.api.functions.source.RichSourceFunction<FlinkInputSplit> implements org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
FlinkInputFormat
, it is
responsible for:
splits
corresponding to the incremental files
The splits to be read are forwarded to the downstream StreamingReaderOperator
which
can have parallelism greater than one.
Constructor and Description |
---|
StreamingMonitorFunction(TableLoader tableLoader,
ScanContext scanContext) |
Modifier and Type | Method and Description |
---|---|
void |
cancel() |
void |
close() |
void |
initializeState(org.apache.flink.runtime.state.FunctionInitializationContext context) |
void |
open(org.apache.flink.configuration.Configuration parameters) |
void |
run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<FlinkInputSplit> ctx) |
void |
snapshotState(org.apache.flink.runtime.state.FunctionSnapshotContext context) |
public StreamingMonitorFunction(TableLoader tableLoader, ScanContext scanContext)
public void open(org.apache.flink.configuration.Configuration parameters) throws java.lang.Exception
open
in interface org.apache.flink.api.common.functions.RichFunction
open
in class org.apache.flink.api.common.functions.AbstractRichFunction
java.lang.Exception
public void initializeState(org.apache.flink.runtime.state.FunctionInitializationContext context) throws java.lang.Exception
initializeState
in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
java.lang.Exception
public void snapshotState(org.apache.flink.runtime.state.FunctionSnapshotContext context) throws java.lang.Exception
snapshotState
in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
java.lang.Exception
public void run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<FlinkInputSplit> ctx) throws java.lang.Exception
run
in interface org.apache.flink.streaming.api.functions.source.SourceFunction<FlinkInputSplit>
java.lang.Exception
public void cancel()
cancel
in interface org.apache.flink.streaming.api.functions.source.SourceFunction<FlinkInputSplit>
public void close()
close
in interface org.apache.flink.api.common.functions.RichFunction
close
in class org.apache.flink.api.common.functions.AbstractRichFunction