IN
- Type of the input elementsKEY
- Type of the key on which the input stream is keyedOUT
- Type of the output elementspublic class FlatSelectCepOperator<IN,KEY,OUT> extends AbstractKeyedCEPPatternOperator<IN,KEY,OUT,PatternFlatSelectFunction<IN,OUT>>
AbstractKeyedCEPPatternOperator
that applies given PatternFlatSelectFunction
to fully matched event patterns.AbstractStreamOperator.CountingOutput
afterMatchSkipStrategy
userFunction
chainingStrategy, config, latencyStats, LOG, metrics, output, timeServiceManager
Constructor and Description |
---|
FlatSelectCepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy skipStrategy,
PatternFlatSelectFunction<IN,OUT> function) |
Modifier and Type | Method and Description |
---|---|
void |
open()
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
|
protected void |
processMatchedSequences(Iterable<Map<String,List<IN>>> matchingSequences,
long timestamp) |
getPQSize, hasNonEmptyNFA, hasNonEmptyPQ, initializeState, onEventTime, onProcessingTime, processElement, processTimedOutSequences
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 FlatSelectCepOperator(TypeSerializer<IN> inputSerializer, boolean isProcessingTime, NFACompiler.NFAFactory<IN> nfaFactory, EventComparator<IN> comparator, AfterMatchSkipStrategy skipStrategy, PatternFlatSelectFunction<IN,OUT> function)
public void open() throws Exception
AbstractStreamOperator
The default implementation does nothing.
open
in interface StreamOperator<OUT>
open
in class AbstractKeyedCEPPatternOperator<IN,KEY,OUT,PatternFlatSelectFunction<IN,OUT>>
Exception
- An exception in this method causes the operator to fail.protected void processMatchedSequences(Iterable<Map<String,List<IN>>> matchingSequences, long timestamp) throws Exception
processMatchedSequences
in class AbstractKeyedCEPPatternOperator<IN,KEY,OUT,PatternFlatSelectFunction<IN,OUT>>
Exception
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.