Modifier and Type | Class and Description |
---|---|
class |
IncrementalAggregationProcessor
Incremental Aggregation Processor to consume events to Incremental Aggregators.
|
Modifier and Type | Method and Description |
---|---|
Processor |
IncrementalAggregationProcessor.getNextProcessor() |
Modifier and Type | Method and Description |
---|---|
void |
IncrementalAggregationProcessor.setNextProcessor(Processor processor) |
void |
IncrementalAggregationProcessor.setToLast(Processor processor) |
Modifier and Type | Field and Description |
---|---|
protected Processor |
ProcessStreamReceiver.next |
protected Processor[] |
MultiProcessStreamReceiver.nextProcessors |
Modifier and Type | Method and Description |
---|---|
void |
MultiProcessStreamReceiver.setNext(Processor nextProcessor) |
void |
StateMultiProcessStreamReceiver.setNext(Processor next) |
void |
SingleProcessStreamReceiver.setNext(Processor next) |
void |
ProcessStreamReceiver.setNext(Processor next) |
Modifier and Type | Method and Description |
---|---|
void |
StreamRuntime.setCommonProcessor(Processor commonProcessor) |
Modifier and Type | Class and Description |
---|---|
class |
JoinProcessor
Created on 12/8/14.
|
Modifier and Type | Method and Description |
---|---|
Processor |
JoinProcessor.getNextProcessor()
Get next processor element in the processor chain.
|
Modifier and Type | Method and Description |
---|---|
void |
JoinStreamRuntime.setCommonProcessor(Processor commonProcessor) |
void |
JoinProcessor.setNextProcessor(Processor processor)
Set next processor element in processor chain.
|
void |
JoinProcessor.setToLast(Processor processor)
Set as the last element of the processor chain.
|
Modifier and Type | Class and Description |
---|---|
class |
EntryValveProcessor
Entry Valve Siddhi processor chain.
|
Modifier and Type | Method and Description |
---|---|
Processor |
EntryValveProcessor.getNextProcessor()
Get next processor element in the processor chain.
|
Processor |
SingleStreamRuntime.getProcessorChain() |
Modifier and Type | Method and Description |
---|---|
void |
SingleStreamRuntime.setCommonProcessor(Processor commonProcessor) |
void |
EntryValveProcessor.setNextProcessor(Processor processor)
Set next processor element in processor chain
|
void |
SingleStreamRuntime.setProcessorChain(Processor processorChain) |
void |
EntryValveProcessor.setToLast(Processor processor)
Set as the last element of the processor chain
|
Constructor and Description |
---|
SingleStreamRuntime(ProcessStreamReceiver processStreamReceiver,
Processor processorChain,
ProcessingMode overallProcessingMode,
MetaComplexEvent metaComplexEvent) |
Modifier and Type | Interface and Description |
---|---|
interface |
AbsentPreStateProcessor
PreStateProcessor of events not received by Siddhi.
|
interface |
PostStateProcessor
Created on 12/17/14.
|
interface |
PreStateProcessor
Created on 12/17/14.
|
Modifier and Type | Class and Description |
---|---|
class |
AbsentLogicalPostStateProcessor
Post-state processor of not logical operator.
|
class |
AbsentLogicalPreStateProcessor
Logical not processor.
|
class |
AbsentStreamPostStateProcessor
PostStateProcessor to handle not pattern state processors.
|
class |
AbsentStreamPreStateProcessor
Pre processor of not operator.
|
class |
CountPostStateProcessor
Created on 1/6/15.
|
class |
CountPreStateProcessor
Created on 1/6/15.
|
class |
LogicalPostStateProcessor
Created on 12/28/14.
|
class |
LogicalPreStateProcessor
Logical and & or processor.
|
class |
StreamPostStateProcessor
Created on 12/17/14.
|
class |
StreamPreStateProcessor
The processor the gets executes before checking state conditions.
|
Modifier and Type | Field and Description |
---|---|
protected Processor |
StreamPreStateProcessor.nextProcessor |
protected Processor |
StreamPostStateProcessor.nextProcessor |
Modifier and Type | Method and Description |
---|---|
Processor |
StreamPreStateProcessor.getNextProcessor()
Get next processor element in the processor chain.
|
Processor |
StreamPostStateProcessor.getNextProcessor()
Get next processor element in the processor chain.
|
Modifier and Type | Method and Description |
---|---|
void |
StateStreamRuntime.setCommonProcessor(Processor commonProcessor) |
void |
StreamPreStateProcessor.setNextProcessor(Processor processor)
Set next processor element in processor chain
|
void |
StreamPostStateProcessor.setNextProcessor(Processor nextProcessor)
Set next processor element in processor chain
|
void |
LogicalPostStateProcessor.setNextProcessor(Processor nextProcessor)
Set next processor element in processor chain
|
void |
StreamPreStateProcessor.setToLast(Processor processor)
Set as the last element of the processor chain
|
void |
StreamPostStateProcessor.setToLast(Processor processor)
Set as the last element of the processor chain
|
void |
LogicalPostStateProcessor.setToLast(Processor processor)
Set as the last element of the processor chain
|
Modifier and Type | Method and Description |
---|---|
void |
InnerStateRuntime.setQuerySelector(Processor commonProcessor) |
void |
NextInnerStateRuntime.setQuerySelector(Processor commonProcessor) |
void |
EveryInnerStateRuntime.setQuerySelector(Processor commonProcessor) |
void |
LogicalInnerStateRuntime.setQuerySelector(Processor commonProcessor) |
void |
StreamInnerStateRuntime.setQuerySelector(Processor commonProcessor) |
Modifier and Type | Interface and Description |
---|---|
interface |
SchedulingProcessor
Parent interface for Processors which need access to Siddhi
Scheduler |
Modifier and Type | Method and Description |
---|---|
Processor |
Processor.getNextProcessor()
Get next processor element in the processor chain.
|
Modifier and Type | Method and Description |
---|---|
void |
Processor.setNextProcessor(Processor processor)
Set next processor element in processor chain
|
void |
Processor.setToLast(Processor processor)
Set as the last element of the processor chain
|
Modifier and Type | Class and Description |
---|---|
class |
FilterProcessor
Implementation of
Processor which handles Filter expressions in Siddhi. |
Modifier and Type | Field and Description |
---|---|
protected Processor |
FilterProcessor.next |
Modifier and Type | Method and Description |
---|---|
Processor |
FilterProcessor.getNextProcessor() |
Modifier and Type | Method and Description |
---|---|
void |
FilterProcessor.setNextProcessor(Processor processor) |
void |
FilterProcessor.setToLast(Processor processor) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamProcessor<S extends State>
Abstract implementation of
Processor intended to be used by any Stream Processors. |
class |
LogStreamProcessor
Input attributes to log is (priority (String), log.message (String), is.event.logged (Bool))
|
class |
StreamProcessor<S extends State>
For Siddhi extensions, extend this class to use the functionality of
AbstractStreamProcessor.
|
Modifier and Type | Field and Description |
---|---|
protected Processor |
AbstractStreamProcessor.nextProcessor |
Modifier and Type | Method and Description |
---|---|
Processor |
AbstractStreamProcessor.getNextProcessor() |
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) |
void |
AbstractStreamProcessor.setNextProcessor(Processor processor) |
void |
AbstractStreamProcessor.setToLast(Processor processor) |
Modifier and Type | Class and Description |
---|---|
class |
Pol2CartStreamFunctionProcessor
Created on 1/26/15.
|
class |
StreamFunctionProcessor<S extends State>
Stream Processor to handle Stream Functions.
|
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 |
---|---|
class |
AggregateWindowProcessor
This is the
WindowProcessor intended to be used with aggregate join queries. |
class |
BatchingFindableWindowProcessor<S extends State>
Window to process events as batches while supporting event search
|
class |
BatchingWindowProcessor<S extends State>
Performs event processing in a tumbling manner
|
class |
BatchWindowProcessor
Implementation of
WindowProcessor which represent a Batch Window that aggregate batch of incoming events
together. |
class |
CronWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on a cron expression. |
class |
DelayWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on delay time. |
class |
EmptyWindowProcessor
Implementation of
WindowProcessor which represent a Batch Window operating based on pre-defined length 0. |
class |
ExternalTimeBatchWindowProcessor
Implementation of
WindowProcessor which represent a Batch Window operating based on external time. |
class |
ExternalTimeWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on external time. |
class |
FrequentWindowProcessor
Deprecated.
|
class |
GroupingFindableWindowProcessor<S extends State>
Window that process event processing as a group while supporting event search
|
class |
GroupingWindowProcessor<S extends State>
Performs event processing with key based event groups
|
class |
HopingWindowProcessor<S extends State>
Performs event processing in a hopping manner
|
class |
LengthBatchWindowProcessor
Implementation of
WindowProcessor which represent a Batch Window operating based on pre-defined length. |
class |
LengthWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on a pre-defined length. |
class |
LossyFrequentWindowProcessor
Deprecated.
|
class |
SessionWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on a session. |
class |
SlidingFindableWindowProcessor<S extends State>
Performs event processing in a sliding manner while supporting event search
|
class |
SlidingWindowProcessor<S extends State>
Performs event processing in a sliding manner
|
class |
SortWindowProcessor
Sample Query:
from inputStream#window.sort(5, attribute1, "asc", attribute2, "desc")
select attribute1, attribute2
insert into outputStream;
|
class |
TableWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on Table . |
class |
TimeBatchWindowProcessor
Implementation of
WindowProcessor which represent a Batch Window operating based on time. |
class |
TimeLengthWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based on pre-defined length. |
class |
TimeWindowProcessor
Implementation of
WindowProcessor which represent a Window operating based time. |
class |
WindowProcessor<S extends State>
Abstract parent implementation of Processor to represent Windows.
|
class |
WindowWindowProcessor
This is the
WindowProcessor intended to be used with window join queries. |
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 |
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 |
AggregateWindowProcessor.process(ComplexEventChunk streamEventChunk,
Processor nextProcessor,
StreamEventCloner streamEventCloner,
State state) |
protected void |
TableWindowProcessor.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 |
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 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 |
QuerySelector
Processor implementation representing selector portion of the Siddhi query.
|
Modifier and Type | Method and Description |
---|---|
Processor |
QuerySelector.getNextProcessor() |
Modifier and Type | Method and Description |
---|---|
void |
QuerySelector.setNextProcessor(Processor processor) |
void |
QuerySelector.setToLast(Processor processor) |
Modifier and Type | Method and Description |
---|---|
static Processor |
SingleInputStreamParser.generateProcessor(io.siddhi.query.api.execution.query.input.handler.StreamHandler streamHandler,
MetaComplexEvent metaEvent,
List<VariableExpressionExecutor> variableExpressionExecutors,
Map<String,Table> tableMap,
boolean supportsBatchProcessing,
boolean outputExpectsExpiredEvents,
boolean findToBeExecuted,
SiddhiQueryContext siddhiQueryContext) |
Copyright © 2019. All rights reserved.