java.lang.Object
org.apache.flink.api.common.functions.AbstractRichFunction
org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction<WindowedValue<byte[]>>
org.apache.beam.runners.flink.translation.wrappers.streaming.io.StreamingImpulseSource
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.ParallelSourceFunction<WindowedValue<byte[]>>, org.apache.flink.streaming.api.functions.source.SourceFunction<WindowedValue<byte[]>>

@Deprecated public class StreamingImpulseSource extends org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction<WindowedValue<byte[]>>
Deprecated.
Legacy non-portable source which can be replaced by a DoFn with timers. https://jira.apache.org/jira/browse/BEAM-8353
A streaming source that periodically produces a byte array. This is mostly useful for debugging, or for triggering periodic behavior in a portable pipeline.
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

    Constructors
    Constructor
    Description
    StreamingImpulseSource(int intervalMillis, int messageCount)
    Deprecated.
     
  • Method Summary

    Modifier and Type
    Method
    Description
    void
    Deprecated.
     
    void
    run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<WindowedValue<byte[]>> ctx)
    Deprecated.
     

    Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction

    close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Constructor Details

    • StreamingImpulseSource

      public StreamingImpulseSource(int intervalMillis, int messageCount)
      Deprecated.
  • Method Details

    • run

      public void run(org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext<WindowedValue<byte[]>> ctx)
      Deprecated.
    • cancel

      public void cancel()
      Deprecated.