Class BoundedSourceP<T>

java.lang.Object
com.hazelcast.jet.core.AbstractProcessor
org.apache.beam.runners.jet.processors.BoundedSourceP<T>
All Implemented Interfaces:
com.hazelcast.jet.core.Processor, com.hazelcast.jet.Traverser

public class BoundedSourceP<T> extends com.hazelcast.jet.core.AbstractProcessor implements com.hazelcast.jet.Traverser
Jet Processor implementation for reading from a bounded Beam source.
  • Nested Class Summary

    Nested classes/interfaces inherited from class com.hazelcast.jet.core.AbstractProcessor

    com.hazelcast.jet.core.AbstractProcessor.FlatMapper<T,R>

    Nested classes/interfaces inherited from interface com.hazelcast.jet.core.Processor

    com.hazelcast.jet.core.Processor.Context
  • Method Summary

    Modifier and Type
    Method
    Description
    void
     
    boolean
     
    protected void
    init(com.hazelcast.jet.core.Processor.Context context)
     
    boolean
     
     
    static <T> com.hazelcast.jet.core.ProcessorMetaSupplier
    supplier(BoundedSource<T> boundedSource, org.apache.beam.runners.core.construction.SerializablePipelineOptions options, Coder outputCoder, String ownerId)
     

    Methods inherited from class com.hazelcast.jet.core.AbstractProcessor

    emitFromTraverser, emitFromTraverser, emitFromTraverser, emitFromTraverserToSnapshot, flatMapper, flatMapper, flatMapper, getLogger, getOutbox, init, process, restoreFromSnapshot, restoreFromSnapshot, tryEmit, tryEmit, tryEmit, tryEmitToSnapshot, tryProcess, tryProcess0, tryProcess1, tryProcess2, tryProcess3, tryProcess4, tryProcessWatermark

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface com.hazelcast.jet.core.Processor

    completeEdge, finishSnapshotRestore, saveToSnapshot, snapshotCommitFinish, snapshotCommitPrepare, tryProcess

    Methods inherited from interface com.hazelcast.jet.Traverser

    append, dropWhile, filter, flatMap, map, onFirstNull, peek, prepend, takeWhile
  • Method Details

    • init

      protected void init(@Nonnull com.hazelcast.jet.core.Processor.Context context) throws Exception
      Overrides:
      init in class com.hazelcast.jet.core.AbstractProcessor
      Throws:
      Exception
    • next

      public Object next()
      Specified by:
      next in interface com.hazelcast.jet.Traverser<T>
    • complete

      public boolean complete()
      Specified by:
      complete in interface com.hazelcast.jet.core.Processor
    • isCooperative

      public boolean isCooperative()
      Specified by:
      isCooperative in interface com.hazelcast.jet.core.Processor
    • close

      public void close() throws Exception
      Specified by:
      close in interface com.hazelcast.jet.core.Processor
      Throws:
      Exception
    • supplier

      public static <T> com.hazelcast.jet.core.ProcessorMetaSupplier supplier(BoundedSource<T> boundedSource, org.apache.beam.runners.core.construction.SerializablePipelineOptions options, Coder outputCoder, String ownerId)