Package | Description |
---|---|
org.apache.flink.cep | |
org.apache.flink.cep.operator |
Modifier and Type | Method and Description |
---|---|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timeoutOutputTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timeoutOutputTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.select(PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.select(PatternSelectFunction<T,R> patternSelectFunction,
TypeInformation<R> outTypeInfo)
Applies a select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<Either<L,R>> |
PatternStream.select(PatternTimeoutFunction<T,L> patternTimeoutFunction,
PatternSelectFunction<T,R> patternSelectFunction)
Deprecated.
Use
PatternStream.select(OutputTag, PatternTimeoutFunction, PatternSelectFunction)
that returns timed out events as a side-output |
Modifier and Type | Method and Description |
---|---|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
CEPOperatorUtils.createPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternSelectFunction<IN,OUT> selectFunction,
TypeInformation<OUT> outTypeInfo)
Creates a data stream containing results of
PatternSelectFunction to fully matching event patterns. |
static <IN,OUT1,OUT2> |
CEPOperatorUtils.createTimeoutPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternSelectFunction<IN,OUT1> selectFunction,
TypeInformation<OUT1> outTypeInfo,
OutputTag<OUT2> outputTag,
PatternTimeoutFunction<IN,OUT2> timeoutFunction)
Creates a data stream containing results of
PatternSelectFunction to fully matching event patterns and
also timed out partially matched with applied PatternTimeoutFunction as a sideoutput. |
Constructor and Description |
---|
SelectCepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy skipStrategy,
PatternSelectFunction<IN,OUT> function) |
SelectTimeoutCepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy skipStrategy,
PatternSelectFunction<IN,OUT1> flatSelectFunction,
PatternTimeoutFunction<IN,OUT2> flatTimeoutFunction,
OutputTag<OUT2> outputTag) |
SelectWrapper(PatternSelectFunction<IN,OUT1> flatSelectFunction,
PatternTimeoutFunction<IN,OUT2> flatTimeoutFunction) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.