Uses of Interface
com.espertech.esper.epl.expression.core.ExprNode

Packages that use ExprNode
com.espertech.esper.client.hook Callback interfaces for use with statement annotations. 
com.espertech.esper.core.context.activator Activation of streams for statement start. 
com.espertech.esper.core.context.factory Statement agent instance factories. 
com.espertech.esper.core.context.mgr Context management. 
com.espertech.esper.core.context.subselect Subselect implementation. 
com.espertech.esper.core.service Implementation of client package interfaces, glue code 
com.espertech.esper.core.start Classes related to start and stop of statements 
com.espertech.esper.epl.agg.rollup Aggregation roll-up services. 
com.espertech.esper.epl.agg.service Aggregation services. 
com.espertech.esper.epl.agg.util Aggregation utility classes centered around local group-by parameters. 
com.espertech.esper.epl.approx Approximation algos. 
com.espertech.esper.epl.core Contains EPL statement specification classes define the constructs that make up an EPL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
com.espertech.esper.epl.core.eval Select expression evaluators. 
com.espertech.esper.epl.datetime.calop Date-Time calendar operations. 
com.espertech.esper.epl.datetime.eval Date-Time methods and related utility classes. 
com.espertech.esper.epl.datetime.interval Interval algebra. 
com.espertech.esper.epl.datetime.reformatop Date-Time re-formatting operations. 
com.espertech.esper.epl.db Database SQL polling views and caches 
com.espertech.esper.epl.declexpr Declared expression handling. 
com.espertech.esper.epl.enummethod.dot Enumeration method utility classes and input data sources. 
com.espertech.esper.epl.expression.accessagg Access-aggregation expressions. 
com.espertech.esper.epl.expression.baseagg Base aggregation expressions. 
com.espertech.esper.epl.expression.core Core expression classes. 
com.espertech.esper.epl.expression.dot Chained expression functionality. 
com.espertech.esper.epl.expression.funcs Function expressions. 
com.espertech.esper.epl.expression.methodagg Method-aggregation expressions. 
com.espertech.esper.epl.expression.ops Operator expressions. 
com.espertech.esper.epl.expression.prev 'Previous'-group expressions. 
com.espertech.esper.epl.expression.prior 'Prior'-group expressions. 
com.espertech.esper.epl.expression.subquery Subselect expressions. 
com.espertech.esper.epl.expression.table Table access and identifiers expressions. 
com.espertech.esper.epl.expression.time Time-related expressions. 
com.espertech.esper.epl.expression.visitor Expression visitors. 
com.espertech.esper.epl.join.base Join process interfaces and glue code 
com.espertech.esper.epl.join.exec.base Inner join execution 
com.espertech.esper.epl.join.hint Hints related to joins. 
com.espertech.esper.epl.join.plan Inner join and outer join query planning 
com.espertech.esper.epl.join.util Join-related utilities 
com.espertech.esper.epl.lookup Subquery execution strategies and lookup indexes 
com.espertech.esper.epl.methodbase Dot-method validation for enumeration and date-time methods. 
com.espertech.esper.epl.named Named window classes are in this package 
com.espertech.esper.epl.parse Parsers and AST tree walkers and helper classes transforming AST into business objects 
com.espertech.esper.epl.rettype EPL-internal expression return type. 
com.espertech.esper.epl.script Script expression evaluation. 
com.espertech.esper.epl.spec Contains EPL statement specification classes define the constructs that make up an EPL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
com.espertech.esper.epl.spec.util Statement spec utilities 
com.espertech.esper.epl.subquery Subquery helper classes are found here. 
com.espertech.esper.epl.table.merge Table on-merge handlers. 
com.espertech.esper.epl.table.mgmt Table-related services and metadata. 
com.espertech.esper.epl.table.strategy Table access evaluators. 
com.espertech.esper.epl.view Internal processing views for output rate limiting, filtering and internal event routing 
com.espertech.esper.epl.virtualdw Virtual data window. 
com.espertech.esper.event.bean JavaBean and legacy Java underlying event classes are here. 
com.espertech.esper.filter Main switchboard filtering and routing of incoming events to interested statements is performed in this package. 
com.espertech.esper.metrics.instrumentation EPL instrumentation helpers. 
com.espertech.esper.pattern Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active pattern instance 
com.espertech.esper.pattern.guard Pattern guards that can define the lifetime of a pattern 
com.espertech.esper.pattern.observer Pattern observer classes the observe timer events 
com.espertech.esper.plugin APIs for plug-in adapter (for input-output) and plug-in event representation (event types and event objects) are in this package. 
com.espertech.esper.rowregex Match-recognize expression tree and state objects. 
com.espertech.esper.view View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering. 
com.espertech.esper.view.ext Extension views that providing services such as sorting, which don't fit much into other categories. 
com.espertech.esper.view.internal Internal management views for buffering view results and providing these to joins. 
com.espertech.esper.view.stat Views computing statistical values. 
com.espertech.esper.view.std Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc. 
com.espertech.esper.view.window Window views are in this package 
 

Uses of ExprNode in com.espertech.esper.client.hook
 

Methods in com.espertech.esper.client.hook that return ExprNode
 ExprNode[] VirtualDataWindowEventConsumerAdd.getFilterExpressions()
          Provides the filter expressions.
 ExprNode[] VirtualDataWindowFactoryContext.getParameterExpressions()
          Returns the expressions passed as parameters to the virtual data window.
 ExprNode[] VirtualDataWindowContext.getParameterExpressions()
          Returns the expressions passed as parameters to the virtual data window.
 

Constructors in com.espertech.esper.client.hook with parameters of type ExprNode
VirtualDataWindowContext(AgentInstanceContext agentInstanceContext, EventType eventType, java.lang.Object[] parameters, ExprNode[] parameterExpressions, EventBeanFactory eventFactory, VirtualDataWindowOutStream outputStream, java.lang.String namedWindowName, ViewFactoryContext viewFactoryContext, java.io.Serializable customConfiguration)
          Ctor.
VirtualDataWindowEventConsumerAdd(java.lang.String namedWindowName, java.lang.Object consumerObject, java.lang.String statementName, int agentInstanceId, ExprNode[] filterExpressions, ExprEvaluatorContext exprEvaluatorContext)
          Ctor.
VirtualDataWindowFactoryContext(EventType eventType, java.lang.Object[] parameters, ExprNode[] parameterExpressions, EventBeanFactory eventFactory, java.lang.String namedWindowName, ViewFactoryContext viewFactoryContext, java.io.Serializable customConfiguration)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.core.context.activator
 

Constructor parameters in com.espertech.esper.core.context.activator with type arguments of type ExprNode
ViewableActivatorNamedWindow(NamedWindowProcessor processor, java.util.List<ExprNode> filterExpressions, PropertyEvaluator optPropertyEvaluator)
           
 

Uses of ExprNode in com.espertech.esper.core.context.factory
 

Methods in com.espertech.esper.core.context.factory that return ExprNode
 ExprNode[] StatementAgentInstanceFactoryOnTriggerSplitDesc.getWhereClauses()
           
 

Constructors in com.espertech.esper.core.context.factory with parameters of type ExprNode
StatementAgentInstanceFactoryOnTriggerNamedWindow(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, NamedWindowOnExprFactory onExprFactory, OutputProcessViewFactory outputProcessViewFactory, EventType activatorResultEventType, NamedWindowProcessor processor)
           
StatementAgentInstanceFactoryOnTriggerSplitDesc(ResultSetProcessorFactoryDesc[] processors, ExprNode[] whereClauses, boolean[] namedWindowInsert)
           
StatementAgentInstanceFactoryOnTriggerTable(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, TableOnViewFactory onExprFactory, EventType activatorResultEventType, TableMetadata tableMetadata, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, OutputProcessViewFactory outputProcessViewFactory)
           
 

Uses of ExprNode in com.espertech.esper.core.context.mgr
 

Constructor parameters in com.espertech.esper.core.context.mgr with type arguments of type ExprNode
ContextControllerHashedGetterCRC32Serialized(java.lang.String statementName, java.util.List<ExprNode> nodes, int granularity)
           
ContextControllerHashedGetterHashMultiple(java.util.List<ExprNode> nodes, int granularity)
           
ContextControllerHashedGetterSingleRow(java.lang.String statementName, java.lang.String functionName, Pair<java.lang.Class,EngineImportSingleRowDesc> func, java.util.List<ExprNode> parameters, int granularity, MethodResolutionService methodResolutionService, EventType eventType, EventAdapterService eventAdapterService, java.lang.String statementId, TableService tableService)
           
 

Uses of ExprNode in com.espertech.esper.core.context.subselect
 

Constructors in com.espertech.esper.core.context.subselect with parameters of type ExprNode
SubSelectStrategyFactoryLocalViewPreloaded(int subqueryNumber, SubSelectActivationHolder subSelectHolder, Pair<EventTableFactory,SubordTableLookupStrategyFactory> pair, ExprNode filterExprNode, ExprEvaluator filterExprEval, boolean correlatedSubquery, AggregationServiceFactoryDesc aggregationServiceFactory, ViewResourceDelegateVerified viewResourceDelegate, ExprEvaluator[] groupKeys)
           
 

Uses of ExprNode in com.espertech.esper.core.service
 

Methods in com.espertech.esper.core.service that return ExprNode
 ExprNode EPAdministratorSPI.compileExpression(java.lang.String expression)
          Compile expression.
 ExprNode EPAdministratorImpl.compileExpression(java.lang.String expression)
           
 

Constructors in com.espertech.esper.core.service with parameters of type ExprNode
InternalEventRouterEntry(int priority, boolean drop, ExprNode optionalWhereClause, ExprNode[] assignments, EventBeanWriter writer, TypeWidener[] wideners, InternalRoutePreprocessView outputView, StatementAgentInstanceLock agentInstanceLock, boolean hasSubselect)
          Ctor.
InternalEventRouterEntry(int priority, boolean drop, ExprNode optionalWhereClause, ExprNode[] assignments, EventBeanWriter writer, TypeWidener[] wideners, InternalRoutePreprocessView outputView, StatementAgentInstanceLock agentInstanceLock, boolean hasSubselect)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.core.start
 

Methods in com.espertech.esper.core.start that return ExprNode
 ExprNode EPPreparedExecuteIUDSingleStreamExecUpdate.getOptionalWhereClause()
           
 ExprNode EPPreparedExecuteIUDSingleStreamExecDelete.getOptionalWhereClause()
           
protected static ExprNode EPStatementStartMethodHelperValidate.validateExprNoAgg(ExprNodeOrigin exprNodeOrigin, ExprNode exprNode, StreamTypeService streamTypeService, StatementContext statementContext, ExprEvaluatorContext exprEvaluatorContext, java.lang.String errorMsg, boolean allowTableConsumption)
           
protected  ExprNode EPStatementStartMethodOnTrigger.validateJoinNamedWindow(java.lang.String engineURI, StatementContext statementContext, ExprNodeOrigin exprNodeOrigin, ExprNode deleteJoinExpr, EventType namedWindowType, java.lang.String namedWindowStreamName, java.lang.String namedWindowName, EventType filteredType, java.lang.String filterStreamName, java.lang.String filteredTypeName, java.lang.String optionalTableName)
           
 

Methods in com.espertech.esper.core.start with parameters of type ExprNode
protected static ExprNode EPStatementStartMethodHelperValidate.validateExprNoAgg(ExprNodeOrigin exprNodeOrigin, ExprNode exprNode, StreamTypeService streamTypeService, StatementContext statementContext, ExprEvaluatorContext exprEvaluatorContext, java.lang.String errorMsg, boolean allowTableConsumption)
           
protected  ExprNode EPStatementStartMethodOnTrigger.validateJoinNamedWindow(java.lang.String engineURI, StatementContext statementContext, ExprNodeOrigin exprNodeOrigin, ExprNode deleteJoinExpr, EventType namedWindowType, java.lang.String namedWindowStreamName, java.lang.String namedWindowName, EventType filteredType, java.lang.String filterStreamName, java.lang.String filteredTypeName, java.lang.String optionalTableName)
           
protected static void EPStatementStartMethodHelperValidate.validateNoAggregations(ExprNode exprNode, java.lang.String errorMsg)
           
protected static void EPStatementStartMethodHelperValidate.validateSubqueryExcludeOuterStream(ExprNode matchCondition)
           
 

Constructors in com.espertech.esper.core.start with parameters of type ExprNode
EPPreparedExecuteIUDSingleStreamExecDelete(FilterSpecCompiled filter, ExprNode optionalWhereClause, java.lang.annotation.Annotation[] annotations, ExprTableAccessNode[] optionalTableNodes, EPServicesContext services)
           
EPPreparedExecuteIUDSingleStreamExecUpdate(FilterSpecCompiled filter, ExprNode optionalWhereClause, java.lang.annotation.Annotation[] annotations, EventBeanUpdateHelper updateHelper, TableUpdateStrategy tableUpdateStrategy, ExprTableAccessNode[] optionalTableNodes, EPServicesContext services)
           
 

Uses of ExprNode in com.espertech.esper.epl.agg.rollup
 

Methods in com.espertech.esper.epl.agg.rollup that return ExprNode
 ExprNode[] GroupByRollupPlanDesc.getExpressions()
           
 

Methods in com.espertech.esper.epl.agg.rollup with parameters of type ExprNode
static GroupByClauseExpressions GroupByExpressionHelper.getGroupByRollupExpressions(java.util.List<GroupByClauseElement> groupByElements, SelectClauseSpecRaw selectClauseSpec, ExprNode optionalHavingNode, java.util.List<OrderByItem> orderByList, ExprNodeSubselectDeclaredDotVisitor visitor)
           
 int GroupByRollupEvalContext.getIndex(ExprNode node)
           
 

Constructors in com.espertech.esper.epl.agg.rollup with parameters of type ExprNode
GroupByRollupNodeSingleExpr(ExprNode expression)
           
GroupByRollupPlanDesc(ExprNode[] expressions, AggregationGroupByRollupDesc rollupDesc)
           
 

Constructor parameters in com.espertech.esper.epl.agg.rollup with type arguments of type ExprNode
GroupByRollupEvalContext(java.util.Map<ExprNode,java.lang.Integer> expressionToIndex)
           
GroupByRollupNodeCombinedExpr(java.util.List<ExprNode> expressions)
           
 

Uses of ExprNode in com.espertech.esper.epl.agg.service
 

Fields in com.espertech.esper.epl.agg.service declared as ExprNode
protected  ExprNode[] AggSvcGroupByWTableBase.accessStateExpr
           
 

Methods in com.espertech.esper.epl.agg.service that return ExprNode
 ExprNode AggregationStateFactoryPlugin.getAggregationExpression()
           
 ExprNode AggregationStateFactory.getAggregationExpression()
           
 ExprNode[] AggregationValidationContext.getExpressions()
          Returns the parameter expressions themselves for interrogation.
 

Methods in com.espertech.esper.epl.agg.service with parameters of type ExprNode
 AggregationServiceFactory AggregationServiceFactoryServiceImpl.getGroupWBinding(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessorPairs, boolean join, IntoTableSpec bindings, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
 AggregationServiceFactory AggregationServiceFactoryService.getGroupWBinding(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessorPairs, boolean join, IntoTableSpec bindings, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
 AggregationServiceFactory AggregationServiceFactoryServiceImpl.getNoGroupWBinding(AggregationAccessorSlotPair[] accessors, boolean join, TableColumnMethodPair[] methodPairs, java.lang.String tableName, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
 AggregationServiceFactory AggregationServiceFactoryService.getNoGroupWBinding(AggregationAccessorSlotPair[] accessors, boolean join, TableColumnMethodPair[] methodPairs, java.lang.String tableName, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
static AggregationServiceFactoryDesc AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes, java.util.Map<ExprNode,java.lang.String> selectClauseNamedNodes, java.util.List<ExprDeclaredNode> declaredExpressions, ExprNode[] groupByNodes, java.util.List<ExprAggregateNode> havingAggregateExprNodes, java.util.List<ExprAggregateNode> orderByAggregateExprNodes, java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions, boolean hasGroupByClause, java.lang.annotation.Annotation[] annotations, VariableService variableService, boolean isJoin, boolean isDisallowNoReclaim, ExprNode whereClause, ExprNode havingClause, AggregationServiceFactoryService factoryService, EventType[] typesPerStream, MethodResolutionService methodResolutionService, AggregationGroupByRollupDesc groupByRollupDesc, java.lang.String optionalContextName, IntoTableSpec intoTableSpec, TableService tableService)
          Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on whether there are any group-by nodes.
static AggregationServiceFactoryDesc AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes, java.util.Map<ExprNode,java.lang.String> selectClauseNamedNodes, java.util.List<ExprDeclaredNode> declaredExpressions, ExprNode[] groupByNodes, java.util.List<ExprAggregateNode> havingAggregateExprNodes, java.util.List<ExprAggregateNode> orderByAggregateExprNodes, java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions, boolean hasGroupByClause, java.lang.annotation.Annotation[] annotations, VariableService variableService, boolean isJoin, boolean isDisallowNoReclaim, ExprNode whereClause, ExprNode havingClause, AggregationServiceFactoryService factoryService, EventType[] typesPerStream, MethodResolutionService methodResolutionService, AggregationGroupByRollupDesc groupByRollupDesc, java.lang.String optionalContextName, IntoTableSpec intoTableSpec, TableService tableService)
          Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on whether there are any group-by nodes.
 

Method parameters in com.espertech.esper.epl.agg.service with type arguments of type ExprNode
static AggregationServiceFactoryDesc AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes, java.util.Map<ExprNode,java.lang.String> selectClauseNamedNodes, java.util.List<ExprDeclaredNode> declaredExpressions, ExprNode[] groupByNodes, java.util.List<ExprAggregateNode> havingAggregateExprNodes, java.util.List<ExprAggregateNode> orderByAggregateExprNodes, java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions, boolean hasGroupByClause, java.lang.annotation.Annotation[] annotations, VariableService variableService, boolean isJoin, boolean isDisallowNoReclaim, ExprNode whereClause, ExprNode havingClause, AggregationServiceFactoryService factoryService, EventType[] typesPerStream, MethodResolutionService methodResolutionService, AggregationGroupByRollupDesc groupByRollupDesc, java.lang.String optionalContextName, IntoTableSpec intoTableSpec, TableService tableService)
          Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on whether there are any group-by nodes.
 

Constructors in com.espertech.esper.epl.agg.service with parameters of type ExprNode
AggregationStateKeyWStream(int streamNum, EventType eventType, AggregationStateTypeWStream stateType, ExprNode[] exprNodes)
           
AggregationValidationContext(java.lang.Class[] parameterTypes, boolean[] constantValue, java.lang.Object[] constantValues, boolean distinct, boolean windowed, ExprNode[] expressions)
          Ctor.
AggSvcGroupAllMixedAccessWTableFactory(AggregationAccessorSlotPair[] accessors, boolean join, TableColumnMethodPair[] methodPairs, java.lang.String tableName, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
AggSvcGroupAllMixedAccessWTableImpl(TableStateInstanceUngrouped tableStateInstance, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
AggSvcGroupByWTableBase(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
AggSvcGroupByWTableFactory(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
AggSvcGroupByWTableImpl(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
AggSvcGroupByWTableRollupMultiKeyImpl(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
AggSvcGroupByWTableRollupSingleKeyImpl(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
 

Uses of ExprNode in com.espertech.esper.epl.agg.util
 

Methods in com.espertech.esper.epl.agg.util that return ExprNode
 ExprNode[] AggregationGroupByLocalGroupLevel.getPartitionExpr()
           
 

Methods in com.espertech.esper.epl.agg.util with parameters of type ExprNode
static AggregationLocalGroupByPlan AggregationGroupByLocalGroupByAnalyzer.analyze(ExprEvaluator[] evaluators, AggregationMethodFactory[] prototypes, AggregationStateFactory[] accessAggregations, AggregationGroupByLocalGroupDesc localGroupDesc, ExprNode[] groupByExpressions, AggregationAccessorSlotPair[] accessors)
           
 

Constructors in com.espertech.esper.epl.agg.util with parameters of type ExprNode
AggregationGroupByLocalGroupLevel(ExprNode[] partitionExpr, java.util.List<AggregationServiceAggExpressionDesc> expressions)
           
 

Uses of ExprNode in com.espertech.esper.epl.approx
 

Methods in com.espertech.esper.epl.approx that return ExprNode
 ExprNode CountMinSketchAggStateFactory.getAggregationExpression()
           
 

Uses of ExprNode in com.espertech.esper.epl.core
 

Methods in com.espertech.esper.epl.core that return ExprNode
 ExprNode OrderByElement.getExprNode()
           
 ExprNode[] ResultSetProcessorRowPerGroupRollupFactory.getGroupKeyNodeExpressions()
           
 ExprNode[] ResultSetProcessorRowPerGroupFactory.getGroupKeyNodeExpressions()
           
 ExprNode[] ResultSetProcessorAggregateGroupedFactory.getGroupKeyNodeExpressions()
           
 ExprNode EngineImportServiceImpl.resolveAggExtendedBuiltin(java.lang.String name, boolean isDistinct)
           
 ExprNode EngineImportService.resolveAggExtendedBuiltin(java.lang.String name, boolean isDistinct)
          Resolve an extended (non-SQL std) builtin aggregation.
 ExprNode EngineImportServiceImpl.resolveSingleRowExtendedBuiltin(java.lang.String name)
           
 ExprNode EngineImportService.resolveSingleRowExtendedBuiltin(java.lang.String name)
          Resolve an extended (non-SQL std) single-row function.
static ExprNode ColumnNamedNodeSwapper.swap(ExprNode exprTree, java.lang.String columnName, ExprNode fullExpr)
          Replace all instances of the node representing the colum name with the full expression.
 

Methods in com.espertech.esper.epl.core with parameters of type ExprNode
 java.lang.Object MethodResolutionServiceImpl.getGroupKeyBinding(ExprNode[] groupKeyExpressions, AggregationGroupByRollupDesc groupByRollupDesc)
           
 java.lang.Object MethodResolutionService.getGroupKeyBinding(ExprNode[] groupKeyExpressions, AggregationGroupByRollupDesc groupByRollupDesc)
           
static OrderByProcessorFactory OrderByProcessorFactoryFactory.getProcessor(java.util.List<SelectClauseExprCompiledSpec> selectionList, ExprNode[] groupByNodes, java.util.List<OrderByItem> orderByList, RowLimitSpec rowLimitSpec, VariableService variableService, boolean isSortUsingCollator, java.lang.String optionalContextName)
          Returns processor for order-by clauses.
static ExprNode ColumnNamedNodeSwapper.swap(ExprNode exprTree, java.lang.String columnName, ExprNode fullExpr)
          Replace all instances of the node representing the colum name with the full expression.
 

Method parameters in com.espertech.esper.epl.core with type arguments of type ExprNode
 void MethodPollingViewable.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
           
 

Constructors in com.espertech.esper.epl.core with parameters of type ExprNode
OrderByElement(ExprNode exprNode, ExprEvaluator expr, boolean descending)
           
OrderByProcessorFactoryImpl(java.util.List<OrderByItem> orderByList, ExprNode[] groupByNodes, boolean needsGroupByKeys, boolean isSortUsingCollator)
          Ctor.
ResultSetProcessorAggregateGroupedFactory(SelectExprProcessor selectExprProcessor, ExprNode[] groupKeyNodeExpressions, ExprEvaluator[] groupKeyNodes, ExprEvaluator optionalHavingNode, boolean isSelectRStream, boolean isUnidirectional, OutputLimitSpec outputLimitSpec, boolean isSorting, boolean isHistoricalOnly)
          Ctor.
ResultSetProcessorRowPerGroupFactory(SelectExprProcessor selectExprProcessor, ExprNode[] groupKeyNodeExpressions, ExprEvaluator[] groupKeyNodes, ExprEvaluator optionalHavingNode, boolean isSelectRStream, boolean isUnidirectional, OutputLimitSpec outputLimitSpec, boolean isSorting, boolean noDataWindowSingleStream, boolean isHistoricalOnly, boolean iterateUnbounded)
          Ctor.
ResultSetProcessorRowPerGroupRollupFactory(GroupByRollupPerLevelExpression perLevelExpression, ExprNode[] groupKeyNodeExpressions, ExprEvaluator[] groupKeyNodes, boolean isSelectRStream, boolean isUnidirectional, OutputLimitSpec outputLimitSpec, boolean isSorting, boolean noDataWindowSingleStream, AggregationGroupByRollupDesc groupByRollupDesc, boolean isJoin, boolean isHistoricalOnly, boolean iterateUnbounded)
          Ctor.
 

Constructor parameters in com.espertech.esper.epl.core with type arguments of type ExprNode
MethodPollingViewable(boolean isStaticMethod, java.lang.Class methodProviderClass, MethodStreamSpec methodStreamSpec, int myStreamNumber, java.util.List<ExprNode> inputParameters, PollExecStrategy pollExecStrategy, DataCache dataCache, EventType eventType, ExprEvaluatorContext exprEvaluatorContext)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.epl.core.eval
 

Methods in com.espertech.esper.epl.core.eval with parameters of type ExprNode
static SelectExprProcessor EvalSelectStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes, SelectExprContext selectExprContext, int streamNumber, EventType targetType, ExprNode[] exprNodes, EngineImportService engineImportService)
           
static SelectExprProcessor EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes, SelectExprContext selectExprContext, int streamNumber, EventType targetType, ExprNode[] exprNodes, EngineImportService engineImportService)
           
 

Uses of ExprNode in com.espertech.esper.epl.datetime.calop
 

Methods in com.espertech.esper.epl.datetime.calop with parameters of type ExprNode
static CalendarFieldEnum CalendarOpUtil.getEnum(java.lang.String methodName, ExprNode exprNode)
           
 

Method parameters in com.espertech.esper.epl.datetime.calop with type arguments of type ExprNode
 CalendarOp CalendarOpFactory.getOp(DatetimeMethodEnum method, java.lang.String methodNameUsed, java.util.List<ExprNode> parameters, ExprEvaluator[] evaluators)
           
 

Uses of ExprNode in com.espertech.esper.epl.datetime.eval
 

Method parameters in com.espertech.esper.epl.datetime.eval with type arguments of type ExprNode
static ExprDotEvalDTMethodDesc ExprDotEvalDTFactory.validateMake(StreamTypeService streamTypeService, java.util.Deque<ExprChainedSpec> chainSpecStack, DatetimeMethodEnum dtMethod, java.lang.String dtMethodName, EPType inputType, java.util.List<ExprNode> parameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 

Constructors in com.espertech.esper.epl.datetime.eval with parameters of type ExprNode
ExprDotNodeFilterAnalyzerDTBetweenDesc(EventType[] typesPerStream, int targetStreamNum, java.lang.String targetPropertyName, ExprNode start, ExprNode end, boolean includeLow, boolean includeHigh)
           
 

Uses of ExprNode in com.espertech.esper.epl.datetime.interval
 

Method parameters in com.espertech.esper.epl.datetime.interval with type arguments of type ExprNode
 ExprDotNodeFilterAnalyzerDTIntervalDesc IntervalOpImpl.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
          Obtain information used by filter analyzer to handle this dot-method invocation as part of query planning/indexing.
 ExprDotNodeFilterAnalyzerDTIntervalDesc IntervalOp.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 IntervalOp IntervalOpFactory.getOp(StreamTypeService streamTypeService, DatetimeMethodEnum method, java.lang.String methodNameUsed, java.util.List<ExprNode> parameters, ExprEvaluator[] evaluators)
           
static IntervalComputer IntervalComputerFactory.make(DatetimeMethodEnum method, java.util.List<ExprNode> expressions)
           
 

Constructor parameters in com.espertech.esper.epl.datetime.interval with type arguments of type ExprNode
IntervalOpImpl(DatetimeMethodEnum method, java.lang.String methodNameUse, StreamTypeService streamTypeService, java.util.List<ExprNode> expressions)
           
 

Uses of ExprNode in com.espertech.esper.epl.datetime.reformatop
 

Method parameters in com.espertech.esper.epl.datetime.reformatop with type arguments of type ExprNode
 ExprDotNodeFilterAnalyzerDesc ReformatOpToMillisec.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpToDate.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpToCalendar.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpStringFormat.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpGetField.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpCalendarEval.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpBetweenNonConstantParams.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOpBetweenConstantParams.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ExprDotNodeFilterAnalyzerDesc ReformatOp.getFilterDesc(EventType[] typesPerStream, DatetimeMethodEnum currentMethod, java.util.List<ExprNode> currentParameters, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 ReformatOp ReformatOpFactory.getOp(DatetimeMethodEnum method, java.lang.String methodNameUsed, java.util.List<ExprNode> parameters)
           
 

Constructor parameters in com.espertech.esper.epl.datetime.reformatop with type arguments of type ExprNode
ReformatOpBetweenConstantParams(java.util.List<ExprNode> parameters)
           
ReformatOpBetweenNonConstantParams(java.util.List<ExprNode> parameters)
           
 

Uses of ExprNode in com.espertech.esper.epl.db
 

Method parameters in com.espertech.esper.epl.db with type arguments of type ExprNode
 void DatabasePollingViewable.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
           
 

Uses of ExprNode in com.espertech.esper.epl.declexpr
 

Subinterfaces of ExprNode in com.espertech.esper.epl.declexpr
 interface ExprDeclaredNode
          Expression instance as declared elsewhere.
 

Classes in com.espertech.esper.epl.declexpr that implement ExprNode
 class ExprDeclaredNodeImpl
          Expression instance as declared elsewhere.
 

Methods in com.espertech.esper.epl.declexpr that return ExprNode
 ExprNode ExprDeclaredNodeImpl.getBody()
           
 ExprNode ExprDeclaredNode.getBody()
           
 ExprNode ExprDeclaredNodeImpl.getExpressionBodyCopy()
           
 ExprNode ExprDeclaredNodeImpl.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.declexpr that return types with arguments of type ExprNode
 java.util.List<ExprNode> ExprDeclaredNodeImpl.getAdditionalNodes()
           
 java.util.List<ExprNode> ExprDeclaredNodeImpl.getChainParameters()
           
 java.util.List<ExprNode> ExprDeclaredNode.getChainParameters()
           
 

Methods in com.espertech.esper.epl.declexpr with parameters of type ExprNode
 void ExprDeclaredNodeImpl.acceptChildnodes(ExprNodeVisitorWithParent visitor, ExprNode parent)
           
 boolean ExprDeclaredNodeImpl.equalsNode(ExprNode node)
           
 

Method parameters in com.espertech.esper.epl.declexpr with type arguments of type ExprNode
static ExprDeclaredNodeImpl ExprDeclaredHelper.getExistsDeclaredExpr(java.lang.String name, java.util.List<ExprNode> parameters, java.util.Collection<ExpressionDeclItem> expressionDeclarations, ExprDeclaredService exprDeclaredService, ContextDescriptor contextDescriptor)
           
static ExprNodeScript ExprDeclaredHelper.getExistsScript(java.lang.String defaultDialect, java.lang.String expressionName, java.util.List<ExprNode> parameters, java.util.Collection<ExpressionScriptProvided> scriptExpressions, ExprDeclaredService exprDeclaredService)
           
 

Constructor parameters in com.espertech.esper.epl.declexpr with type arguments of type ExprNode
ExprDeclaredNodeImpl(ExpressionDeclItem prototype, java.util.List<ExprNode> chainParameters, ContextDescriptor contextDescriptor)
           
 

Uses of ExprNode in com.espertech.esper.epl.enummethod.dot
 

Classes in com.espertech.esper.epl.enummethod.dot that implement ExprNode
 class ExprLambdaGoesNode
          Represents the case-when-then-else control flow function is an expression tree.
 

Methods in com.espertech.esper.epl.enummethod.dot that return ExprNode
 ExprNode ExprDotEvalParam.getBody()
           
 ExprNode ExprLambdaGoesNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.enummethod.dot with parameters of type ExprNode
 boolean ExprLambdaGoesNode.equalsNode(ExprNode node_)
           
 

Method parameters in com.espertech.esper.epl.enummethod.dot with type arguments of type ExprNode
 void ExprDotEvalEnumMethodBase.init(java.lang.Integer streamOfProviderIfApplicable, EnumMethodEnum enumMethodEnum, java.lang.String enumMethodUsedName, EPType typeInfo, java.util.List<ExprNode> parameters, ExprValidationContext validationContext)
           
 void ExprDotEvalEnumMethod.init(java.lang.Integer streamOfProviderIfApplicable, EnumMethodEnum lambda, java.lang.String lambdaUsedName, EPType currentInputType, java.util.List<ExprNode> parameters, ExprValidationContext validationContext)
           
 

Constructors in com.espertech.esper.epl.enummethod.dot with parameters of type ExprNode
ExprDotEvalParam(int parameterNum, ExprNode body, ExprEvaluator bodyEvaluator)
           
ExprDotEvalParamExpr(int parameterNum, ExprNode body, ExprEvaluator bodyEvaluator)
           
ExprDotEvalParamLambda(int parameterNum, ExprNode body, ExprEvaluator bodyEvaluator, int streamCountIncoming, java.util.List<java.lang.String> goesToNames, EventType[] goesToTypes)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.accessagg
 

Classes in com.espertech.esper.epl.expression.accessagg that implement ExprNode
 class ExprAggCountMinSketchNode
          Represents the Count-min sketch aggregate function.
 class ExprAggMultiFunctionLinearAccessNode
           
 class ExprAggMultiFunctionSortedMinMaxByNode
           
 class ExprPlugInAggMultiFunctionNode
          Represents a custom aggregation function in an expresson tree.
 

Methods in com.espertech.esper.epl.expression.accessagg with parameters of type ExprNode
static int ExprAggMultiFunctionUtil.validateStreamWildcardGetStreamNum(ExprNode node)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.baseagg
 

Subinterfaces of ExprNode in com.espertech.esper.epl.expression.baseagg
 interface ExprAggregateNode
          Base expression node that represents an aggregation function such as 'sum' or 'count'.
 

Classes in com.espertech.esper.epl.expression.baseagg that implement ExprNode
 class ExprAggregateNodeBase
          Base expression node that represents an aggregation function such as 'sum' or 'count'.
 class ExprAggregateNodeGroupKey
           
 

Fields in com.espertech.esper.epl.expression.baseagg declared as ExprNode
protected  ExprNode[] ExprAggregateNodeBase.positionalParams
           
 

Methods in com.espertech.esper.epl.expression.baseagg that return ExprNode
 ExprNode[] ExprAggregateLocalGroupByDesc.getPartitionExpressions()
           
 ExprNode[] ExprAggregateNodeParamDesc.getPositionalParams()
           
 ExprNode[] ExprAggregateNodeBase.getPositionalParams()
           
 ExprNode[] ExprAggregateNode.getPositionalParams()
           
 ExprNode ExprAggregateNodeGroupKey.validate(ExprValidationContext validationContext)
           
 ExprNode ExprAggregateNodeBase.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.baseagg with parameters of type ExprNode
 boolean ExprAggregateNodeGroupKey.equalsNode(ExprNode node)
           
 boolean ExprAggregateNodeBase.equalsNode(ExprNode node)
           
static void ExprAggregateNodeUtil.getAggregatesBottomUp(ExprNode[][] nodes, java.util.List<ExprAggregateNode> aggregateNodes)
           
static void ExprAggregateNodeUtil.getAggregatesBottomUp(ExprNode[] nodes, java.util.List<ExprAggregateNode> aggregateNodes)
           
static void ExprAggregateNodeUtil.getAggregatesBottomUp(ExprNode topNode, java.util.List<ExprAggregateNode> aggregateNodes)
          Populates into the supplied list all aggregation functions within this expression, if any.
static ExprAggregateNodeParamDesc ExprAggregateNodeUtil.getValidatePositionalParams(ExprNode[] childNodes, boolean allowOnlyGroupBy)
           
static boolean ExprAggregateNodeUtil.isNonPositionalParameter(ExprNode node)
           
 

Method parameters in com.espertech.esper.epl.expression.baseagg with type arguments of type ExprNode
static int ExprAggregateNodeUtil.countPositionalArgs(java.util.List<ExprNode> args)
           
 

Constructors in com.espertech.esper.epl.expression.baseagg with parameters of type ExprNode
ExprAggregateLocalGroupByDesc(ExprNode[] partitionExpressions)
           
ExprAggregateNodeParamDesc(ExprNode[] positionalParams, ExprAggregateLocalGroupByDesc optLocalGroupBy)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.core
 

Subinterfaces of ExprNode in com.espertech.esper.epl.expression.core
 interface ExprConstantNode
          Represents a constant in an expressiun tree.
 interface ExprIdentNode
          Represents an stream property identifier in a filter expressiun tree.
 interface ExprStreamRefNode
          Represents a stream-reference.
 interface ExprStreamUnderlyingNode
          Represents an stream selector that returns the streams underlying event, or null if undefined.
 interface ExprVariableNode
          Represents a variable in an expression tree.
 

Classes in com.espertech.esper.epl.expression.core that implement ExprNode
 class ExprConstantNodeImpl
          Represents a constant in an expressiun tree.
 class ExprContextPropertyNode
          Represents an stream property identifier in a filter expressiun tree.
 class ExprCurrentEvaluationContextNode
          Represents the "current_evaluation_context" function in an expression tree.
 class ExprGroupingIdNode
           
 class ExprGroupingNode
           
 class ExprIdentNodeImpl
          Represents an stream property identifier in a filter expressiun tree.
 class ExprNamedParameterNodeImpl
           
 class ExprNodeBase
          Superclass for filter nodes in a filter expression tree.
 class ExprNodeValidated
          A placeholder for another expression node that has been validated already.
 class ExprNumberSetCronParam
          Expression for a parameter within a crontab.
 class ExprNumberSetFrequency
          Expression for use within crontab to specify a frequency.
 class ExprNumberSetList
          Expression for use within crontab to specify a list of values.
 class ExprNumberSetRange
          Expression for use within crontab to specify a range.
 class ExprOrderedExpr
          A placeholder expression for view/pattern object parameters that allow sorting expression values ascending or descending.
 class ExprStreamUnderlyingNodeImpl
          Represents an stream selector that returns the streams underlying event, or null if undefined.
 class ExprSubstitutionNode
          Represents a substitution value to be substituted in an expression tree, not valid for any purpose of use as an expression, however can take a place in an expression tree.
 class ExprTypedNoEvalNode
          Represents an expression node that returns the predefined type and that cannot be evaluated.
 class ExprVariableNodeImpl
          Represents a variable in an expression tree.
 class ExprWildcardImpl
          Expression for use within crontab to specify a wildcard.
 

Fields in com.espertech.esper.epl.expression.core declared as ExprNode
static ExprNode[] ExprNodeUtility.EMPTY_EXPR_ARRAY
           
 

Methods in com.espertech.esper.epl.expression.core that return ExprNode
static ExprNode ExprNodeUtility.connectExpressionsByLogicalAnd(java.util.List<ExprNode> nodes, ExprNode optionalAdditionalFilter)
           
 ExprNode[] ExprNodeBase.getChildNodes()
           
 ExprNode[] ExprNode.getChildNodes()
          Returns list of child nodes.
 ExprNode[] ExprNamedParameterNode.getChildNodes()
           
 ExprNode ExprNodePropOrStreamExprDesc.getOriginator()
           
static ExprNode ExprNodeUtility.getValidatedAssignment(OnTriggerSetAssignment assignment, ExprValidationContext validationContext)
           
static ExprNode ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin, ExprNode exprNode, ExprValidationContext validationContext)
          Validates the expression node subtree that has this node as root.
static ExprNode[] ExprNodeUtility.toArray(java.util.Collection<ExprNode> expressions)
           
 ExprNode ExprWildcardImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprVariableNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprValidator.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTypedNoEvalNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprSubstitutionNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprStreamUnderlyingNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprOrderedExpr.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetRange.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetList.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetFrequency.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetCronParam.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNodeValidated.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNamedParameterNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprIdentNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprGroupingNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprGroupingIdNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCurrentEvaluationContextNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprContextPropertyNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprConstantNodeImpl.validate(ExprValidationContext validationContext)
           
static ExprNode ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin, ExprNode expression, StatementContext statementContext, EventType optionalEventType, boolean allowBindingConsumption)
           
 

Methods in com.espertech.esper.epl.expression.core that return types with arguments of type ExprNode
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToProp(ExprNode node)
           
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node)
           
static java.util.List<ExprNode> ExprNodeUtility.collectChainParameters(java.util.List<ExprChainedSpec> chainSpec)
           
static java.util.List<Pair<ExprNode,ExprNode>> ExprNodeUtility.findExpression(ExprNode selectExpression, ExprNode searchExpression)
           
static java.util.List<Pair<ExprNode,ExprNode>> ExprNodeUtility.findExpression(ExprNode selectExpression, ExprNode searchExpression)
           
 java.util.List<ExprNode> ExprNodeInnerNodeProvider.getAdditionalNodes()
           
 java.util.List<ExprNode> ExprChainedSpec.getParameters()
           
 

Methods in com.espertech.esper.epl.expression.core with parameters of type ExprNode
static void ExprNodeUtility.acceptChain(ExprNodeVisitorWithParent visitor, java.util.List<ExprChainedSpec> chainSpec, ExprNode parent)
           
 void ExprNodeBase.acceptChildnodes(ExprNodeVisitorWithParent visitor, ExprNode parent)
           
 void ExprNode.acceptChildnodes(ExprNodeVisitorWithParent visitor, ExprNode parent)
          Accept a visitor that receives both parent and child node.
 void ExprNodeBase.addChildNode(ExprNode childNode)
           
 void ExprNode.addChildNode(ExprNode childNode)
          Adds a child node.
 void ExprNodeBase.addChildNodeToFront(ExprNode childNode)
           
static void ExprNodeUtility.addNonAggregatedProps(ExprNode exprNode, ExprNodePropOrStreamSet set, EventType[] types, ContextPropertyRegistry contextPropertyRegistry)
           
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToProp(ExprNode node)
           
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node)
           
static ExprNode ExprNodeUtility.connectExpressionsByLogicalAnd(java.util.List<ExprNode> nodes, ExprNode optionalAdditionalFilter)
           
static boolean ExprNodeUtility.deepEquals(ExprNode[] one, ExprNode[] two)
          Compares two expression nodes via deep comparison, considering all child nodes of either side.
static boolean ExprNodeUtility.deepEquals(ExprNode[] one, ExprNode[] two)
          Compares two expression nodes via deep comparison, considering all child nodes of either side.
static boolean ExprNodeUtility.deepEquals(ExprNode nodeOne, ExprNode nodeTwo)
          Compare two expression nodes and their children in exact child-node sequence, returning true if the 2 expression nodes trees are equals, or false if they are not equals.
static boolean ExprNodeUtility.deepEqualsIgnoreDupAndOrder(ExprNode[] setOne, ExprNode[] setTwo)
           
static boolean ExprNodeUtility.deepEqualsIgnoreDupAndOrder(ExprNode[] setOne, ExprNode[] setTwo)
           
static boolean ExprNodeUtility.deepEqualsIsSubset(ExprNode[] subset, ExprNode[] superset)
           
static boolean ExprNodeUtility.deepEqualsIsSubset(ExprNode[] subset, ExprNode[] superset)
           
 boolean ExprWildcardImpl.equalsNode(ExprNode node)
           
 boolean ExprVariableNodeImpl.equalsNode(ExprNode node)
           
 boolean ExprTypedNoEvalNode.equalsNode(ExprNode node)
           
 boolean ExprSubstitutionNode.equalsNode(ExprNode node)
           
 boolean ExprStreamUnderlyingNodeImpl.equalsNode(ExprNode node)
           
 boolean ExprOrderedExpr.equalsNode(ExprNode node)
           
 boolean ExprNumberSetRange.equalsNode(ExprNode node)
           
 boolean ExprNumberSetList.equalsNode(ExprNode node)
           
 boolean ExprNumberSetFrequency.equalsNode(ExprNode node)
           
 boolean ExprNumberSetCronParam.equalsNode(ExprNode node)
           
 boolean ExprNodeValidated.equalsNode(ExprNode node)
           
 boolean ExprNode.equalsNode(ExprNode node)
          Return true if a expression node semantically equals the current node, or false if not.
 boolean ExprNamedParameterNodeImpl.equalsNode(ExprNode other)
           
 boolean ExprIdentNodeImpl.equalsNode(ExprNode node)
           
 boolean ExprGroupingNode.equalsNode(ExprNode node)
           
 boolean ExprGroupingIdNode.equalsNode(ExprNode node)
           
 boolean ExprCurrentEvaluationContextNode.equalsNode(ExprNode node)
           
 boolean ExprContextPropertyNode.equalsNode(ExprNode node)
           
 boolean ExprConstantNodeImpl.equalsNode(ExprNode node)
           
static java.util.List<Pair<ExprNode,ExprNode>> ExprNodeUtility.findExpression(ExprNode selectExpression, ExprNode searchExpression)
           
static ExprEvaluator[] ExprNodeUtility.getEvaluators(ExprNode[] exprNodes)
           
static java.util.List<Pair<java.lang.Integer,java.lang.String>> ExprNodeUtility.getExpressionProperties(ExprNode exprNode, boolean visitAggregateNodes)
          Walk expression returning properties used.
static java.lang.Class[] ExprNodeUtility.getExprResultTypes(ExprNode[] groupByNodes)
           
static ExprNodePropOrStreamSet ExprNodeUtility.getGroupByPropertiesValidateHasOne(ExprNode[] groupByNodes)
           
static java.lang.String[] ExprNodeUtility.getIdentResolvedPropertyNames(ExprNode[] nodes)
           
static java.util.Set<java.lang.Integer> ExprNodeUtility.getIdentStreamNumbers(ExprNode child)
           
static java.util.Set<java.lang.String> ExprNodeUtility.getPropertyNamesIfAllProps(ExprNode[] expressions)
           
static void ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin, ExprNode[][] exprNode, ExprValidationContext validationContext)
           
static void ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin, ExprNode[] exprNode, ExprValidationContext validationContext)
           
static ExprNode ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin, ExprNode exprNode, ExprValidationContext validationContext)
          Validates the expression node subtree that has this node as root.
static boolean ExprNodeUtility.hasRemoveStreamForAggregations(ExprNode child, StreamTypeService streamTypeService, boolean unidirectionalJoin)
          Returns true if all properties within the expression are witin data window'd streams.
static boolean ExprNodeUtility.isConstantValueExpr(ExprNode exprNode)
           
static java.lang.String ExprNodeUtility.isMinimalExpression(ExprNode expression)
          Check if the expression is minimal: does not have a subselect, aggregation and does not need view resources
static java.lang.Object ExprNodeProxy.newInstance(java.lang.String engineURI, java.lang.String statementName, ExprNode exprNode)
           
static void ExprNodeUtility.replaceChainChildNode(ExprNode nodeToReplace, ExprNode newNode, java.util.List<ExprChainedSpec> chainSpec)
           
static void ExprNodeUtility.replaceChildNode(ExprNode parentNode, ExprNode nodeToReplace, ExprNode newNode)
           
 void ExprNodeBase.replaceUnlistedChildNode(ExprNode nodeToReplace, ExprNode newNode)
           
 void ExprNode.replaceUnlistedChildNode(ExprNode nodeToReplace, ExprNode newNode)
           
 void ExprNodeBase.setChildNode(int index, ExprNode newNode)
           
 void ExprNode.setChildNode(int index, ExprNode newNode)
           
 void ExprNodeBase.setChildNodes(ExprNode... nodes)
           
 void ExprNode.setChildNodes(ExprNode... nodes)
           
static java.lang.String ExprNodeUtility.toExpressionStringMinPrecedence(ExprNode[] nodes)
           
static java.lang.String ExprNodeUtility.toExpressionStringMinPrecedenceSafe(ExprNode node)
           
static void ExprNodeUtility.toExpressionStringParameterList(ExprNode[] childNodes, java.io.StringWriter buffer)
           
static void ExprNodeUtility.toExpressionStringParams(java.io.StringWriter writer, ExprNode[] params)
           
static java.lang.String[] ExprNodeUtility.toExpressionStringsMinPrecedence(ExprNode[] expressions)
           
static void ExprNodeUtility.toExpressionStringWFunctionName(java.lang.String functionName, ExprNode[] childNodes, java.io.StringWriter writer)
           
static void ExprNodeUtility.validateNoSpecialsGroupByExpressions(ExprNode[] groupByNodes)
           
static void ExprNodeUtility.validatePlainExpression(ExprNodeOrigin origin, java.lang.String expressionTextualName, ExprNode expression)
           
static ExprNode ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin, ExprNode expression, StatementContext statementContext, EventType optionalEventType, boolean allowBindingConsumption)
           
 

Method parameters in com.espertech.esper.epl.expression.core with type arguments of type ExprNode
 void ExprNodeBase.addChildNodes(java.util.Collection<ExprNode> childNodeColl)
           
 void ExprNode.addChildNodes(java.util.Collection<ExprNode> childNodes)
          Adds child nodes.
static void ExprNodeUtility.applyFilterExpressionsIterable(java.lang.Iterable<EventBean> iterable, java.util.List<ExprNode> filterExpressions, ExprEvaluatorContext exprEvaluatorContext, java.util.Collection<EventBean> eventsInWindow)
           
static ExprAndNode ExprNodeUtility.connectExpressionsByLogicalAnd(java.util.Collection<ExprNode> nodes)
           
static ExprNode ExprNodeUtility.connectExpressionsByLogicalAnd(java.util.List<ExprNode> nodes, ExprNode optionalAdditionalFilter)
           
static boolean ExprNodeUtility.deepEquals(java.util.List<ExprNode> one, java.util.List<ExprNode> two)
           
static boolean ExprNodeUtility.deepEquals(java.util.List<ExprNode> one, java.util.List<ExprNode> two)
           
static ExprEvaluator[] ExprNodeUtility.getEvaluators(java.util.List<ExprNode> childNodes)
           
static java.lang.Class[] ExprNodeUtility.getExprResultTypes(java.util.List<ExprNode> expressions)
           
static java.util.Map<java.lang.String,ExprNamedParameterNode> ExprNodeUtility.getNamedExpressionsHandleDups(java.util.List<ExprNode> parameters)
           
static ExprNodePropOrStreamSet ExprNodeUtility.getNonAggregatedProps(EventType[] types, java.util.List<ExprNode> exprNodes, ContextPropertyRegistry contextPropertyRegistry)
           
static boolean ExprNodeUtility.hasStreamSelect(java.util.List<ExprNode> exprNodes)
           
static boolean ExprNodeUtility.isAllConstants(java.util.List<ExprNode> parameters)
           
static ExprNodeUtilMethodDesc ExprNodeUtility.resolveMethodAllowWildcardAndStream(java.lang.String className, java.lang.Class optionalClass, java.lang.String methodName, java.util.List<ExprNode> parameters, MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, java.lang.String statementId, boolean allowWildcard, EventType wildcardType, ExprNodeUtilResolveExceptionHandler exceptionHandler, java.lang.String functionName, TableService tableService)
           
 void ExprChainedSpec.setParameters(java.util.List<ExprNode> parameters)
           
static ExprNode[] ExprNodeUtility.toArray(java.util.Collection<ExprNode> expressions)
           
static ScheduleSpec ExprNodeUtility.toCrontabSchedule(ExprNodeOrigin origin, java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext context, boolean allowBindingConsumption)
           
static void ExprNodeUtility.toExpressionStringIncludeParen(java.util.List<ExprNode> parameters, java.io.StringWriter buffer)
           
static void ExprNodeUtility.toExpressionStringParameterList(java.util.List<ExprNode> parameters, java.io.StringWriter buffer)
           
 

Constructors in com.espertech.esper.epl.expression.core with parameters of type ExprNode
ExprNodePropOrStreamExprDesc(int streamNum, ExprNode originator)
           
ExprNodeProxy(java.lang.String engineURI, java.lang.String statementName, ExprNode exprNode)
           
ExprNodeValidated(ExprNode inner)
          Ctor.
 

Constructor parameters in com.espertech.esper.epl.expression.core with type arguments of type ExprNode
ExprChainedSpec(java.lang.String name, java.util.List<ExprNode> parameters, boolean property)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.dot
 

Classes in com.espertech.esper.epl.expression.dot that implement ExprNode
 class ExprDotNode
          Represents an Dot-operator expression, for use when "(expression).method(...).method(...)"
 

Methods in com.espertech.esper.epl.expression.dot that return ExprNode
 ExprNode ExprDotNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.dot that return types with arguments of type ExprNode
 java.util.List<ExprNode> ExprDotNode.getAdditionalNodes()
           
 

Methods in com.espertech.esper.epl.expression.dot with parameters of type ExprNode
 void ExprDotNode.acceptChildnodes(ExprNodeVisitorWithParent visitor, ExprNode parent)
           
 boolean ExprDotNode.equalsNode(ExprNode node)
           
static ExprDotEnumerationSource ExprDotNodeUtility.getEnumerationSource(ExprNode inputExpression, StreamTypeService streamTypeService, EventAdapterService eventAdapterService, java.lang.String statementId, boolean hasEnumerationMethod, boolean disablePropertyExpressionEventCollCache)
           
 void ExprDotNode.replaceUnlistedChildNode(ExprNode nodeToReplace, ExprNode newNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.funcs
 

Classes in com.espertech.esper.epl.expression.funcs that implement ExprNode
 class ExprCaseNode
          Represents the case-when-then-else control flow function is an expression tree.
 class ExprCastNode
          Represents the CAST(expression, type) function is an expression tree.
 class ExprCoalesceNode
          Represents the COALESCE(a,b,...) function is an expression tree.
 class ExprInstanceofNode
          Represents the INSTANCEOF(a,b,...) function is an expression tree.
 class ExprIStreamNode
          Represents the RSTREAM() function in an expression tree.
 class ExprMinMaxRowNode
          Represents the MAX(a,b) and MIN(a,b) functions is an expression tree.
 class ExprPlugInSingleRowNode
          Represents an invocation of a plug-in single-row function in the expression tree.
 class ExprPropertyExistsNode
          Represents the EXISTS(property) function in an expression tree.
 class ExprTypeofNode
          Represents the TYPEOF(a) function is an expression tree.
 

Methods in com.espertech.esper.epl.expression.funcs that return ExprNode
 ExprNode ExprCaseNode.CaseAnalysis.getOptionalCompareExprNode()
           
 ExprNode ExprCaseNode.CaseAnalysis.getOptionalElseExprNode()
           
 ExprNode ExprTypeofNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprPropertyExistsNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprPlugInSingleRowNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprMinMaxRowNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprIStreamNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprInstanceofNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCoalesceNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCastNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCaseNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.funcs that return types with arguments of type ExprNode
 java.util.List<ExprNode> ExprPlugInSingleRowNode.getAdditionalNodes()
           
 java.util.List<UniformPair<ExprNode>> ExprCaseNode.CaseAnalysis.getWhenThenNodeList()
           
 

Methods in com.espertech.esper.epl.expression.funcs with parameters of type ExprNode
 void ExprPlugInSingleRowNode.acceptChildnodes(ExprNodeVisitorWithParent visitor, ExprNode parent)
           
 boolean ExprTypeofNode.equalsNode(ExprNode node)
           
 boolean ExprPropertyExistsNode.equalsNode(ExprNode node)
           
 boolean ExprPlugInSingleRowNode.equalsNode(ExprNode node)
           
 boolean ExprMinMaxRowNode.equalsNode(ExprNode node)
           
 boolean ExprIStreamNode.equalsNode(ExprNode node)
           
 boolean ExprInstanceofNode.equalsNode(ExprNode node)
           
 boolean ExprCoalesceNode.equalsNode(ExprNode node)
           
 boolean ExprCastNode.equalsNode(ExprNode node)
           
 boolean ExprCaseNode.equalsNode(ExprNode node_)
           
 void ExprPlugInSingleRowNode.replaceUnlistedChildNode(ExprNode nodeToReplace, ExprNode newNode)
           
 

Constructors in com.espertech.esper.epl.expression.funcs with parameters of type ExprNode
ExprCaseNode.CaseAnalysis(java.util.List<UniformPair<ExprNode>> whenThenNodeList, ExprNode optionalCompareExprNode, ExprNode optionalElseExprNode)
           
 

Constructor parameters in com.espertech.esper.epl.expression.funcs with type arguments of type ExprNode
ExprCaseNode.CaseAnalysis(java.util.List<UniformPair<ExprNode>> whenThenNodeList, ExprNode optionalCompareExprNode, ExprNode optionalElseExprNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.methodagg
 

Classes in com.espertech.esper.epl.expression.methodagg that implement ExprNode
 class ExprAvedevNode
          Represents the avedev(...) aggregate function is an expression tree.
 class ExprAvgNode
          Represents the avg(...) aggregate function is an expression tree.
 class ExprCountEverNode
          Represents the "countever" aggregate function is an expression tree.
 class ExprCountNode
          Represents the count(...) and count(*) and count(distinct ...) aggregate function is an expression tree.
 class ExprFirstEverNode
          Represents the "firstever" aggregate function is an expression tree.
 class ExprLastEverNode
          Represents the "lastever" aggregate function is an expression tree.
 class ExprLeavingAggNode
          Represents the leaving() aggregate function is an expression tree.
 class ExprMedianNode
          Represents the median(...) aggregate function is an expression tree.
 class ExprMinMaxAggrNode
          Represents the min/max(distinct? ...) aggregate function is an expression tree.
 class ExprNthAggNode
          Represents the nth(...) and aggregate function is an expression tree.
 class ExprPlugInAggFunctionFactoryNode
          Represents a custom aggregation function in an expresson tree.
 class ExprRateAggNode
          Represents the rate(...) and aggregate function is an expression tree.
 class ExprStddevNode
          Represents the stddev(...) aggregate function is an expression tree.
 class ExprSumNode
          Represents the sum(...) aggregate function is an expression tree.
 

Methods in com.espertech.esper.epl.expression.methodagg with parameters of type ExprNode
static ExprEvaluator ExprMethodAggUtil.getDefaultEvaluator(ExprNode[] childNodes, boolean join, EventType[] typesPerStream)
           
static ExprEvaluator ExprCountNodeFactory.getMethodAggregationEvaluatorCountBy(ExprNode[] childNodes, boolean join, EventType[] typesPerStream)
           
static ExprEvaluator ExprMethodAggUtil.getMultiNodeEvaluator(ExprNode[] childNodes, boolean join, EventType[] typesPerStream)
           
 

Constructors in com.espertech.esper.epl.expression.methodagg with parameters of type ExprNode
ExprAvedevNodeFactory(ExprAvedevNode parent, java.lang.Class aggregatedValueType, ExprNode[] positionalParameters)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.ops
 

Subinterfaces of ExprNode in com.espertech.esper.epl.expression.ops
 interface ExprAndNode
          Represents an And-condition.
 interface ExprBetweenNode
          Represents the between-clause function in an expression tree.
 interface ExprEqualsNode
          Represents an equals (=, !=, <>, is, is not) comparator in a filter expressiun tree.
 interface ExprInNode
          Represents the in-clause (set check) function in an expression tree.
 interface ExprRelationalOpNode
          Represents a lesser or greater then (/>=) expression in a filter expression tree.
 

Classes in com.espertech.esper.epl.expression.ops that implement ExprNode
 class ExprAndNodeImpl
          Represents an And-condition.
 class ExprArrayNode
          Represents an array in a filter expressiun tree.
 class ExprBetweenNodeImpl
          Represents the between-clause function in an expression tree.
 class ExprBitWiseNode
          Represents the bit-wise operators in an expression tree.
 class ExprConcatNode
          Represents a simple Math (+/-/divide/*) in a filter expression tree.
 class ExprEqualsAllAnyNode
          Represents an equals-for-group (= ANY/ALL/SOME (expression list)) comparator in a expression tree.
 class ExprEqualsNodeImpl
          Represents an equals (=) comparator in a filter expressiun tree.
 class ExprInNodeImpl
          Represents the in-clause (set check) function in an expression tree.
 class ExprLikeNode
          Represents the like-clause in an expression tree.
 class ExprMathNode
          Represents a simple Math (+/-/divide/*) in a filter expression tree.
 class ExprNewInstanceNode
          Represents the "new Class(...)" operator in an expression tree.
 class ExprNewStructNode
          Represents the "new {...}" operator in an expression tree.
 class ExprNotNode
          Represents a NOT expression in an expression tree.
 class ExprOrNode
          Represents an OR expression in a filter expression tree.
 class ExprRegexpNode
          Represents the regexp-clause in an expression tree.
 class ExprRelationalOpAllAnyNode
          Represents a lesser or greater then (/>=) expression in a filter expression tree.
 class ExprRelationalOpNodeImpl
          Represents a lesser or greater then (/>=) expression in a filter expression tree.
 

Methods in com.espertech.esper.epl.expression.ops that return ExprNode
 ExprNode ExprRelationalOpNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprRelationalOpAllAnyNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprRegexpNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprOrNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNotNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNewStructNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNewInstanceNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprMathNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprLikeNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprInNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprEqualsNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprEqualsAllAnyNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprConcatNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprBitWiseNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprBetweenNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprArrayNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprAndNodeImpl.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.ops with parameters of type ExprNode
 boolean ExprRelationalOpNodeImpl.equalsNode(ExprNode node)
           
 boolean ExprRelationalOpAllAnyNode.equalsNode(ExprNode node)
           
 boolean ExprRegexpNode.equalsNode(ExprNode node_)
           
 boolean ExprOrNode.equalsNode(ExprNode node)
           
 boolean ExprNotNode.equalsNode(ExprNode node)
           
 boolean ExprNewStructNode.equalsNode(ExprNode node)
           
 boolean ExprNewInstanceNode.equalsNode(ExprNode node)
           
 boolean ExprMathNode.equalsNode(ExprNode node)
           
 boolean ExprLikeNode.equalsNode(ExprNode node_)
           
 boolean ExprInNodeImpl.equalsNode(ExprNode node_)
           
 boolean ExprEqualsNodeImpl.equalsNode(ExprNode node)
           
 boolean ExprEqualsAllAnyNode.equalsNode(ExprNode node)
           
 boolean ExprConcatNode.equalsNode(ExprNode node)
           
 boolean ExprBitWiseNode.equalsNode(ExprNode node)
           
 boolean ExprBetweenNodeImpl.equalsNode(ExprNode node_)
           
 boolean ExprArrayNode.equalsNode(ExprNode node)
           
 boolean ExprAndNodeImpl.equalsNode(ExprNode node)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.prev
 

Classes in com.espertech.esper.epl.expression.prev that implement ExprNode
 class ExprPreviousMatchRecognizeNode
          Represents the 'prev' previous event function in match-recognize "define" item.
 class ExprPreviousNode
          Represents the 'prev' previous event function in an expression node tree.
 

Methods in com.espertech.esper.epl.expression.prev that return ExprNode
 ExprNode ExprPreviousNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprPreviousMatchRecognizeNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.prev with parameters of type ExprNode
 boolean ExprPreviousNode.equalsNode(ExprNode node)
           
 boolean ExprPreviousMatchRecognizeNode.equalsNode(ExprNode node)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.prior
 

Classes in com.espertech.esper.epl.expression.prior that implement ExprNode
 class ExprPriorNode
          Represents the 'prior' prior event function in an expression node tree.
 

Methods in com.espertech.esper.epl.expression.prior that return ExprNode
 ExprNode ExprPriorNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.prior with parameters of type ExprNode
 boolean ExprPriorNode.equalsNode(ExprNode node)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.subquery
 

Classes in com.espertech.esper.epl.expression.subquery that implement ExprNode
 class ExprSubselectAllSomeAnyNode
          Represents a subselect in an expression tree.
 class ExprSubselectExistsNode
          Represents an exists-subselect in an expression tree.
 class ExprSubselectInNode
          Represents a subselect in an expression tree.
 class ExprSubselectNode
          Represents a subselect in an expression tree.
 class ExprSubselectRowNode
          Represents a subselect in an expression tree.
 

Fields in com.espertech.esper.epl.expression.subquery declared as ExprNode
protected  ExprNode[] ExprSubselectNode.selectClause
          The validated select clause.
 

Methods in com.espertech.esper.epl.expression.subquery that return ExprNode
 ExprNode[] ExprSubselectNode.getSelectClause()
          Returns the select clause or null if none.
 ExprNode ExprSubselectNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.subquery with parameters of type ExprNode
 boolean ExprSubselectNode.equalsNode(ExprNode node)
           
 void ExprSubselectNode.setSelectClause(ExprNode[] selectClause)
          Sets the validate select clause
 

Uses of ExprNode in com.espertech.esper.epl.expression.table
 

Classes in com.espertech.esper.epl.expression.table that implement ExprNode
 class ExprTableAccessNode
           
 class ExprTableAccessNodeKeys
           
 class ExprTableAccessNodeSubprop
           
 class ExprTableAccessNodeSubpropAccessor
           
 class ExprTableAccessNodeTopLevel
           
 class ExprTableIdentNode
           
 class ExprTableIdentNodeSubpropAccessor
           
 

Methods in com.espertech.esper.epl.expression.table that return ExprNode
 ExprNode ExprTableIdentNodeSubpropAccessor.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTableIdentNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTableAccessNode.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.table with parameters of type ExprNode
 boolean ExprTableIdentNodeSubpropAccessor.equalsNode(ExprNode node)
           
 boolean ExprTableIdentNode.equalsNode(ExprNode node)
           
 boolean ExprTableAccessNode.equalsNode(ExprNode o)
           
static void ExprTableNodeUtil.validateExpressions(java.lang.String tableName, java.lang.Class[] providedTypes, java.lang.String providedName, ExprNode[] providedExpr, java.lang.Class[] expectedTypes, java.lang.String expectedName)
           
 

Constructors in com.espertech.esper.epl.expression.table with parameters of type ExprNode
ExprTableAccessNodeSubpropAccessor(java.lang.String tableName, java.lang.String subpropName, ExprNode aggregateAccessMultiValueNode)
           
ExprTableIdentNodeSubpropAccessor(int streamNum, java.lang.String optionalStreamName, TableMetadataColumnAggregation tableAccessColumn, ExprNode aggregateAccessMultiValueNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.time
 

Subinterfaces of ExprNode in com.espertech.esper.epl.expression.time
 interface ExprTimePeriod
          Expression representing a time period.
 

Classes in com.espertech.esper.epl.expression.time that implement ExprNode
 class ExprTimePeriodImpl
          Expression representing a time period.
 class ExprTimestampNode
          Represents the CURRENT_TIMESTAMP() function or reserved keyword in an expression tree.
 

Methods in com.espertech.esper.epl.expression.time that return ExprNode
 ExprNode ExprTimestampNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTimePeriodImpl.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.expression.time with parameters of type ExprNode
 boolean ExprTimestampNode.equalsNode(ExprNode node)
           
 boolean ExprTimePeriodImpl.equalsNode(ExprNode node)
           
 

Uses of ExprNode in com.espertech.esper.epl.expression.visitor
 

Methods in com.espertech.esper.epl.expression.visitor that return types with arguments of type ExprNode
 java.util.List<ExprNode> ExprNodeViewResourceVisitor.getExprNodes()
          Returns the list of expression nodes requiring view resources.
 java.util.List<Pair<ExprNode,ExprIdentNode>> ExprNodeIdentifierCollectVisitorWContainer.getExprProperties()
          Returns list of event property stream numbers and names that uniquely identify which property is from whcih stream, and the name of each.
 java.util.List<Pair<ExprNode,ExprGroupingIdNode>> ExprNodeGroupingVisitorWParent.getGroupingIdNodes()
           
 java.util.List<Pair<ExprNode,ExprGroupingNode>> ExprNodeGroupingVisitorWParent.getGroupingNodes()
           
 java.util.List<Pair<ExprNode,ExprIdentNode>> ExprNodeIdentVisitorWParent.getIdentNodes()
           
 java.util.List<Pair<ExprNode,ExprPreviousNode>> ExprNodePreviousVisitorWParent.getPrevious()
          Returns the pair of previous nodes and their parent expression.
 

Methods in com.espertech.esper.epl.expression.visitor with parameters of type ExprNode
 boolean ExprNodeVisitorWithParent.isVisit(ExprNode exprNode)
          Allows visitor to indicate whether to visit a given node.
 boolean ExprNodeVisitor.isVisit(ExprNode exprNode)
          Allows visitor to indicate whether to visit a given node.
 boolean ExprNodeViewResourceVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeVariableVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeTableAccessFinderVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeSummaryVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeSubselectDeclaredNoTraverseVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeSubselectDeclaredDotVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeStreamUseCollectVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeStreamSelectVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodePreviousVisitorWParent.isVisit(ExprNode exprNode)
           
 boolean ExprNodeIdentVisitorWParent.isVisit(ExprNode exprNode)
           
 boolean ExprNodeIdentifierVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeIdentifierCollectVisitorWContainer.isVisit(ExprNode exprNode)
           
 boolean ExprNodeIdentifierCollectVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeIdentifierAndStreamRefVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeGroupingVisitorWParent.isVisit(ExprNode exprNode)
           
 boolean ExprNodeDeclaredVisitor.isVisit(ExprNode exprNode)
           
 boolean ExprNodeContextPropertiesVisitor.isVisit(ExprNode exprNode)
           
 void ExprNodeVisitor.visit(ExprNode exprNode)
          Visit the given expression node.
 void ExprNodeViewResourceVisitor.visit(ExprNode exprNode)
           
 void ExprNodeVariableVisitor.visit(ExprNode exprNode)
           
 void ExprNodeTableAccessFinderVisitor.visit(ExprNode exprNode)
           
 void ExprNodeSummaryVisitor.visit(ExprNode exprNode)
           
 void ExprNodeSubselectDeclaredDotVisitor.visit(ExprNode exprNode)
           
 void ExprNodeStreamUseCollectVisitor.visit(ExprNode exprNode)
           
 void ExprNodeStreamSelectVisitor.visit(ExprNode exprNode)
           
 void ExprNodeIdentifierVisitor.visit(ExprNode exprNode)
           
 void ExprNodeIdentifierCollectVisitor.visit(ExprNode exprNode)
           
 void ExprNodeIdentifierAndStreamRefVisitor.visit(ExprNode exprNode)
           
 void ExprNodeDeclaredVisitor.visit(ExprNode exprNode)
           
 void ExprNodeContextPropertiesVisitor.visit(ExprNode exprNode)
           
 void ExprNodeVisitorWithParent.visit(ExprNode exprNode, ExprNode parentExprNode)
          Visit the given expression node.
 void ExprNodeSubselectDeclaredNoTraverseVisitor.visit(ExprNode exprNode, ExprNode parentExprNode)
           
 void ExprNodePreviousVisitorWParent.visit(ExprNode exprNode, ExprNode parentExprNode)
           
 void ExprNodeIdentVisitorWParent.visit(ExprNode exprNode, ExprNode parentExprNode)
           
 void ExprNodeIdentifierCollectVisitorWContainer.visit(ExprNode exprNode, ExprNode containerExprNode)
           
 void ExprNodeGroupingVisitorWParent.visit(ExprNode exprNode, ExprNode parentExprNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.join.base
 

Methods in com.espertech.esper.epl.join.base with parameters of type ExprNode
static JoinSetComposerPrototype JoinSetComposerPrototypeFactory.makeComposerPrototype(java.lang.String statementName, java.lang.String statementId, OuterJoinDesc[] outerJoinDescList, ExprNode optionalFilterNode, EventType[] streamTypes, java.lang.String[] streamNames, StreamJoinAnalysisResult streamJoinAnalysisResult, boolean queryPlanLogging, StatementContext statementContext, HistoricalViewableDesc historicalViewableDesc, ExprEvaluatorContext exprEvaluatorContext, boolean selectsRemoveStream, boolean hasAggregations, TableService tableService, boolean isOnDemandQuery)
          Builds join tuple composer.
 

Constructors in com.espertech.esper.epl.join.base with parameters of type ExprNode
HistoricalIndexLookupStrategyInKeywordMulti(int lookupStream, ExprNode expression)
          Ctor.
HistoricalIndexLookupStrategyInKeywordSingle(int lookupStream, ExprNode[] expressions)
          Ctor.
JoinSetComposerPrototypeHistorical2StreamImpl(ExprNode optionalFilterNode, EventType[] streamTypes, ExprEvaluatorContext exprEvaluatorContext, int polledViewNum, int streamViewNum, boolean outerJoin, ExprNode outerJoinEqualsNode, Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> indexStrategies, boolean allHistoricalNoSubordinate, OuterJoinDesc[] outerJoinDescList)
           
JoinSetComposerPrototypeImpl(java.lang.String statementName, java.lang.String statementId, OuterJoinDesc[] outerJoinDescList, ExprNode optionalFilterNode, EventType[] streamTypes, java.lang.String[] streamNames, StreamJoinAnalysisResult streamJoinAnalysisResult, java.lang.annotation.Annotation[] annotations, HistoricalViewableDesc historicalViewableDesc, ExprEvaluatorContext exprEvaluatorContext, QueryPlanIndex[] indexSpecs, QueryPlan queryPlan, HistoricalStreamIndexList[] historicalStreamIndexLists, boolean joinRemoveStream, boolean isOuterJoins, TableService tableService)
           
 

Uses of ExprNode in com.espertech.esper.epl.join.exec.base
 

Constructors in com.espertech.esper.epl.join.exec.base with parameters of type ExprNode
IndexedTableLookupStrategySingleExpr(ExprNode exprNode, int streamNum, PropertyIndexedEventTableSingle index, LookupStrategyDesc strategyDesc)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.epl.join.hint
 

Methods in com.espertech.esper.epl.join.hint with parameters of type ExprNode
 boolean ExcludePlanHint.filter(int streamLookup, int streamIndexed, ExcludePlanFilterOperatorType opType, ExprNode... exprNodes)
           
static EventBean ExcludePlanHintExprUtil.toEvent(int from_streamnum, int to_streamnum, java.lang.String from_streamname, java.lang.String to_streamname, java.lang.String opname, ExprNode[] expressions)
           
 

Uses of ExprNode in com.espertech.esper.epl.join.plan
 

Methods in com.espertech.esper.epl.join.plan that return ExprNode
 ExprNode QueryGraphValueEntryRangeIn.getExprEnd()
           
 ExprNode QueryGraphValueEntryRangeRelOp.getExpression()
           
 ExprNode[] QueryGraphValueEntryRangeRelOp.getExpressions()
           
 ExprNode[] QueryGraphValueEntryRangeIn.getExpressions()
           
abstract  ExprNode[] QueryGraphValueEntryRange.getExpressions()
           
 ExprNode[] InKeywordTableLookupPlanSingleIdx.getExpressions()
           
 ExprNode QueryGraphValueEntryRangeIn.getExprStart()
           
 ExprNode[] QueryGraphValuePairInKWMultiIdx.getIndexed()
           
 ExprNode[] QueryGraphValueDesc.getIndexExprs()
           
 ExprNode QueryGraphValueEntryInKeywordMultiIdx.getKeyExpr()
           
 ExprNode QueryGraphValueEntryHashKeyed.getKeyExpr()
           
 ExprNode InKeywordTableLookupPlanMultiIdx.getKeyExpr()
           
 ExprNode[] QueryGraphValueEntryInKeywordSingleIdx.getKeyExprs()
           
 

Methods in com.espertech.esper.epl.join.plan with parameters of type ExprNode
 void QueryGraphValue.addInKeywordMultiIdx(ExprNode testPropExpr, ExprNode[] setProps)
           
 void QueryGraphValue.addInKeywordMultiIdx(ExprNode testPropExpr, ExprNode[] setProps)
           
 void QueryGraphValue.addInKeywordSingleIdx(ExprNode testPropIdent, ExprNode[] setPropExpr)
           
 void QueryGraphValue.addInKeywordSingleIdx(ExprNode testPropIdent, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetMultiIndex(int testStreamNum, ExprNode testPropExpr, int setStreamNum, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetMultiIndex(int testStreamNum, ExprNode testPropExpr, int setStreamNum, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetMultiIndexUnkeyed(ExprNode testPropExpr, int setStreamNum, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetMultiIndexUnkeyed(ExprNode testPropExpr, int setStreamNum, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetSingleIndex(int testStreamNum, ExprNode testPropExpr, int setStreamNum, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetSingleIndex(int testStreamNum, ExprNode testPropExpr, int setStreamNum, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetSingleIndexUnkeyed(int testStreamNum, ExprNode testPropExpr, ExprNode[] setPropExpr)
           
 void QueryGraph.addInSetSingleIndexUnkeyed(int testStreamNum, ExprNode testPropExpr, ExprNode[] setPropExpr)
           
 void QueryGraphValue.addKeyedExpr(ExprIdentNode indexedPropIdent, ExprNode exprNodeNoIdent)
           
 void QueryGraph.addKeyedExpression(int indexedStream, ExprIdentNode indexedProp, int keyExprStream, ExprNode exprNodeNoIdent)
           
 void QueryGraphValue.addRange(QueryGraphRangeEnum rangeType, ExprNode propertyStart, ExprNode propertyEnd, ExprIdentNode propertyValueIdent)
           
 void QueryGraph.addRangeExpr(int indexedStream, ExprIdentNode indexedProp, ExprNode startNode, java.lang.Integer optionalStartStreamNum, ExprNode endNode, java.lang.Integer optionalEndStreamNum)
           
 void QueryGraph.addRelationalOp(int indexedStream, ExprIdentNode indexedProp, java.lang.Integer keyStreamNum, ExprNode exprNodeNoIdent, RelationalOpEnum relationalOpEnum)
           
 void QueryGraphValue.addRelOp(ExprNode propertyKey, QueryGraphRangeEnum op, ExprIdentNode propertyValueIdent, boolean isBetweenOrIn)
           
 void QueryGraphValue.addUnkeyedExpr(ExprIdentNode indexedPropIdent, ExprNode exprNodeNoIdent)
           
 void QueryGraph.addUnkeyedExpression(int indexedStream, ExprIdentNode indexedProp, ExprNode exprNodeNoIdent)
           
static void FilterExprAnalyzer.analyze(ExprNode topNode, QueryGraph queryGraph, boolean isOuterJoin)
          Analyzes filter expression to build query graph model.
static java.lang.Class CoercionUtil.getCoercionTypeRangeIn(java.lang.Class valuePropType, ExprNode exprStart, ExprNode exprEnd)
           
static SubordPropPlan QueryPlanIndexBuilder.getJoinProps(ExprNode filterExpr, int outsideStreamCount, EventType[] allStreamTypesZeroIndexed, ExcludePlanHint excludePlanHint)
           
 

Constructors in com.espertech.esper.epl.join.plan with parameters of type ExprNode
HistoricalDataPlanNode(int streamNum, int rootStreamNum, int lookupStreamNum, int numStreams, ExprNode exprNode)
          Ctor.
InKeywordTableLookupPlanMultiIdx(int lookupStream, int indexedStream, TableLookupIndexReqKey[] indexNum, ExprNode keyExpr)
          Ctor.
InKeywordTableLookupPlanSingleIdx(int lookupStream, int indexedStream, TableLookupIndexReqKey indexNum, ExprNode[] expressions)
          Ctor.
QueryGraphValueDesc(ExprNode[] indexExprs, QueryGraphValueEntry entry)
           
QueryGraphValueEntryHashKeyed(ExprNode keyExpr)
           
QueryGraphValueEntryHashKeyedExpr(ExprNode keyExpr, boolean requiresKey)
           
QueryGraphValueEntryHashKeyedProp(ExprNode keyExpr, java.lang.String keyProperty)
           
QueryGraphValueEntryInKeywordMultiIdx(ExprNode keyExpr)
           
QueryGraphValueEntryInKeywordSingleIdx(ExprNode[] keyExprs)
           
QueryGraphValueEntryRangeIn(QueryGraphRangeEnum rangeType, ExprNode exprStart, ExprNode exprEnd, boolean allowRangeReversal)
           
QueryGraphValueEntryRangeRelOp(QueryGraphRangeEnum type, ExprNode expression, boolean isBetweenPart)
           
QueryGraphValuePairInKWMultiIdx(ExprNode[] indexed, QueryGraphValueEntryInKeywordMultiIdx key)
           
 

Uses of ExprNode in com.espertech.esper.epl.join.util
 

Methods in com.espertech.esper.epl.join.util with parameters of type ExprNode
static void RangeFilterAnalyzer.apply(ExprNode target, ExprNode start, ExprNode end, boolean includeStart, boolean includeEnd, boolean isNot, QueryGraph queryGraph)
           
static EligibilityDesc EligibilityUtil.verifyInputStream(ExprNode expression, int indexedStream)
           
 

Uses of ExprNode in com.espertech.esper.epl.lookup
 

Methods in com.espertech.esper.epl.lookup that return ExprNode
 ExprNode SubordPropInKeywordMultiIndex.getExpression()
           
 ExprNode[] SubordPropInKeywordSingleIndex.getExpressions()
           
 

Methods in com.espertech.esper.epl.lookup with parameters of type ExprNode
static SubordTableLookupStrategyFactory SubordinateTableLookupStrategyUtil.getLookupStrategy(EventType[] outerStreamTypesZeroIndexed, java.util.List<SubordPropHashKey> hashKeys, CoercionDesc hashKeyCoercionTypes, java.util.List<SubordPropRangeKey> rangeKeys, CoercionDesc rangeKeyCoercionTypes, ExprNode[] inKeywordSingleIdxKeys, ExprNode inKeywordMultiIdxKey, boolean isNWOnTrigger)
           
static SubordTableLookupStrategyFactory SubordinateTableLookupStrategyUtil.getLookupStrategy(EventType[] outerStreamTypesZeroIndexed, java.util.List<SubordPropHashKey> hashKeys, CoercionDesc hashKeyCoercionTypes, java.util.List<SubordPropRangeKey> rangeKeys, CoercionDesc rangeKeyCoercionTypes, ExprNode[] inKeywordSingleIdxKeys, ExprNode inKeywordMultiIdxKey, boolean isNWOnTrigger)
           
static SubordinateWMatchExprQueryPlanResult SubordinateQueryPlanner.planOnExpression(ExprNode joinExpr, EventType filterEventType, IndexHint optionalIndexHint, boolean isIndexShare, int subqueryNumber, ExcludePlanHint excludePlanHint, boolean isVirtualDataWindow, EventTableIndexMetadata indexMetadata, EventType eventTypeIndexed, java.util.Set<java.lang.String> optionalUniqueKeyProps, boolean onlyUseExistingIndexes, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
           
 

Constructors in com.espertech.esper.epl.lookup with parameters of type ExprNode
SubordInKeywordMultiTableLookupStrategyFactory(boolean isNWOnTrigger, int streamCountOuter, ExprNode exprNode)
           
SubordInKeywordSingleTableLookupStrategyFactory(boolean isNWOnTrigger, int streamCountOuter, ExprNode[] exprNodes)
           
SubordPropInKeywordMultiIndex(java.lang.String[] indexedProp, java.lang.Class coercionType, ExprNode expression)
           
SubordPropInKeywordSingleIndex(java.lang.String indexedProp, java.lang.Class coercionType, ExprNode[] expressions)
           
 

Uses of ExprNode in com.espertech.esper.epl.methodbase
 

Methods in com.espertech.esper.epl.methodbase that return ExprNode
 ExprNode DotMethodFPProvidedParam.getExpression()
           
 

Methods in com.espertech.esper.epl.methodbase with parameters of type ExprNode
static void DotMethodUtil.validateSpecificType(java.lang.String methodUsedName, DotMethodTypeEnum type, DotMethodFPParamTypeEnum expectedTypeEnum, java.lang.Class expectedTypeClass, java.lang.Class providedType, int parameterNum, ExprNode parameterExpression)
           
 

Method parameters in com.espertech.esper.epl.methodbase with type arguments of type ExprNode
static DotMethodFPProvided DotMethodUtil.getProvidedFootprint(java.util.List<ExprNode> parameters)
           
 

Constructors in com.espertech.esper.epl.methodbase with parameters of type ExprNode
DotMethodFPProvidedParam(int lambdaParamNum, java.lang.Class returnType, ExprNode expression)
           
 

Uses of ExprNode in com.espertech.esper.epl.named
 

Methods in com.espertech.esper.epl.named that return types with arguments of type ExprNode
 java.util.List<ExprNode> NamedWindowConsumerDesc.getFilterList()
           
 

Methods in com.espertech.esper.epl.named with parameters of type ExprNode
 EventBean[] NamedWindowTailViewInstance.snapshotDelete(FilterSpecCompiled filter, ExprNode filterExpr, java.lang.annotation.Annotation[] annotations)
           
 java.util.Collection<EventBean> NamedWindowTailViewInstance.snapshotNoLockWithFilter(FilterSpecCompiled filter, java.lang.annotation.Annotation[] annotations, ExprNode filterExpr, ExprEvaluatorContext exprEvaluatorContext)
           
 EventBean[] NamedWindowTailViewInstance.snapshotUpdate(FilterSpecCompiled filter, ExprNode optionalWhereClause, EventBeanUpdateHelper updateHelper, java.lang.annotation.Annotation[] annotations)
           
 

Constructors in com.espertech.esper.epl.named with parameters of type ExprNode
NamedWindowOnMergeMatch(ExprNode optionalCond, java.util.List<NamedWindowOnMergeAction> actions)
           
 

Constructor parameters in com.espertech.esper.epl.named with type arguments of type ExprNode
NamedWindowConsumerDesc(java.util.List<ExprNode> filterList, PropertyEvaluator optPropertyEvaluator, AgentInstanceContext agentInstanceContext)
           
 

Uses of ExprNode in com.espertech.esper.epl.parse
 

Methods in com.espertech.esper.epl.parse that return ExprNode
static ExprNode[] ASTExprHelper.exprCollectSubNodesPerNode(java.util.List<EsperEPL2GrammarParser.ExpressionContext> expression, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static ExprNode ASTExprHelper.mathGetExpr(org.antlr.v4.runtime.tree.ParseTree ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, ConfigurationInformation configurationInformation)
           
static ExprNode ASTExprHelper.resolvePropertyOrVariableIdentifier(java.lang.String identifier, VariableService variableService, StatementSpecRaw spec)
           
static ExprNode ASTAggregationHelper.tryResolveAsAggregation(EngineImportService engineImportService, boolean distinct, java.lang.String functionName, LazyAllocatedMap<ConfigurationPlugInAggregationMultiFunction,PlugInAggregationMultiFunctionFactory> plugInAggregations, java.lang.String engineURI)
           
 

Methods in com.espertech.esper.epl.parse that return types with arguments of type ExprNode
static java.util.List<ExprNode> ASTExprHelper.exprCollectSubNodes(org.antlr.v4.runtime.tree.Tree parentNode, int startIndex, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static java.util.List<ExprNode> ASTLibFunctionHelper.getExprNodesLibFunc(EsperEPL2GrammarParser.LibFunctionArgsContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
 

Methods in com.espertech.esper.epl.parse with parameters of type ExprNode
static void ASTExprHelper.addOptionalNumber(ExprNode exprNode, EsperEPL2GrammarParser.NumberContext number)
           
static void ASTExprHelper.addOptionalSimpleProperty(ExprNode exprNode, org.antlr.v4.runtime.Token token, VariableService variableService, StatementSpecRaw spec)
           
static void ASTExprHelper.exprCollectAddSingle(ExprNode parentNode, org.antlr.v4.runtime.tree.Tree node, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTExprHelper.exprCollectAddSubNodes(ExprNode parentNode, org.antlr.v4.runtime.tree.Tree node, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTExprHelper.exprCollectAddSubNodesAddParentNode(ExprNode exprNode, org.antlr.v4.runtime.tree.Tree node, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTExprHelper.exprCollectAddSubNodesExpressionCtx(ExprNode parentNode, java.util.List<EsperEPL2GrammarParser.ExpressionContext> expressionContexts, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static boolean ASTMatchUntilHelper.validate(ExprNode lowerBounds, ExprNode upperBounds, boolean isAllowLowerZero)
          Validate.
 

Method parameters in com.espertech.esper.epl.parse with type arguments of type ExprNode
static OutputLimitSpec ASTOutputLimitHelper.buildOutputLimitSpec(org.antlr.v4.runtime.CommonTokenStream tokenStream, EsperEPL2GrammarParser.OutputLimitContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, VariableService variableService, java.lang.String engineURI, TimeProvider timeProvider, ExprEvaluatorContext exprEvaluatorContext)
          Build an output limit spec from the AST node supplied.
static void ASTExprHelper.exprCollectAddSingle(ExprNode parentNode, org.antlr.v4.runtime.tree.Tree node, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTExprHelper.exprCollectAddSubNodes(ExprNode parentNode, org.antlr.v4.runtime.tree.Tree node, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTExprHelper.exprCollectAddSubNodesAddParentNode(ExprNode exprNode, org.antlr.v4.runtime.tree.Tree node, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTExprHelper.exprCollectAddSubNodesExpressionCtx(ExprNode parentNode, java.util.List<EsperEPL2GrammarParser.ExpressionContext> expressionContexts, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static java.util.List<ExprNode> ASTExprHelper.exprCollectSubNodes(org.antlr.v4.runtime.tree.Tree parentNode, int startIndex, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static ExprNode[] ASTExprHelper.exprCollectSubNodesPerNode(java.util.List<EsperEPL2GrammarParser.ExpressionContext> expression, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static java.util.List<CreateTableColumn> ASTTableHelper.getColumns(java.util.List<EsperEPL2GrammarParser.CreateTableColumnContext> ctxs, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, EngineImportService engineImportService)
           
static java.util.List<ExprNode> ASTLibFunctionHelper.getExprNodesLibFunc(EsperEPL2GrammarParser.LibFunctionArgsContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static java.util.List<ExprChainedSpec> ASTLibFunctionHelper.getLibFuncChain(java.util.List<EsperEPL2GrammarParser.LibFunctionNoClassContext> ctxs, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static ExprChainedSpec ASTLibFunctionHelper.getLibFunctionChainSpec(EsperEPL2GrammarParser.LibFunctionNoClassContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
protected static java.util.List<OnTriggerSetAssignment> ASTExprHelper.getOnTriggerSetAssignments(EsperEPL2GrammarParser.OnSetAssignmentListContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
          Returns the list of set-variable assignments under the given node.
static void ASTLibFunctionHelper.handleLibFunc(org.antlr.v4.runtime.CommonTokenStream tokenStream, EsperEPL2GrammarParser.LibFunctionContext ctx, ConfigurationInformation configurationInformation, EngineImportService engineImportService, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, LazyAllocatedMap<ConfigurationPlugInAggregationMultiFunction,PlugInAggregationMultiFunctionFactory> plugInAggregations, java.lang.String engineURI, ExpressionDeclDesc expressionDeclarations, ExprDeclaredService exprDeclaredService, java.util.List<ExpressionScriptProvided> scriptExpressions, ContextDescriptor contextDescriptor, TableService tableService, StatementSpecRaw statementSpec)
           
static ExprNode ASTExprHelper.mathGetExpr(org.antlr.v4.runtime.tree.ParseTree ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, ConfigurationInformation configurationInformation)
           
static ExprTimePeriod ASTExprHelper.timePeriodGetExprAllParams(EsperEPL2GrammarParser.TimePeriodContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, VariableService variableService, StatementSpecRaw spec)
           
static ExprTimePeriod ASTExprHelper.timePeriodGetExprJustSeconds(EsperEPL2GrammarParser.ExpressionContext expression, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static CreateContextDesc ASTContextHelper.walkCreateContext(EsperEPL2GrammarParser.CreateContextExprContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, java.util.Map<org.antlr.v4.runtime.tree.Tree,EvalFactoryNode> astPatternNodeMap, PropertyEvalSpec propertyEvalSpec, FilterSpecRaw filterSpec)
           
static Pair<ExpressionDeclItem,ExpressionScriptProvided> ASTExpressionDeclHelper.walkExpressionDecl(EsperEPL2GrammarParser.ExpressionDeclContext ctx, java.util.List<java.lang.String> scriptBodies, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, org.antlr.v4.runtime.CommonTokenStream tokenStream)
           
static FilterSpecRaw ASTFilterSpecHelper.walkFilterSpec(EsperEPL2GrammarParser.EventFilterExpressionContext ctx, PropertyEvalSpec propertyEvalSpec, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
static void ASTGroupByHelper.walkGroupBy(EsperEPL2GrammarParser.GroupByListExprContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, java.util.List<GroupByClauseElement> groupByExpressions)
           
static RowRegexExprRepeatDesc ASTMatchRecognizeHelper.walkOptionalRepeat(EsperEPL2GrammarParser.MatchRecogPatternRepeatContext ctx, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap)
           
 

Uses of ExprNode in com.espertech.esper.epl.rettype
 

Methods in com.espertech.esper.epl.rettype with parameters of type ExprNode
static EPType EPTypeHelper.optionalFromEnumerationExpr(java.lang.String statementId, EventAdapterService eventAdapterService, ExprNode exprNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.script
 

Classes in com.espertech.esper.epl.script that implement ExprNode
 class ExprNodeScript
           
 

Methods in com.espertech.esper.epl.script that return ExprNode
 ExprNode ExprNodeScript.validate(ExprValidationContext validationContext)
           
 

Methods in com.espertech.esper.epl.script that return types with arguments of type ExprNode
 java.util.List<ExprNode> ExprNodeScript.getAdditionalNodes()
           
 java.util.List<ExprNode> ExprNodeScript.getParameters()
           
 

Methods in com.espertech.esper.epl.script with parameters of type ExprNode
 boolean ExprNodeScript.equalsNode(ExprNode node)
           
 

Constructor parameters in com.espertech.esper.epl.script with type arguments of type ExprNode
ExprNodeScript(java.lang.String defaultDialect, ExpressionScriptProvided script, java.util.List<ExprNode> parameters)
           
 

Uses of ExprNode in com.espertech.esper.epl.spec
 

Methods in com.espertech.esper.epl.spec that return ExprNode
 ExprNode OutputLimitSpec.getAndAfterTerminateExpr()
           
 ExprNode CreateVariableDesc.getAssignment()
          Returns the assignment expression, or null if none
 ExprNode[] ContextDetailInitiatedTerminated.getDistinctExpressions()
           
 ExprNode MatchRecognizeMeasureItem.getExpr()
          Returns the expression.
 ExprNode GroupByClauseElementExpr.getExpr()
           
 ExprNode OnTriggerSetAssignment.getExpression()
          Returns the expression providing the new variable value, or null if none
 ExprNode MatchRecognizeDefineItem.getExpression()
          Returns the expression.
 ExprNode ContextDetailCategoryItem.getExpression()
           
 ExprNode OrderByItem.getExprNode()
          Returns the order-by expression node.
 ExprNode StatementSpecRaw.getFilterExprRootNode()
          Gets the where clause.
 ExprNode StatementSpecRaw.getFilterRootNode()
          Returns the WHERE-clause root node of filter expression.
 ExprNode StatementSpecCompiled.getFilterRootNode()
          Returns the WHERE-clause root node of filter expression.
 ExprNode[] GroupByClauseExpressions.getGroupByNodes()
           
 ExprNode StatementSpecRaw.getHavingExprRootNode()
          Returns expression root node representing the having-clause, if present, or null if no having clause was supplied.
 ExprNode StatementSpecCompiled.getHavingExprRootNode()
          Returns expression root node representing the having-clause, if present, or null if no having clause was supplied.
 ExprNode ExpressionDeclItem.getInner()
           
 ExprNode CreateWindowDesc.getInsertFilter()
          Returns the expression to filter insert-from events, or null if none supplied.
 ExprNode NewItem.getOptExpression()
           
 ExprNode CreateTableColumn.getOptExpression()
           
 ExprNode[] GroupByClauseExpressions.getOptHavingNodePerLevel()
           
 ExprNode OnTriggerMergeMatched.getOptionalMatchCond()
           
 ExprNode OnTriggerMergeEntry.getOptionalMatchCond()
           
 ExprNode UpdateDesc.getOptionalWhereClause()
          Returns the where-clause if defined.
 ExprNode PropertyEvalAtom.getOptionalWhereClause()
          Returns the where clause, if specified.
 ExprNode OnTriggerMergeAction.getOptionalWhereClause()
           
 ExprNode[][] GroupByClauseExpressions.getOptOrderByPerLevel()
           
 ExprNode[][] GroupByClauseExpressions.getSelectClausePerLevel()
           
 ExprNode SelectClauseExprRawSpec.getSelectExpression()
          Returns the expression node representing the item in the select clause.
 ExprNode SelectClauseExprCompiledSpec.getSelectExpression()
          Returns the expression node representing the item in the select clause.
 ExprNode PropertyEvalAtom.getSplitterExpression()
           
 ExprNode OutputLimitSpec.getWhenExpressionNode()
          Returns the when-keyword trigger expression, or null if not using when.
 ExprNode OnTriggerSplitStream.getWhereClause()
          Returns the where clause or null if not defined
 ExprNode OuterJoinDesc.makeExprNode(ExprEvaluatorContext exprEvaluatorContext)
          Make an expression node that represents the outer join criteria as specified in the on-clause.
 

Methods in com.espertech.esper.epl.spec that return types with arguments of type ExprNode
 java.util.List<ExprNode> ContextDetailConditionCrontab.getCrontab()
           
 java.util.List<ExprNode> OutputLimitSpec.getCrontabAtSchedule()
          Returns crontab parameters, or null if not using crontab-at output.
 java.util.List<ExprNode> MethodStreamSpec.getExpressions()
          Returns the parameter expressions.
 java.util.List<ExprNode> GroupByClauseElementCombinedExpr.getExpressions()
           
 java.util.List<ExprNode> ForClauseItemSpec.getExpressions()
           
 java.util.List<ExprNode> TableQueryStreamSpec.getFilterExpressions()
           
 java.util.List<ExprNode> NamedWindowConsumerStreamSpec.getFilterExpressions()
          Returns list of filter expressions onto the named window, or no filter expressions if none defined.
 java.util.List<ExprNode> FilterSpecRaw.getFilterExpressions()
          Returns the list of filter expressions.
 java.util.List<ExprNode> ObjectSpec.getObjectParameters()
          Returns the list of object parameters.
 java.util.List<ExprNode> MatchRecognizeSpec.getPartitionByExpressions()
          Returns partition expressions.
 java.util.Map<java.lang.Integer,java.util.List<ExprNode>> StatementSpecRaw.getSqlParameters()
           
 java.util.Map<java.lang.Integer,java.util.List<ExprNode>> StatementSpecCompiled.getSqlParameters()
           
 

Methods in com.espertech.esper.epl.spec with parameters of type ExprNode
 void OutputLimitSpec.setAndAfterTerminateExpr(ExprNode andAfterTerminateExpr)
           
 void MatchRecognizeMeasureItem.setExpr(ExprNode validated)
          Sets the validated expression.
 void OnTriggerSetAssignment.setExpression(ExprNode expression)
          Sets the expression providing the new variable value
 void MatchRecognizeDefineItem.setExpression(ExprNode validated)
          Sets the validated expression
 void StatementSpecRaw.setFilterExprRootNode(ExprNode filterExprRootNode)
          Sets the where clause or null if none
 void StatementSpecCompiled.setFilterExprRootNode(ExprNode optionalFilterNode)
          Set the where clause filter node.
 void StatementSpecRaw.setHavingExprRootNode(ExprNode havingExprRootNode)
          Sets the having-clause filter expression node.
 void CreateWindowDesc.setInsertFilter(ExprNode insertFilter)
          Sets the filter expression to use to apply
 void OnTriggerMergeMatched.setOptionalMatchCond(ExprNode optionalMatchCond)
           
 void OnTriggerMergeEntry.setOptionalMatchCond(ExprNode optionalMatchCond)
           
 void UpdateDesc.setOptionalWhereClause(ExprNode optionalWhereClause)
          Sets the where-clause if defined.
 void OnTriggerMergeAction.setOptionalWhereClause(ExprNode optionalWhereClause)
           
 void SelectClauseExprCompiledSpec.setSelectExpression(ExprNode selectExpression)
          Sets the select expression to use.
 void OutputLimitSpec.setWhenExpressionNode(ExprNode whenExpressionNode)
          Sets a new when-keyword trigger expression.
static Expression StatementSpecMapper.unmap(ExprNode expression)
          Unmap expresission.
 

Method parameters in com.espertech.esper.epl.spec with type arguments of type ExprNode
 void ForClauseItemSpec.setExpressions(java.util.List<ExprNode> expressions)
           
 void MatchRecognizeSpec.setPartitionByExpressions(java.util.List<ExprNode> partitionByExpressions)
          Returns partition expressions.
 void StatementSpecRaw.setSqlParameters(java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters)
           
 

Constructors in com.espertech.esper.epl.spec with parameters of type ExprNode
ContextDetailCategoryItem(ExprNode expression, java.lang.String name)
           
ContextDetailInitiatedTerminated(ContextDetailCondition start, ContextDetailCondition end, boolean overlapping, ExprNode[] distinctExpressions)
           
CreateTableColumn(java.lang.String columnName, ExprNode optExpression, java.lang.String optTypeName, java.lang.Boolean optTypeIsArray, java.lang.Boolean optTypeIsPrimitiveArray, java.util.List<AnnotationDesc> annotations, java.lang.Boolean primaryKey)
           
CreateVariableDesc(java.lang.String variableType, java.lang.String variableName, ExprNode assignment, boolean constant, boolean array, boolean arrayOfPrimitive)
          Ctor.
CreateWindowDesc(java.lang.String windowName, java.util.List<ViewSpec> viewSpecs, StreamSpecOptions streamSpecOptions, boolean insert, ExprNode insertFilter, java.util.List<ColumnDesc> columns, java.lang.String asEventTypeName)
          Ctor.
ExpressionDeclItem(java.lang.String name, java.util.List<java.lang.String> parametersNames, ExprNode inner, boolean alias)
           
GroupByClauseElementExpr(ExprNode expr)
           
GroupByClauseExpressions(ExprNode[] groupByNodes)
           
GroupByClauseExpressions(ExprNode[] groupByNodes, int[][] groupByRollupLevels, ExprNode[][] selectClauseCopy, ExprNode[] optHavingNodeCopy, ExprNode[][] optOrderByPerLevel)
           
GroupByClauseExpressions(ExprNode[] groupByNodes, int[][] groupByRollupLevels, ExprNode[][] selectClauseCopy, ExprNode[] optHavingNodeCopy, ExprNode[][] optOrderByPerLevel)
           
GroupByClauseExpressions(ExprNode[] groupByNodes, int[][] groupByRollupLevels, ExprNode[][] selectClauseCopy, ExprNode[] optHavingNodeCopy, ExprNode[][] optOrderByPerLevel)
           
GroupByClauseExpressions(ExprNode[] groupByNodes, int[][] groupByRollupLevels, ExprNode[][] selectClauseCopy, ExprNode[] optHavingNodeCopy, ExprNode[][] optOrderByPerLevel)
           
MatchRecognizeDefineItem(java.lang.String identifier, ExprNode expression)
          Ctor.
MatchRecognizeMeasureItem(ExprNode expr, java.lang.String name)
          Ctor.
NewItem(java.lang.String name, ExprNode optExpression)
           
OnTriggerMergeAction(ExprNode optionalWhereClause)
           
OnTriggerMergeActionDelete(ExprNode optionalMatchCond)
           
OnTriggerMergeActionInsert(ExprNode optionalWhereClause, java.lang.String optionalStreamName, java.util.List<java.lang.String> columns, java.util.List<SelectClauseElementRaw> selectClause)
           
OnTriggerMergeActionUpdate(ExprNode optionalMatchCond, java.util.List<OnTriggerSetAssignment> assignments)
           
OnTriggerMergeEntry(ExprNode optionalMatchCond)
           
OnTriggerMergeMatched(boolean matchedUnmatched, ExprNode optionalMatchCond, java.util.List<OnTriggerMergeAction> actions)
           
OnTriggerSetAssignment(ExprNode expression)
          Ctor.
OnTriggerSplitStream(InsertIntoDesc insertInto, SelectClauseSpecRaw selectClause, ExprNode whereClause)
          Ctor.
OrderByItem(ExprNode exprNode, boolean ascending)
          Ctor.
OutputLimitSpec(java.lang.Double rate, java.lang.String variableForRate, OutputLimitRateType rateType, OutputLimitLimitType displayLimit, ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> thenExpressions, java.util.List<ExprNode> crontabAtSchedule, ExprTimePeriod timePeriodExpr, ExprTimePeriod afterTimePeriodExpr, java.lang.Integer afterNumberOfEvents, boolean andAfterTerminate, ExprNode andAfterTerminateExpr, java.util.List<OnTriggerSetAssignment> andAfterTerminateSetExpressions)
          Ctor.
PropertyEvalAtom(ExprNode splitterExpression, java.lang.String optionalResultEventType, java.lang.String optionalAsName, SelectClauseSpecRaw optionalSelectClause, ExprNode optionalWhereClause)
          Ctor.
SelectClauseExprCompiledSpec(ExprNode selectExpression, java.lang.String assignedName, java.lang.String providedName, boolean isEvents)
          Ctor.
SelectClauseExprRawSpec(ExprNode selectExpression, java.lang.String optionalAsName, boolean isEvents)
          Ctor.
StatementSpecCompiled(OnTriggerDesc onTriggerDesc, CreateWindowDesc createWindowDesc, CreateIndexDesc createIndexDesc, CreateVariableDesc createVariableDesc, CreateTableDesc createTableDesc, CreateSchemaDesc createSchemaDesc, InsertIntoDesc insertIntoDesc, SelectClauseStreamSelectorEnum selectClauseStreamSelectorEnum, SelectClauseSpecCompiled selectClauseSpec, StreamSpecCompiled[] streamSpecs, OuterJoinDesc[] outerJoinDescList, ExprNode filterExprRootNode, ExprNode havingExprRootNode, OutputLimitSpec outputLimitSpec, OrderByItem[] orderByList, ExprSubselectNode[] subSelectExpressions, ExprDeclaredNode[] declaredExpressions, java.util.Set<java.lang.String> variableReferences, RowLimitSpec rowLimitSpec, java.lang.String[] eventTypeReferences, java.lang.annotation.Annotation[] annotations, UpdateDesc updateSpec, MatchRecognizeSpec matchRecognizeSpec, ForClauseSpec forClauseSpec, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, CreateContextDesc contextDesc, java.lang.String optionalContextName, CreateDataFlowDesc createGraphDesc, CreateExpressionDesc createExpressionDesc, FireAndForgetSpec fireAndForgetSpec, GroupByClauseExpressions groupByExpressions, IntoTableSpec intoTableSpec, ExprTableAccessNode[] tableNodes)
          Ctor.
UpdateDesc(java.lang.String optionalStreamName, java.util.List<OnTriggerSetAssignment> assignments, ExprNode optionalWhereClause)
          Ctor.
 

Constructor parameters in com.espertech.esper.epl.spec with type arguments of type ExprNode
ContextDetailConditionCrontab(java.util.List<ExprNode> crontab, boolean immediate)
           
FilterSpecRaw(java.lang.String eventTypeName, java.util.List<ExprNode> filterExpressions, PropertyEvalSpec optionalPropertyEvalSpec)
          Ctor.
ForClauseItemSpec(java.lang.String keyword, java.util.List<ExprNode> expressions)
           
GroupByClauseElementCombinedExpr(java.util.List<ExprNode> expressions)
           
MethodStreamSpec(java.lang.String optionalStreamName, ViewSpec[] viewSpecs, java.lang.String ident, java.lang.String className, java.lang.String methodName, java.util.List<ExprNode> expressions)
          Ctor.
NamedWindowConsumerStreamSpec(java.lang.String windowName, java.lang.String optionalAsName, ViewSpec[] viewSpecs, java.util.List<ExprNode> filterExpressions, StreamSpecOptions streamSpecOptions, PropertyEvaluator optPropertyEvaluator)
          Ctor.
ObjectSpec(java.lang.String namespace, java.lang.String objectName, java.util.List<ExprNode> objectParameters)
          Constructor.
OutputLimitSpec(java.lang.Double rate, java.lang.String variableForRate, OutputLimitRateType rateType, OutputLimitLimitType displayLimit, ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> thenExpressions, java.util.List<ExprNode> crontabAtSchedule, ExprTimePeriod timePeriodExpr, ExprTimePeriod afterTimePeriodExpr, java.lang.Integer afterNumberOfEvents, boolean andAfterTerminate, ExprNode andAfterTerminateExpr, java.util.List<OnTriggerSetAssignment> andAfterTerminateSetExpressions)
          Ctor.
PatternGuardSpec(java.lang.String namespace, java.lang.String objectName, java.util.List<ExprNode> objectParameters)
          Constructor.
PatternObserverSpec(java.lang.String namespace, java.lang.String objectName, java.util.List<ExprNode> objectParameters)
          Constructor.
StatementSpecCompiled(OnTriggerDesc onTriggerDesc, CreateWindowDesc createWindowDesc, CreateIndexDesc createIndexDesc, CreateVariableDesc createVariableDesc, CreateTableDesc createTableDesc, CreateSchemaDesc createSchemaDesc, InsertIntoDesc insertIntoDesc, SelectClauseStreamSelectorEnum selectClauseStreamSelectorEnum, SelectClauseSpecCompiled selectClauseSpec, StreamSpecCompiled[] streamSpecs, OuterJoinDesc[] outerJoinDescList, ExprNode filterExprRootNode, ExprNode havingExprRootNode, OutputLimitSpec outputLimitSpec, OrderByItem[] orderByList, ExprSubselectNode[] subSelectExpressions, ExprDeclaredNode[] declaredExpressions, java.util.Set<java.lang.String> variableReferences, RowLimitSpec rowLimitSpec, java.lang.String[] eventTypeReferences, java.lang.annotation.Annotation[] annotations, UpdateDesc updateSpec, MatchRecognizeSpec matchRecognizeSpec, ForClauseSpec forClauseSpec, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, CreateContextDesc contextDesc, java.lang.String optionalContextName, CreateDataFlowDesc createGraphDesc, CreateExpressionDesc createExpressionDesc, FireAndForgetSpec fireAndForgetSpec, GroupByClauseExpressions groupByExpressions, IntoTableSpec intoTableSpec, ExprTableAccessNode[] tableNodes)
          Ctor.
TableQueryStreamSpec(java.lang.String optionalStreamName, ViewSpec[] viewSpecs, StreamSpecOptions streamSpecOptions, java.lang.String tableName, java.util.List<ExprNode> filterExpressions)
           
ViewSpec(java.lang.String namespace, java.lang.String objectName, java.util.List<ExprNode> viewParameters)
          Constructor.
 

Uses of ExprNode in com.espertech.esper.epl.spec.util
 

Methods in com.espertech.esper.epl.spec.util that return types with arguments of type ExprNode
static java.util.List<ExprNode> StatementSpecRawAnalyzer.collectExpressionsShallow(StatementSpecRaw raw)
           
 

Uses of ExprNode in com.espertech.esper.epl.subquery
 

Constructors in com.espertech.esper.epl.subquery with parameters of type ExprNode
SubselectAggregatorViewFilteredGrouped(AggregationService aggregationService, ExprEvaluator optionalFilterExpr, ExprEvaluatorContext exprEvaluatorContext, ExprEvaluator[] groupKeys, ExprNode filterExprNode)
           
SubselectAggregatorViewFilteredUngrouped(AggregationService aggregationService, ExprEvaluator optionalFilterExpr, ExprEvaluatorContext exprEvaluatorContext, ExprEvaluator[] groupKeys, ExprNode filterExprNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.table.merge
 

Constructors in com.espertech.esper.epl.table.merge with parameters of type ExprNode
TableOnMergeMatch(ExprNode optionalCond, java.util.List<TableOnMergeAction> actions)
           
 

Uses of ExprNode in com.espertech.esper.epl.table.mgmt
 

Methods in com.espertech.esper.epl.table.mgmt that return ExprNode
 ExprNode TableColumnMethodPair.getAggregationNode()
           
 

Methods in com.espertech.esper.epl.table.mgmt that return types with arguments of type ExprNode
 Pair<ExprNode,java.util.List<ExprChainedSpec>> TableServiceImpl.getTableNodeChainable(StreamTypeService streamTypeService, java.util.List<ExprChainedSpec> chainSpec, EngineImportService engineImportService)
           
 Pair<ExprNode,java.util.List<ExprChainedSpec>> TableService.getTableNodeChainable(StreamTypeService streamTypeService, java.util.List<ExprChainedSpec> chainSpec, EngineImportService engineImportService)
           
 

Constructors in com.espertech.esper.epl.table.mgmt with parameters of type ExprNode
TableColumnMethodPair(ExprEvaluator evaluator, int targetIndex, ExprNode aggregationNode)
           
 

Uses of ExprNode in com.espertech.esper.epl.table.strategy
 

Fields in com.espertech.esper.epl.table.strategy declared as ExprNode
protected  ExprNode ExprTableExprEvaluatorBase.exprNode
           
 

Methods in com.espertech.esper.epl.table.strategy with parameters of type ExprNode
static ExprEvaluator ExprTableEvalStrategyFactory.getTableAccessEvalStrategy(ExprNode exprNode, java.lang.String tableName, java.lang.Integer streamNum, TableMetadataColumnAggregation agg)
           
 

Constructors in com.espertech.esper.epl.table.strategy with parameters of type ExprNode
ExprTableExprEvaluatorAccess(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName, int streamNum, java.lang.Class returnType, AggregationAccessorSlotPair accessAccessorSlotPair, EventType eventTypeColl)
           
ExprTableExprEvaluatorBase(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName, int streamNum, java.lang.Class returnType)
           
ExprTableExprEvaluatorMethod(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName, int streamNum, java.lang.Class returnType, int methodNum)
           
 

Uses of ExprNode in com.espertech.esper.epl.view
 

Constructors in com.espertech.esper.epl.view with parameters of type ExprNode
FilterExprView(ExprNode exprNode, ExprEvaluator exprEvaluator, ExprEvaluatorContext exprEvaluatorContext)
          Ctor.
OutputConditionExpressionFactory(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, StatementContext statementContext, ExprNode andWhenTerminatedExpr, java.util.List<OnTriggerSetAssignment> afterTerminateAssignments, boolean isStartConditionOnCreation)
           
OutputConditionPolledExpression(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, AgentInstanceContext agentInstanceContext)
          Ctor.
 

Constructor parameters in com.espertech.esper.epl.view with type arguments of type ExprNode
OutputConditionCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext statementContext, boolean isStartConditionOnCreation)
           
OutputConditionPolledCrontab(java.util.List<ExprNode> scheduleSpecExpressionList, AgentInstanceContext agentInstanceContext)
          Constructor.
 

Uses of ExprNode in com.espertech.esper.epl.virtualdw
 

Method parameters in com.espertech.esper.epl.virtualdw with type arguments of type ExprNode
 void VirtualDWViewFactoryImpl.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParameters)
           
 

Uses of ExprNode in com.espertech.esper.event.bean
 

Methods in com.espertech.esper.event.bean with parameters of type ExprNode
static InstanceManufacturer InstanceManufacturerFactory.getManufacturer(java.lang.Class targetClass, EngineImportService engineImportService, ExprNode[] childNodes)
           
 

Uses of ExprNode in com.espertech.esper.filter
 

Fields in com.espertech.esper.filter declared as ExprNode
protected  ExprNode ExprNodeAdapterBase.exprNode
           
 

Methods in com.espertech.esper.filter that return ExprNode
 ExprNode FilterSpecParamExprNode.getExprNode()
          Returns the expression node of the boolean expression this filter parameter represents.
 ExprNode ExprNodeAdapterBase.getExprNode()
           
 ExprNode FilterParamExprMap.removeEntry(FilterSpecParam param)
          Removes a filter parameter and it's associated expression node
static ExprNode FilterSpecCompilerMakeParamUtil.rewriteOrToInIfApplicable(ExprNode constituent)
           
 

Methods in com.espertech.esper.filter that return types with arguments of type ExprNode
 java.util.List<ExprNode> FilterParamExprMap.getUnassignedExpressions()
          Returns all expression nodes for which no filter parameter exists.
static java.util.List<ExprNode> FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin, java.util.List<ExprNode> exprNodes, StreamTypeService streamTypeService, StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
          Validates expression nodes and returns a list of validated nodes.
 

Methods in com.espertech.esper.filter with parameters of type ExprNode
protected static FilterSpecParam FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementName)
          For a given expression determine if this is optimizable and create the filter parameter representing the expression, or null if not optimizable.
 void FilterParamExprMap.put(ExprNode exprNode, FilterSpecParam param)
          Add a node and filter param.
 void FilterParamExprMap.removeNode(ExprNode node)
           
static ExprNode FilterSpecCompilerMakeParamUtil.rewriteOrToInIfApplicable(ExprNode constituent)
           
 

Method parameters in com.espertech.esper.filter with type arguments of type ExprNode
static FilterSpecCompiled FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext stmtContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
           
static FilterSpecCompiled FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementId, java.lang.String statementName, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ConfigurationInformation configurationInformation, NamedWindowService namedWindowService)
           
static FilterSpecCompiled FilterSpecCompiler.makeFilterSpec(EventType eventType, java.lang.String eventTypeName, java.util.List<ExprNode> filterExpessions, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext statementContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
          Factory method for compiling filter expressions into a filter specification for use with filter service.
protected static java.util.List<FilterSpecParam>[] FilterSpecCompilerPlanner.planFilterParameters(java.util.List<ExprNode> validatedNodes, FilterSpecCompilerArgs args)
           
static java.util.List<ExprNode> FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin, java.util.List<ExprNode> exprNodes, StreamTypeService streamTypeService, StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
          Validates expression nodes and returns a list of validated nodes.
 

Constructors in com.espertech.esper.filter with parameters of type ExprNode
ExprNodeAdapterBase(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext)
          Ctor.
ExprNodeAdapterBaseStmtLock(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, VariableService variableService)
           
ExprNodeAdapterBaseVariables(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, VariableService variableService)
           
ExprNodeAdapterBaseWTableAccess(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, ExprNodeAdapterBase evalBase, TableService tableService)
           
ExprNodeAdapterMultiStream(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, VariableService variableService, EventBean[] prototype)
           
ExprNodeAdapterMultiStreamNoTL(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, VariableService variableService, EventBean[] prototype)
           
ExprNodeAdapterMultiStreamNoTLStmtLock(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, VariableService variableService, EventBean[] prototype)
           
ExprNodeAdapterMultiStreamStmtLock(java.lang.String statementName, ExprNode exprNode, ExprEvaluatorContext evaluatorContext, VariableService variableService, EventBean[] prototype)
           
FilterSpecParamExprNode(FilterSpecLookupable lookupable, FilterOperator filterOperator, ExprNode exprNode, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, VariableService variableService, TableService tableService, EventAdapterService eventAdapterService, ConfigurationInformation configurationInformation, java.lang.String statementName, boolean hasSubquery, boolean hasTableAccess)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.metrics.instrumentation
 

Methods in com.espertech.esper.metrics.instrumentation with parameters of type ExprNode
 void InstrumentationDefault.qAggAccessEnterLeave(boolean enter, int index, AggregationState state, ExprNode aggExpr)
           
 void Instrumentation.qAggAccessEnterLeave(boolean enter, int index, AggregationState state, ExprNode aggExpr)
           
 void InstrumentationDefault.qAggNoAccessEnterLeave(boolean enter, int index, AggregationMethod aggregationMethod, ExprNode aggExpr)
           
 void Instrumentation.qAggNoAccessEnterLeave(boolean enter, int index, AggregationMethod aggregationMethod, ExprNode aggExpr)
           
 void InstrumentationDefault.qExprAnd(ExprNode exprNode)
           
 void Instrumentation.qExprAnd(ExprNode exprNode)
           
 void InstrumentationDefault.qExprBitwise(ExprNode exprNode, BitWiseOpEnum bitWiseOpEnum)
           
 void Instrumentation.qExprBitwise(ExprNode exprNode, BitWiseOpEnum bitWiseOpEnum)
           
 void InstrumentationDefault.qExprBool(ExprNode exprNode, EventBean[] eventsPerStream)
           
 void Instrumentation.qExprBool(ExprNode exprNode, EventBean[] eventsPerStream)
           
 void InstrumentationDefault.qExprEquals(ExprNode exprNode)
           
 void Instrumentation.qExprEquals(ExprNode exprNode)
           
 void InstrumentationDefault.qExprLike(ExprNode exprNode)
           
 void Instrumentation.qExprLike(ExprNode exprNode)
           
 void InstrumentationDefault.qExprTableSubpropAccessor(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName, ExprAggregateNode aggregationExpression)
           
 void Instrumentation.qExprTableSubpropAccessor(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName, ExprAggregateNode aggregationExpression)
           
 void InstrumentationDefault.qExprTableSubproperty(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName)
           
 void Instrumentation.qExprTableSubproperty(ExprNode exprNode, java.lang.String tableName, java.lang.String subpropName)
           
 void InstrumentationDefault.qExprTableTop(ExprNode exprNode, java.lang.String tableName)
           
 void Instrumentation.qExprTableTop(ExprNode exprNode, java.lang.String tableName)
           
 void InstrumentationDefault.qExprValue(ExprNode exprNode, EventBean[] eventsPerStream)
           
 void Instrumentation.qExprValue(ExprNode exprNode, EventBean[] eventsPerStream)
           
 void InstrumentationDefault.qRegExPartition(ExprNode[] partitionExpressionNodes)
           
 void Instrumentation.qRegExPartition(ExprNode[] partitionExpressionNodes)
           
 void InstrumentationDefault.qRegIntervalValue(ExprNode exprNode)
           
 void Instrumentation.qRegIntervalValue(ExprNode exprNode)
           
 void InstrumentationDefault.qResultSetProcessComputeGroupKeys(boolean enter, ExprNode[] groupKeyNodeExpressions, EventBean[] eventsPerStream)
           
 void Instrumentation.qResultSetProcessComputeGroupKeys(boolean enter, ExprNode[] groupKeyNodeExpressions, EventBean[] eventsPerStream)
           
 void InstrumentationDefault.qSubselectAggregation(ExprNode optionalFilterExprNode)
           
 void Instrumentation.qSubselectAggregation(ExprNode optionalFilterExprNode)
           
 void InstrumentationDefault.qWhereClauseFilter(ExprNode exprNode, EventBean[] newData, EventBean[] oldData)
           
 void Instrumentation.qWhereClauseFilter(ExprNode exprNode, EventBean[] newData, EventBean[] oldData)
           
 

Uses of ExprNode in com.espertech.esper.pattern
 

Fields in com.espertech.esper.pattern with type parameters of type ExprNode
protected  java.util.List<ExprNode> EvalEveryDistinctFactoryNode.distinctExpressions
           
protected  java.util.List<ExprNode> EvalEveryDistinctFactoryNode.expressions
           
 

Methods in com.espertech.esper.pattern that return ExprNode
 ExprNode EvalMatchUntilFactoryNode.getLowerBounds()
           
 ExprNode EvalMatchUntilFactoryNode.getSingleBound()
           
 ExprNode EvalMatchUntilFactoryNode.getUpperBounds()
           
 

Methods in com.espertech.esper.pattern that return types with arguments of type ExprNode
 java.util.List<ExprNode> EvalEveryDistinctFactoryNode.getDistinctExpressions()
          Returns distinct expressions.
 java.util.List<ExprNode> EvalEveryDistinctFactoryNode.getExpressions()
          Returns all expressions.
 java.util.List<ExprNode> EvalFollowedByFactoryNode.getOptionalMaxExpressions()
           
 

Methods in com.espertech.esper.pattern with parameters of type ExprNode
static java.lang.Object PatternExpressionUtil.evaluate(java.lang.String objectName, MatchedEventMap beginState, ExprNode parameter, MatchedEventConvertor convertor, ExprEvaluatorContext exprEvaluatorContext)
           
 EvalFactoryNode PatternNodeFactoryImpl.makeMatchUntilNode(ExprNode lowerBounds, ExprNode upperBounds, ExprNode singleBounds)
           
 EvalFactoryNode PatternNodeFactory.makeMatchUntilNode(ExprNode lowerBounds, ExprNode upperBounds, ExprNode singleBounds)
           
 void EvalEveryDistinctFactoryNode.setDistinctExpressions(java.util.List<ExprNode> distinctExpressions, ExprTimePeriodEvalDeltaConst timeDeltaComputation, ExprNode expiryTimeExp)
          Sets expressions for distinct-value.
 void EvalMatchUntilFactoryNode.setLowerBounds(ExprNode lowerBounds)
           
 void EvalMatchUntilFactoryNode.setSingleBound(ExprNode singleBound)
           
 void EvalMatchUntilFactoryNode.setUpperBounds(ExprNode upperBounds)
           
 

Method parameters in com.espertech.esper.pattern with type arguments of type ExprNode
static java.util.List<java.lang.Object> PatternExpressionUtil.evaluate(java.lang.String objectName, MatchedEventMap beginState, java.util.List<ExprNode> parameters, MatchedEventConvertor convertor, ExprEvaluatorContext exprEvaluatorContext)
          Ctor.
 EvalFactoryNode PatternNodeFactoryImpl.makeEveryDistinctNode(java.util.List<ExprNode> expressions)
           
 EvalFactoryNode PatternNodeFactory.makeEveryDistinctNode(java.util.List<ExprNode> expressions)
           
 EvalFactoryNode PatternNodeFactoryImpl.makeFollowedByNode(java.util.List<ExprNode> maxExpressions, boolean hasEngineWideMax)
           
 EvalFactoryNode PatternNodeFactory.makeFollowedByNode(java.util.List<ExprNode> maxExpressions, boolean hasEngineWideMax)
           
 void EvalEveryDistinctFactoryNode.setDistinctExpressions(java.util.List<ExprNode> distinctExpressions, ExprTimePeriodEvalDeltaConst timeDeltaComputation, ExprNode expiryTimeExp)
          Sets expressions for distinct-value.
 void EvalFollowedByFactoryNode.setOptionalMaxExpressions(java.util.List<ExprNode> optionalMaxExpressions)
           
 

Constructors in com.espertech.esper.pattern with parameters of type ExprNode
EvalMatchUntilFactoryNode(ExprNode lowerBounds, ExprNode upperBounds, ExprNode singleBound)
          Ctor.
 

Constructor parameters in com.espertech.esper.pattern with type arguments of type ExprNode
EvalEveryDistinctFactoryNode(java.util.List<ExprNode> expressions)
          Ctor.
EvalFollowedByFactoryNode(java.util.List<ExprNode> optionalMaxExpressions, boolean hasEngineWidePatternCount)
           
 

Uses of ExprNode in com.espertech.esper.pattern.guard
 

Fields in com.espertech.esper.pattern.guard declared as ExprNode
protected  ExprNode ExpressionGuardFactory.expression
           
protected  ExprNode TimerWithinOrMaxCountGuardFactory.millisecondsExpr
          Number of milliseconds.
protected  ExprNode TimerWithinGuardFactory.millisecondsExpr
          Number of milliseconds.
protected  ExprNode TimerWithinOrMaxCountGuardFactory.numCountToExpr
          Number of count-to max.
 

Method parameters in com.espertech.esper.pattern.guard with type arguments of type ExprNode
 void TimerWithinOrMaxCountGuardFactory.setGuardParameters(java.util.List<ExprNode> parameters, MatchedEventConvertor convertor)
           
 void TimerWithinGuardFactory.setGuardParameters(java.util.List<ExprNode> parameters, MatchedEventConvertor convertor)
           
 void GuardFactory.setGuardParameters(java.util.List<ExprNode> guardParameters, MatchedEventConvertor convertor)
          Sets the guard object parameters.
 void ExpressionGuardFactory.setGuardParameters(java.util.List<ExprNode> parameters, MatchedEventConvertor convertor)
           
 

Uses of ExprNode in com.espertech.esper.pattern.observer
 

Fields in com.espertech.esper.pattern.observer declared as ExprNode
protected  ExprNode TimerIntervalObserverFactory.parameter
          Parameters.
 

Fields in com.espertech.esper.pattern.observer with type parameters of type ExprNode
protected  java.util.List<ExprNode> TimerAtObserverFactory.parameters
          Parameters.
 

Method parameters in com.espertech.esper.pattern.observer with type arguments of type ExprNode
 void TimerScheduleObserverFactory.setObserverParameters(java.util.List<ExprNode> parameters, MatchedEventConvertor convertor)
           
 void TimerIntervalObserverFactory.setObserverParameters(java.util.List<ExprNode> parameters, MatchedEventConvertor convertor)
           
 void TimerAtObserverFactory.setObserverParameters(java.util.List<ExprNode> parameters, MatchedEventConvertor convertor)
           
 void ObserverFactory.setObserverParameters(java.util.List<ExprNode> observerParameters, MatchedEventConvertor convertor)
          Sets the observer object parameters.
static void ObserverParameterUtil.validateNoNamedParameters(java.lang.String name, java.util.List<ExprNode> parameter)
           
 

Uses of ExprNode in com.espertech.esper.plugin
 

Methods in com.espertech.esper.plugin that return ExprNode
 ExprNode[] PlugInAggregationMultiFunctionValidationContext.getAllParameterExpressions()
          Returns positional and non-positional parameters.
 ExprNode[] PlugInAggregationMultiFunctionAgentContext.getChildNodes()
           
 ExprNode[] PlugInAggregationMultiFunctionValidationContext.getParameterExpressions()
          Returns positional parameters expressions to this aggregation function.
 

Constructors in com.espertech.esper.plugin with parameters of type ExprNode
PlugInAggregationMultiFunctionAgentContext(ExprNode[] childNodes)
           
PlugInAggregationMultiFunctionValidationContext(java.lang.String functionName, EventType[] eventTypes, ExprNode[] parameterExpressions, java.lang.String engineURI, java.lang.String statementName, ExprValidationContext validationContext, ConfigurationPlugInAggregationMultiFunction config, TableMetadataColumnAggregation optionalTableColumnAccessed, ExprNode[] allParameterExpressions)
          Ctor.
PlugInAggregationMultiFunctionValidationContext(java.lang.String functionName, EventType[] eventTypes, ExprNode[] parameterExpressions, java.lang.String engineURI, java.lang.String statementName, ExprValidationContext validationContext, ConfigurationPlugInAggregationMultiFunction config, TableMetadataColumnAggregation optionalTableColumnAccessed, ExprNode[] allParameterExpressions)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.rowregex
 

Methods in com.espertech.esper.rowregex that return ExprNode
 ExprNode RowRegexExprRepeatDesc.getLower()
           
 ExprNode[] RegexPartitionStateRepoGroupMeta.getPartitionExpressionNodes()
           
 ExprNode RowRegexExprRepeatDesc.getSingle()
           
 ExprNode RowRegexExprRepeatDesc.getUpper()
           
 

Method parameters in com.espertech.esper.rowregex with type arguments of type ExprNode
protected static RegexNFAStrandResult EventRowRegexHelper.recursiveBuildStartStates(RowRegexExprNode parent, java.util.Map<java.lang.String,ExprNode> variableDefinitions, java.util.Map<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, boolean[] exprRequiresMultimatchState)
          Build a list of start states from the parent node.
 void EventRowRegexNFAViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParameters)
           
 

Constructors in com.espertech.esper.rowregex with parameters of type ExprNode
RegexNFAStateFilter(java.lang.String nodeNum, java.lang.String variableName, int streamNum, boolean multiple, ExprNode exprNode, boolean exprRequiresMultimatchState)
          Ctor.
RegexNFAStateOneOptional(java.lang.String nodeNum, java.lang.String variableName, int streamNum, boolean multiple, boolean isGreedy, ExprNode exprNode, boolean exprRequiresMultimatchState)
          Ctor.
RegexNFAStateOneToMany(java.lang.String nodeNum, java.lang.String variableName, int streamNum, boolean multiple, boolean isGreedy, ExprNode exprNode, boolean exprRequiresMultimatchState)
          Ctor.
RegexNFAStateZeroToMany(java.lang.String nodeNum, java.lang.String variableName, int streamNum, boolean multiple, boolean isGreedy, ExprNode exprNode, boolean exprRequiresMultimatchState)
          Ctor.
RegexPartitionStateRepoGroupMeta(boolean hasInterval, ExprNode[] partitionExpressionNodes, ExprEvaluator[] partitionExpressions, ExprEvaluatorContext exprEvaluatorContext)
           
RowRegexExprRepeatDesc(ExprNode lower, ExprNode upper, ExprNode single)
           
 

Uses of ExprNode in com.espertech.esper.view
 

Methods in com.espertech.esper.view that return ExprNode
static ExprNode[] ViewFactorySupport.validate(java.lang.String viewName, EventType eventType, StatementContext statementContext, java.util.List<ExprNode> expressions, boolean allowConstantResult)
          Validate the view parameter expressions and return the validated expression for later execution.
static ExprNode ViewFactorySupport.validateExpr(java.lang.String viewName, StatementContext statementContext, ExprNode expression, StreamTypeService streamTypeService, int expressionNumber)
           
 

Methods in com.espertech.esper.view with parameters of type ExprNode
static void ViewFactorySupport.assertReturnsNonConstant(java.lang.String viewName, ExprNode expression, int index)
          Assert and throws an exception if the expression passed returns a non-constant value.
static java.lang.Object ViewFactorySupport.evaluateAssertNoProperties(java.lang.String viewName, ExprNode expression, int index, ExprEvaluatorContext exprEvaluatorContext)
          Assert and throws an exception if the expression uses event property values.
static java.lang.Object ViewFactorySupport.validateAndEvaluate(java.lang.String viewName, StatementContext statementContext, ExprNode expression)
          Validate the view parameter expression and evaluate the expression returning the result object.
static java.lang.Object ViewFactorySupport.validateAndEvaluateExpr(java.lang.String viewName, StatementContext statementContext, ExprNode expression, StreamTypeService streamTypeService, int expressionNumber)
           
static ExprTimePeriodEvalDeltaConst ViewFactoryTimePeriodHelper.validateAndEvaluateTimeDelta(java.lang.String viewName, StatementContext statementContext, ExprNode expression, java.lang.String expectedMessage, int expressionNumber)
           
static ExprNode ViewFactorySupport.validateExpr(java.lang.String viewName, StatementContext statementContext, ExprNode expression, StreamTypeService streamTypeService, int expressionNumber)
           
 

Method parameters in com.espertech.esper.view with type arguments of type ExprNode
 void ViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParameters)
          Indicates user EPL query view parameters to the view factory.
 void ValidatedView.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
          Validate the view.
static ExprNode[] ViewFactorySupport.validate(java.lang.String viewName, EventType eventType, StatementContext statementContext, java.util.List<ExprNode> expressions, boolean allowConstantResult)
          Validate the view parameter expressions and return the validated expression for later execution.
static java.util.List<java.lang.Object> ViewFactorySupport.validateAndEvaluate(java.lang.String viewName, StatementContext statementContext, java.util.List<ExprNode> expressions)
          Validate the view parameter expressions and evaluate the expressions returning the result object.
 

Uses of ExprNode in com.espertech.esper.view.ext
 

Fields in com.espertech.esper.view.ext declared as ExprNode
protected  ExprNode[] SortWindowViewFactory.sortCriteriaExpressions
          The sort-by expressions.
protected  ExprNode[] RankWindowViewFactory.sortCriteriaExpressions
          The sort-by expressions.
protected  ExprNode TimeOrderViewFactory.timestampExpression
          The timestamp expression.
protected  ExprNode[] RankWindowViewFactory.uniqueCriteriaExpressions
          The unique-by expressions.
 

Methods in com.espertech.esper.view.ext that return ExprNode
protected  ExprNode[] SortWindowView.getSortCriteriaExpressions()
          Returns the field names supplying the values to sort by.
 ExprNode TimeOrderView.getTimestampExpression()
          Returns the timestamp property name.
 

Method parameters in com.espertech.esper.view.ext with type arguments of type ExprNode
 void TimeOrderViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void SortWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParams)
           
 void RankWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParams)
           
 

Constructors in com.espertech.esper.view.ext with parameters of type ExprNode
RankWindowView(RankWindowViewFactory rankWindowViewFactory, ExprNode[] uniqueCriteriaExpressions, ExprEvaluator[] uniqueCriteriaEvaluators, ExprNode[] sortCriteriaExpressions, ExprEvaluator[] sortCriteriaEvaluators, boolean[] descendingValues, int sortWindowSize, IStreamSortRankRandomAccess optionalRankedRandomAccess, boolean isSortUsingCollator, AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
          Ctor.
RankWindowView(RankWindowViewFactory rankWindowViewFactory, ExprNode[] uniqueCriteriaExpressions, ExprEvaluator[] uniqueCriteriaEvaluators, ExprNode[] sortCriteriaExpressions, ExprEvaluator[] sortCriteriaEvaluators, boolean[] descendingValues, int sortWindowSize, IStreamSortRankRandomAccess optionalRankedRandomAccess, boolean isSortUsingCollator, AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
          Ctor.
SortWindowView(SortWindowViewFactory sortWindowViewFactory, ExprNode[] sortCriteriaExpressions, ExprEvaluator[] sortCriteriaEvaluators, boolean[] descendingValues, int sortWindowSize, IStreamSortRankRandomAccess optionalSortedRandomAccess, boolean isSortUsingCollator, AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
          Ctor.
TimeOrderView(AgentInstanceViewFactoryChainContext agentInstanceContext, TimeOrderViewFactory timeOrderViewFactory, ExprNode timestampExpr, ExprEvaluator timestampEvaluator, ExprTimePeriodEvalDeltaConst timeDeltaComputation, IStreamSortRankRandomAccess optionalSortedRandomAccess)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.view.internal
 

Method parameters in com.espertech.esper.view.internal with type arguments of type ExprNode
 void UnionViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParameters)
           
 void PriorEventViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void IntersectViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> viewParameters)
           
 

Constructors in com.espertech.esper.view.internal with parameters of type ExprNode
RouteResultView(boolean isFirst, EventType eventType, EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableStateInstance[] tableStateInstances, boolean[] isNamedWindowInsert, ResultSetProcessor[] processors, ExprNode[] whereClauses, AgentInstanceContext agentInstanceContext)
          Ctor.
 

Uses of ExprNode in com.espertech.esper.view.stat
 

Fields in com.espertech.esper.view.stat declared as ExprNode
protected  ExprNode RegressionLinestViewFactory.expressionX
          Expression X field.
protected  ExprNode CorrelationViewFactory.expressionX
          Property name of X field.
protected  ExprNode RegressionLinestViewFactory.expressionY
          Expression Y field.
protected  ExprNode CorrelationViewFactory.expressionY
          Property name of Y field.
protected  ExprNode UnivariateStatisticsViewFactory.fieldExpression
          Property name of data field.
protected  ExprNode WeightedAverageViewFactory.fieldNameWeight
          Expression of weight field.
protected  ExprNode WeightedAverageViewFactory.fieldNameX
          Expression of X field.
 

Methods in com.espertech.esper.view.stat that return ExprNode
 ExprNode BaseBivariateStatisticsView.getExpressionX()
          Returns the expression supplying X data points.
 ExprNode BaseBivariateStatisticsView.getExpressionY()
          Returns the expression supplying Y data points.
 ExprNode UnivariateStatisticsView.getFieldExpression()
          Returns field name of the field to report statistics on.
 ExprNode WeightedAverageView.getFieldNameWeight()
          Returns the expression supplying the weight values.
 ExprNode WeightedAverageView.getFieldNameX()
          Returns the expression supplying the X values.
 

Methods in com.espertech.esper.view.stat with parameters of type ExprNode
static StatViewAdditionalProps StatViewAdditionalProps.make(ExprNode[] validated, int startIndex, EventType parentEventType)
           
 void UnivariateStatisticsViewFactory.setFieldExpression(ExprNode fieldExpression)
           
 void WeightedAverageViewFactory.setFieldNameWeight(ExprNode fieldNameWeight)
           
 void WeightedAverageViewFactory.setFieldNameX(ExprNode fieldNameX)
           
 

Method parameters in com.espertech.esper.view.stat with type arguments of type ExprNode
 void WeightedAverageViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void UnivariateStatisticsViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void RegressionLinestViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void CorrelationViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 

Constructors in com.espertech.esper.view.stat with parameters of type ExprNode
BaseBivariateStatisticsView(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprNode expressionX, ExprNode expressionY, EventType eventType, StatViewAdditionalProps additionalProps)
          Constructor requires the name of the two fields to use in the parent view to compute the statistics.
CorrelationView(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprNode xExpression, ExprNode yExpression, EventType eventType, StatViewAdditionalProps additionalProps)
          Constructor.
RegressionLinestView(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprNode xFieldName, ExprNode yFieldName, EventType eventType, StatViewAdditionalProps additionalProps)
          Constructor.
 

Uses of ExprNode in com.espertech.esper.view.std
 

Fields in com.espertech.esper.view.std declared as ExprNode
protected  ExprNode[] UniqueByPropertyViewFactory.criteriaExpressions
          Property name to evaluate unique values.
protected  ExprNode[] GroupByViewFactory.criteriaExpressions
          List of criteria expressions.
protected  ExprNode[] FirstUniqueByPropertyViewFactory.criteriaExpressions
          Property name to evaluate unique values.
 

Fields in com.espertech.esper.view.std with type parameters of type ExprNode
protected  java.util.List<ExprNode> UniqueByPropertyViewFactory.viewParameters
          View parameters.
protected  java.util.List<ExprNode> GroupByViewFactory.viewParameters
          View parameters.
protected  java.util.List<ExprNode> FirstUniqueByPropertyViewFactory.viewParameters
          View parameters.
 

Methods in com.espertech.esper.view.std that return ExprNode
 ExprNode[] UniqueByPropertyView.getCriteriaExpressions()
          Returns the name of the field supplying the unique value to keep the most recent record for.
 ExprNode[] GroupByViewReclaimAged.getCriteriaExpressions()
          Returns the field name that provides the key valie by which to group by.
 ExprNode[] GroupByViewImpl.getCriteriaExpressions()
          Returns the field name that provides the key valie by which to group by.
 ExprNode[] GroupByViewFactoryMarker.getCriteriaExpressions()
           
 ExprNode[] GroupByViewFactory.getCriteriaExpressions()
          Returns the names of fields to group by
 ExprNode[] GroupByView.getCriteriaExpressions()
           
 ExprNode[] MergeViewMarker.getGroupFieldNames()
           
 ExprNode[] MergeView.getGroupFieldNames()
          Returns the field name that contains the values to group by.
 ExprNode[] FirstUniqueByPropertyView.getUniqueCriteria()
          Returns the expressions supplying the unique value to keep the most recent record for.
 

Method parameters in com.espertech.esper.view.std with type arguments of type ExprNode
 void UniqueByPropertyViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void SizeViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void MergeViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void LastElementViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void GroupByViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void FirstUniqueByPropertyViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void FirstElementViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 

Constructors in com.espertech.esper.view.std with parameters of type ExprNode
GroupByViewImpl(AgentInstanceViewFactoryChainContext agentInstanceContext, ExprNode[] criteriaExpressions, ExprEvaluator[] criteriaEvaluators)
          Constructor.
GroupByViewReclaimAged(AgentInstanceViewFactoryChainContext agentInstanceContext, ExprNode[] criteriaExpressions, ExprEvaluator[] criteriaEvaluators, double reclaimMaxAge, double reclaimFrequency)
          Constructor.
MergeView(AgentInstanceViewFactoryChainContext agentInstanceContext, ExprNode[] groupCriteria, EventType resultEventType, boolean removable)
          Constructor.
 

Uses of ExprNode in com.espertech.esper.view.window
 

Fields in com.espertech.esper.view.window declared as ExprNode
protected  ExprNode ExpressionViewFactoryBase.expiryExpression
           
protected  ExprNode ExternallyTimedWindowViewFactory.timestampExpression
          The timestamp property name.
protected  ExprNode ExternallyTimedBatchViewFactory.timestampExpression
          The timestamp property name.
 

Methods in com.espertech.esper.view.window that return ExprNode
 ExprNode ExternallyTimedWindowView.getTimestampExpression()
          Returns the field name to get timestamp values from.
 ExprNode ExternallyTimedBatchView.getTimestampExpression()
          Returns the field name to get timestamp values from.
 

Method parameters in com.espertech.esper.view.window with type arguments of type ExprNode
 void TimeWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void TimeLengthBatchViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void TimeBatchViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void TimeAccumViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void LengthWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void LengthBatchViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void KeepAllViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void FirstTimeViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void FirstLengthWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void ExternallyTimedWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void ExternallyTimedBatchViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void ExpressionWindowViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 void ExpressionBatchViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext, java.util.List<ExprNode> expressionParameters)
           
 

Constructors in com.espertech.esper.view.window with parameters of type ExprNode
ExternallyTimedBatchView(ExternallyTimedBatchViewFactory factory, ExprNode timestampExpression, ExprEvaluator timestampExpressionEval, ExprTimePeriodEvalDeltaConst timeDeltaComputation, java.lang.Long optionalReferencePoint, ViewUpdatedCollection viewUpdatedCollection, AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
          Constructor.
ExternallyTimedWindowView(ExternallyTimedWindowViewFactory externallyTimedWindowViewFactory, ExprNode timestampExpression, ExprEvaluator timestampExpressionEval, ExprTimePeriodEvalDeltaConst timeDeltaComputation, ViewUpdatedCollection viewUpdatedCollection, AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
          Constructor.
 


© 2006-2015 EsperTech Inc.
All rights reserved.
Visit us at espertech.com