Package | Description |
---|---|
org.apache.flink.cep.nfa | |
org.apache.flink.cep.nfa.aftermatch | |
org.apache.flink.cep.operator | |
org.apache.flink.cep.pattern |
Modifier and Type | Method and Description |
---|---|
Tuple2<Collection<Map<String,List<T>>>,Collection<Tuple2<Map<String,List<T>>,Long>>> |
NFA.advanceTime(SharedBufferAccessor<T> sharedBufferAccessor,
NFAState nfaState,
long timestamp,
AfterMatchSkipStrategy afterMatchSkipStrategy)
Prunes states assuming there will be no events with timestamp lower than the given
one.
|
Collection<Map<String,List<T>>> |
NFA.process(SharedBufferAccessor<T> sharedBufferAccessor,
NFAState nfaState,
T event,
long timestamp,
AfterMatchSkipStrategy afterMatchSkipStrategy,
TimerService timerService)
Processes the next input event.
|
Modifier and Type | Class and Description |
---|---|
class |
NoSkipStrategy
Every possible match will be emitted.
|
class |
SkipPastLastStrategy
Discards every partial match that started before emitted match ended.
|
class |
SkipToFirstStrategy
Discards every partial match that started before the first event of emitted match mapped to
*PatternName*.
|
class |
SkipToLastStrategy
Discards every partial match that started before the last event of emitted match mapped to
*PatternName*.
|
class |
SkipToNextStrategy
Discards every partial match that started with the same event, emitted match was started.
|
Modifier and Type | Method and Description |
---|---|
static AfterMatchSkipStrategy |
AfterMatchSkipStrategy.skipToNext()
Discards every partial match that started with the same event, emitted match was started.
|
Constructor and Description |
---|
CepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy afterMatchSkipStrategy,
PatternProcessFunction<IN,OUT> function,
OutputTag<IN> lateDataOutputTag) |
Modifier and Type | Method and Description |
---|---|
AfterMatchSkipStrategy |
Pattern.getAfterMatchSkipStrategy() |
Modifier and Type | Method and Description |
---|---|
static <T,F extends T> |
Pattern.begin(Pattern<T,F> group,
AfterMatchSkipStrategy afterMatchSkipStrategy)
Starts a new pattern sequence.
|
static <X> Pattern<X,X> |
Pattern.begin(String name,
AfterMatchSkipStrategy afterMatchSkipStrategy)
Starts a new pattern sequence.
|
Constructor and Description |
---|
Pattern(String name,
Pattern<T,? extends T> previous,
Quantifier.ConsumingStrategy consumingStrategy,
AfterMatchSkipStrategy afterMatchSkipStrategy) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.