Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StreamEvent> |
OutOfOrderEventsDataAggregator.aggregateData(ComplexEventChunk<StreamEvent> retrievedData) |
ComplexEventChunk<StreamEvent> |
IncrementalDataAggregator.aggregateInMemoryData(Map<io.siddhi.query.api.aggregation.TimePeriod.Duration,Executor> incrementalExecutorMap) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StreamEvent> |
OutOfOrderEventsDataAggregator.aggregateData(ComplexEventChunk<StreamEvent> retrievedData) |
void |
IncrementalExecutor.execute(ComplexEventChunk streamEventChunk) |
void |
Executor.execute(ComplexEventChunk complexEventChunk)
Execute the handed StreamEvent
|
void |
IncrementalAggregationProcessor.process(ComplexEventChunk complexEventChunk) |
void |
AggregationRuntime.processEvents(ComplexEventChunk<StreamEvent> streamEventComplexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
IncrementalAggregationProcessor.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
void |
PersistedIncrementalExecutor.execute(ComplexEventChunk streamEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
PersistedAggregationResultsProcessor.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
PersistedAggregationResultsProcessor.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
void |
ComplexEventChunk.addAll(ComplexEventChunk<E> complexEventChunk) |
Modifier and Type | Class and Description |
---|---|
class |
ConversionStreamEventChunk
A StreamEvent holder that can also convert other events into StreamEvents
|
Modifier and Type | Method and Description |
---|---|
protected void |
ProcessStreamReceiver.processAndClear(ComplexEventChunk<StreamEvent> streamEventChunk) |
protected void |
SingleProcessStreamReceiver.processAndClear(ComplexEventChunk<StreamEvent> streamEventChunk) |
void |
MultiProcessStreamReceiver.ReturnEventHolder.setReturnEvents(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
JoinProcessor.process(ComplexEventChunk complexEventChunk)
Process the handed StreamEvent.
|
Modifier and Type | Method and Description |
---|---|
void |
JoinProcessor.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
void |
EntryValveExecutor.execute(ComplexEventChunk complexEventChunk)
Execute the handed StreamEvent
|
void |
EntryValveExecutor.process(ComplexEventChunk complexEventChunk)
Implements process method in Schedulable interface.
|
void |
EntryValveProcessor.process(ComplexEventChunk complexEventChunk)
Process the handed StreamEvent
|
Modifier and Type | Method and Description |
---|---|
void |
EntryValveProcessor.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StateEvent> |
StreamPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
LogicalPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
CountPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
AbsentStreamPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
AbsentLogicalPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk |
PreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
StreamPreStateProcessor.process(ComplexEventChunk complexEventChunk)
Process the handed StreamEvent
|
void |
StreamPostStateProcessor.process(ComplexEventChunk complexEventChunk)
Process the handed StreamEvent
|
void |
AbsentStreamPreStateProcessor.process(ComplexEventChunk complexEventChunk) |
void |
AbsentLogicalPreStateProcessor.process(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 |
CountPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
protected void |
StreamPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
protected void |
AbsentLogicalPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
protected void |
LogicalPostStateProcessor.process(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
StreamPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
LogicalPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
CountPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
AbsentStreamPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk<StateEvent> |
AbsentLogicalPreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
ComplexEventChunk |
PreStateProcessor.processAndReturn(ComplexEventChunk complexEventChunk) |
void |
CountPostStateProcessor.processMinCountReached(StateEvent stateEvent,
ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
StreamPreStateProcessor.process(List<ComplexEventChunk> complexEventChunks) |
void |
StreamPostStateProcessor.process(List<ComplexEventChunk> complexEventChunks) |
void |
AbsentStreamPreStateProcessor.process(List<ComplexEventChunk> complexEventChunks) |
void |
AbsentLogicalPreStateProcessor.process(List<ComplexEventChunk> complexEventChunks) |
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 |
---|---|
protected ComplexEventChunk<StateEvent> |
OutputCallback.constructMatchingStateEventChunk(ComplexEventChunk matchingComplexEventChunk,
boolean convertToStreamEvent,
StateEventFactory stateEventFactory,
int matchingStreamIndex,
StreamEventFactory streamEventFactory,
StreamEventConverter streamEventConverter) |
void |
QueryCallback.receiveStreamEvent(ComplexEventChunk complexEventChunk) |
void |
InsertIntoTableCallback.send(ComplexEventChunk complexEventChunk,
int noOfEvents) |
void |
DeleteTableCallback.send(ComplexEventChunk deletingEventChunk,
int noOfEvents) |
void |
InsertIntoStreamCallback.send(ComplexEventChunk complexEventChunk,
int noOfEvents) |
void |
InsertIntoStreamEndPartitionCallback.send(ComplexEventChunk complexEventChunk,
int noOfEvents) |
void |
InsertIntoWindowCallback.send(ComplexEventChunk complexEventChunk,
int noOfEvents)
Add the event into the
Window |
void |
InsertIntoWindowEndPartitionCallback.send(ComplexEventChunk complexEventChunk,
int noOfEvents)
Add the event into the
Window |
abstract void |
OutputCallback.send(ComplexEventChunk complexEventChunk,
int noOfEvents) |
void |
UpdateOrInsertTableCallback.send(ComplexEventChunk updateOrAddEventChunk,
int noOfEvents) |
void |
UpdateTableCallback.send(ComplexEventChunk updatingEventChunk,
int noOfEvents) |
Modifier and Type | Method and Description |
---|---|
void |
PassThroughOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
abstract void |
OutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
OutputRateLimiter.sendToCallBacks(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
OutputRateLimiter.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
void |
AllPerEventOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
LastGroupByPerEventOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
FirstGroupByPerEventOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
FirstPerEventOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
LastPerEventOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
WrappedSnapshotOutputRateLimiter.passToCallBacks(ComplexEventChunk complexEventChunk) |
abstract void |
SnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
AllAggregationGroupByWindowedPerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
GroupByPerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk)
Sends the collected unique outputs per group by key upon arrival of timer event from scheduler.
|
void |
WindowedPerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
AggregationGroupByWindowedPerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
WrappedSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
PerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
AllAggregationPerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
AggregationWindowedPerSnapshotOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
protected void |
SnapshotOutputRateLimiter.sendToCallBacks(List<ComplexEventChunk> outputEventChunks) |
Modifier and Type | Method and Description |
---|---|
void |
AllPerTimeOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
LastPerTimeOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
FirstGroupByPerTimeOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
LastGroupByPerTimeOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
void |
FirstPerTimeOutputRateLimiter.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
Processor.process(ComplexEventChunk complexEventChunk)
Process the handed StreamEvent
|
Modifier and Type | Method and Description |
---|---|
void |
Processor.process(List<ComplexEventChunk> complexEventChunks)
Process the handed StreamEvent
|
Modifier and Type | Method and Description |
---|---|
void |
FilterProcessor.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
FilterProcessor.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractStreamProcessor.process(ComplexEventChunk streamEventChunk) |
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 |
---|---|
void |
AbstractStreamProcessor.process(List<ComplexEventChunk> complexEventChunks) |
Modifier and Type | Method and Description |
---|---|
protected void |
StreamFunctionProcessor.processEventChunk(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
S state) |
Modifier and Type | Class and Description |
---|---|
static class |
SessionWindowProcessor.SessionComplexEventChunk<E extends ComplexEvent>
Collection used to manage session windows.
|
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 |
EmptyWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.EmptyWindowProcessor.WindowState state) |
protected void |
ExpressionBatchWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.ExpressionBatchWindowProcessor.WindowState state) |
protected void |
ExpressionWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.ExpressionWindowProcessor.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 |
TimeWindowProcessor.process(ComplexEventChunk<StreamEvent> streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
io.siddhi.core.query.processor.stream.window.TimeWindowProcessor.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 |
TableWindowProcessor.process(ComplexEventChunk streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
State state) |
protected void |
AggregateWindowProcessor.process(ComplexEventChunk streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
State state) |
protected void |
BatchingWindowProcessor.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 void |
SlidingWindowProcessor.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 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
|
protected void |
WindowWindowProcessor.processEventChunk(ComplexEventChunk streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
ComplexEventPopulater complexEventPopulater,
State state) |
Modifier and Type | Class and Description |
---|---|
class |
SelectorTypeComplexEventChunk
ComplexEventChunk to also have the processing type
|
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk |
QuerySelector.execute(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk |
QuerySelector.execute(ComplexEventChunk complexEventChunk) |
void |
QuerySelector.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
QuerySelector.process(List<ComplexEventChunk> complexEventChunks) |
Constructor and Description |
---|
SelectorTypeComplexEventChunk(ComplexEventChunk<ComplexEvent> complexEventChunk,
boolean isProcessPassThrough) |
Modifier and Type | Method and Description |
---|---|
void |
TableInputHandler.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
TableInputHandler.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
TableInputHandler.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
TableInputHandler.updateOrAdd(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
Modifier and Type | Method and Description |
---|---|
protected ComplexEventChunk<StreamEvent> |
InMemoryTable.reduceEventsForUpdateOrInsert(AddingStreamEventExtractor addingStreamEventExtractor,
InMemoryCompiledCondition inMemoryCompiledCondition,
InMemoryCompiledUpdateSet compiledUpdateSet,
ComplexEventChunk<StateEvent> failedEvents) |
Modifier and Type | Method and Description |
---|---|
void |
InMemoryTable.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
abstract void |
Table.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
CacheTable.addAndTrimUptoMaxSize(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
Table.addEvents(ComplexEventChunk<StreamEvent> addingEventChunk,
int noOfEvents) |
void |
InMemoryTable.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
abstract void |
Table.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
Table.deleteEvents(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition,
int noOfEvents) |
protected void |
Table.onAddError(ComplexEventChunk<StreamEvent> addingEventChunk,
Exception e) |
protected void |
Table.onDeleteError(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition,
Exception e) |
protected void |
Table.onUpdateError(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
Exception e) |
protected void |
Table.onUpdateOrAddError(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor,
Exception e) |
protected ComplexEventChunk<StreamEvent> |
InMemoryTable.reduceEventsForUpdateOrInsert(AddingStreamEventExtractor addingStreamEventExtractor,
InMemoryCompiledCondition inMemoryCompiledCondition,
InMemoryCompiledUpdateSet compiledUpdateSet,
ComplexEventChunk<StateEvent> failedEvents) |
void |
InMemoryTable.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
abstract void |
Table.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
Table.updateEvents(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
int noOfEvents) |
void |
InMemoryTable.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
abstract void |
Table.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
void |
CacheTable.updateOrAddAndTrimUptoMaxSize(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor,
int maxTableSize) |
void |
Table.updateOrAddEvents(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor,
int noOfEvents) |
Modifier and Type | Method and Description |
---|---|
void |
ListEventHolder.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
EventHolder.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
IndexEventHolder.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractQueryableRecordTable.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
AbstractRecordTable.add(ComplexEventChunk<StreamEvent> addingEventChunk) |
void |
AbstractQueryableRecordTable.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
AbstractRecordTable.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
CompiledCondition compiledCondition) |
void |
AbstractQueryableRecordTable.handleCacheExpiry(CompiledCondition cacheExpiryCompiledCondition,
ComplexEventChunk<StateEvent> deleteEventChunk) |
void |
AbstractQueryableRecordTable.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
AbstractRecordTable.update(ComplexEventChunk<StateEvent> updatingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet) |
void |
AbstractQueryableRecordTable.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
void |
AbstractRecordTable.updateOrAdd(ComplexEventChunk<StateEvent> updateOrAddingEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
Modifier and Type | Method and Description |
---|---|
void |
Schedulable.process(ComplexEventChunk complexEventChunk) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk<StateEvent> |
EventChunkOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
OverwriteTableIndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
OverwriteTableIndexOperatorForCache.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
CollectionOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
IndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
Operator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
SnapshotableEventQueueOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
MapOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
Modifier and Type | Method and Description |
---|---|
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 |
Operator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
SnapshotableEventQueueOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
void |
MapOperator.delete(ComplexEventChunk<StateEvent> deletingEventChunk,
Object storeEvents) |
ComplexEventChunk<StateEvent> |
EventChunkOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
OverwriteTableIndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
OverwriteTableIndexOperatorForCache.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
CollectionOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
IndexOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
Operator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
SnapshotableEventQueueOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
ComplexEventChunk<StateEvent> |
MapOperator.tryUpdate(ComplexEventChunk<StateEvent> updatingOrAddingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor) |
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 |
Operator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
SnapshotableEventQueueOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
void |
MapOperator.update(ComplexEventChunk<StateEvent> updatingEventChunk,
Object storeEvents,
InMemoryCompiledUpdateSet compiledUpdateSet) |
Modifier and Type | Method and Description |
---|---|
ComplexEventChunk |
ReplayableTableRecord.getComplexEventChunk() |
Modifier and Type | Method and Description |
---|---|
void |
ReplayableTableRecord.setComplexEventChunk(ComplexEventChunk complexEventChunk) |
Constructor and Description |
---|
ReplayableTableRecord(ComplexEventChunk complexEventChunk)
For onAddError
|
ReplayableTableRecord(ComplexEventChunk complexEventChunk,
CompiledCondition compiledCondition)
For onDeleteError
|
ReplayableTableRecord(ComplexEventChunk complexEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet)
For onUpdateError
|
ReplayableTableRecord(ComplexEventChunk complexEventChunk,
CompiledCondition compiledCondition,
CompiledUpdateSet compiledUpdateSet,
AddingStreamEventExtractor addingStreamEventExtractor)
For onUpdateOrAddError
|
Modifier and Type | Method and Description |
---|---|
static String |
ErrorHandlerUtils.constructAddErrorRecordString(ComplexEventChunk<StreamEvent> eventChunk,
boolean isObjectColumnPresent,
io.siddhi.query.api.definition.TableDefinition tableDefinition,
Exception e) |
static String |
ErrorHandlerUtils.constructErrorRecordString(ComplexEventChunk<StateEvent> eventChunk,
boolean isObjectColumnPresent,
io.siddhi.query.api.definition.TableDefinition tableDefinition,
Exception e) |
Modifier and Type | Method and Description |
---|---|
void |
Window.add(ComplexEventChunk complexEventChunk)
Add the given ComplexEventChunk to the Window.
|
Copyright © 2021. All rights reserved.