Class DataGeneratorSource<T>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction<T>
-
- org.apache.flink.streaming.api.functions.source.datagen.DataGeneratorSource<T>
-
- All Implemented Interfaces:
Serializable
,Function
,RichFunction
,CheckpointedFunction
,ParallelSourceFunction<T>
,SourceFunction<T>
@Internal public class DataGeneratorSource<T> extends RichParallelSourceFunction<T> implements CheckpointedFunction
Deprecated.Useorg.apache.flink.connector.datagen.source.DataGeneratorSource
instead.A data generator source that abstract data generator. It can be used to easy startup/test for streaming job and performance testing. It is stateful, re-scalable, possibly in parallel.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction
SourceFunction.SourceContext<T>
-
-
Constructor Summary
Constructors Constructor Description DataGeneratorSource(DataGenerator<T> generator)
Deprecated.Creates a source that emits records byDataGenerator
without controlling emit rate.DataGeneratorSource(DataGenerator<T> generator, long rowsPerSecond, Long numberOfRows)
Deprecated.Creates a source that emits records byDataGenerator
.
-
Method Summary
All Methods Instance Methods Concrete Methods Deprecated Methods Modifier and Type Method Description void
cancel()
Deprecated.Cancels the source.void
close()
Deprecated.Tear-down method for the user code.void
initializeState(FunctionInitializationContext context)
Deprecated.This method is called when the parallel function instance is created during distributed execution.void
open(OpenContext openContext)
Deprecated.Initialization method for the function.void
run(SourceFunction.SourceContext<T> ctx)
Deprecated.Starts the source.void
snapshotState(FunctionSnapshotContext context)
Deprecated.This method is called when a snapshot for a checkpoint is requested.-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
-
-
-
-
Constructor Detail
-
DataGeneratorSource
public DataGeneratorSource(DataGenerator<T> generator)
Deprecated.Creates a source that emits records byDataGenerator
without controlling emit rate.- Parameters:
generator
- data generator.
-
DataGeneratorSource
public DataGeneratorSource(DataGenerator<T> generator, long rowsPerSecond, @Nullable Long numberOfRows)
Deprecated.Creates a source that emits records byDataGenerator
.- Parameters:
generator
- data generator.rowsPerSecond
- Control the emit rate.numberOfRows
- Total number of rows to output.
-
-
Method Detail
-
open
public void open(OpenContext openContext) throws Exception
Deprecated.Description copied from interface:RichFunction
Initialization method for the function. It is called before the actual working methods (like map or join) and thus suitable for one time setup work. For functions that are part of an iteration, this method will be invoked at the beginning of each iteration superstep.The openContext object passed to the function can be used for configuration and initialization. The openContext contains some necessary information that were configured on the function in the program composition.
public class MyFilter extends RichFilterFunction<String> { private String searchString; public void open(OpenContext openContext) { // initialize the value of searchString } public boolean filter(String value) { return value.equals(searchString); } }
- Specified by:
open
in interfaceRichFunction
- Overrides:
open
in classAbstractRichFunction
- Parameters:
openContext
- The context containing information about the context in which the function is opened.- Throws:
Exception
- Implementations may forward exceptions, which are caught by the runtime. When the runtime catches an exception, it aborts the task and lets the fail-over logic decide whether to retry the task execution.
-
initializeState
public void initializeState(FunctionInitializationContext context) throws Exception
Deprecated.Description copied from interface:CheckpointedFunction
This method is called when the parallel function instance is created during distributed execution. Functions typically set up their state storing data structures in this method.- Specified by:
initializeState
in interfaceCheckpointedFunction
- Parameters:
context
- the context for initializing the operator- Throws:
Exception
- Thrown, if state could not be created ot restored.
-
snapshotState
public void snapshotState(FunctionSnapshotContext context) throws Exception
Deprecated.Description copied from interface:CheckpointedFunction
This method is called when a snapshot for a checkpoint is requested. This acts as a hook to the function to ensure that all state is exposed by means previously offered throughFunctionInitializationContext
when the Function was initialized, or offered now byFunctionSnapshotContext
itself.- Specified by:
snapshotState
in interfaceCheckpointedFunction
- Parameters:
context
- the context for drawing a snapshot of the operator- Throws:
Exception
- Thrown, if state could not be created ot restored.
-
run
public void run(SourceFunction.SourceContext<T> ctx) throws Exception
Deprecated.Description copied from interface:SourceFunction
Starts the source. Implementations use theSourceFunction.SourceContext
to emit elements. Sources that checkpoint their state for fault tolerance should use thecheckpoint lock
to ensure consistency between the bookkeeping and emitting the elements.Sources that implement
CheckpointedFunction
must lock on thecheckpoint lock
checkpoint lock (using a synchronized block) before updating internal state and emitting elements, to make both an atomic operation.Refer to the
top-level class docs
for an example.- Specified by:
run
in interfaceSourceFunction<T>
- Parameters:
ctx
- The context to emit elements to and for accessing locks.- Throws:
Exception
-
close
public void close() throws Exception
Deprecated.Description copied from interface:RichFunction
Tear-down method for the user code. It is called after the last call to the main working methods (e.g. map or join). For functions that are part of an iteration, this method will be invoked after each iteration superstep.This method can be used for clean up work.
- Specified by:
close
in interfaceRichFunction
- Overrides:
close
in classAbstractRichFunction
- Throws:
Exception
- Implementations may forward exceptions, which are caught by the runtime. When the runtime catches an exception, it aborts the task and lets the fail-over logic decide whether to retry the task execution.
-
cancel
public void cancel()
Deprecated.Description copied from interface:SourceFunction
Cancels the source. Most sources will have a while loop inside theSourceFunction.run(SourceContext)
method. The implementation needs to ensure that the source will break out of that loop after this method is called.A typical pattern is to have an
"volatile boolean isRunning"
flag that is set tofalse
in this method. That flag is checked in the loop condition.In case of an ungraceful shutdown (cancellation of the source operator, possibly for failover), the thread that calls
SourceFunction.run(SourceContext)
will also beinterrupted
) by the Flink runtime, in order to speed up the cancellation (to ensure threads exit blocking methods fast, like I/O, blocking queues, etc.). The interruption happens strictly after this method has been called, so any interruption handler can rely on the fact that this method has completed (for example to ignore exceptions that happen after cancellation).During graceful shutdown (for example stopping a job with a savepoint), the program must cleanly exit the
SourceFunction.run(SourceContext)
method soon after this method was called. The Flink runtime will NOT interrupt the source thread during graceful shutdown. Source implementors must ensure that no thread interruption happens on any thread that emits records through theSourceContext
from theSourceFunction.run(SourceContext)
method; otherwise the clean shutdown may fail when threads are interrupted while processing the final records.Because the
SourceFunction
cannot easily differentiate whether the shutdown should be graceful or ungraceful, we recommend that implementors refrain from interrupting any threads that interact with theSourceContext
at all. You can rely on the Flink runtime to interrupt the source thread in case of ungraceful cancellation. Any additionally spawned threads that directly emit records through theSourceContext
should use a shutdown method that does not rely on thread interruption.- Specified by:
cancel
in interfaceSourceFunction<T>
-
-