Package | Description |
---|---|
org.apache.flink.cep | |
org.apache.flink.cep.nfa.compiler | |
org.apache.flink.cep.pattern | |
org.apache.flink.table.planner.plan.nodes.exec.stream |
Modifier and Type | Method and Description |
---|---|
static <T> PatternStream<T> |
CEP.pattern(DataStream<T> input,
Pattern<T,?> pattern)
Creates a
PatternStream from an input data stream and a pattern. |
static <T> PatternStream<T> |
CEP.pattern(DataStream<T> input,
Pattern<T,?> pattern,
EventComparator<T> comparator)
Creates a
PatternStream from an input data stream and a pattern. |
Modifier and Type | Method and Description |
---|---|
static boolean |
NFACompiler.canProduceEmptyMatches(Pattern<?,?> pattern)
Verifies if the provided pattern can possibly generate empty match.
|
static <T> NFACompiler.NFAFactory<T> |
NFACompiler.compileFactory(Pattern<T,?> pattern,
boolean timeoutHandling)
Compiles the given pattern into a
NFACompiler.NFAFactory . |
Modifier and Type | Class and Description |
---|---|
class |
GroupPattern<T,F extends T>
Base class for a group pattern definition.
|
Modifier and Type | Method and Description |
---|---|
Pattern<T,F> |
Pattern.allowCombinations()
Applicable only to
Quantifier.looping(ConsumingStrategy) and Quantifier.times(ConsumingStrategy) patterns, this option allows more flexibility to the
matching events. |
static <X> Pattern<X,X> |
Pattern.begin(String name)
Starts a new pattern sequence.
|
static <X> Pattern<X,X> |
Pattern.begin(String name,
AfterMatchSkipStrategy afterMatchSkipStrategy)
Starts a new pattern sequence.
|
Pattern<T,F> |
Pattern.consecutive()
Works in conjunction with
oneOrMore() or times(int) . |
Pattern<T,T> |
Pattern.followedBy(String name)
Appends a new pattern to the existing one.
|
Pattern<T,T> |
Pattern.followedByAny(String name)
Appends a new pattern to the existing one.
|
Pattern<T,? extends T> |
Pattern.getPrevious() |
Pattern<T,? extends T> |
GroupPattern.getRawPattern() |
Pattern<T,F> |
Pattern.greedy()
Specifies that this pattern is greedy.
|
Pattern<T,T> |
Pattern.next(String name)
Appends a new pattern to the existing one.
|
Pattern<T,T> |
Pattern.notFollowedBy(String name)
Appends a new pattern to the existing one.
|
Pattern<T,T> |
Pattern.notNext(String name)
Appends a new pattern to the existing one.
|
Pattern<T,F> |
Pattern.oneOrMore()
Specifies that this pattern can occur
one or more times. |
Pattern<T,F> |
Pattern.optional()
Specifies that this pattern is optional for a final match of the pattern sequence to happen.
|
Pattern<T,F> |
Pattern.or(IterativeCondition<F> condition)
Adds a condition that has to be satisfied by an event in order to be considered a match.
|
Pattern<T,F> |
GroupPattern.or(IterativeCondition<F> condition) |
<S extends F> |
Pattern.subtype(Class<S> subtypeClass)
Applies a subtype constraint on the current pattern.
|
<S extends F> |
GroupPattern.subtype(Class<S> subtypeClass) |
Pattern<T,F> |
Pattern.times(int times)
Specifies exact number of times that this pattern should be matched.
|
Pattern<T,F> |
Pattern.times(int from,
int to)
Specifies that the pattern can occur between from and to times.
|
Pattern<T,F> |
Pattern.timesOrMore(int times)
Specifies that this pattern can occur the specified times at least.
|
Pattern<T,F> |
Pattern.until(IterativeCondition<F> untilCondition)
Applies a stop condition for a looping state.
|
Pattern<T,F> |
Pattern.where(IterativeCondition<F> condition)
Adds a condition that has to be satisfied by an event in order to be considered a match.
|
Pattern<T,F> |
GroupPattern.where(IterativeCondition<F> condition) |
Pattern<T,F> |
Pattern.within(Time windowTime)
Defines the maximum time interval in which a matching pattern has to be completed in order to
be considered valid.
|
Modifier and Type | Method and Description |
---|---|
static <T,F extends T> |
Pattern.begin(Pattern<T,F> group)
Starts a new pattern sequence.
|
static <T,F extends T> |
Pattern.begin(Pattern<T,F> group,
AfterMatchSkipStrategy afterMatchSkipStrategy)
Starts a new pattern sequence.
|
GroupPattern<T,F> |
Pattern.followedBy(Pattern<T,F> group)
Appends a new group pattern to the existing one.
|
GroupPattern<T,F> |
Pattern.followedByAny(Pattern<T,F> group)
Appends a new group pattern to the existing one.
|
GroupPattern<T,F> |
Pattern.next(Pattern<T,F> group)
Appends a new group pattern to the existing one.
|
Constructor and Description |
---|
Pattern(String name,
Pattern<T,? extends T> previous,
Quantifier.ConsumingStrategy consumingStrategy,
AfterMatchSkipStrategy afterMatchSkipStrategy) |
Modifier and Type | Method and Description |
---|---|
static Tuple2<Pattern<RowData,RowData>,List<String>> |
StreamExecMatch.translatePattern(MatchSpec matchSpec,
TableConfig tableConfig,
org.apache.calcite.tools.RelBuilder relBuilder,
RowType inputRowType) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.