Package | Description |
---|---|
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 | |
com.espertech.esper.epl.agg.service |
Aggregation services.
|
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 |
This package contains the EPL expression nodes that represent all expressions such as used in select clauses, group-by and having clauses, or order-by clauses
|
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.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.view |
Internal processing views for output rate limiting, filtering and internal event routing
|
com.espertech.esper.epl.virtualdw |
Virtual data window.
|
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 | |
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
|
Modifier and Type | Method and Description |
---|---|
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.
|
Constructor and Description |
---|
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.
|
Constructor and Description |
---|
ViewableActivatorNamedWindow(NamedWindowProcessor processor,
java.util.List<ExprNode> filterExpressions,
PropertyEvaluator optPropertyEvaluator) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
StatementAgentInstanceFactoryOnTriggerSplitDesc.getWhereClauses() |
Constructor and Description |
---|
StatementAgentInstanceFactoryOnTrigger(StatementContext statementContext,
StatementSpecCompiled statementSpec,
EPServicesContext services,
ViewableActivator activator,
SubSelectStrategyCollection subSelectStrategyCollection,
ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
ExprNode validatedJoin,
EventType activatorResultEventType,
StatementAgentInstanceFactoryOnTriggerSplitDesc splitDesc,
ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype,
OnSetVariableViewFactory onSetVariableViewFactory,
NamedWindowOnExprFactory onExprFactory,
OutputProcessViewFactory outputProcessViewFactory,
boolean recoveringStatement) |
StatementAgentInstanceFactoryOnTriggerSplitDesc(ResultSetProcessorFactoryDesc[] processors,
ExprNode[] whereClauses,
boolean[] namedWindowInsert) |
Constructor and Description |
---|
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) |
Constructor and Description |
---|
SubSelectStrategyFactoryLocalViewPreloaded(int subqueryNumber,
SubSelectActivationHolder subSelectHolder,
Pair<EventTableFactory,SubordTableLookupStrategyFactory> pair,
ExprNode filterExprNode,
ExprEvaluator filterExprEval,
boolean correlatedSubquery,
AggregationServiceFactoryDesc aggregationServiceFactory,
ViewResourceDelegateVerified viewResourceDelegate,
ExprEvaluator[] groupKeys) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
EPAdministratorSPI.compileExpression(java.lang.String expression)
Compile expression.
|
ExprNode |
EPAdministratorImpl.compileExpression(java.lang.String expression) |
Constructor and Description |
---|
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.
|
Constructor and Description |
---|
EPPreparedExecuteSingleStreamExecDelete(FilterSpecCompiled filter,
ExprNode optionalWhereClause,
java.lang.annotation.Annotation[] annotations) |
EPPreparedExecuteSingleStreamExecUpdate(FilterSpecCompiled filter,
ExprNode optionalWhereClause,
java.lang.annotation.Annotation[] annotations,
NamedWindowUpdateHelper updateHelper) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
GroupByRollupPlanDesc.getExpressions() |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
GroupByRollupNodeSingleExpr(ExprNode expression) |
GroupByRollupPlanDesc(ExprNode[] expressions,
AggregationGroupByRollupDesc rollupDesc) |
Constructor and Description |
---|
GroupByRollupEvalContext(java.util.Map<ExprNode,java.lang.Integer> expressionToIndex) |
GroupByRollupNodeCombinedExpr(java.util.List<ExprNode> expressions) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
AggregationStateFactoryPlugin.getAggregationExpression() |
ExprNode |
AggregationStateFactory.getAggregationExpression() |
ExprNode |
AggregationMethodFactory.getAggregationExpression() |
ExprNode[] |
AggregationValidationContext.getExpressions()
Returns the parameter expressions themselves for interrogation.
|
Modifier and Type | Method and Description |
---|---|
static AggregationServiceFactoryDesc |
AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes,
ExprNode[] groupByNodes,
java.util.List<ExprAggregateNode> havingAggregateExprNodes,
java.util.List<ExprAggregateNode> orderByAggregateExprNodes,
java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
ExprEvaluatorContext exprEvaluatorContext,
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)
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,
ExprNode[] groupByNodes,
java.util.List<ExprAggregateNode> havingAggregateExprNodes,
java.util.List<ExprAggregateNode> orderByAggregateExprNodes,
java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
ExprEvaluatorContext exprEvaluatorContext,
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)
Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on
whether there are any group-by nodes.
|
Constructor and Description |
---|
AggregationStateKeyWStream(int streamNum,
AggregationStateTypeWStream stateType,
ExprNode[] exprNodes) |
AggregationValidationContext(java.lang.Class[] parameterTypes,
boolean[] constantValue,
java.lang.Object[] constantValues,
boolean distinct,
boolean windowed,
ExprNode[] expressions)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
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.
|
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.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
void |
MethodPollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
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) |
Constructor and Description |
---|
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)
Ctor.
|
ResultSetProcessorRowPerGroupFactory(SelectExprProcessor selectExprProcessor,
ExprNode[] groupKeyNodeExpressions,
ExprEvaluator[] groupKeyNodes,
ExprEvaluator optionalHavingNode,
boolean isSelectRStream,
boolean isUnidirectional,
OutputLimitSpec outputLimitSpec,
boolean isSorting,
boolean noDataWindowSingleStream)
Ctor.
|
ResultSetProcessorRowPerGroupRollupFactory(GroupByRollupPerLevelExpression perLevelExpression,
ExprNode[] groupKeyNodeExpressions,
ExprEvaluator[] groupKeyNodes,
boolean isSelectRStream,
boolean isUnidirectional,
OutputLimitSpec outputLimitSpec,
boolean isSorting,
boolean noDataWindowSingleStream,
AggregationGroupByRollupDesc groupByRollupDesc,
boolean isJoin)
Ctor.
|
Constructor and Description |
---|
MethodPollingViewable(MethodStreamSpec methodStreamSpec,
int myStreamNumber,
java.util.List<ExprNode> inputParameters,
PollExecStrategy pollExecStrategy,
DataCache dataCache,
EventType eventType,
ExprEvaluatorContext exprEvaluatorContext)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
static CalendarFieldEnum |
CalendarOpUtil.getEnum(java.lang.String methodName,
ExprNode exprNode) |
Modifier and Type | Method and Description |
---|---|
CalendarOp |
CalendarOpFactory.getOp(DatetimeMethodEnum method,
java.lang.String methodNameUsed,
java.util.List<ExprNode> parameters,
ExprEvaluator[] evaluators) |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
ExprDotNodeFilterAnalyzerDTBetweenDesc(EventType[] typesPerStream,
int targetStreamNum,
java.lang.String targetPropertyName,
ExprNode start,
ExprNode end,
boolean includeLow,
boolean includeHigh) |
Modifier and Type | Method and Description |
---|---|
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 and Description |
---|
IntervalOpImpl(DatetimeMethodEnum method,
java.lang.String methodNameUse,
StreamTypeService streamTypeService,
java.util.List<ExprNode> expressions) |
Modifier and Type | Method and Description |
---|---|
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 and Description |
---|
ReformatOpBetweenConstantParams(java.util.List<ExprNode> parameters) |
ReformatOpBetweenNonConstantParams(java.util.List<ExprNode> parameters) |
Modifier and Type | Method and Description |
---|---|
void |
DatabasePollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
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) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprDeclaredNode
Expression instance as declared elsewhere.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprDeclaredNodeImpl
Expression instance as declared elsewhere.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprDeclaredNodeImpl.getBody() |
ExprNode |
ExprDeclaredNode.getBody() |
ExprNode |
ExprDeclaredNodeImpl.getExpressionBodyCopy() |
Modifier and Type | Method and Description |
---|---|
java.util.List<ExprNode> |
ExprDeclaredNodeImpl.getAdditionalNodes() |
java.util.List<ExprNode> |
ExprDeclaredNodeImpl.getChainParameters() |
java.util.List<ExprNode> |
ExprDeclaredNode.getChainParameters() |
Modifier and Type | Method and Description |
---|---|
void |
ExprDeclaredNodeImpl.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
boolean |
ExprDeclaredNodeImpl.equalsNode(ExprNode node) |
Modifier and Type | Method and Description |
---|---|
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 and Description |
---|
ExprDeclaredNodeImpl(ExpressionDeclItem prototype,
java.util.List<ExprNode> chainParameters,
ContextDescriptor contextDescriptor) |
Modifier and Type | Class and Description |
---|---|
class |
ExprLambdaGoesNode
Represents the case-when-then-else control flow function is an expression tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprDotEvalParam.getBody() |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprLambdaGoesNode.equalsNode(ExprNode node_) |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
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) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprAggregateNode
Base expression node that represents an aggregation function such as 'sum' or 'count'.
|
interface |
ExprAndNode
Represents an And-condition.
|
interface |
ExprBetweenNode
Represents the between-clause function in an expression tree.
|
interface |
ExprConstantNode
Represents a constant in an expressiun tree.
|
interface |
ExprEqualsNode
Represents an equals (=, !=, <>, is, is not) comparator in a filter expressiun tree.
|
interface |
ExprIdentNode
Represents an stream property identifier 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.
|
interface |
ExprStreamUnderlyingNode
Represents an stream selector that returns the streams underlying event, or null if undefined.
|
interface |
ExprTimePeriod
Expression representing a time period.
|
interface |
ExprVariableNode
Represents a variable in an expression tree.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprAggMultiFunctionLinearAccessNode |
class |
ExprAggMultiFunctionSortedMinMaxByNode |
class |
ExprAggregateNodeBase
Base expression node that represents an aggregation function such as 'sum' or 'count'.
|
class |
ExprAggregateNodeGroupKey |
class |
ExprAndNodeImpl
Represents an And-condition.
|
class |
ExprArrayNode
Represents an array in a filter expressiun tree.
|
class |
ExprAvedevNode
Represents the avedev(...) aggregate function is an expression tree.
|
class |
ExprAvgNode
Represents the avg(...) aggregate function is an expression tree.
|
class |
ExprBetweenNodeImpl
Represents the between-clause function in an expression tree.
|
class |
ExprBitWiseNode
Represents the bit-wise operators in an expression tree.
|
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 |
ExprConcatNode
Represents a simple Math (+/-/divide/*) in a filter expression tree.
|
class |
ExprConstantNodeImpl
Represents a constant in an expressiun tree.
|
class |
ExprContextPropertyNode
Represents an stream property identifier in a filter expressiun tree.
|
class |
ExprCountNode
Represents the count(...) and count(*) and count(distinct ...) aggregate function is an expression tree.
|
class |
ExprDotNode
Represents an Dot-operator expression, for use when "(expression).method(...).method(...)"
|
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 |
ExprFirstEverNode
Represents the "firstever" aggregate function is an expression tree.
|
class |
ExprGroupingIdNode |
class |
ExprGroupingNode |
class |
ExprIdentNodeImpl
Represents an stream property identifier in a filter expressiun tree.
|
class |
ExprInNodeImpl
Represents the in-clause (set check) function in 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 |
ExprLastEverNode
Represents the "lastever" aggregate function is an expression tree.
|
class |
ExprLeavingAggNode
Represents the leaving() aggregate function is 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 |
ExprMedianNode
Represents the median(...) aggregate function is an expression tree.
|
class |
ExprMinMaxAggrNode
Represents the min/max(distinct? ...) aggregate function is an expression tree.
|
class |
ExprMinMaxRowNode
Represents the MAX(a,b) and MIN(a,b) functions is an expression tree.
|
class |
ExprNewNode
Represents the bit-wise operators in an expression tree.
|
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 |
ExprNotNode
Represents a NOT expression in an expression tree.
|
class |
ExprNthAggNode
Represents the nth(...) and aggregate function is an expression tree.
|
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 |
ExprNumberSetWildcard
Expression for use within crontab to specify a wildcard.
|
class |
ExprOrderedExpr
A placeholder expression for view/pattern object parameters that allow
sorting expression values ascending or descending.
|
class |
ExprOrNode
Represents an OR expression in a filter expression tree.
|
class |
ExprPlugInAggFunctionFactoryNode
Represents a custom aggregation function in an expresson tree.
|
class |
ExprPlugInAggMultiFunctionNode
Represents a custom aggregation function in an expresson tree.
|
class |
ExprPlugInSingleRowNode
Represents an invocation of a plug-in single-row function in the expression tree.
|
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.
|
class |
ExprPriorNode
Represents the 'prior' prior event function in an expression node tree.
|
class |
ExprPropertyExistsNode
Represents the EXISTS(property) function in an expression tree.
|
class |
ExprRateAggNode
Represents the rate(...) and aggregate function is an 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.
|
class |
ExprStddevNode
Represents the stddev(...) aggregate function is an expression tree.
|
class |
ExprStreamUnderlyingNodeImpl
Represents an stream selector that returns the streams underlying event, or null if undefined.
|
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.
|
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 |
ExprSumNode
Represents the sum(...) aggregate function is an expression tree.
|
class |
ExprTimePeriodImpl
Expression representing a time period.
|
class |
ExprTimestampNode
Represents the CURRENT_TIMESTAMP() function or reserved keyword in an expression tree.
|
class |
ExprTypeofNode
Represents the TYPEOF(a) function is an expression tree.
|
class |
ExprVariableNodeImpl
Represents a variable in an expression tree.
|
Modifier and Type | Field and Description |
---|---|
static ExprNode[] |
ExprNodeUtility.EMPTY_EXPR_ARRAY |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprSumNodeFactory.getAggregationExpression() |
ExprNode |
ExprStddevNodeFactory.getAggregationExpression() |
ExprNode |
ExprRateAggNodeFactory.getAggregationExpression() |
ExprNode |
ExprPlugInAggMultiFunctionNodeFactory.getAggregationExpression() |
ExprNode |
ExprPlugInAggFunctionFactory.getAggregationExpression() |
ExprNode |
ExprNthAggNodeFactory.getAggregationExpression() |
ExprNode |
ExprMinMaxAggrNodeFactory.getAggregationExpression() |
ExprNode |
ExprMedianNodeFactory.getAggregationExpression() |
ExprNode |
ExprLeavingAggNodeFactory.getAggregationExpression() |
ExprNode |
ExprLastEverNodeFactory.getAggregationExpression() |
ExprNode |
ExprFirstEverNodeFactory.getAggregationExpression() |
ExprNode |
ExprCountNodeFactory.getAggregationExpression() |
ExprNode |
ExprAvgNodeFactory.getAggregationExpression() |
ExprNode |
ExprAvedevNodeFactory.getAggregationExpression() |
ExprNode |
ExprAggMultiFunctionSortedMinMaxByNodeFactory.getAggregationExpression() |
ExprNode |
ExprAggMultiFunctionLinearAccessNodeFactory.getAggregationExpression() |
ExprNode[] |
ExprNodeBase.getChildNodes() |
ExprNode[] |
ExprNode.getChildNodes()
Returns list of child nodes.
|
ExprNode |
ExprCaseNode.CaseAnalysis.getOptionalCompareExprNode() |
ExprNode |
ExprCaseNode.CaseAnalysis.getOptionalElseExprNode() |
ExprNode[] |
ExprSubselectNode.getSelectClause()
Returns the select clause or null if none.
|
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) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType) |
Modifier and Type | Method and Description |
---|---|
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> |
ExprPlugInSingleRowNode.getAdditionalNodes() |
java.util.List<ExprNode> |
ExprNodeInnerNodeProvider.getAdditionalNodes() |
java.util.List<ExprNode> |
ExprDotNode.getAdditionalNodes() |
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<ExprNode> |
ExprChainedSpec.getParameters() |
java.util.List<Pair<ExprNode,ExprPreviousNode>> |
ExprNodePreviousVisitorWParent.getPrevious()
Returns the pair of previous nodes and their parent expression.
|
java.util.List<UniformPair<ExprNode>> |
ExprCaseNode.CaseAnalysis.getWhenThenNodeList() |
Modifier and Type | Method and Description |
---|---|
static void |
ExprNodeUtility.acceptChain(ExprNodeVisitorWithParent visitor,
java.util.List<ExprChainedSpec> chainSpec,
ExprNode parent) |
void |
ExprPlugInSingleRowNode.acceptChildnodes(ExprNodeVisitorWithParent visitor,
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 |
ExprDotNode.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
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,
java.util.Set<Pair<java.lang.Integer,java.lang.String>> set) |
static Pair<java.lang.String,ExprNode> |
ExprNodeUtility.checkGetAssignmentToProp(ExprNode node) |
static Pair<java.lang.String,ExprNode> |
ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node) |
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.
|
boolean |
ExprVariableNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprTypeofNode.equalsNode(ExprNode node) |
boolean |
ExprTimestampNode.equalsNode(ExprNode node) |
boolean |
ExprTimePeriodImpl.equalsNode(ExprNode node) |
boolean |
ExprSubstitutionNode.equalsNode(ExprNode node) |
boolean |
ExprSubselectNode.equalsNode(ExprNode node) |
boolean |
ExprStreamUnderlyingNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprRelationalOpNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprRelationalOpAllAnyNode.equalsNode(ExprNode node) |
boolean |
ExprRegexpNode.equalsNode(ExprNode node_) |
boolean |
ExprPropertyExistsNode.equalsNode(ExprNode node) |
boolean |
ExprPriorNode.equalsNode(ExprNode node) |
boolean |
ExprPreviousNode.equalsNode(ExprNode node) |
boolean |
ExprPreviousMatchRecognizeNode.equalsNode(ExprNode node) |
boolean |
ExprPlugInSingleRowNode.equalsNode(ExprNode node) |
boolean |
ExprOrNode.equalsNode(ExprNode node) |
boolean |
ExprOrderedExpr.equalsNode(ExprNode node) |
boolean |
ExprNumberSetWildcard.equalsNode(ExprNode node) |
boolean |
ExprNumberSetRange.equalsNode(ExprNode node) |
boolean |
ExprNumberSetList.equalsNode(ExprNode node) |
boolean |
ExprNumberSetFrequency.equalsNode(ExprNode node) |
boolean |
ExprNumberSetCronParam.equalsNode(ExprNode node) |
boolean |
ExprNotNode.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 |
ExprNewNode.equalsNode(ExprNode node) |
boolean |
ExprMinMaxRowNode.equalsNode(ExprNode node) |
boolean |
ExprMathNode.equalsNode(ExprNode node) |
boolean |
ExprLikeNode.equalsNode(ExprNode node_) |
boolean |
ExprIStreamNode.equalsNode(ExprNode node) |
boolean |
ExprInstanceofNode.equalsNode(ExprNode node) |
boolean |
ExprInNodeImpl.equalsNode(ExprNode node_) |
boolean |
ExprIdentNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprGroupingNode.equalsNode(ExprNode node) |
boolean |
ExprGroupingIdNode.equalsNode(ExprNode node) |
boolean |
ExprEqualsNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprEqualsAllAnyNode.equalsNode(ExprNode node) |
boolean |
ExprDotNode.equalsNode(ExprNode node) |
boolean |
ExprContextPropertyNode.equalsNode(ExprNode node) |
boolean |
ExprConstantNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprConcatNode.equalsNode(ExprNode node) |
boolean |
ExprCoalesceNode.equalsNode(ExprNode node) |
boolean |
ExprCastNode.equalsNode(ExprNode node) |
boolean |
ExprCaseNode.equalsNode(ExprNode node_) |
boolean |
ExprBitWiseNode.equalsNode(ExprNode node) |
boolean |
ExprBetweenNodeImpl.equalsNode(ExprNode node_) |
boolean |
ExprArrayNode.equalsNode(ExprNode node) |
boolean |
ExprAndNodeImpl.equalsNode(ExprNode node) |
boolean |
ExprAggregateNodeGroupKey.equalsNode(ExprNode node) |
boolean |
ExprAggregateNodeBase.equalsNode(ExprNode node) |
static java.util.List<Pair<ExprNode,ExprNode>> |
ExprNodeUtility.findExpression(ExprNode selectExpression,
ExprNode searchExpression) |
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 ExprDotNode.EnumerationSource |
ExprDotNode.getEnumerationSource(ExprNode inputExpression,
StreamTypeService streamTypeService,
EventAdapterService eventAdapterService,
java.lang.String statementId,
boolean hasEnumerationMethod,
boolean disablePropertyExpressionEventCollCache) |
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.util.Set<Pair<java.lang.Integer,java.lang.String>> |
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.hasRemoveStream(ExprNode child,
StreamTypeService streamTypeService)
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
|
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 |
ExprNodeSummaryVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeSubselectDeclaredNoTraverseVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeSubselectDeclaredDotVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeStreamUseCollectVisitor.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 |
ExprNodeGroupingVisitorWParent.isVisit(ExprNode exprNode) |
boolean |
ExprNodeContextPropertiesVisitor.isVisit(ExprNode exprNode) |
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 |
ExprPlugInSingleRowNode.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
void |
ExprNodeBase.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
void |
ExprNode.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
void |
ExprDotNode.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) |
void |
ExprSubselectNode.setSelectClause(ExprNode[] selectClause)
Sets the validate select clause
|
static java.lang.String |
ExprNodeUtility.toExpressionStringMinPrecedence(ExprNode node) |
static java.lang.String |
ExprNodeUtility.toExpressionStringMinPrecedence(ExprNode[] nodes) |
static void |
ExprNodeUtility.toExpressionStringParameterList(ExprNode[] childNodes,
java.io.StringWriter buffer) |
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.toExpressionStringWWildcardParams(java.io.StringWriter writer,
ExprNode[] params,
boolean isWildcard,
java.lang.String streamWildcard,
boolean firstParamOnly) |
static void |
ExprNodeUtility.validatePlainExpression(ExprNodeOrigin origin,
java.lang.String expressionTextualName,
ExprNode expression) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType) |
void |
ExprNodeVisitor.visit(ExprNode exprNode)
Visit the given expression node.
|
void |
ExprNodeViewResourceVisitor.visit(ExprNode exprNode) |
void |
ExprNodeVariableVisitor.visit(ExprNode exprNode) |
void |
ExprNodeSummaryVisitor.visit(ExprNode exprNode) |
void |
ExprNodeSubselectDeclaredDotVisitor.visit(ExprNode exprNode) |
void |
ExprNodeStreamUseCollectVisitor.visit(ExprNode exprNode) |
void |
ExprNodeIdentifierVisitor.visit(ExprNode exprNode) |
void |
ExprNodeIdentifierCollectVisitor.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) |
Modifier and Type | Method and Description |
---|---|
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.List<ExprNode> nodes) |
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.Set<Pair<java.lang.Integer,java.lang.String>> |
ExprNodeUtility.getNonAggregatedProps(EventType[] types,
java.util.List<ExprNode> exprNodes,
ContextPropertyRegistry contextPropertyRegistry) |
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) |
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) |
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) |
Constructor and Description |
---|
CaseAnalysis(java.util.List<UniformPair<ExprNode>> whenThenNodeList,
ExprNode optionalCompareExprNode,
ExprNode optionalElseExprNode) |
ExprAggMultiFunctionLinearAccessNodeFactory(ExprAggMultiFunctionLinearAccessNode parent,
java.lang.Class resultType,
int streamNum,
ExprEvaluator childNode,
ExprNode indexEvalNode,
boolean istreamOnly,
boolean ondemandQuery) |
ExprAggMultiFunctionSortedMinMaxByNodeFactory(ExprAggMultiFunctionSortedMinMaxByNode parent,
int streamNum,
java.lang.Class resultType,
ExprNode[] criteriaExpressions,
MethodResolutionService methodResolutionService,
boolean[] sortDescending,
ExprEvaluator[] evaluators,
boolean ever) |
ExprNodeProxy(java.lang.String engineURI,
java.lang.String statementName,
ExprNode exprNode) |
ExprNodeValidated(ExprNode inner)
Ctor.
|
Constructor and Description |
---|
CaseAnalysis(java.util.List<UniformPair<ExprNode>> whenThenNodeList,
ExprNode optionalCompareExprNode,
ExprNode optionalElseExprNode) |
ExprChainedSpec(java.lang.String name,
java.util.List<ExprNode> parameters,
boolean property) |
Modifier and Type | Method and Description |
---|---|
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)
Builds join tuple composer.
|
Constructor and Description |
---|
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) |
Constructor and Description |
---|
IndexedTableLookupStrategySingleExpr(ExprNode exprNode,
int streamNum,
PropertyIndexedEventTableSingle index,
LookupStrategyDesc strategyDesc)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
HistoricalDataPlanNode(int streamNum,
int rootStreamNum,
int lookupStreamNum,
int numStreams,
ExprNode exprNode)
Ctor.
|
InKeywordTableLookupPlanMultiIdx(int lookupStream,
int indexedStream,
java.lang.String[] indexNum,
ExprNode keyExpr)
Ctor.
|
InKeywordTableLookupPlanSingleIdx(int lookupStream,
int indexedStream,
java.lang.String indexNum,
ExprNode[] expressions)
Ctor.
|
QueryGraphValueDesc(ExprNode[] indexExprs,
QueryGraphValueEntry entry) |
QueryGraphValueEntryHashKeyed(ExprNode keyExpr) |
QueryGraphValueEntryHashKeyedExpr(ExprNode keyExpr,
boolean requiresKey) |
QueryGraphValueEntryHashKeyedProp(ExprNode keyExpr,
java.lang.String keyProperty) |
QueryGraphValueEntryRangeIn(QueryGraphRangeEnum rangeType,
ExprNode exprStart,
ExprNode exprEnd,
boolean allowRangeReversal) |
QueryGraphValueEntryRangeRelOp(QueryGraphRangeEnum type,
ExprNode expression,
boolean isBetweenPart) |
QueryGraphValuePairInKWMultiIdx(ExprNode[] indexed,
QueryGraphValueEntryInKeywordMultiIdx key) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
SubordPropInKeywordMultiIndex.getExpression() |
ExprNode[] |
SubordPropInKeywordSingleIndex.getExpressions() |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
DotMethodFPProvidedParam.getExpression() |
Modifier and Type | Method and Description |
---|---|
static void |
DotMethodUtil.validateSpecificType(java.lang.String methodUsedName,
DotMethodTypeEnum type,
DotMethodFPParamTypeEnum expectedTypeEnum,
java.lang.Class expectedTypeClass,
java.lang.Class providedType,
int parameterNum,
ExprNode parameterExpression) |
Modifier and Type | Method and Description |
---|---|
static DotMethodFPProvided |
DotMethodUtil.getProvidedFootprint(java.util.List<ExprNode> parameters) |
Constructor and Description |
---|
DotMethodFPProvidedParam(int lambdaParamNum,
java.lang.Class returnType,
ExprNode expression) |
Modifier and Type | Method and Description |
---|---|
java.util.List<ExprNode> |
NamedWindowConsumerDesc.getFilterList() |
Modifier and Type | Method and Description |
---|---|
NamedWindowOnExprBaseView |
NamedWindowRootViewInstance.addOnExpr(NamedWindowOnExprFactory onExprFactory,
AgentInstanceContext agentInstanceContext,
ExprNode joinExpr,
EventType filterEventType,
ResultSetProcessor resultSetProcessor,
java.lang.String streamNameOn,
ExcludePlanHint excludePlanHint,
IndexHint indexHint)
Add an on-trigger view that, using a lookup strategy, looks up from the named window and may select or delete rows.
|
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,
NamedWindowUpdateHelper updateHelper,
java.lang.annotation.Annotation[] annotations) |
Constructor and Description |
---|
NamedWindowOnMergeMatch(ExprNode optionalCond,
java.util.List<NamedWindowOnMergeAction> actions) |
Constructor and Description |
---|
NamedWindowConsumerDesc(java.util.List<ExprNode> filterList,
PropertyEvaluator optPropertyEvaluator,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
static ExprNode[] |
ASTExprHelper.exprCollectSubNodesPerNode(java.util.List<EsperEPL2GrammarParser.ExpressionContext> expression,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static ExprNode |
ASTExprHelper.mathGetExpr(ParseTree ctx,
java.util.Map<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) |
Modifier and Type | Method and Description |
---|---|
static java.util.List<ExprNode> |
ASTExprHelper.exprCollectSubNodes(Tree parentNode,
int startIndex,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static java.util.List<ExprNode> |
ASTLibFunctionHelper.getExprNodesLibFunc(EsperEPL2GrammarParser.LibFunctionArgsContext ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
Modifier and Type | Method and Description |
---|---|
static void |
ASTExprHelper.addOptionalNumber(ExprNode exprNode,
EsperEPL2GrammarParser.NumberContext number) |
static void |
ASTExprHelper.addOptionalSimpleProperty(ExprNode exprNode,
Token token,
VariableService variableService,
StatementSpecRaw spec) |
static void |
ASTExprHelper.exprCollectAddSubNodes(ExprNode parentNode,
Tree node,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static void |
ASTExprHelper.exprCollectAddSubNodesAddParentNode(ExprNode exprNode,
Tree node,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static void |
ASTExprHelper.exprCollectAddSubNodesExpressionCtx(ExprNode parentNode,
java.util.List<EsperEPL2GrammarParser.ExpressionContext> expressionContexts,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static boolean |
ASTMatchUntilHelper.validate(ExprNode lowerBounds,
ExprNode upperBounds,
boolean isAllowLowerZero)
Validate.
|
Modifier and Type | Method and Description |
---|---|
static OutputLimitSpec |
ASTOutputLimitHelper.buildOutputLimitSpec(CommonTokenStream tokenStream,
EsperEPL2GrammarParser.OutputLimitContext ctx,
java.util.Map<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.exprCollectAddSubNodes(ExprNode parentNode,
Tree node,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static void |
ASTExprHelper.exprCollectAddSubNodesAddParentNode(ExprNode exprNode,
Tree node,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static void |
ASTExprHelper.exprCollectAddSubNodesExpressionCtx(ExprNode parentNode,
java.util.List<EsperEPL2GrammarParser.ExpressionContext> expressionContexts,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static java.util.List<ExprNode> |
ASTExprHelper.exprCollectSubNodes(Tree parentNode,
int startIndex,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static ExprNode[] |
ASTExprHelper.exprCollectSubNodesPerNode(java.util.List<EsperEPL2GrammarParser.ExpressionContext> expression,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static java.util.List<ExprNode> |
ASTLibFunctionHelper.getExprNodesLibFunc(EsperEPL2GrammarParser.LibFunctionArgsContext ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static java.util.List<ExprChainedSpec> |
ASTLibFunctionHelper.getLibFuncChain(java.util.List<EsperEPL2GrammarParser.LibFunctionNoClassContext> ctxs,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static ExprChainedSpec |
ASTLibFunctionHelper.getLibFunctionChainSpec(EsperEPL2GrammarParser.LibFunctionNoClassContext ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static void |
ASTLibFunctionHelper.handleLibFunc(CommonTokenStream tokenStream,
EsperEPL2GrammarParser.LibFunctionContext ctx,
ConfigurationInformation configurationInformation,
EngineImportService engineImportService,
java.util.Map<Tree,ExprNode> astExprNodeMap,
LazyAllocatedMap<ConfigurationPlugInAggregationMultiFunction,PlugInAggregationMultiFunctionFactory> plugInAggregations,
java.lang.String engineURI,
ExpressionDeclDesc expressionDeclarations,
ExprDeclaredService exprDeclaredService,
java.util.List<ExpressionScriptProvided> scriptExpressions,
ContextDescriptor contextDescriptor) |
static ExprNode |
ASTExprHelper.mathGetExpr(ParseTree ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap,
ConfigurationInformation configurationInformation) |
static ExprTimePeriod |
ASTExprHelper.timePeriodGetExprAllParams(EsperEPL2GrammarParser.TimePeriodContext ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap,
VariableService variableService,
StatementSpecRaw spec) |
static ExprTimePeriod |
ASTExprHelper.timePeriodGetExprJustSeconds(EsperEPL2GrammarParser.ExpressionContext expression,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static CreateContextDesc |
ASTContextHelper.walkCreateContext(EsperEPL2GrammarParser.CreateContextExprContext ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap,
java.util.Map<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<Tree,ExprNode> astExprNodeMap) |
static FilterSpecRaw |
ASTFilterSpecHelper.walkFilterSpec(EsperEPL2GrammarParser.EventFilterExpressionContext ctx,
PropertyEvalSpec propertyEvalSpec,
java.util.Map<Tree,ExprNode> astExprNodeMap) |
static void |
ASTGroupByHelper.walkGroupBy(EsperEPL2GrammarParser.GroupByListExprContext ctx,
java.util.Map<Tree,ExprNode> astExprNodeMap,
java.util.List<GroupByClauseElement> groupByExpressions) |
Modifier and Type | Class and Description |
---|---|
class |
ExprNodeScript |
Modifier and Type | Method and Description |
---|---|
java.util.List<ExprNode> |
ExprNodeScript.getAdditionalNodes() |
java.util.List<ExprNode> |
ExprNodeScript.getParameters() |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprNodeScript.equalsNode(ExprNode node) |
Constructor and Description |
---|
ExprNodeScript(java.lang.String defaultDialect,
ExpressionScriptProvided script,
java.util.List<ExprNode> parameters) |
Modifier and Type | Method and Description |
---|---|
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[] |
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.
|
Modifier and Type | Method and Description |
---|---|
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> |
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() |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
ContextDetailCategoryItem(ExprNode expression,
java.lang.String name) |
ContextDetailInitiatedTerminated(ContextDetailCondition start,
ContextDetailCondition end,
boolean overlapping,
ExprNode[] distinctExpressions) |
CreateVariableDesc(java.lang.String variableType,
java.lang.String variableName,
ExprNode assignment,
boolean constant,
boolean array)
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) |
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) |
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) |
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,
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)
Ctor.
|
UpdateDesc(java.lang.String optionalStreamName,
java.util.List<OnTriggerSetAssignment> assignments,
ExprNode optionalWhereClause)
Ctor.
|
Constructor and Description |
---|
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,
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)
Ctor.
|
ViewSpec(java.lang.String namespace,
java.lang.String objectName,
java.util.List<ExprNode> viewParameters)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
static java.util.List<ExprNode> |
StatementSpecRawAnalyzer.collectExpressionsShallow(StatementSpecRaw raw) |
Constructor and Description |
---|
SubselectAggregatorViewFilteredGrouped(AggregationService aggregationService,
ExprEvaluator optionalFilterExpr,
ExprEvaluatorContext exprEvaluatorContext,
ExprEvaluator[] groupKeys,
ExprNode filterExprNode) |
SubselectAggregatorViewFilteredUngrouped(AggregationService aggregationService,
ExprEvaluator optionalFilterExpr,
ExprEvaluatorContext exprEvaluatorContext,
ExprEvaluator[] groupKeys,
ExprNode filterExprNode) |
Constructor and Description |
---|
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) |
OutputConditionPolledExpression(ExprNode whenExpressionNode,
java.util.List<OnTriggerSetAssignment> assignments,
AgentInstanceContext agentInstanceContext)
Ctor.
|
Constructor and Description |
---|
OutputConditionCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList,
StatementContext statementContext) |
OutputConditionPolledCrontab(java.util.List<ExprNode> scheduleSpecExpressionList,
AgentInstanceContext agentInstanceContext)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
VirtualDWViewFactoryImpl.setViewParameters(ViewFactoryContext viewFactoryContext,
java.util.List<ExprNode> viewParameters) |
Modifier and Type | Method and Description |
---|---|
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 |
FilterSpecCompiler.rewriteOrToInIfApplicable(ExprNode constituent) |
Modifier and Type | Method and Description |
---|---|
static java.util.List<ExprNode> |
FilterSpecCompiler.decomposeCheckAggregation(java.util.List<ExprNode> validatedNodes) |
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.
|
Modifier and Type | Method and Description |
---|---|
void |
FilterParamExprMap.put(ExprNode exprNode,
FilterSpecParam param)
Add a node and filter param.
|
static ExprNode |
FilterSpecCompiler.rewriteOrToInIfApplicable(ExprNode constituent) |
Modifier and Type | Method and Description |
---|---|
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> 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,
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,
ConfigurationInformation configurationInformation,
NamedWindowService namedWindowService) |
static java.util.List<ExprNode> |
FilterSpecCompiler.decomposeCheckAggregation(java.util.List<ExprNode> validatedNodes) |
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.
|
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.
|
Constructor and Description |
---|
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) |
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,
EventAdapterService eventAdapterService,
ConfigurationInformation configurationInformation,
java.lang.String statementName,
boolean hasSubquery)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
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.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) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
EvalMatchUntilFactoryNode.getLowerBounds() |
ExprNode |
EvalMatchUntilFactoryNode.getSingleBound() |
ExprNode |
EvalMatchUntilFactoryNode.getUpperBounds() |
Modifier and Type | Method and Description |
---|---|
java.util.List<ExprNode> |
EvalEveryDistinctFactoryNode.getDistinctExpressions()
Returns distinct expressions.
|
java.util.List<ExprNode> |
EvalEveryDistinctFactoryNode.getExpressions()
Returns all expressions.
|
java.util.List<ExprNode> |
EvalFollowedByFactoryNode.getOptionalMaxExpressions() |
Modifier and Type | Method and Description |
---|---|
static java.lang.Object |
PatternExpressionUtil.evaluate(java.lang.String objectName,
MatchedEventMap beginState,
ExprNode parameter,
MatchedEventConvertor convertor,
ExprEvaluatorContext exprEvaluatorContext)
Evaluate the pattern expression.
|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
PlugInAggregationMultiFunctionValidationContext.getParameterExpressions()
Returns parameters expressions to this aggregation function.
|
Constructor and Description |
---|
PlugInAggregationMultiFunctionValidationContext(java.lang.String functionName,
EventType[] eventTypes,
ExprNode[] parameterExpressions,
java.lang.String engineURI,
java.lang.String statementName,
ExprValidationContext validationContext,
ConfigurationPlugInAggregationMultiFunction config)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
RegexPartitionStateRepoGroupMeta.getPartitionExpressionNodes() |
Modifier and Type | Method and Description |
---|---|
void |
EventRowRegexNFAViewFactory.setViewParameters(ViewFactoryContext viewFactoryContext,
java.util.List<ExprNode> viewParameters) |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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,
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.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
TimeOrderView.getTimestampExpression()
Returns the timestamp property name.
|
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
RouteResultView(boolean isFirst,
EventType eventType,
EPStatementHandle epStatementHandle,
InternalEventRouter internalEventRouter,
boolean[] isNamedWindowInsert,
ResultSetProcessor[] processors,
ExprNode[] whereClauses,
AgentInstanceContext agentInstanceContext)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static StatViewAdditionalProps |
StatViewAdditionalProps.make(ExprNode[] validated,
int startIndex,
EventType parentEventType) |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
BaseBivariateStatisticsView(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(AgentInstanceContext agentInstanceContext,
ExprNode xExpression,
ExprNode yExpression,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor.
|
RegressionLinestView(AgentInstanceContext agentInstanceContext,
ExprNode xFieldName,
ExprNode yFieldName,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor.
|
UnivariateStatisticsView(AgentInstanceContext agentInstanceContext,
ExprNode fieldExpression,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the field to use in the parent view to compute the statistics.
|
WeightedAverageView(AgentInstanceContext agentInstanceContext,
ExprNode fieldNameX,
ExprNode fieldNameWeight,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the field to use in the parent view to compute the weighted average on,
as well as the name of the field in the parent view to get the weight from.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
FirstUniqueByPropertyView(ExprNode[] uniqueCriteria,
AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
Constructor.
|
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.
|
UniqueByPropertyView(ExprNode[] criteriaExpressions,
AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExternallyTimedWindowView.getTimestampExpression()
Returns the field name to get timestamp values from.
|
ExprNode |
ExternallyTimedBatchView.getTimestampExpression()
Returns the field name to get timestamp values from.
|
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
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.
|