Modifier and Type | Method and Description |
---|---|
StreamEvent |
AggregationRuntime.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
SiddhiQueryContext siddhiQueryContext) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StreamEvent> |
IncrementalExternalTimestampDataAggregator.aggregateData(ComplexEventChunk<StreamEvent> retrievedData) |
ComplexEventChunk<StreamEvent> |
IncrementalDataAggregator.aggregateInMemoryData(Map<io.siddhi.query.api.aggregation.TimePeriod.Duration,IncrementalExecutor> incrementalExecutorMap) |
Map<String,StreamEvent> |
BaseIncrementalValueStore.getGroupedByEvents() |
Modifier and Type | Method and Description |
---|---|
void |
BaseIncrementalValueStore.clearValues(long startTimeOfNewAggregates,
StreamEvent resetEvent) |
void |
BaseIncrementalValueStore.process(StreamEvent streamEvent) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StreamEvent> |
IncrementalExternalTimestampDataAggregator.aggregateData(ComplexEventChunk<StreamEvent> retrievedData) |
void |
BaseIncrementalValueStore.process(Map<String,StreamEvent> groupedByEvents) |
void |
AggregationRuntime.processEvents(ComplexEventChunk<StreamEvent> streamEventComplexEventChunk) |
Modifier and Type | Field and Description |
---|---|
protected StreamEvent[] |
StateEvent.streamEvents |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
StateEvent.getStreamEvent(int position) |
StreamEvent |
StateEvent.getStreamEvent(int[] position) |
StreamEvent[] |
StateEvent.getStreamEvents() |
Modifier and Type | Method and Description |
---|---|
void |
StateEvent.addEvent(int position,
StreamEvent streamEvent) |
void |
StateEvent.setEvent(int position,
StreamEvent streamEvent) |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
StreamEventCloner.copyStreamEvent(StreamEvent streamEvent)
Method to copy new StreamEvent from StreamEvent
|
StreamEvent |
StreamEvent.getNext() |
StreamEvent |
StreamEventFactory.newInstance()
Constructs new Events
|
Modifier and Type | Method and Description |
---|---|
StreamEvent |
StreamEventCloner.copyStreamEvent(StreamEvent streamEvent)
Method to copy new StreamEvent from StreamEvent
|
Modifier and Type | Method and Description |
---|---|
StreamEvent |
FaultStreamEventConverter.convert(ComplexEvent complexEvents,
Exception e) |
StreamEvent |
FaultStreamEventConverter.convert(Event[] events,
Exception e) |
StreamEvent |
FaultStreamEventConverter.convert(Event event,
Exception e) |
StreamEvent |
FaultStreamEventConverter.convert(List<Event> events,
Exception e) |
StreamEvent |
FaultStreamEventConverter.convert(long timestamp,
Object[] data,
Exception e) |
Modifier and Type | Method and Description |
---|---|
void |
StreamEventConverter.convertComplexEvent(ComplexEvent complexEvent,
StreamEvent newEvent)
Method to construct(change format) new StreamEvent from StreamEvent
|
void |
SelectiveStreamEventConverter.convertComplexEvent(ComplexEvent complexEvent,
StreamEvent newEvent) |
void |
SimpleStreamEventConverter.convertComplexEvent(ComplexEvent complexEvent,
StreamEvent newEvent) |
void |
ZeroStreamEventConverter.convertComplexEvent(ComplexEvent complexEvent,
StreamEvent newEvent) |
void |
StreamEventConverter.convertData(long timeStamp,
Object[] data,
ComplexEvent.Type type,
StreamEvent newEvent)
Method to construct(change format) timeStamp and data from StreamEvent
|
void |
SelectiveStreamEventConverter.convertData(long timestamp,
Object[] data,
ComplexEvent.Type type,
StreamEvent newEvent) |
void |
SimpleStreamEventConverter.convertData(long timestamp,
Object[] data,
ComplexEvent.Type type,
StreamEvent newEvent) |
void |
ZeroStreamEventConverter.convertData(long timestamp,
Object[] data,
ComplexEvent.Type type,
StreamEvent newEvent) |
void |
StreamEventConverter.convertData(long timeStamp,
Object[] data,
StreamEvent newEvent)
Method to construct(change format) timeStamp and data from StreamEvent
|
void |
SelectiveStreamEventConverter.convertData(long timeStamp,
Object[] data,
StreamEvent newEvent) |
void |
SimpleStreamEventConverter.convertData(long timestamp,
Object[] data,
StreamEvent newEvent) |
void |
ZeroStreamEventConverter.convertData(long timestamp,
Object[] data,
StreamEvent newEvent) |
void |
StreamEventConverter.convertEvent(Event event,
StreamEvent newEvent)
Method to construct StreamEvent form Event
|
void |
SelectiveStreamEventConverter.convertEvent(Event event,
StreamEvent newEvent) |
void |
SimpleStreamEventConverter.convertEvent(Event event,
StreamEvent newEvent) |
void |
ZeroStreamEventConverter.convertEvent(Event event,
StreamEvent newEvent) |
Modifier and Type | Field and Description |
---|---|
protected StreamEvent |
SnapshotableStreamEventQueue.first |
protected StreamEvent |
SnapshotableStreamEventQueue.last |
protected StreamEvent |
SnapshotableStreamEventQueue.lastReturned |
protected StreamEvent |
SnapshotableStreamEventQueue.previousToLastReturned |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
SnapshotableStreamEventQueue.getFirst() |
StreamEvent |
SnapshotableStreamEventQueue.getLast() |
StreamEvent |
SnapshotableStreamEventQueue.next()
Returns the next element in the iteration.
|
StreamEvent |
SnapshotableStreamEventQueue.poll() |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotableStreamEventQueue.add(StreamEvent events) |
void |
SnapshotableStreamEventQueue.overwrite(StreamEvent streamEvent) |
Modifier and Type | Method and Description |
---|---|
protected void |
MultiProcessStreamReceiver.processAndClear(int processIndex,
StreamEvent streamEvent) |
protected void |
StateMultiProcessStreamReceiver.processAndClear(int processIndex,
StreamEvent streamEvent) |
Modifier and Type | Method and Description |
---|---|
protected void |
SingleProcessStreamReceiver.processAndClear(ComplexEventChunk<StreamEvent> streamEventChunk) |
protected void |
ProcessStreamReceiver.processAndClear(ComplexEventChunk<StreamEvent> streamEventChunk) |
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 |
---|---|
protected abstract void |
StreamProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state)
The main processing method that will be called upon event arrival
|
protected void |
LogStreamProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
State state) |
protected abstract void |
AbstractStreamProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state)
The main processing method that will be called upon event arrival
|
protected void |
StreamProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
Modifier and Type | Method and Description |
---|---|
protected void |
StreamFunctionProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
WindowWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
TableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
GroupingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
SlidingFindableWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
AggregateWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
StreamEvent |
BatchingFindableWindowProcessor.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 |
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 |
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.
|
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.
|
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 |
DelayWindowProcessor.find(StateEvent matchingEvent,
CompiledCondition compiledCondition,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeWindowProcessor.WindowState state) |
StreamEvent |
TimeWindowProcessor.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 void |
BatchWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.BatchWindowProcessor.WindowState state) |
protected void |
CronWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.CronWindowProcessor.WindowState state) |
protected void |
ExternalTimeBatchWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.ExternalTimeBatchWindowProcessor.WindowState state)
Here an assumption is taken:
Parameter: timestamp: The time which the window determines as current time and will act upon,
the value of this parameter should be monotonically increasing.
|
protected void |
ExternalTimeWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.ExternalTimeWindowProcessor.WindowState state) |
protected void |
FrequentWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.FrequentWindowProcessor.WindowState state)
Deprecated.
|
protected void |
LengthBatchWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.LengthBatchWindowProcessor.WindowState state) |
protected void |
LengthWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.LengthWindowProcessor.WindowState state) |
protected void |
LossyFrequentWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.LossyFrequentWindowProcessor.WindowState state)
Deprecated.
|
protected abstract void |
BatchingWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
S state)
The main processing method that will be called upon event arrival
|
protected abstract void |
SlidingWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
S state)
The main processing method that will be called upon event arrival
|
protected void |
SortWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.SortWindowProcessor.WindowState state) |
protected void |
TimeBatchWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeBatchWindowProcessor.WindowState state) |
protected void |
TimeLengthWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeLengthWindowProcessor.WindowState state) |
protected void |
DelayWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeWindowProcessor.WindowState windowState) |
protected void |
TimeWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeWindowProcessor.WindowState state) |
protected void |
BatchingWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
protected void |
GroupingWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
protected void |
SlidingWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
protected void |
HopingWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
protected abstract void |
GroupingWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
GroupingWindowProcessor.GroupingKeyPopulator groupingKeyPopulater,
S state)
The main processing method that will be called upon event arrival
|
protected void |
SessionWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
GroupingWindowProcessor.GroupingKeyPopulator groupingKeyPopulater,
io.siddhi.core.query.processor.stream.window.SessionWindowProcessor.WindowState state) |
protected abstract void |
HopingWindowProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
HopingWindowProcessor.HopingTimestampPopulator hopingTimestampPopulator)
The main processing method that will be called upon event arrival
|
Modifier and Type | Method and Description |
---|---|
StreamEvent |
InMemoryTable.find(CompiledCondition compiledCondition,
StateEvent matchingEvent) |
protected abstract StreamEvent |
Table.find(CompiledCondition compiledCondition,
StateEvent matchingEvent) |
StreamEvent |
Table.find(StateEvent matchingEvent,
CompiledCondition compiledCondition) |
Modifier and Type | Method and Description |
---|---|
void |
InMemoryTable.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
protected abstract void |
Table.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
Table.addEvents(ComplexEventChunk<StreamEvent> addingEventChunk,
int noOfEvents) |
Modifier and Type | Method and Description |
---|---|
Collection<StreamEvent> |
IndexedEventHolder.findEvents(String attribute,
io.siddhi.query.api.expression.condition.Compare.Operator operator,
Object value) |
Collection<StreamEvent> |
IndexEventHolder.findEvents(String attribute,
io.siddhi.query.api.expression.condition.Compare.Operator operator,
Object value) |
Collection<StreamEvent> |
IndexedEventHolder.getAllEvents() |
Collection<StreamEvent> |
IndexEventHolder.getAllEvents() |
Modifier and Type | Method and Description |
---|---|
void |
IndexedEventHolder.overwrite(StreamEvent streamEvent) |
void |
IndexEventHolder.overwrite(StreamEvent streamEvent) |
Modifier and Type | Method and Description |
---|---|
void |
ListEventHolder.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
IndexEventHolder.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
EventHolder.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
IndexedEventHolder.deleteAll(Collection<StreamEvent> storeEventSet) |
void |
IndexEventHolder.deleteAll(Collection<StreamEvent> storeEventSet) |
Modifier and Type | Method and Description |
---|---|
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.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
Modifier and Type | Method and Description |
---|---|
SessionWindowProcessor.SessionComplexEventChunk<StreamEvent> |
SessionContainer.getCurrentSession() |
SessionWindowProcessor.SessionComplexEventChunk<StreamEvent> |
SessionContainer.getPreviousSession() |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
AddingStreamEventExtractor.getAddingStreamEvent(StateEvent updateOrAddingEvent) |
Modifier and Type | Method and Description |
---|---|
StreamEvent |
CompareExhaustiveAndCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
NotCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
NonAndCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
AnyAndCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
OrCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
AndMultiPrimaryKeyCollectionExecutor.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 |
ExhaustiveCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
CompareCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
StreamEvent |
NonCollectionExecutor.find(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder,
StreamEventCloner storeEventCloner) |
Modifier and Type | Method and Description |
---|---|
Collection<StreamEvent> |
ExhaustiveCollectionExecutor.findEvents(StateEvent matchingEvent,
Collection<StreamEvent> preProcessedstoreEvents) |
Collection<StreamEvent> |
CompareExhaustiveAndCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
NotCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
NonAndCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
AnyAndCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
OrCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
AndMultiPrimaryKeyCollectionExecutor.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
|
Set<StreamEvent> |
ExhaustiveCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
CompareCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Collection<StreamEvent> |
NonCollectionExecutor.findEvents(StateEvent matchingEvent,
IndexedEventHolder indexedEventHolder) |
Modifier and Type | Method and Description |
---|---|
Collection<StreamEvent> |
ExhaustiveCollectionExecutor.findEvents(StateEvent matchingEvent,
Collection<StreamEvent> preProcessedstoreEvents) |
Modifier and Type | Method and Description |
---|---|
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 |
Operator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
CollectionOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
SnapshotableEventQueueOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
EventChunkOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
IndexOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
StreamEvent |
MapOperator.find(StateEvent matchingEvent,
Object storeEvents,
StreamEventCloner storeEventCloner) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StreamEvent> |
Operator.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> |
SnapshotableEventQueueOperator.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> |
IndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
MapOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StreamEvent> |
OverwriteTableIndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
Modifier and Type | Method and Description |
---|---|
static StreamEvent |
AggregationParser.createRestEvent(MetaStreamEvent metaStreamEvent,
StreamEvent streamEvent) |
Modifier and Type | Method and Description |
---|---|
static StreamEvent |
AggregationParser.createRestEvent(MetaStreamEvent metaStreamEvent,
StreamEvent streamEvent) |
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.