Package | Description |
---|---|
com.espertech.esper.core.context.factory |
Statement agent instance factories.
|
com.espertech.esper.core.context.stmt |
Registries for context partitions to handle aggregations, prev/prior and subselects.
|
com.espertech.esper.core.context.subselect |
Subselect implementation.
|
com.espertech.esper.core.service.resource |
Core service statement resource holders.
|
com.espertech.esper.core.start |
Classes related to start and stop of statements
|
com.espertech.esper.epl.agg.service.common |
Aggregation services - common.
|
com.espertech.esper.epl.agg.service.groupall |
Aggregation services group-all.
|
com.espertech.esper.epl.agg.service.groupby |
Aggregation services group-by regular
|
com.espertech.esper.epl.agg.service.groupbylocal |
Aggregation services - local-grouping
|
com.espertech.esper.epl.agg.service.groupbyrollup |
Aggregation services - rollup.
|
com.espertech.esper.epl.agg.service.table |
Aggregation services - table aggregation.
|
com.espertech.esper.epl.core.orderby |
Order-by and row-limit processors
|
com.espertech.esper.epl.core.resultset.agggrouped |
Result set processor for Aggregated and Grouped
|
com.espertech.esper.epl.core.resultset.core |
Result set processor Core classes
|
com.espertech.esper.epl.core.resultset.grouped |
Result set processor utility classes for general grouped-aggregation
|
com.espertech.esper.epl.core.resultset.handthru |
Result set processor for Un-Aggregated and Un-Grouped with having or output-rate-limiting or order-by
|
com.espertech.esper.epl.core.resultset.rowforall |
Result set processor for Fully-Aggregated and Un-Grouped
|
com.espertech.esper.epl.core.resultset.rowperevent |
Result set processor for Aggregated and Un-Grouped
|
com.espertech.esper.epl.core.resultset.rowpergroup |
Result set processor for Fully-Aggregated and Grouped
|
com.espertech.esper.epl.core.resultset.rowpergrouprollup |
Result set processor for Rollup
|
com.espertech.esper.epl.expression.subquery |
Subselect expressions.
|
com.espertech.esper.epl.subquery |
Subquery helper classes are found here.
|
com.espertech.esper.view.window |
Window views are in this package
|
Modifier and Type | Method and Description |
---|---|
AggregationService |
StatementAgentInstanceFactoryResult.getOptionalAggegationService() |
AggregationService |
StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult.getOptionalAggregationService() |
Modifier and Type | Interface and Description |
---|---|
interface |
AIRegistryAggregation |
Modifier and Type | Class and Description |
---|---|
class |
AIRegistryAggregationMap |
class |
AIRegistryAggregationMultiPerm |
class |
AIRegistryAggregationSingle |
Modifier and Type | Method and Description |
---|---|
AggregationService |
AIRegistryAggregationSingle.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AIRegistryAggregationMultiPerm.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AIRegistryAggregationMap.getContextPartitionAggregationService(int agentInstanceId) |
Modifier and Type | Method and Description |
---|---|
void |
AIRegistryAggregationSingle.assignService(int serviceId,
AggregationService aggregationService) |
void |
AIRegistryAggregationMultiPerm.assignService(int serviceId,
AggregationService aggregationService) |
void |
AIRegistryAggregationMap.assignService(int serviceId,
AggregationService aggregationService) |
void |
AIRegistryAggregation.assignService(int serviceId,
AggregationService aggregationService) |
Modifier and Type | Method and Description |
---|---|
AggregationService |
SubSelectStrategyRealization.getSubselectAggregationService() |
AggregationService |
SubSelectStrategyHolder.getSubselectAggregationService() |
Constructor and Description |
---|
SubSelectStrategyHolder(ExprSubselectStrategy stategy,
AggregationService subselectAggregationService,
java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorStrategies,
java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies,
Viewable subselectView,
StatementAgentInstancePostLoad postLoad,
ViewableActivationResult subselectActivationResult) |
SubSelectStrategyRealization(SubordTableLookupStrategy strategy,
SubselectAggregationPreprocessorBase subselectAggregationPreprocessor,
AggregationService subselectAggregationService,
java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorNodeStrategies,
java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies,
Viewable subselectView,
StatementAgentInstancePostLoad postLoad) |
Modifier and Type | Method and Description |
---|---|
AggregationService |
StatementResourceHolder.getAggregationService() |
Modifier and Type | Method and Description |
---|---|
protected void |
StatementResourceHolder.setAggregationService(AggregationService aggregationService) |
Modifier and Type | Method and Description |
---|---|
static Pair<ResultSetProcessor,AggregationService> |
EPStatementStartMethodHelperUtil.startResultSetAndAggregation(ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
AgentInstanceContext agentInstanceContext,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
static void |
EPStatementStartMethodHelperAssignExpr.assignExpressionStrategies(EPStatementStartMethodSelectDesc selectDesc,
AggregationService aggregationService,
java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategyInstances,
java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorStrategyInstances,
java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousStrategyInstances,
java.util.Set<ExprPreviousMatchRecognizeNode> matchRecognizeNodes,
RegexExprPreviousEvalStrategy matchRecognizePrevEvalStrategy,
java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategyInstances) |
Modifier and Type | Class and Description |
---|---|
class |
AggregationServiceBase
All aggregation services require evaluation nodes which supply the value to be aggregated (summed, averaged, etc.)
and aggregation state factories to make new aggregation states.
|
class |
AggregationServiceBaseGrouped
All aggregation services require evaluation nodes which supply the value to be aggregated (summed, averaged, etc.)
and aggregation state factories to make new aggregation states.
|
class |
AggregationServiceNull
A null object implementation of the AggregationService
interface.
|
class |
AggregationServiceTable |
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggregationServiceTable.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggregationServiceNull.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggregationServiceBaseGrouped.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggregationService.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggregationServiceNullFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
AggregationService |
AggregationServiceFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Class and Description |
---|---|
class |
AggSvcGroupAllImplAccessOnly
Aggregation service for use when only first/last/window aggregation functions are used an none other.
|
class |
AggSvcGroupAllImplMixedAccess
Implementation for handling aggregation without any grouping (no group-by).
|
class |
AggSvcGroupAllImplNoAccess
Implementation for handling aggregation without any grouping (no group-by).
|
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggSvcGroupAllImplNoAccess.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupAllImplMixedAccess.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupAllImplAccessOnly.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupAllFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Class and Description |
---|---|
class |
AggSvcGroupByNoReclaimAccessOnlyImpl
Aggregation service for use when only first/last/window aggregation functions are used an none other.
|
class |
AggSvcGroupByNoReclaimMixedAccessImpl
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByNoReclaimNoAccessImpl
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByReclaimAgedImpl
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByRefcountedNoAccessImpl
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByRefcountedWAccessImpl
Implementation for handling aggregation with grouping by group-keys.
|
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggSvcGroupByNoReclaimAccessOnlyImpl.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupByRefcountedFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
AggregationService |
AggSvcGroupByReclaimAgedFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
AggregationService |
AggSvcGroupByNoReclaimFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Class and Description |
---|---|
class |
AggSvcGroupAllLocalGroupBy
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByLocalGroupBy
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupLocalGroupByBase
Implementation for handling aggregation with grouping by group-keys.
|
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggSvcGroupLocalGroupByBase.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupByLocalGroupByFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllLocalGroupByFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Class and Description |
---|---|
class |
AggSvcGroupByRollupImpl
Implementation for handling aggregation with grouping by group-keys.
|
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggSvcGroupByRollupFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Class and Description |
---|---|
class |
AggSvcGroupAllWTableImpl
Implementation for handling aggregation without any grouping (no group-by).
|
class |
AggSvcGroupByWTableBase
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByWTableImpl
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByWTableRollupMultiKeyImpl
Implementation for handling aggregation with grouping by group-keys.
|
class |
AggSvcGroupByWTableRollupSingleKeyImpl
Implementation for handling aggregation with grouping by group-keys.
|
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggSvcGroupByWTableBase.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupAllWTableImpl.getContextPartitionAggregationService(int agentInstanceId) |
AggregationService |
AggSvcGroupByWTableFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllWTableFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
java.lang.Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
EventBean |
OrderByProcessorImpl.determineLocalMinMax(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorRowLimitOnly.sortPlain(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorOrderedLimit.sortPlain(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorImpl.sortPlain(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessor.sortPlain(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService)
Sort the output events.
|
EventBean[] |
OrderByProcessorRowLimitOnly.sortRollup(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorOrderedLimit.sortRollup(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorImpl.sortRollup(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessor.sortRollup(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
AggregationService aggregationService)
Sort the output events, using the provided group-by keys for
evaluating grouped aggregation functions, and avoiding the cost of
recomputing the keys.
|
EventBean[] |
OrderByProcessorRowLimitOnly.sortWGroupKeys(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
java.lang.Object[] groupByKeys,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorOrderedLimit.sortWGroupKeys(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
java.lang.Object[] groupByKeys,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessorImpl.sortWGroupKeys(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
java.lang.Object[] groupByKeys,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
EventBean[] |
OrderByProcessor.sortWGroupKeys(EventBean[] outgoingEvents,
EventBean[][] generatingEvents,
java.lang.Object[] groupByKeys,
boolean isNewData,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService)
Sort the output events, using the provided group-by keys for
evaluating grouped aggregation functions, and avoiding the cost of
recomputing the keys.
|
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
ResultSetProcessorAggregateGroupedImpl.aggregationService |
Modifier and Type | Method and Description |
---|---|
AggregationService |
ResultSetProcessorAggregateGroupedImpl.getAggregationService() |
AggregationService |
ResultSetProcessorAggregateGrouped.getAggregationService() |
Modifier and Type | Method and Description |
---|---|
ResultSetProcessor |
ResultSetProcessorAggregateGroupedFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
ResultSetProcessorAggregateGroupedIterator(java.util.Iterator<EventBean> sourceIterator,
ResultSetProcessorAggregateGrouped resultSetProcessor,
AggregationService aggregationService,
ExprEvaluatorContext exprEvaluatorContext)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static void |
ResultSetProcessorUtil.applyAggJoinResult(AggregationService aggregationService,
ExprEvaluatorContext exprEvaluatorContext,
java.util.Set<MultiKey<EventBean>> newEvents,
java.util.Set<MultiKey<EventBean>> oldEvents)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
ResultSetProcessorUtil.applyAggViewResult(AggregationService aggregationService,
ExprEvaluatorContext exprEvaluatorContext,
EventBean[] newData,
EventBean[] oldData,
EventBean[] eventsPerStream)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
ResultSetProcessorUtil.clearAndAggregateUngrouped(ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService,
Viewable parent) |
static EventBean[] |
ResultSetProcessorUtil.getSelectEventsHavingWithOrderBy(AggregationService aggregationService,
SelectExprProcessor exprProcessor,
OrderByProcessor orderByProcessor,
EventBean[] events,
ExprEvaluator havingNode,
boolean isNewData,
boolean isSynthesize,
ExprEvaluatorContext exprEvaluatorContext)
Applies the select-clause to the given events returning the selected events.
|
static EventBean[] |
ResultSetProcessorUtil.getSelectEventsNoHavingWithOrderBy(AggregationService aggregationService,
SelectExprProcessor exprProcessor,
OrderByProcessor orderByProcessor,
EventBean[] events,
boolean isNewData,
boolean isSynthesize,
ExprEvaluatorContext exprEvaluatorContext)
Applies the select-clause to the given events returning the selected events.
|
static EventBean[] |
ResultSetProcessorUtil.getSelectJoinEventsHavingWithOrderBy(AggregationService aggregationService,
SelectExprProcessor exprProcessor,
OrderByProcessor orderByProcessor,
java.util.Set<MultiKey<EventBean>> events,
ExprEvaluator havingNode,
boolean isNewData,
boolean isSynthesize,
ExprEvaluatorContext exprEvaluatorContext)
Applies the select-clause to the given events returning the selected events.
|
static EventBean[] |
ResultSetProcessorUtil.getSelectJoinEventsNoHavingWithOrderBy(AggregationService aggregationService,
SelectExprProcessor exprProcessor,
OrderByProcessor orderByProcessor,
java.util.Set<MultiKey<EventBean>> events,
boolean isNewData,
boolean isSynthesize,
ExprEvaluatorContext exprEvaluatorContext)
Applies the select-clause to the given events returning the selected events.
|
ResultSetProcessor |
ResultSetProcessorFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
static EventBean[] |
ResultSetProcessorUtil.outputFromCountMaySort(int count,
EventBean[] events,
java.lang.Object[] keys,
EventBean[][] currentGenerators,
boolean isNewData,
OrderByProcessor orderByProcessor,
AgentInstanceContext agentInstanceContext,
AggregationService aggregationService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
static void |
ResultSetProcessorGroupedUtil.applyAggJoinResultKeyedJoin(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext,
java.util.Set<MultiKey<EventBean>> newEvents,
java.lang.Object[] newDataMultiKey,
java.util.Set<MultiKey<EventBean>> oldEvents,
java.lang.Object[] oldDataMultiKey)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
ResultSetProcessorGroupedUtil.applyAggViewResultKeyedView(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext,
EventBean[] newData,
java.lang.Object[] newDataMultiKey,
EventBean[] oldData,
java.lang.Object[] oldDataMultiKey,
EventBean[] eventsPerStream)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
ResultSetProcessor |
ResultSetProcessorSimpleFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
ResultSetProcessorRowForAllImpl.aggregationService |
Modifier and Type | Method and Description |
---|---|
AggregationService |
ResultSetProcessorRowForAllImpl.getAggregationService() |
AggregationService |
ResultSetProcessorRowForAll.getAggregationService() |
Modifier and Type | Method and Description |
---|---|
ResultSetProcessor |
ResultSetProcessorRowForAllFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
ResultSetProcessor |
ResultSetProcessorRowPerEventFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
ResultSetProcessorRowPerGroupImpl.aggregationService |
Modifier and Type | Method and Description |
---|---|
AggregationService |
ResultSetProcessorRowPerGroupImpl.getAggregationService() |
AggregationService |
ResultSetProcessorRowPerGroup.getAggregationService() |
Modifier and Type | Method and Description |
---|---|
ResultSetProcessor |
ResultSetProcessorRowPerGroupFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
ResultSetProcessorRowPerGroupIterator(java.util.Iterator<EventBean> sourceIterator,
ResultSetProcessorRowPerGroup resultSetProcessor,
AggregationService aggregationService,
ExprEvaluatorContext exprEvaluatorContext)
Ctor.
|
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
ResultSetProcessorRowPerGroupRollupImpl.aggregationService |
Modifier and Type | Method and Description |
---|---|
AggregationService |
ResultSetProcessorRowPerGroupRollupImpl.getAggregationService() |
AggregationService |
ResultSetProcessorRowPerGroupRollup.getAggregationService() |
Modifier and Type | Method and Description |
---|---|
ResultSetProcessor |
ResultSetProcessorRowPerGroupRollupFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
ExprSubselectNode.subselectAggregationService |
Modifier and Type | Method and Description |
---|---|
AggregationService |
ExprSubselectNode.getSubselectAggregationService() |
Modifier and Type | Method and Description |
---|---|
java.lang.Object |
SubselectEvalStrategyNRExistsWGroupByWHaving.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationServiceAnyPartition) |
java.lang.Object |
SubselectEvalStrategyNRExistsWGroupBy.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
java.lang.Object |
SubselectEvalStrategyNRExistsDefault.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
java.lang.Object |
SubselectEvalStrategyNRExistsAlwaysTrue.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
java.lang.Object |
SubselectEvalStrategyNRExistsAggregated.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
java.lang.Object |
SubselectEvalStrategyNRBase.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
java.lang.Object |
SubselectEvalStrategyNR.evaluate(EventBean[] eventsPerStream,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService)
Evaluate.
|
protected java.lang.Object |
SubselectEvalStrategyNRRelOpAnyWGroupBy.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationServiceAnyPartition) |
protected java.lang.Object |
SubselectEvalStrategyNRRelOpAnyDefault.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNRRelOpAllWGroupBy.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationServiceAnyPartition) |
protected java.lang.Object |
SubselectEvalStrategyNRRelOpAllDefault.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNRRelOpAllAnyAggregated.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsInWGroupBy.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationServiceAnyPartition) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsInUnfiltered.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsInFiltered.evaluateInternal(java.lang.Object leftResult,
EventBean[] eventsZeroOffset,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsInAggregated.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsAnyWGroupBy.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationServiceAnyPartition) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsAnyDefault.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsAllWGroupBy.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationServiceAnyPartition) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsAllDefault.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected java.lang.Object |
SubselectEvalStrategyNREqualsAllAnyAggregated.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
protected abstract java.lang.Object |
SubselectEvalStrategyNRBase.evaluateInternal(java.lang.Object leftResult,
EventBean[] events,
boolean isNewData,
java.util.Collection<EventBean> matchingEvents,
ExprEvaluatorContext exprEvaluatorContext,
AggregationService aggregationService) |
void |
ExprSubselectNode.setSubselectAggregationService(AggregationService subselectAggregationService) |
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
SubselectAggregatorViewBase.aggregationService |
protected AggregationService |
SubselectAggregationPreprocessorBase.aggregationService |
Modifier and Type | Field and Description |
---|---|
protected AggregationService |
ExpressionViewBase.aggregationService |
Modifier and Type | Method and Description |
---|---|
AggregationService |
ExpressionViewBase.getAggregationService() |