A B C D E F G H I L M N O P Q R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- addEdge(SharedBufferEdge) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode
- addIgnore(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
- addIgnore(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
- addProceed(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
- addStage() - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a new dewey number from this such that a 0 is appended as new last digit.
- addStateTransition(StateTransitionAction, State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
- addTake(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
- addTake(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
- advanceTime(long) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Notifies shared buffer that there will be no events with timestamp <&eq; the given value.
- advanceTime(SharedBufferAccessor<T>, NFAState, long, AfterMatchSkipStrategy) - Method in class org.apache.flink.cep.nfa.NFA
-
Prunes states assuming there will be no events with timestamp lower than the given one.
- AfterMatchSkipStrategy - Class in org.apache.flink.cep.nfa.aftermatch
-
Indicate the skip strategy after a match process.
- allowCombinations() - Method in class org.apache.flink.cep.pattern.Pattern
-
Applicable only to
Quantifier.looping(ConsumingStrategy)
andQuantifier.times(ConsumingStrategy)
patterns, this option allows more flexibility to the matching events.
B
- begin(String) - Static method in class org.apache.flink.cep.pattern.Pattern
-
Starts a new pattern sequence.
- begin(String, AfterMatchSkipStrategy) - Static method in class org.apache.flink.cep.pattern.Pattern
-
Starts a new pattern sequence.
- begin(Pattern<T, F>) - Static method in class org.apache.flink.cep.pattern.Pattern
-
Starts a new pattern sequence.
- begin(Pattern<T, F>, AfterMatchSkipStrategy) - Static method in class org.apache.flink.cep.pattern.Pattern
-
Starts a new pattern sequence.
- BooleanConditions - Class in org.apache.flink.cep.pattern.conditions
-
Utility class containing an
IterativeCondition
that always returnstrue
and one that always returnsfalse
. - BooleanConditions() - Constructor for class org.apache.flink.cep.pattern.conditions.BooleanConditions
C
- canProduceEmptyMatches(Pattern<?, ?>) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
-
Verifies if the provided pattern can possibly generate empty match.
- CEP - Class in org.apache.flink.cep
-
Utility class for complex event processing.
- CEP() - Constructor for class org.apache.flink.cep.CEP
- CEP_CACHE_STATISTICS_INTERVAL - Static variable in class org.apache.flink.cep.configuration.CEPCacheOptions
- CEP_SHARED_BUFFER_ENTRY_CACHE_SLOTS - Static variable in class org.apache.flink.cep.configuration.CEPCacheOptions
- CEP_SHARED_BUFFER_EVENT_CACHE_SLOTS - Static variable in class org.apache.flink.cep.configuration.CEPCacheOptions
- CEPCacheOptions - Class in org.apache.flink.cep.configuration
-
CEP Cache Options.
- CepOperator<IN,KEY,OUT> - Class in org.apache.flink.cep.operator
-
CEP pattern operator for a keyed input stream.
- CepOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, PatternProcessFunction<IN, OUT>, OutputTag<IN>) - Constructor for class org.apache.flink.cep.operator.CepOperator
- checkNameUniqueness(String) - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Checks if the given name is already used or not.
- clear() - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Clear the names added during checking name uniqueness.
- close() - Method in class org.apache.flink.cep.functions.adaptors.PatternFlatSelectAdapter
- close() - Method in class org.apache.flink.cep.functions.adaptors.PatternSelectAdapter
- close() - Method in class org.apache.flink.cep.functions.adaptors.PatternTimeoutFlatSelectAdapter
- close() - Method in class org.apache.flink.cep.functions.adaptors.PatternTimeoutSelectAdapter
- close() - Method in class org.apache.flink.cep.nfa.NFA
-
Tear-down method for the NFA.
- close() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Persists the entry in the cache to the underlay state.
- close() - Method in class org.apache.flink.cep.operator.CepOperator
- close() - Method in class org.apache.flink.cep.pattern.conditions.RichCompositeIterativeCondition
- close() - Method in class org.apache.flink.cep.pattern.conditions.RichIterativeCondition
- combinations() - Method in class org.apache.flink.cep.pattern.Quantifier
- COMPARATOR - Static variable in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- compare(StreamRecord<IN>, StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.StreamRecordComparator
- compareTo(EventId) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- compileFactory(Pattern<T, ?>, boolean) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
-
Compiles the given pattern into a
NFACompiler.NFAFactory
. - COMPUTATION_STATE_COMPARATOR - Static variable in class org.apache.flink.cep.nfa.NFAState
- ComputationState - Class in org.apache.flink.cep.nfa
-
Helper class which encapsulates the currentStateName of the NFA computation.
- consecutive() - Method in class org.apache.flink.cep.pattern.Pattern
-
Works in conjunction with
Pattern.oneOrMore()
orPattern.times(int)
. - consecutive() - Method in class org.apache.flink.cep.pattern.Quantifier
- copy(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- copy(DeweyNumber, DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- copy(NFAState) - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- copy(NFAState, NFAState) - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- copy(EventId) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- copy(EventId, EventId) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- copy(Lockable<E>) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- copy(Lockable<E>, Lockable<E>) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- copy(NodeId) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- copy(NodeId, NodeId) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- copy(SharedBufferEdge) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- copy(SharedBufferEdge, SharedBufferEdge) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- copy(SharedBufferNode) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- copy(SharedBufferNode, SharedBufferNode) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- createInitialNFAState() - Method in class org.apache.flink.cep.nfa.NFA
- createInstance() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- createInstance() - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- createInstance() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- createInstance() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- createInstance() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- createInstance() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- createInstance() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- createNFA() - Method in interface org.apache.flink.cep.nfa.compiler.NFACompiler.NFAFactory
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.cep.nfa.sharedbuffer.LockableTypeSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer.NodeIdSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializerSnapshotV2
- createStartState(String) - Static method in class org.apache.flink.cep.nfa.ComputationState
- createStartState(String, DeweyNumber) - Static method in class org.apache.flink.cep.nfa.ComputationState
- createState(String, NodeId, DeweyNumber, long, long, EventId) - Static method in class org.apache.flink.cep.nfa.ComputationState
- currentProcessingTime() - Method in interface org.apache.flink.cep.time.TimeContext
-
Returns the current processing time.
- currentProcessingTime() - Method in interface org.apache.flink.cep.time.TimerService
-
Current processing time as returned from
TimerService
.
D
- deserialize(DeweyNumber, DataInputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- deserialize(NFAState, DataInputView) - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- deserialize(EventId, DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- deserialize(Lockable<E>, DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- deserialize(NodeId, DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- deserialize(SharedBufferEdge, DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- deserialize(SharedBufferNode, DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- DeweyNumber - Class in org.apache.flink.cep.nfa
-
Versioning scheme which allows to retrieve dependencies between different versions.
- DeweyNumber(int) - Constructor for class org.apache.flink.cep.nfa.DeweyNumber
- DeweyNumber(DeweyNumber) - Constructor for class org.apache.flink.cep.nfa.DeweyNumber
- DeweyNumber.DeweyNumberSerializer - Class in org.apache.flink.cep.nfa
-
A
TypeSerializer
for theDeweyNumber
which serves as a version number. - DeweyNumber.DeweyNumberSerializer.DeweyNumberSerializerSnapshot - Class in org.apache.flink.cep.nfa
-
Serializer configuration snapshot for compatibility and format evolution.
- DeweyNumberSerializerSnapshot() - Constructor for class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer.DeweyNumberSerializerSnapshot
- duplicate() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
E
- ENDING_STATE_NAME - Static variable in class org.apache.flink.cep.nfa.compiler.NFACompiler
- equals(Object) - Method in class org.apache.flink.cep.nfa.ComputationState
- equals(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- equals(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber
- equals(Object) - Method in class org.apache.flink.cep.nfa.NFAState
- equals(Object) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- equals(Object) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable
- equals(Object) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- equals(Object) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId
- equals(Object) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge
- equals(Object) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode
- equals(Object) - Method in class org.apache.flink.cep.nfa.State
- equals(Object) - Method in class org.apache.flink.cep.nfa.StateTransition
- equals(Object) - Method in class org.apache.flink.cep.pattern.Quantifier
- equals(Object) - Method in class org.apache.flink.cep.pattern.Quantifier.Times
- EventComparator<T> - Interface in org.apache.flink.cep
-
Custom comparator used to compares two events.
- EventId - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Composite key for events in
SharedBuffer
. - EventId(int, long) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.EventId
- EventId.EventIdSerializer - Class in org.apache.flink.cep.nfa.sharedbuffer
-
TypeSerializer
forEventId
. - EventId.EventIdSerializer.EventIdSerializerSnapshot - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer configuration snapshot for compatibility and format evolution.
- EventIdSerializerSnapshot() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer.EventIdSerializerSnapshot
- extractPatterns(NodeId, DeweyNumber) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Returns all elements from the previous relation starting at the given entry.
F
- falseFunction() - Static method in class org.apache.flink.cep.pattern.conditions.BooleanConditions
- filter(T) - Method in class org.apache.flink.cep.pattern.conditions.SubtypeCondition
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.IterativeCondition
-
The filter function that evaluates the predicate.
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.RichAndCondition
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.RichNotCondition
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.RichOrCondition
- filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.SimpleCondition
- Final - org.apache.flink.cep.nfa.State.StateType
- FIRST_AND_LAST - org.apache.flink.cep.pattern.WithinType
- flatSelect(Map<String, List<IN>>, Collector<OUT>) - Method in interface org.apache.flink.cep.PatternFlatSelectFunction
-
Generates zero or more resulting elements given a map of detected pattern events.
- flatSelect(Map<String, List<IN>>, Collector<OUT>) - Method in class org.apache.flink.cep.RichPatternFlatSelectFunction
- flatSelect(PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(PatternFlatSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(OutputTag<L>, PatternFlatTimeoutFunction<T, L>, TypeInformation<R>, PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- flatSelect(OutputTag<L>, PatternFlatTimeoutFunction<T, L>, PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a flat select function to the detected pattern sequence.
- followedBy(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
- followedBy(Pattern<T, F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new group pattern to the existing one.
- followedByAny(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
- followedByAny(Pattern<T, F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new group pattern to the existing one.
- fromString(String) - Static method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a dewey number from a string representation.
G
- getAccessor() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
-
Construct an accessor to deal with this sharedBuffer.
- getAction() - Method in class org.apache.flink.cep.nfa.StateTransition
- getAfterMatchSkipStrategy() - Method in class org.apache.flink.cep.pattern.Pattern
- getCacheStatisticsInterval() - Method in class org.apache.flink.cep.configuration.SharedBufferCacheConfig
- getCompletedMatches() - Method in class org.apache.flink.cep.nfa.NFAState
- getCondition() - Method in class org.apache.flink.cep.nfa.StateTransition
- getCondition() - Method in class org.apache.flink.cep.pattern.Pattern
- getConsumingStrategy() - Method in class org.apache.flink.cep.pattern.Quantifier
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.cep.nfa.sharedbuffer.LockableTypeSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer.NodeIdSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializerSnapshotV2
- getCurrentStateName() - Method in class org.apache.flink.cep.nfa.ComputationState
- getEdges() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode
- getEdgeSerializer() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- getElement() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable
- getEntryCacheSlots() - Method in class org.apache.flink.cep.configuration.SharedBufferCacheConfig
- getEventId() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId
- getEventsBufferCacheSize() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- getEventsBufferCacheSlots() - Method in class org.apache.flink.cep.configuration.SharedBufferCacheConfig
- getEventsBufferSize() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- getEventsForPattern(String) - Method in interface org.apache.flink.cep.pattern.conditions.IterativeCondition.Context
- getFrom() - Method in class org.apache.flink.cep.pattern.Quantifier.Times
- getId() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- getInnerConsumingStrategy() - Method in class org.apache.flink.cep.pattern.Quantifier
- getIterationRuntimeContext() - Method in class org.apache.flink.cep.pattern.conditions.RichIterativeCondition
- getLeft() - Method in class org.apache.flink.cep.pattern.conditions.RichAndCondition
- getLeft() - Method in class org.apache.flink.cep.pattern.conditions.RichOrCondition
- getLength() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- getLength() - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- getLength() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- getLength() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- getLength() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- getLength() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- getLength() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- getName() - Method in class org.apache.flink.cep.nfa.State
- getName() - Method in class org.apache.flink.cep.pattern.Pattern
- getNestedConditions() - Method in class org.apache.flink.cep.pattern.conditions.RichCompositeIterativeCondition
- getNestedSerializers(NFAStateSerializer) - Method in class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
- getNestedSerializers(Lockable.LockableTypeSerializer<E>) - Method in class org.apache.flink.cep.nfa.sharedbuffer.LockableTypeSerializerSnapshot
- getNestedSerializers(NodeId.NodeIdSerializer) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer.NodeIdSerializerSnapshot
- getNestedSerializers(SharedBufferEdge.SharedBufferEdgeSerializer) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot
- getNestedSerializers(SharedBufferNodeSerializer) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializerSnapshotV2
- getOriginalNameFromInternal(String) - Static method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Implements the reverse process of the
NFAStateNameHandler.getUniqueInternalName(String)
. - getPageName() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId
- getPartialMatches() - Method in class org.apache.flink.cep.nfa.NFAState
- getPatternName() - Method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Name of pattern that processing will be skipped to.
- getPrevious() - Method in class org.apache.flink.cep.pattern.Pattern
- getPreviousBufferEntry() - Method in class org.apache.flink.cep.nfa.ComputationState
- getPreviousTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
- getPruningId(Collection<Map<String, List<EventId>>>) - Method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Retrieves event id of the pruning element from the given match based on the strategy.
- getPruningId(Collection<Map<String, List<EventId>>>) - Method in class org.apache.flink.cep.nfa.aftermatch.NoSkipStrategy
- getPruningId(Collection<Map<String, List<EventId>>>) - Method in class org.apache.flink.cep.nfa.aftermatch.SkipPastLastStrategy
- getPruningId(Collection<Map<String, List<EventId>>>) - Method in class org.apache.flink.cep.nfa.aftermatch.SkipToNextStrategy
- getQuantifier() - Method in class org.apache.flink.cep.pattern.Pattern
- getRawPattern() - Method in class org.apache.flink.cep.pattern.GroupPattern
- getRight() - Method in class org.apache.flink.cep.pattern.conditions.RichAndCondition
- getRight() - Method in class org.apache.flink.cep.pattern.conditions.RichOrCondition
- getRun() - Method in class org.apache.flink.cep.nfa.DeweyNumber
- getRuntimeContext() - Method in class org.apache.flink.cep.pattern.conditions.RichIterativeCondition
- getSharedBufferNodeCacheSize() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- getSharedBufferNodeSize() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- getSourceState() - Method in class org.apache.flink.cep.nfa.StateTransition
- getStartEventID() - Method in class org.apache.flink.cep.nfa.ComputationState
- getStartTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
- getStates() - Method in class org.apache.flink.cep.nfa.NFA
- getStateTransitions() - Method in class org.apache.flink.cep.nfa.State
- getStateType() - Method in class org.apache.flink.cep.nfa.State
- getTargetState() - Method in class org.apache.flink.cep.nfa.StateTransition
- getTimes() - Method in class org.apache.flink.cep.pattern.Pattern
- getTimestamp() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- getTo() - Method in class org.apache.flink.cep.pattern.Quantifier.Times
- getUniqueInternalName(String) - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
-
Used to give a unique name to
NFA
states created during the translation process. - getUntilCondition() - Method in class org.apache.flink.cep.pattern.Pattern
- getVersion() - Method in class org.apache.flink.cep.nfa.ComputationState
- getWindowSize() - Method in class org.apache.flink.cep.pattern.Pattern
- getWindowSize() - Method in class org.apache.flink.cep.pattern.Quantifier.Times
- getWindowSize(WithinType) - Method in class org.apache.flink.cep.pattern.Pattern
- getWindowTime() - Method in class org.apache.flink.cep.nfa.NFA
- greedy() - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern is greedy.
- greedy() - Method in class org.apache.flink.cep.pattern.Quantifier
- GREEDY - org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
- GroupPattern<T,F extends T> - Class in org.apache.flink.cep.pattern
-
Base class for a group pattern definition.
H
- hashCode() - Method in class org.apache.flink.cep.nfa.ComputationState
- hashCode() - Method in class org.apache.flink.cep.nfa.DeweyNumber
- hashCode() - Method in class org.apache.flink.cep.nfa.NFAState
- hashCode() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- hashCode() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable
- hashCode() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- hashCode() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId
- hashCode() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge
- hashCode() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode
- hashCode() - Method in class org.apache.flink.cep.nfa.State
- hashCode() - Method in class org.apache.flink.cep.nfa.StateTransition
- hashCode() - Method in class org.apache.flink.cep.pattern.Quantifier
- hashCode() - Method in class org.apache.flink.cep.pattern.Quantifier.Times
- hasProperty(Quantifier.QuantifierProperty) - Method in class org.apache.flink.cep.pattern.Quantifier
I
- IGNORE - org.apache.flink.cep.nfa.StateTransitionAction
- increase() - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a new dewey number from this such that its last digit is increased by one.
- increase(int) - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Creates a new dewey number from this such that its last digit is increased by the supplied number.
- inEventTime() - Method in class org.apache.flink.cep.PatternStream
-
Sets the time characteristic to event time.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.cep.operator.CepOperator
- inProcessingTime() - Method in class org.apache.flink.cep.PatternStream
-
Sets the time characteristic to processing time.
- INSTANCE - Static variable in class org.apache.flink.cep.nfa.aftermatch.SkipPastLastStrategy
- INSTANCE - Static variable in class org.apache.flink.cep.nfa.aftermatch.SkipToNextStrategy
- INSTANCE - Static variable in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- INSTANCE - Static variable in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- isCompatibleWith(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber
-
Checks whether this dewey number is compatible to the other dewey number.
- isEmpty() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
-
Checks if there is no elements in the buffer.
- isFinal() - Method in class org.apache.flink.cep.nfa.State
- isImmutableType() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- isImmutableType() - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- isImmutableType() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- isImmutableType() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- isImmutableType() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- isImmutableType() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- isImmutableType() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- isNewStartPartialMatch() - Method in class org.apache.flink.cep.nfa.NFAState
- isPending() - Method in class org.apache.flink.cep.nfa.State
- isSkipStrategy() - Method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Tells if the strategy may skip some matches.
- isSkipStrategy() - Method in class org.apache.flink.cep.nfa.aftermatch.NoSkipStrategy
- isStart() - Method in class org.apache.flink.cep.nfa.State
- isStateChanged() - Method in class org.apache.flink.cep.nfa.NFAState
-
Check if the matching status of the NFA has changed so far.
- isStop() - Method in class org.apache.flink.cep.nfa.State
- isSupportsPreviousTimestamp() - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- IterativeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A user-defined condition that decides if an element should be accepted in the pattern or not.
- IterativeCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.IterativeCondition
- IterativeCondition.Context<T> - Interface in org.apache.flink.cep.pattern.conditions
-
The context used when evaluating the
condition
.
L
- length() - Method in class org.apache.flink.cep.nfa.DeweyNumber
- lock() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable
- Lockable<T> - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Implements locking logic for incoming event and
SharedBufferNode
using a lock reference counter. - Lockable(T, int) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.Lockable
- Lockable.LockableTypeSerializer<E> - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer for
Lockable
. - LockableTypeSerializer(TypeSerializer<E>) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- LockableTypeSerializerSnapshot<E> - Class in org.apache.flink.cep.nfa.sharedbuffer
-
A
TypeSerializerSnapshot
for theLockable.LockableTypeSerializer
. - LockableTypeSerializerSnapshot() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.LockableTypeSerializerSnapshot
-
Constructor for read instantiation.
- LockableTypeSerializerSnapshot(Lockable.LockableTypeSerializer<E>) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.LockableTypeSerializerSnapshot
-
Constructor to create the snapshot for writing.
- lockNode(NodeId, DeweyNumber) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Increases the reference counter for the given entry so that it is not accidentally removed.
- looping(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
- LOOPING - org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
M
- makeStart() - Method in class org.apache.flink.cep.nfa.State
- MalformedPatternException - Exception in org.apache.flink.cep.pattern
-
An exception used to indicate that a
Pattern
was not specified correctly. - MalformedPatternException(String) - Constructor for exception org.apache.flink.cep.pattern.MalformedPatternException
- materializeMatch(Map<String, List<EventId>>) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Extracts the real event from the sharedBuffer with pre-extracted eventId.
N
- next(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
- next(Pattern<T, F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new group pattern to the existing one.
- NFA<T> - Class in org.apache.flink.cep.nfa
-
Non-deterministic finite automaton implementation.
- NFA(Collection<State<T>>, Map<String, Long>, long, boolean) - Constructor for class org.apache.flink.cep.nfa.NFA
- NFACompiler - Class in org.apache.flink.cep.nfa.compiler
- NFACompiler() - Constructor for class org.apache.flink.cep.nfa.compiler.NFACompiler
- NFACompiler.NFAFactory<T> - Interface in org.apache.flink.cep.nfa.compiler
-
Factory interface for
NFA
. - NFAState - Class in org.apache.flink.cep.nfa
-
State kept for a
NFA
. - NFAState(Iterable<ComputationState>) - Constructor for class org.apache.flink.cep.nfa.NFAState
- NFAState(Queue<ComputationState>, Queue<ComputationState>) - Constructor for class org.apache.flink.cep.nfa.NFAState
- NFAStateNameHandler - Class in org.apache.flink.cep.nfa.compiler
-
A utility class used to handle name conventions and guarantee unique names for the states of our
NFA
. - NFAStateNameHandler() - Constructor for class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
- NFAStateSerializer - Class in org.apache.flink.cep.nfa
-
A
TypeSerializer
forNFAState
. - NFAStateSerializer() - Constructor for class org.apache.flink.cep.nfa.NFAStateSerializer
- NFAStateSerializerSnapshot - Class in org.apache.flink.cep.nfa
-
Snapshot class for
NFAStateSerializer
. - NFAStateSerializerSnapshot() - Constructor for class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
-
Constructor for read instantiation.
- NFAStateSerializerSnapshot(NFAStateSerializer) - Constructor for class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
-
Constructor to create the snapshot for writing.
- NodeId - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Unique identifier for
SharedBufferNode
. - NodeId(EventId, String) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.NodeId
- NodeId.NodeIdSerializer - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer for
NodeId
. - NodeId.NodeIdSerializer.NodeIdSerializerSnapshot - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer configuration snapshot for compatibility and format evolution.
- NodeIdSerializer() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- NodeIdSerializerSnapshot() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer.NodeIdSerializerSnapshot
- NodeIdSerializerSnapshot(NodeId.NodeIdSerializer) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer.NodeIdSerializerSnapshot
- Normal - org.apache.flink.cep.nfa.State.StateType
- noSkip() - Static method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Every possible match will be emitted.
- NoSkipStrategy - Class in org.apache.flink.cep.nfa.aftermatch
-
Every possible match will be emitted.
- NOT_FOLLOW - org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
- NOT_NEXT - org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
- notFollowedBy(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
- notNext(String) - Method in class org.apache.flink.cep.pattern.Pattern
-
Appends a new pattern to the existing one.
O
- of(int, int, Duration) - Static method in class org.apache.flink.cep.pattern.Quantifier.Times
- of(int, Duration) - Static method in class org.apache.flink.cep.pattern.Quantifier.Times
- of(FilterFunction<T>) - Static method in class org.apache.flink.cep.pattern.conditions.SimpleCondition
- of(ReadableConfig) - Static method in class org.apache.flink.cep.configuration.SharedBufferCacheConfig
- one(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
- oneOrMore() - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern can occur
one or more
times. - oneOrMore(Duration) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern can occur
one or more
times and time interval corresponds to the maximum time gap between previous and current event for each times. - onEventTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.cep.operator.CepOperator
- onProcessingTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.cep.operator.CepOperator
- open() - Method in class org.apache.flink.cep.operator.CepOperator
- open(OpenContext) - Method in class org.apache.flink.cep.functions.adaptors.PatternFlatSelectAdapter
- open(OpenContext) - Method in class org.apache.flink.cep.functions.adaptors.PatternSelectAdapter
- open(OpenContext) - Method in class org.apache.flink.cep.functions.adaptors.PatternTimeoutFlatSelectAdapter
- open(OpenContext) - Method in class org.apache.flink.cep.functions.adaptors.PatternTimeoutSelectAdapter
- open(OpenContext) - Method in class org.apache.flink.cep.pattern.conditions.RichCompositeIterativeCondition
- open(OpenContext) - Method in class org.apache.flink.cep.pattern.conditions.RichIterativeCondition
- open(RuntimeContext, Configuration) - Method in class org.apache.flink.cep.nfa.NFA
-
Initialization method for the NFA.
- optional() - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern is optional for a final match of the pattern sequence to happen.
- optional() - Method in class org.apache.flink.cep.pattern.Quantifier
- OPTIONAL - org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
- or(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.GroupPattern
- or(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Adds a condition that has to be satisfied by an event in order to be considered a match.
- org.apache.flink.cep - package org.apache.flink.cep
- org.apache.flink.cep.configuration - package org.apache.flink.cep.configuration
- org.apache.flink.cep.functions - package org.apache.flink.cep.functions
- org.apache.flink.cep.functions.adaptors - package org.apache.flink.cep.functions.adaptors
- org.apache.flink.cep.nfa - package org.apache.flink.cep.nfa
- org.apache.flink.cep.nfa.aftermatch - package org.apache.flink.cep.nfa.aftermatch
- org.apache.flink.cep.nfa.compiler - package org.apache.flink.cep.nfa.compiler
- org.apache.flink.cep.nfa.sharedbuffer - package org.apache.flink.cep.nfa.sharedbuffer
- org.apache.flink.cep.operator - package org.apache.flink.cep.operator
- org.apache.flink.cep.pattern - package org.apache.flink.cep.pattern
- org.apache.flink.cep.pattern.conditions - package org.apache.flink.cep.pattern.conditions
- org.apache.flink.cep.time - package org.apache.flink.cep.time
- output(OutputTag<X>, X) - Method in interface org.apache.flink.cep.functions.PatternProcessFunction.Context
-
Emits a record to the side output identified by the
OutputTag
.
P
- pattern(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.CEP
-
Creates a
PatternStream
from an input data stream and a pattern. - pattern(DataStream<T>, Pattern<T, ?>, EventComparator<T>) - Static method in class org.apache.flink.cep.CEP
-
Creates a
PatternStream
from an input data stream and a pattern. - Pattern<T,F extends T> - Class in org.apache.flink.cep.pattern
-
Base class for a pattern definition.
- Pattern(String, Pattern<T, ? extends T>, Quantifier.ConsumingStrategy, AfterMatchSkipStrategy) - Constructor for class org.apache.flink.cep.pattern.Pattern
- PatternFlatSelectAdapter<IN,OUT> - Class in org.apache.flink.cep.functions.adaptors
-
Adapter that expresses
PatternFlatSelectFunction
withPatternProcessFunction
. - PatternFlatSelectAdapter(PatternFlatSelectFunction<IN, OUT>) - Constructor for class org.apache.flink.cep.functions.adaptors.PatternFlatSelectAdapter
- PatternFlatSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern select function which can produce multiple resulting elements.
- PatternFlatTimeoutFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern timeout function which can produce multiple resulting elements.
- PatternProcessFunction<IN,OUT> - Class in org.apache.flink.cep.functions
-
It is called with a map of detected events which are identified by their names.
- PatternProcessFunction() - Constructor for class org.apache.flink.cep.functions.PatternProcessFunction
- PatternProcessFunction.Context - Interface in org.apache.flink.cep.functions
-
Gives access to time related characteristics as well as enables emitting elements to side outputs.
- PatternSelectAdapter<IN,OUT> - Class in org.apache.flink.cep.functions.adaptors
-
Adapter that expresses
PatternSelectFunction
withPatternProcessFunction
. - PatternSelectAdapter(PatternSelectFunction<IN, OUT>) - Constructor for class org.apache.flink.cep.functions.adaptors.PatternSelectAdapter
- PatternSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern select function.
- PatternStream<T> - Class in org.apache.flink.cep
-
Stream abstraction for CEP pattern detection.
- PatternTimeoutFlatSelectAdapter<IN,OUT,T> - Class in org.apache.flink.cep.functions.adaptors
-
Adapter that expresses combination of
PatternFlatSelectFunction
andPatternTimeoutFlatSelectAdapter
withPatternProcessFunction
. - PatternTimeoutFlatSelectAdapter(PatternFlatSelectFunction<IN, OUT>, PatternFlatTimeoutFunction<IN, T>, OutputTag<T>) - Constructor for class org.apache.flink.cep.functions.adaptors.PatternTimeoutFlatSelectAdapter
- PatternTimeoutFunction<IN,OUT> - Interface in org.apache.flink.cep
-
Base interface for a pattern timeout function.
- PatternTimeoutSelectAdapter<IN,OUT,T> - Class in org.apache.flink.cep.functions.adaptors
-
Adapter that expresses combination of
PatternSelectFunction
andPatternTimeoutFlatSelectAdapter
withPatternProcessFunction
. - PatternTimeoutSelectAdapter(PatternSelectFunction<IN, OUT>, PatternTimeoutFunction<IN, T>, OutputTag<T>) - Constructor for class org.apache.flink.cep.functions.adaptors.PatternTimeoutSelectAdapter
- Pending - org.apache.flink.cep.nfa.State.StateType
- PREVIOUS_AND_CURRENT - org.apache.flink.cep.pattern.WithinType
- PROCEED - org.apache.flink.cep.nfa.StateTransitionAction
- process(PatternProcessFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a process function to the detected pattern sequence.
- process(PatternProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a process function to the detected pattern sequence.
- process(SharedBufferAccessor<T>, NFAState, T, long, AfterMatchSkipStrategy, TimerService) - Method in class org.apache.flink.cep.nfa.NFA
-
Processes the next input event.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.CepOperator
- processMatch(Map<String, List<IN>>, PatternProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.cep.functions.adaptors.PatternFlatSelectAdapter
- processMatch(Map<String, List<IN>>, PatternProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.cep.functions.adaptors.PatternSelectAdapter
- processMatch(Map<String, List<IN>>, PatternProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.cep.functions.PatternProcessFunction
-
Generates resulting elements given a map of detected pattern events.
- processTimedOutMatch(Map<String, List<IN>>, PatternProcessFunction.Context) - Method in class org.apache.flink.cep.functions.adaptors.PatternTimeoutFlatSelectAdapter
- processTimedOutMatch(Map<String, List<IN>>, PatternProcessFunction.Context) - Method in class org.apache.flink.cep.functions.adaptors.PatternTimeoutSelectAdapter
- processTimedOutMatch(Map<String, List<IN>>, PatternProcessFunction.Context) - Method in interface org.apache.flink.cep.functions.TimedOutPartialMatchHandler
-
Called for every timed out partial match (due to
Pattern.within(Duration)
). - prune(Collection<ComputationState>, Collection<Map<String, List<EventId>>>, SharedBufferAccessor<?>) - Method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Prunes matches/partial matches based on the chosen strategy.
- put(String, EventId, NodeId, DeweyNumber) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Stores given value (value + timestamp) under the given state.
Q
- Quantifier - Class in org.apache.flink.cep.pattern
-
A quantifier describing the Pattern.
- Quantifier.ConsumingStrategy - Enum in org.apache.flink.cep.pattern
-
Describes strategy for which events are matched in this
Pattern
. - Quantifier.QuantifierProperty - Enum in org.apache.flink.cep.pattern
-
Properties that a
Quantifier
can have. - Quantifier.Times - Class in org.apache.flink.cep.pattern
-
Describe the times this
Pattern
can occur.
R
- readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
- registerEvent(V, long) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Adds another unique event to the shared buffer and assigns a unique id for it.
- releaseCacheStatisticsTimer() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- releaseEvent(EventId) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Decreases the reference counter for the given event so that it can be removed once the reference counter reaches 0.
- releaseNode(NodeId, DeweyNumber) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferAccessor
-
Decreases the reference counter for the given entry so that it can be removed once the reference counter reaches 0.
- resetNewStartPartialMatch() - Method in class org.apache.flink.cep.nfa.NFAState
- resetStateChanged() - Method in class org.apache.flink.cep.nfa.NFAState
-
Reset the changed bit checked via
NFAState.isStateChanged()
tofalse
. - resolveOuterSchemaCompatibility(TypeSerializerSnapshot<NFAState>) - Method in class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
- RichAndCondition<T> - Class in org.apache.flink.cep.pattern.conditions
- RichAndCondition(IterativeCondition<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.RichAndCondition
- RichCompositeIterativeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A base class of composite
IterativeCondition
conditions such asRichAndCondition
,RichOrCondition
andRichNotCondition
, etc. - RichCompositeIterativeCondition(IterativeCondition<T>...) - Constructor for class org.apache.flink.cep.pattern.conditions.RichCompositeIterativeCondition
- RichIterativeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
Rich variant of the
IterativeCondition
. - RichIterativeCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.RichIterativeCondition
- RichNotCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A
condition
which negates the condition it wraps and returnstrue
if the original condition returnsfalse
. - RichNotCondition(IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.RichNotCondition
- RichOrCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A
condition
which combines two conditions with a logicalOR
and returnstrue
if at least one istrue
. - RichOrCondition(IterativeCondition<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.RichOrCondition
- RichPatternFlatSelectFunction<IN,OUT> - Class in org.apache.flink.cep
-
Rich variant of the
PatternFlatSelectFunction
. - RichPatternFlatSelectFunction() - Constructor for class org.apache.flink.cep.RichPatternFlatSelectFunction
- RichPatternSelectFunction<IN,OUT> - Class in org.apache.flink.cep
-
Rich variant of the
PatternSelectFunction
. - RichPatternSelectFunction() - Constructor for class org.apache.flink.cep.RichPatternSelectFunction
S
- select(Map<String, List<IN>>) - Method in interface org.apache.flink.cep.PatternSelectFunction
-
Generates a result from the given map of events.
- select(Map<String, List<IN>>) - Method in class org.apache.flink.cep.RichPatternSelectFunction
- select(PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(PatternSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(OutputTag<L>, PatternTimeoutFunction<T, L>, TypeInformation<R>, PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- select(OutputTag<L>, PatternTimeoutFunction<T, L>, PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
-
Applies a select function to the detected pattern sequence.
- serialize(DeweyNumber, DataOutputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- serialize(NFAState, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- serialize(EventId, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- serialize(Lockable<E>, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- serialize(NodeId, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- serialize(SharedBufferEdge, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- serialize(SharedBufferNode, DataOutputView) - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- serialVersionUID - Static variable in interface org.apache.flink.cep.EventComparator
- setCondition(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.StateTransition
- setNewPartialMatches(PriorityQueue<ComputationState>) - Method in class org.apache.flink.cep.nfa.NFAState
- setNewStartPartiailMatch() - Method in class org.apache.flink.cep.nfa.NFAState
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.cep.pattern.conditions.RichCompositeIterativeCondition
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.cep.pattern.conditions.RichIterativeCondition
- setStateChanged() - Method in class org.apache.flink.cep.nfa.NFAState
-
Set the changed bit checked via
NFAState.isStateChanged()
totrue
. - setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.cep.operator.CepOperator
- SharedBuffer<V> - Class in org.apache.flink.cep.nfa.sharedbuffer
-
A shared buffer implementation which stores values under according state.
- SharedBuffer(KeyedStateStore, TypeSerializer<V>) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- SharedBuffer(KeyedStateStore, TypeSerializer<V>, SharedBufferCacheConfig) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBuffer
- SharedBufferAccessor<V> - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Accessor to SharedBuffer that allows operations on the underlying structures in batches.
- SharedBufferCacheConfig - Class in org.apache.flink.cep.configuration
-
Configuration immutable class.
- SharedBufferCacheConfig() - Constructor for class org.apache.flink.cep.configuration.SharedBufferCacheConfig
- SharedBufferCacheConfig(int, int, Duration) - Constructor for class org.apache.flink.cep.configuration.SharedBufferCacheConfig
- SharedBufferEdge - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Versioned edge in
SharedBuffer
that allows retrieving predecessors. - SharedBufferEdge(NodeId, DeweyNumber) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge
-
Creates versioned (with
DeweyNumber
) edge that points to the target entry. - SharedBufferEdge.SharedBufferEdgeSerializer - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer for
SharedBufferEdge
. - SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer configuration snapshot for compatibility and format evolution.
- SharedBufferEdgeSerializer() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- SharedBufferEdgeSerializerSnapshot() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot
- SharedBufferEdgeSerializerSnapshot(SharedBufferEdge.SharedBufferEdgeSerializer) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot
- SharedBufferNode - Class in org.apache.flink.cep.nfa.sharedbuffer
-
An entry in
SharedBuffer
that allows to store relations between different entries. - SharedBufferNode() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode
- SharedBufferNodeSerializer - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer for
SharedBufferNode
. - SharedBufferNodeSerializer() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- SharedBufferNodeSerializerSnapshotV2 - Class in org.apache.flink.cep.nfa.sharedbuffer
-
Serializer configuration snapshot for compatibility and format evolution.
- SharedBufferNodeSerializerSnapshotV2() - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializerSnapshotV2
- SharedBufferNodeSerializerSnapshotV2(SharedBufferNodeSerializer) - Constructor for class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializerSnapshotV2
- shouldPrune(EventId, EventId) - Method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Tells if the partial/completed match starting at given id should be prunned by given pruningId.
- shouldPrune(EventId, EventId) - Method in class org.apache.flink.cep.nfa.aftermatch.NoSkipStrategy
- sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.cep.PatternStream
-
Send late arriving data to the side output identified by the given
OutputTag
. - SimpleCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A user-defined condition that decides if an element should be accepted in the pattern or not.
- SimpleCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.SimpleCondition
- SINGLE - org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
- SKIP_TILL_ANY - org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
- SKIP_TILL_NEXT - org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
- skipPastLastEvent() - Static method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Discards every partial match that started before emitted match ended.
- SkipPastLastStrategy - Class in org.apache.flink.cep.nfa.aftermatch
-
Discards every partial match that started before emitted match ended.
- skipToFirst(String) - Static method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Discards every partial match that started before the first event of emitted match mapped to *PatternName*.
- SkipToFirstStrategy - Class in org.apache.flink.cep.nfa.aftermatch
-
Discards every partial match that started before the first event of emitted match mapped to *PatternName*.
- skipToLast(String) - Static method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Discards every partial match that started before the last event of emitted match mapped to *PatternName*.
- SkipToLastStrategy - Class in org.apache.flink.cep.nfa.aftermatch
-
Discards every partial match that started before the last event of emitted match mapped to *PatternName*.
- skipToNext() - Static method in class org.apache.flink.cep.nfa.aftermatch.AfterMatchSkipStrategy
-
Discards every partial match that started with the same event, emitted match was started.
- SkipToNextStrategy - Class in org.apache.flink.cep.nfa.aftermatch
-
Discards every partial match that started with the same event, emitted match was started.
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.NFAStateSerializer
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId.EventIdSerializer
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId.NodeIdSerializer
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge.SharedBufferEdgeSerializer
- snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNodeSerializer
- Start - org.apache.flink.cep.nfa.State.StateType
- State<T> - Class in org.apache.flink.cep.nfa
-
Represents a state of the
NFA
. - State(String, State.StateType) - Constructor for class org.apache.flink.cep.nfa.State
- STATE_NAME_DELIM - Static variable in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
- State.StateType - Enum in org.apache.flink.cep.nfa
-
Set of valid state types.
- StateTransition<T> - Class in org.apache.flink.cep.nfa
-
Represents a transition from one
State
to another. - StateTransition(State<T>, StateTransitionAction, State<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.nfa.StateTransition
- StateTransitionAction - Enum in org.apache.flink.cep.nfa
-
Set of actions when doing a state transition from a
State
to another. - Stop - org.apache.flink.cep.nfa.State.StateType
- StreamRecordComparator<IN> - Class in org.apache.flink.cep.operator
-
Compares two
StreamRecord
s based on their timestamp. - StreamRecordComparator() - Constructor for class org.apache.flink.cep.operator.StreamRecordComparator
- STRICT - org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
- subtype(Class<S>) - Method in class org.apache.flink.cep.pattern.GroupPattern
- subtype(Class<S>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Applies a subtype constraint on the current pattern.
- SubtypeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
-
A
condition
which filters elements of the given type. - SubtypeCondition(Class<? extends T>) - Constructor for class org.apache.flink.cep.pattern.conditions.SubtypeCondition
T
- TAKE - org.apache.flink.cep.nfa.StateTransitionAction
- throwExceptionOnMiss() - Method in class org.apache.flink.cep.nfa.aftermatch.SkipToFirstStrategy
- throwExceptionOnMiss() - Method in class org.apache.flink.cep.nfa.aftermatch.SkipToLastStrategy
- TimeContext - Interface in org.apache.flink.cep.time
-
Enables access to time related characteristics such as current processing time or timestamp of currently processed element.
- TimedOutPartialMatchHandler<IN> - Interface in org.apache.flink.cep.functions
-
Enables handling timed out partial matches.
- timeout(Map<String, List<IN>>, long) - Method in interface org.apache.flink.cep.PatternTimeoutFunction
-
Generates a timeout result from the given map of events and timeout timestamp.
- timeout(Map<String, List<IN>>, long, Collector<OUT>) - Method in interface org.apache.flink.cep.PatternFlatTimeoutFunction
-
Generates zero or more resulting timeout elements given a map of partial pattern events and the timestamp of the timeout.
- TimerService - Interface in org.apache.flink.cep.time
-
Enables to provide time characteristic to
NFA
for use inIterativeCondition
. - times(int) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies exact number of times that this pattern should be matched.
- times(int, int) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that the pattern can occur between from and to times.
- times(int, int, Duration) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that the pattern can occur between from and to times with time interval corresponds to the maximum time gap between previous and current event for each times.
- times(int, Duration) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies exact number of times that this pattern should be matched and time interval corresponds to the maximum time gap between previous and current event for each times.
- times(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
- TIMES - org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
- timesOrMore(int) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern can occur the specified times at least.
- timesOrMore(int, Duration) - Method in class org.apache.flink.cep.pattern.Pattern
-
Specifies that this pattern can occur the specified times at least with interval corresponds to the maximum time gap between previous and current event for each times.
- timestamp() - Method in interface org.apache.flink.cep.time.TimeContext
-
Timestamp of the element currently being processed.
- toString() - Method in class org.apache.flink.cep.nfa.aftermatch.NoSkipStrategy
- toString() - Method in class org.apache.flink.cep.nfa.aftermatch.SkipPastLastStrategy
- toString() - Method in class org.apache.flink.cep.nfa.aftermatch.SkipToFirstStrategy
- toString() - Method in class org.apache.flink.cep.nfa.aftermatch.SkipToLastStrategy
- toString() - Method in class org.apache.flink.cep.nfa.aftermatch.SkipToNextStrategy
- toString() - Method in class org.apache.flink.cep.nfa.ComputationState
- toString() - Method in class org.apache.flink.cep.nfa.DeweyNumber
- toString() - Method in class org.apache.flink.cep.nfa.NFAState
- toString() - Method in class org.apache.flink.cep.nfa.sharedbuffer.EventId
- toString() - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable
- toString() - Method in class org.apache.flink.cep.nfa.sharedbuffer.NodeId
- toString() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferEdge
- toString() - Method in class org.apache.flink.cep.nfa.sharedbuffer.SharedBufferNode
- toString() - Method in class org.apache.flink.cep.nfa.State
- toString() - Method in class org.apache.flink.cep.nfa.StateTransition
- toString() - Method in class org.apache.flink.cep.pattern.Pattern
- toString() - Method in class org.apache.flink.cep.pattern.Quantifier
- transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.cep.nfa.sharedbuffer.Lockable.LockableTypeSerializer
- trueFunction() - Static method in class org.apache.flink.cep.pattern.conditions.BooleanConditions
U
- until(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Applies a stop condition for a looping state.
- useSplittableTimers() - Method in class org.apache.flink.cep.operator.CepOperator
V
- valueOf(String) - Static method in enum org.apache.flink.cep.nfa.State.StateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.nfa.StateTransitionAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.cep.pattern.WithinType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.cep.nfa.State.StateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.cep.nfa.StateTransitionAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.cep.pattern.WithinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- where(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.GroupPattern
- where(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.Pattern
-
Adds a condition that has to be satisfied by an event in order to be considered a match.
- within(Duration) - Method in class org.apache.flink.cep.pattern.Pattern
-
Defines the maximum time interval in which a matching pattern has to be completed in order to be considered valid.
- within(Duration, WithinType) - Method in class org.apache.flink.cep.pattern.Pattern
-
Defines the maximum time interval in which a matching pattern has to be completed in order to be considered valid.
- WithinType - Enum in org.apache.flink.cep.pattern
-
Type enum of time interval corresponds to the maximum time gap between events.
- writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.cep.nfa.NFAStateSerializerSnapshot
All Classes All Packages