Class PatternTimeoutFlatSelectAdapter<IN,OUT,T>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.cep.functions.PatternProcessFunction<IN,OUT>
-
- org.apache.flink.cep.functions.adaptors.PatternFlatSelectAdapter<IN,OUT>
-
- org.apache.flink.cep.functions.adaptors.PatternTimeoutFlatSelectAdapter<IN,OUT,T>
-
- All Implemented Interfaces:
Serializable
,Function
,RichFunction
,TimedOutPartialMatchHandler<IN>
@Internal public class PatternTimeoutFlatSelectAdapter<IN,OUT,T> extends PatternFlatSelectAdapter<IN,OUT> implements TimedOutPartialMatchHandler<IN>
Adapter that expresses combination ofPatternFlatSelectFunction
andPatternTimeoutFlatSelectAdapter
withPatternProcessFunction
.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.cep.functions.PatternProcessFunction
PatternProcessFunction.Context
-
-
Constructor Summary
Constructors Constructor Description PatternTimeoutFlatSelectAdapter(PatternFlatSelectFunction<IN,OUT> flatSelectFunction, PatternFlatTimeoutFunction<IN,T> flatTimeoutFunction, OutputTag<T> timedOutPartialMatchesTag)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
Tear-down method for the user code.void
open(OpenContext openContext)
Initialization method for the function.void
processTimedOutMatch(Map<String,List<IN>> match, PatternProcessFunction.Context ctx)
Called for every timed out partial match (due toPattern.within(Duration)
).-
Methods inherited from class org.apache.flink.cep.functions.adaptors.PatternFlatSelectAdapter
processMatch
-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
-
-
-
-
Constructor Detail
-
PatternTimeoutFlatSelectAdapter
public PatternTimeoutFlatSelectAdapter(PatternFlatSelectFunction<IN,OUT> flatSelectFunction, PatternFlatTimeoutFunction<IN,T> flatTimeoutFunction, OutputTag<T> timedOutPartialMatchesTag)
-
-
Method Detail
-
open
public void open(OpenContext openContext) throws Exception
Description copied from interface:RichFunction
Initialization method for the function. It is called before the actual working methods (like map or join) and thus suitable for one time setup work. For functions that are part of an iteration, this method will be invoked at the beginning of each iteration superstep.The openContext object passed to the function can be used for configuration and initialization. The openContext contains some necessary information that were configured on the function in the program composition.
public class MyFilter extends RichFilterFunction<String> { private String searchString; public void open(OpenContext openContext) { // initialize the value of searchString } public boolean filter(String value) { return value.equals(searchString); } }
- Specified by:
open
in interfaceRichFunction
- Overrides:
open
in classPatternFlatSelectAdapter<IN,OUT>
- Parameters:
openContext
- The context containing information about the context in which the function is opened.- Throws:
Exception
- Implementations may forward exceptions, which are caught by the runtime. When the runtime catches an exception, it aborts the task and lets the fail-over logic decide whether to retry the task execution.
-
close
public void close() throws Exception
Description copied from interface:RichFunction
Tear-down method for the user code. It is called after the last call to the main working methods (e.g. map or join). For functions that are part of an iteration, this method will be invoked after each iteration superstep.This method can be used for clean up work.
- Specified by:
close
in interfaceRichFunction
- Overrides:
close
in classPatternFlatSelectAdapter<IN,OUT>
- Throws:
Exception
- Implementations may forward exceptions, which are caught by the runtime. When the runtime catches an exception, it aborts the task and lets the fail-over logic decide whether to retry the task execution.
-
processTimedOutMatch
public void processTimedOutMatch(Map<String,List<IN>> match, PatternProcessFunction.Context ctx) throws Exception
Description copied from interface:TimedOutPartialMatchHandler
Called for every timed out partial match (due toPattern.within(Duration)
). It enables custom handling, e.g. one can emit the timed out results through a side output:{@code private final OutputTag
timedOutPartialMatchesTag = ... private class MyFunction extends PatternProcessFunction implements TimedOutPartialMatchHandler { - Specified by:
processTimedOutMatch
in interfaceTimedOutPartialMatchHandler<IN>
- Parameters:
match
- map containing the timed out partial match. Events are identified by their names.ctx
- enables access to time features and emitting results through side outputs- Throws:
Exception
- This method may throw exceptions. Throwing an exception will cause the operation to fail and may trigger recovery.
-
-