Package | Description |
---|---|
org.apache.flink.cep.functions | |
org.apache.flink.cep.functions.adaptors | |
org.apache.flink.table.runtime.operators.match |
Modifier and Type | Method and Description |
---|---|
abstract void |
PatternProcessFunction.processMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx,
Collector<OUT> out)
Generates resulting elements given a map of detected pattern events.
|
void |
TimedOutPartialMatchHandler.processTimedOutMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx)
Called for every timed out partial match (due to
Pattern.within(Time) ). |
Modifier and Type | Method and Description |
---|---|
void |
PatternFlatSelectAdapter.processMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx,
Collector<OUT> out) |
void |
PatternSelectAdapter.processMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx,
Collector<OUT> out) |
void |
PatternTimeoutSelectAdapter.processTimedOutMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx) |
void |
PatternTimeoutFlatSelectAdapter.processTimedOutMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx) |
Modifier and Type | Method and Description |
---|---|
void |
PatternProcessFunctionRunner.processMatch(Map<String,List<RowData>> match,
PatternProcessFunction.Context ctx,
Collector<RowData> out) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.