Class/Object

org.apache.flink.cep.scala

PatternStream

Related Docs: object PatternStream | package scala

Permalink

class PatternStream[T] extends AnyRef

Stream abstraction for CEP pattern detection. A pattern stream is a stream which emits detected pattern sequences as a map of events associated with their names. The pattern is detected using a org.apache.flink.cep.nfa.NFA. In order to process the detected sequences, the user has to specify a PatternSelectFunction or a PatternFlatSelectFunction.

T

Type of the events

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. PatternStream
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new PatternStream(jPatternStream: cep.PatternStream[T])

    Permalink

    jPatternStream

    Underlying pattern stream from Java API

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  6. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  7. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  8. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  9. def flatSelect[L, R](outputTag: OutputTag[L])(patternFlatTimeoutFunction: (Map[String, Iterable[T]], Long, Collector[L]) ⇒ Unit)(patternFlatSelectFunction: (Map[String, Iterable[T]], Collector[R]) ⇒ Unit)(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a flat select function to the detected pattern sequence.

    Applies a flat select function to the detected pattern sequence. For each pattern sequence the provided PatternFlatSelectFunction is called. The pattern flat select function can produce an arbitrary number of resulting elements.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternFlatTimeoutFunction is called. The pattern timeout function can produce an arbitrary number of resulting timeout events.

    You can get the stream of timeouted matches using DataStream.getSideOutput() on the DataStream resulting from the windowed operation with the same OutputTag.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    outputTag

    OutputTag that identifies side output with timeouted patterns

    patternFlatTimeoutFunction

    The pattern flat timeout function which is called for each partially matched pattern sequence which has timed out.

    patternFlatSelectFunction

    The pattern flat select function which is called for each detected pattern sequence.

    returns

    Data stream of either type which contains the resulting events and the resulting timeout events wrapped in a Either type.

  10. def flatSelect[R](patternFlatSelectFun: (Map[String, Iterable[T]], Collector[R]) ⇒ Unit)(implicit arg0: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a flat select function to the detected pattern sequence.

    Applies a flat select function to the detected pattern sequence. For each pattern sequence the provided PatternFlatSelectFunction is called. The pattern flat select function can produce an arbitrary number of resulting elements.

    R

    Type of the resulting elements

    patternFlatSelectFun

    The pattern flat select function which is called for each detected pattern sequence.

    returns

    DataStream which contains the resulting elements from the pattern flat select function.

  11. def flatSelect[L, R](outputTag: OutputTag[L], patternFlatTimeoutFunction: PatternFlatTimeoutFunction[T, L], patternFlatSelectFunction: PatternFlatSelectFunction[T, R])(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a flat select function to the detected pattern sequence.

    Applies a flat select function to the detected pattern sequence. For each pattern sequence the provided PatternFlatSelectFunction is called. The pattern flat select function can produce an arbitrary number of resulting elements.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternFlatTimeoutFunction is called. The pattern timeout function can produce an arbitrary number of resulting timeout events.

    You can get the stream of timeouted matches using DataStream.getSideOutput() on the DataStream resulting from the windowed operation with the same OutputTag.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    outputTag

    OutputTag that identifies side output with timeouted patterns

    patternFlatTimeoutFunction

    The pattern flat timeout function which is called for each partially matched pattern sequence which has timed out.

    patternFlatSelectFunction

    The pattern flat select function which is called for each detected pattern sequence.

    returns

    Data stream which contains the resulting elements with the resulting timeout elements in a side output.

  12. def flatSelect[R](patternFlatSelectFunction: PatternFlatSelectFunction[T, R])(implicit arg0: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a flat select function to the detected pattern sequence.

    Applies a flat select function to the detected pattern sequence. For each pattern sequence the provided PatternFlatSelectFunction is called. The pattern flat select function can produce an arbitrary number of resulting elements.

    R

    Type of the resulting elements

    patternFlatSelectFunction

    The pattern flat select function which is called for each detected pattern sequence.

    returns

    DataStream which contains the resulting elements from the pattern flat select function.

  13. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  14. def getComparator: EventComparator[T]

    Permalink
  15. def getInputStream: DataStream[T]

    Permalink
  16. def getPattern: Pattern[T, T]

    Permalink
  17. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  18. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  19. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  20. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  21. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  22. def select[L, R](outputTag: OutputTag[L])(patternTimeoutFunction: (Map[String, Iterable[T]], Long) ⇒ L)(patternSelectFunction: (Map[String, Iterable[T]]) ⇒ R)(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a select function to the detected pattern sequence.

    Applies a select function to the detected pattern sequence. For each pattern sequence the provided PatternSelectFunction is called. The pattern select function can produce exactly one resulting element.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternTimeoutFunction is called. The pattern timeout function has to produce exactly one resulting element.

    You can get the stream of timeouted matches using DataStream.getSideOutput() on the DataStream resulting from the windowed operation with the same OutputTag.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    outputTag

    OutputTag that identifies side output with timeouted patterns

    patternTimeoutFunction

    The pattern timeout function which is called for each partial pattern sequence which has timed out.

    patternSelectFunction

    The pattern select function which is called for each detected pattern sequence.

    returns

    Data stream of either type which contain the resulting events and resulting timeout events.

  23. def select[R](patternSelectFun: (Map[String, Iterable[T]]) ⇒ R)(implicit arg0: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a select function to the detected pattern sequence.

    Applies a select function to the detected pattern sequence. For each pattern sequence the provided PatternSelectFunction is called. The pattern select function can produce exactly one resulting element.

    R

    Type of the resulting elements

    patternSelectFun

    The pattern select function which is called for each detected pattern sequence.

    returns

    DataStream which contains the resulting elements from the pattern select function.

  24. def select[L, R](outputTag: OutputTag[L], patternTimeoutFunction: PatternTimeoutFunction[T, L], patternSelectFunction: PatternSelectFunction[T, R])(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a select function to the detected pattern sequence.

    Applies a select function to the detected pattern sequence. For each pattern sequence the provided PatternSelectFunction is called. The pattern select function can produce exactly one resulting element.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternTimeoutFunction is called. The pattern timeout function has to produce exactly one resulting timeout event.

    You can get the stream of timeouted matches using DataStream.getSideOutput() on the DataStream resulting from the windowed operation with the same OutputTag.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    outputTag

    OutputTag that identifies side output with timeouted patterns

    patternTimeoutFunction

    The pattern timeout function which is called for each partial pattern sequence which has timed out.

    patternSelectFunction

    The pattern select function which is called for each detected pattern sequence.

    returns

    Data stream which contains the resulting elements with the resulting timeout elements in a side output.

  25. def select[R](patternSelectFunction: PatternSelectFunction[T, R])(implicit arg0: TypeInformation[R]): DataStream[R]

    Permalink

    Applies a select function to the detected pattern sequence.

    Applies a select function to the detected pattern sequence. For each pattern sequence the provided PatternSelectFunction is called. The pattern select function can produce exactly one resulting element.

    R

    Type of the resulting elements

    patternSelectFunction

    The pattern select function which is called for each detected pattern sequence.

    returns

    DataStream which contains the resulting elements from the pattern select function.

  26. def sideOutputLateData(lateDataOutputTag: OutputTag[T]): PatternStream[T]

    Permalink
  27. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  28. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  29. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  30. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  31. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def flatSelect[L, R](patternFlatTimeoutFunction: (Map[String, Iterable[T]], Long, Collector[L]) ⇒ Unit)(patternFlatSelectFunction: (Map[String, Iterable[T]], Collector[R]) ⇒ Unit)(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[Either[L, R]]

    Permalink

    Applies a flat select function to the detected pattern sequence.

    Applies a flat select function to the detected pattern sequence. For each pattern sequence the provided PatternFlatSelectFunction is called. The pattern flat select function can produce an arbitrary number of resulting elements.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternFlatTimeoutFunction is called. The pattern timeout function can produce an arbitrary number of resulting timeout events.

    The resulting event and the resulting timeout event are wrapped in an Either instance.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    patternFlatTimeoutFunction

    The pattern flat timeout function which is called for each partially matched pattern sequence which has timed out.

    patternFlatSelectFunction

    The pattern flat select function which is called for each detected pattern sequence.

    returns

    Data stream of either type which contains the resulting events and the resulting timeout events wrapped in a Either type.

    Annotations
    @deprecated
    Deprecated
  2. def flatSelect[L, R](patternFlatTimeoutFunction: PatternFlatTimeoutFunction[T, L], patternFlatSelectFunction: PatternFlatSelectFunction[T, R])(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[Either[L, R]]

    Permalink

    Applies a flat select function to the detected pattern sequence.

    Applies a flat select function to the detected pattern sequence. For each pattern sequence the provided PatternFlatSelectFunction is called. The pattern flat select function can produce an arbitrary number of resulting elements.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternFlatTimeoutFunction is called. The pattern timeout function can produce an arbitrary number of resulting timeout events.

    The resulting event and the resulting timeout event are wrapped in an Either instance.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    patternFlatTimeoutFunction

    The pattern flat timeout function which is called for each partially matched pattern sequence which has timed out.

    patternFlatSelectFunction

    The pattern flat select function which is called for each detected pattern sequence.

    returns

    Data stream of either type which contains the resulting events and the resulting timeout events wrapped in a Either type.

    Annotations
    @deprecated
    Deprecated
  3. def select[L, R](patternTimeoutFunction: (Map[String, Iterable[T]], Long) ⇒ L)(patternSelectFunction: (Map[String, Iterable[T]]) ⇒ R)(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[Either[L, R]]

    Permalink

    Applies a select function to the detected pattern sequence.

    Applies a select function to the detected pattern sequence. For each pattern sequence the provided PatternSelectFunction is called. The pattern select function can produce exactly one resulting element.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternTimeoutFunction is called. The pattern timeout function has to produce exactly one resulting element.

    The resulting event and the resulting timeout event are wrapped in an Either instance.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    patternTimeoutFunction

    The pattern timeout function which is called for each partial pattern sequence which has timed out.

    patternSelectFunction

    The pattern select function which is called for each detected pattern sequence.

    returns

    Data stream of either type which contain the resulting events and resulting timeout events.

    Annotations
    @deprecated
    Deprecated
  4. def select[L, R](patternTimeoutFunction: PatternTimeoutFunction[T, L], patternSelectFunction: PatternSelectFunction[T, R])(implicit arg0: TypeInformation[L], arg1: TypeInformation[R]): DataStream[Either[L, R]]

    Permalink

    Applies a select function to the detected pattern sequence.

    Applies a select function to the detected pattern sequence. For each pattern sequence the provided PatternSelectFunction is called. The pattern select function can produce exactly one resulting element.

    Additionally a timeout function is applied to partial event patterns which have timed out. For each partial pattern sequence the provided PatternTimeoutFunction is called. The pattern timeout function has to produce exactly one resulting timeout event.

    The resulting event and the resulting timeout event are wrapped in an Either instance.

    L

    Type of the resulting timeout event

    R

    Type of the resulting event

    patternTimeoutFunction

    The pattern timeout function which is called for each partial pattern sequence which has timed out.

    patternSelectFunction

    The pattern select function which is called for each detected pattern sequence.

    returns

    Data stream of either type which contains the resulting events and resulting timeout events.

    Annotations
    @deprecated
    Deprecated

Inherited from AnyRef

Inherited from Any

Ungrouped