Modifier and Type | Method and Description |
---|---|
StreamEvent |
AggregationRuntime.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
SiddhiQueryContext siddhiQueryContext) |
Modifier and Type | Field and Description |
---|---|
protected StateEvent |
StateEvent.next |
Modifier and Type | Method and Description |
---|---|
StateEvent |
StateEventCloner.copyStateEvent(StateEvent stateEvent)
Method to copy new StreamEvent from StreamEvent
|
StateEvent |
StateEvent.getNext() |
StateEvent |
StateEventFactory.newInstance() |
Modifier and Type | Method and Description |
---|---|
StateEvent |
StateEventCloner.copyStateEvent(StateEvent stateEvent)
Method to copy new StreamEvent from StreamEvent
|
Modifier and Type | Method and Description |
---|---|
StateEvent |
JoinProcessor.joinEventBuilder(StreamEvent leftStream,
StreamEvent rightStream,
ComplexEvent.Type type)
Join the given two event streams.
|
Modifier and Type | Method and Description |
---|---|
List<StateEvent> |
StreamPreStateProcessor.getPendingStateEventList() |
ComplexEventChunk<StateEvent> |
CountPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
AbsentStreamPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
StreamPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
AbsentLogicalPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
LogicalPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
LogicalPreStateProcessor.addEventToNewAndEveryStateEventList(StateEvent event) |
void |
PreStateProcessor.addEveryState(StateEvent stateEvent) |
void |
AbsentStreamPreStateProcessor.addEveryState(StateEvent stateEvent) |
void |
StreamPreStateProcessor.addEveryState(StateEvent stateEvent) |
void |
AbsentLogicalPreStateProcessor.addEveryState(StateEvent stateEvent) |
void |
LogicalPreStateProcessor.addEveryState(StateEvent stateEvent) |
void |
PreStateProcessor.addState(StateEvent stateEvent) |
void |
StreamPreStateProcessor.addState(StateEvent stateEvent) |
protected void |
CountPreStateProcessor.addState(StateEvent stateEvent,
io.siddhi.core.query.input.stream.state.StreamPreStateProcessor.StreamPreState state) |
protected void |
AbsentStreamPreStateProcessor.addState(StateEvent stateEvent,
io.siddhi.core.query.input.stream.state.StreamPreStateProcessor.StreamPreState preState) |
protected void |
StreamPreStateProcessor.addState(StateEvent stateEvent,
io.siddhi.core.query.input.stream.state.StreamPreStateProcessor.StreamPreState state) |
protected void |
AbsentLogicalPreStateProcessor.addState(StateEvent stateEvent,
io.siddhi.core.query.input.stream.state.StreamPreStateProcessor.StreamPreState state) |
protected void |
LogicalPreStateProcessor.addState(StateEvent stateEvent,
io.siddhi.core.query.input.stream.state.StreamPreStateProcessor.StreamPreState state) |
protected boolean |
StreamPreStateProcessor.isExpired(StateEvent pendingStateEvent,
long currentTimestamp) |
boolean |
AbsentLogicalPreStateProcessor.partnerCanProceed(StateEvent stateEvent) |
protected void |
StreamPreStateProcessor.process(StateEvent stateEvent) |
protected void |
StreamPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
protected void |
CountPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
protected void |
AbsentStreamPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk)
This method just mark the state changed but does not send the stateEvent to the next processors.
|
protected void |
LogicalPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
protected void |
AbsentLogicalPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
void |
CountPostStateProcessor.processMinCountReached(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
protected ComplexEventChunk<StateEvent> |
OutputCallback.constructMatchingStateEventChunk(ComplexEventChunk matchingComplexEventChunk,
boolean convertToStreamEvent,
StateEventFactory stateEventFactory,
int matchingStreamIndex,
StreamEventFactory streamEventFactory,
StreamEventConverter streamEventConverter) |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
BatchingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
GroupingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
TableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
FindableProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition)
To find events from the processor event pool, that the matches the matchingEvent based on finder logic.
|
StreamEvent |
WindowWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
SlidingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
AggregateWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
BatchWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.BatchWindowProcessor.WindowState state) |
StreamEvent |
ExternalTimeBatchWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.ExternalTimeBatchWindowProcessor.WindowState state) |
StreamEvent |
ExternalTimeWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.ExternalTimeWindowProcessor.WindowState state) |
StreamEvent |
FrequentWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.FrequentWindowProcessor.WindowState state)
Deprecated.
|
StreamEvent |
LengthBatchWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.LengthBatchWindowProcessor.WindowState state) |
StreamEvent |
LengthWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.LengthWindowProcessor.WindowState state) |
StreamEvent |
LossyFrequentWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.LossyFrequentWindowProcessor.WindowState state)
Deprecated.
|
abstract StreamEvent |
BatchingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
S state)
To find events from the processor event pool, that the matches the matchingEvent based on finder logic.
|
abstract StreamEvent |
GroupingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
S state)
To find events from the processor event pool, that the matches the matchingEvent based on finder logic.
|
abstract StreamEvent |
SlidingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
S state)
To find events from the processor event pool, that the matches the matchingEvent based on finder logic.
|
StreamEvent |
SessionWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.SessionWindowProcessor.WindowState state) |
StreamEvent |
SortWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.SortWindowProcessor.WindowState state) |
StreamEvent |
TimeBatchWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeBatchWindowProcessor.WindowState state) |
StreamEvent |
TimeLengthWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeLengthWindowProcessor.WindowState state) |
StreamEvent |
TimeWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeWindowProcessor.WindowState state) |
StreamEvent |
DelayWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeWindowProcessor.WindowState state) |
StreamEvent |
QueryableProcessor.query(StateEvent matchingEvent,
CompiledCondition compiledCondition,
CompiledSelection compiledSelection)
Deprecated.
|
StreamEvent |
QueryableProcessor.query(StateEvent matchingEvent,
CompiledCondition compiledCondition,
CompiledSelection compiledSelection,
io.siddhi.query.api.definition.Attribute[] outputAttributes)
To find events from the processor event pool, that the matches the matchingEvent based on finder logic and
return them based on the defined selection.
|
Modifier and Type | Method and Description |
---|---|
protected abstract boolean |
Table.contains(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
boolean |
InMemoryTable.contains(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
boolean |
Table.containsEvent(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
protected abstract StreamEvent |
Table.find(CompiledCondition compiledCondition,
StateEvent matchingEvent) |
StreamEvent |
InMemoryTable.find(CompiledCondition compiledCondition,
StateEvent matchingEvent) |
StreamEvent |
Table.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
Table.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
InMemoryTable.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
Table.deleteEvents(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition,
int noOfEvents) |
protected abstract void |
Table.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
InMemoryTable.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
Table.updateEvents(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
int noOfEvents) |
protected abstract void |
Table.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
void |
InMemoryTable.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
void |
Table.updateOrAddEvents(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor,
int noOfEvents) |
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractRecordTable.contains(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
AbstractRecordTable.find(CompiledCondition compiledCondition,
StateEvent matchingEvent) |
StreamEvent |
AbstractQueryableRecordTable.query(StateEvent matchingEvent,
CompiledCondition compiledCondition,
CompiledSelection compiledSelection) |
StreamEvent |
AbstractQueryableRecordTable.query(StateEvent matchingEvent,
CompiledCondition compiledCondition,
CompiledSelection compiledSelection,
io.siddhi.query.api.definition.Attribute[] outputAttributes) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRecordTable.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
AbstractRecordTable.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
AbstractRecordTable.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
Modifier and Type | Class and Description |
---|---|
class |
FinderStateEvent
State Event holder used by
InConditionExpressionExecutor |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
AddingStreamEventExtractor.getAddingStreamEvent(StateEvent updateOrAddingEvent) |
void |
FinderStateEvent.setEvent(StateEvent matchingStateEvent) |
Modifier and Type | Method and Description |
---|---|
boolean |
CompareCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
CompareExhaustiveAndCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
AndMultiPrimaryKeyCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
OrCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
ExhaustiveCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
CollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder)
Checks if a matching event exist in indexedEventHolder
|
boolean |
NotCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
AnyAndCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
NonCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
boolean |
NonAndCollectionExecutor.contains(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
void |
CompareCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
CompareExhaustiveAndCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
AndMultiPrimaryKeyCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
OrCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
ExhaustiveCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
CollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder)
Delete matching events exists from indexedEventHolder
|
void |
NotCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
AnyAndCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
NonCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
void |
NonAndCollectionExecutor.delete(StateEvent deletingEvent,
IndexedEventHolder indexedEventHolder) |
StreamEvent |
CompareCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
CompareExhaustiveAndCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
AndMultiPrimaryKeyCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
OrCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
ExhaustiveCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
CollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner)
Find the Events matching to the condition, used on the primary call
|
StreamEvent |
NotCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
AnyAndCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
NonCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
NonAndCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
Collection<StreamEvent> |
ExhaustiveCollectionExecutor.findEvents(StateEvent matchingEvent,
Collection<StreamEvent> preProcessedstoreEvents) |
Collection<StreamEvent> |
CompareCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
CompareExhaustiveAndCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
AndMultiPrimaryKeyCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
OrCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Set<StreamEvent> |
ExhaustiveCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
CollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder)
Find the Events matching to the condition, used for consecutive calls from parent CollectionExecutor
|
Collection<StreamEvent> |
NotCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
AnyAndCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
NonCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
NonAndCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Modifier and Type | Method and Description |
---|---|
boolean |
MapOperator.contains(StateEvent matchingEvent,
Object storeEvents) |
boolean |
Operator.contains(StateEvent matchingEvent,
Object storeEvents) |
boolean |
EventChunkOperator.contains(StateEvent matchingEvent,
Object storeEvents) |
boolean |
CollectionOperator.contains(StateEvent matchingEvent,
Object storeEvents) |
boolean |
IndexOperator.contains(StateEvent matchingEvent,
Object storeEvents) |
boolean |
SnapshotableEventQueueOperator.contains(StateEvent matchingEvent,
Object storeEvents) |
StreamEvent |
IncrementalAggregateCompileCondition.find(StateEvent matchingEvent,
io.siddhi.query.api.definition.AggregationDefinition aggregationDefinition,
Map<io.siddhi.query.api.aggregation.TimePeriod.Duration,IncrementalExecutor> incrementalExecutorMap,
Map<io.siddhi.query.api.aggregation.TimePeriod.Duration,Table> aggregationTables,
List<io.siddhi.query.api.aggregation.TimePeriod.Duration> incrementalDurations,
List<ExpressionExecutor> baseExecutorsForFind,
List<ExpressionExecutor> outputExpressionExecutors,
SiddhiQueryContext siddhiQueryContext,
List<List<ExpressionExecutor>> aggregateProcessingExecutorsListForFind,
List<GroupByKeyGenerator> groupbyKeyGeneratorList,
ExpressionExecutor shouldUpdateTimestamp,
Map<io.siddhi.query.api.aggregation.TimePeriod.Duration,IncrementalExecutor> incrementalExecutorMapForPartitions) |
StreamEvent |
MapOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
Operator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
EventChunkOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
CollectionOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
IndexOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
SnapshotableEventQueueOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
Modifier and Type | Method and Description |
---|---|
void |
MapOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
Operator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
EventChunkOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
CollectionOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
IndexOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
SnapshotableEventQueueOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
ComplexEventChunk<StreamEvent> |
MapOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
Operator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
EventChunkOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
CollectionOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
IndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
SnapshotableEventQueueOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
OverwriteTableIndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
void |
MapOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
Operator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
EventChunkOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
CollectionOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
IndexOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
SnapshotableEventQueueOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
Window.find(StateEvent matchingEvent,
CompiledCondition compiledCondition)
To find events from the processor event pool, that the matches the matchingEvent based on finder logic.
|
Copyright © 2019. All rights reserved.