IN
- Type of the input elementsKEY
- Type of the key on which the input stream is keyedOUT1
- Type of the output elementsOUT2
- Type of the timed out output elementspublic class SelectTimeoutCepOperator<IN,OUT1,OUT2,KEY> extends AbstractKeyedCEPPatternOperator<IN,KEY,OUT1,SelectTimeoutCepOperator.SelectWrapper<IN,OUT1,OUT2>>
AbstractKeyedCEPPatternOperator
that applies given PatternSelectFunction
to fully
matched event patterns and PatternTimeoutFunction
to timed out ones. The timed out elements are returned
as a side-output.Modifier and Type | Class and Description |
---|---|
static class |
SelectTimeoutCepOperator.SelectWrapper<IN,OUT1,OUT2>
Wrapper that enables storing
PatternSelectFunction and PatternTimeoutFunction in one udf. |
AbstractStreamOperator.CountingOutput
afterMatchSkipStrategy
userFunction
chainingStrategy, config, latencyStats, LOG, metrics, output, timeServiceManager
Constructor and Description |
---|
SelectTimeoutCepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy skipStrategy,
PatternSelectFunction<IN,OUT1> flatSelectFunction,
PatternTimeoutFunction<IN,OUT2> flatTimeoutFunction,
OutputTag<OUT2> outputTag) |
Modifier and Type | Method and Description |
---|---|
protected void |
processMatchedSequences(Iterable<Map<String,List<IN>>> matchingSequences,
long timestamp) |
protected void |
processTimedOutSequences(Iterable<Tuple2<Map<String,List<IN>>,Long>> timedOutSequences,
long timestamp) |
getPQSize, hasNonEmptyNFA, hasNonEmptyPQ, initializeState, onEventTime, onProcessingTime, open, processElement
close, dispose, getUserFunction, getUserFunctionParameters, notifyCheckpointComplete, setOutputType, setup, snapshotState
getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getUserCodeClassloader, initializeState, numEventTimeTimers, numProcessingTimeTimers, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
processLatencyMarker, processWatermark
close, dispose, getChainingStrategy, getMetricGroup, getOperatorID, initializeState, setChainingStrategy, setKeyContextElement1, setKeyContextElement2, setup, snapshotState
notifyCheckpointComplete
getCurrentKey, setCurrentKey
public SelectTimeoutCepOperator(TypeSerializer<IN> inputSerializer, boolean isProcessingTime, NFACompiler.NFAFactory<IN> nfaFactory, EventComparator<IN> comparator, AfterMatchSkipStrategy skipStrategy, PatternSelectFunction<IN,OUT1> flatSelectFunction, PatternTimeoutFunction<IN,OUT2> flatTimeoutFunction, OutputTag<OUT2> outputTag)
protected void processMatchedSequences(Iterable<Map<String,List<IN>>> matchingSequences, long timestamp) throws Exception
processMatchedSequences
in class AbstractKeyedCEPPatternOperator<IN,KEY,OUT1,SelectTimeoutCepOperator.SelectWrapper<IN,OUT1,OUT2>>
Exception
protected void processTimedOutSequences(Iterable<Tuple2<Map<String,List<IN>>,Long>> timedOutSequences, long timestamp) throws Exception
processTimedOutSequences
in class AbstractKeyedCEPPatternOperator<IN,KEY,OUT1,SelectTimeoutCepOperator.SelectWrapper<IN,OUT1,OUT2>>
Exception
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.