Class TestStreamSource<T>
java.lang.Object
org.apache.flink.api.common.functions.AbstractRichFunction
org.apache.flink.streaming.api.functions.source.RichSourceFunction<WindowedValue<T>>
org.apache.beam.runners.flink.translation.wrappers.streaming.io.TestStreamSource<T>
- All Implemented Interfaces:
 Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.RichFunction,org.apache.flink.streaming.api.functions.source.SourceFunction<WindowedValue<T>>
public class TestStreamSource<T>
extends org.apache.flink.streaming.api.functions.source.RichSourceFunction<WindowedValue<T>>
Flink source for executing 
TestStream.- See Also:
 
- 
Nested Class Summary
Nested classes/interfaces inherited from interface org.apache.flink.streaming.api.functions.source.SourceFunction
org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<T> - 
Constructor Summary
ConstructorsConstructorDescriptionTestStreamSource(SerializableFunction<byte[], TestStream<T>> testStreamDecoder, byte[] payload)  - 
Method Summary
Modifier and TypeMethodDescriptionvoidcancel()voidrun(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<WindowedValue<T>> ctx) Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext 
- 
Constructor Details
- 
TestStreamSource
public TestStreamSource(SerializableFunction<byte[], TestStream<T>> testStreamDecoder, byte[] payload)  
 - 
 - 
Method Details
- 
run
public void run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<WindowedValue<T>> ctx) throws CoderException - Throws:
 CoderException
 - 
cancel
public void cancel() 
 -