Uses of Class
com.espertech.esper.epl.expression.core.ExprValidationException

Packages that use ExprValidationException
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.dataflow.core Data flow core classes. 
com.espertech.esper.dataflow.ops Data flow built-in operators. 
com.espertech.esper.epl.agg.rollup Aggregation roll-up services. 
com.espertech.esper.epl.agg.service Aggregation services. 
com.espertech.esper.epl.annotation Classes for EPL annotation processing. 
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.enummethod.eval Enumeration method implementations. 
com.espertech.esper.epl.expression.accessagg Access-aggregation expressions. 
com.espertech.esper.epl.expression.baseagg Base aggregation expressions. 
com.espertech.esper.epl.expression.core Core expression classes. 
com.espertech.esper.epl.expression.dot Chained expression functionality. 
com.espertech.esper.epl.expression.funcs Function expressions. 
com.espertech.esper.epl.expression.methodagg Method-aggregation expressions. 
com.espertech.esper.epl.expression.ops Operator expressions. 
com.espertech.esper.epl.expression.prev 'Previous'-group expressions. 
com.espertech.esper.epl.expression.prior 'Prior'-group expressions. 
com.espertech.esper.epl.expression.subquery Subselect expressions. 
com.espertech.esper.epl.expression.table Table access and identifiers expressions. 
com.espertech.esper.epl.expression.time Time-related expressions. 
com.espertech.esper.epl.join.base Join process interfaces and glue code 
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.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.property Classes for handling events-within-events. 
com.espertech.esper.epl.rettype EPL-internal expression return type. 
com.espertech.esper.epl.script Script expression evaluation. 
com.espertech.esper.epl.script.jsr223 JSR-223 script expression evaluation. 
com.espertech.esper.epl.script.mvel MVEL 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.table.merge Table on-merge handlers. 
com.espertech.esper.epl.table.mgmt Table-related services and metadata. 
com.espertech.esper.epl.table.onaction Table on-action handlers. 
com.espertech.esper.epl.table.strategy Table access evaluators. 
com.espertech.esper.epl.table.upd Table update strategies. 
com.espertech.esper.epl.updatehelper Helpers for EPL update functionality. 
com.espertech.esper.epl.util EPL utility classes. 
com.espertech.esper.epl.variable Variable service and variable collections 
com.espertech.esper.epl.view Internal processing views for output rate limiting, filtering and internal event routing 
com.espertech.esper.event This package defines the internal event APIs. 
com.espertech.esper.event.bean JavaBean and legacy Java underlying event classes are here. 
com.espertech.esper.event.vaevent Value added events are revision events and variant events. 
com.espertech.esper.filter Main switchboard filtering and routing of incoming events to interested statements is performed in this package. 
com.espertech.esper.rowregex Match-recognize expression tree and state objects. 
com.espertech.esper.util Utility classes that center around Java type handling, printing, reflection, debugging 
com.espertech.esper.view View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering. 
 

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

Methods in com.espertech.esper.core.context.factory that throw ExprValidationException
protected static StatementAgentInstanceFactoryOnTriggerNamedWindow.IndexHintPair StatementAgentInstanceFactoryOnTriggerNamedWindow.getIndexHintPair(StatementContext statementContext, StatementSpecCompiled statementSpec)
           
 

Constructors in com.espertech.esper.core.context.factory that throw ExprValidationException
StatementAgentInstanceFactoryOnTriggerNamedWindow(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, NamedWindowOnExprFactory onExprFactory, OutputProcessViewFactory outputProcessViewFactory, EventType activatorResultEventType, NamedWindowProcessor processor)
           
StatementAgentInstanceFactoryOnTriggerTable(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, TableOnViewFactory onExprFactory, EventType activatorResultEventType, TableMetadata tableMetadata, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, OutputProcessViewFactory outputProcessViewFactory)
           
 

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

Methods in com.espertech.esper.core.context.mgr that throw ExprValidationException
 void ContextManagementServiceImpl.addContextSpec(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, CreateContextDesc contextDesc, boolean isRecoveringResilient)
           
 void ContextManagementService.addContextSpec(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, CreateContextDesc contextDesc, boolean isRecoveringResilient)
           
static void ContextPropertyEventType.addEndpointTypes(java.lang.String contextName, ContextDetailCondition endpoint, java.util.Map<java.lang.String,java.lang.Object> properties, java.util.Set<java.lang.String> allTags)
           
 void ContextManagerNested.addStatement(ContextControllerStatementBase statement, boolean isRecoveringResilient)
           
 void ContextManagerImpl.addStatement(ContextControllerStatementBase statement, boolean isRecoveringResilient)
           
 void ContextManager.addStatement(ContextControllerStatementBase statement, boolean isRecoveringResilient)
           
 void ContextManagementServiceImpl.addStatement(java.lang.String contextName, ContextControllerStatementBase statement, boolean isRecoveringResilient)
           
 void ContextManagementService.addStatement(java.lang.String contextName, ContextControllerStatementBase statement, boolean isRecoveringResilient)
           
static ContextControllerHashFactory.HashFunctionEnum ContextControllerHashFactory.HashFunctionEnum.determine(java.lang.String contextName, java.lang.String name)
           
 ContextControllerFactory[] ContextControllerFactoryServiceImpl.getFactory(ContextControllerFactoryServiceContext serviceContext)
           
 ContextControllerFactory[] ContextControllerFactoryService.getFactory(ContextControllerFactoryServiceContext context)
           
static ContextControllerFactory[] ContextControllerFactoryHelper.getFactory(ContextControllerFactoryServiceContext serviceContext, ContextStateCache contextStateCache)
           
protected static java.lang.Class[] ContextControllerPartitionedUtil.validateContextDesc(java.lang.String contextName, ContextDetailPartitioned segmentedSpec)
           
 void ContextControllerPartitionedFactory.validateFactory()
           
 void ContextControllerInitTermFactory.validateFactory()
           
 void ContextControllerHashFactory.validateFactory()
           
 void ContextControllerFactory.validateFactory()
           
 void ContextControllerCategoryFactory.validateFactory()
           
 ContextControllerStatementCtxCache ContextControllerPartitionedFactory.validateStatement(ContextControllerStatementBase statement)
           
 ContextControllerStatementCtxCache ContextControllerHashFactory.validateStatement(ContextControllerStatementBase statement)
           
 ContextControllerStatementCtxCache ContextControllerFactory.validateStatement(ContextControllerStatementBase statement)
           
 ContextControllerStatementCtxCache ContextControllerCategoryFactory.validateStatement(ContextControllerStatementBase statement)
           
protected static void ContextControllerPartitionedUtil.validateStatementForContext(java.lang.String contextName, ContextControllerStatementBase statement, StatementSpecCompiledAnalyzerResult streamAnalysis, java.util.Collection<EventType> itemEventTypes, NamedWindowService namedWindowService)
           
 

Constructors in com.espertech.esper.core.context.mgr that throw ExprValidationException
ContextControllerHashedGetterSingleRow(java.lang.String statementName, java.lang.String functionName, Pair<java.lang.Class,EngineImportSingleRowDesc> func, java.util.List<ExprNode> parameters, int granularity, MethodResolutionService methodResolutionService, EventType eventType, EventAdapterService eventAdapterService, java.lang.String statementId, TableService tableService)
           
ContextManagerImpl(ContextControllerFactoryServiceContext factoryServiceContext)
           
ContextManagerNested(ContextControllerFactoryServiceContext factoryServiceContext)
           
 

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

Constructors in com.espertech.esper.core.context.subselect that throw ExprValidationException
SubSelectStrategyFactoryIndexShare(java.lang.String statementName, java.lang.String statementId, int subqueryNum, EventType[] outerEventTypesSelect, NamedWindowProcessor optionalNamedWindowProcessor, TableMetadata optionalTableMetadata, boolean fullTableScan, IndexHint optionalIndexHint, SubordPropPlan joinedPropPlan, ExprEvaluator filterExprEval, AggregationServiceFactoryDesc aggregationServiceFactory, ExprEvaluator[] groupByKeys, TableService tableService, java.lang.annotation.Annotation[] annotations, StatementStopService statementStopService)
           
 

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

Methods in com.espertech.esper.core.service that throw ExprValidationException
static SelectClauseSpecCompiled StatementLifecycleSvcImpl.compileSelectAllowSubselect(SelectClauseSpecRaw spec)
          Compile a select clause allowing subselects.
 InternalEventRouterDesc InternalEventRouterImpl.getValidatePreprocessing(EventType eventType, UpdateDesc desc, java.lang.annotation.Annotation[] annotations)
           
 InternalEventRouterDesc InternalEventRouter.getValidatePreprocessing(EventType eventType, UpdateDesc desc, java.lang.annotation.Annotation[] annotations)
           
static void StatementLifecycleSvcUtil.walkStatement(StatementSpecRaw spec, ExprNodeSubselectDeclaredDotVisitor visitor)
           
 

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

Methods in com.espertech.esper.core.start that throw ExprValidationException
protected static SubSelectActivationCollection EPStatementStartMethodHelperSubselect.createSubSelectActivation(EPServicesContext services, StatementSpecCompiled statementSpecContainer, StatementContext statementContext, EPStatementDestroyCallbackList destroyCallbacks)
           
protected  AgentInstanceContext EPStatementStartMethodBase.getDefaultAgentInstanceContext(StatementContext statementContext)
           
protected  EPStatementAgentInstanceHandle EPStatementStartMethodBase.getDefaultAgentInstanceHandle(StatementContext statementContext)
           
abstract  EPPreparedExecuteIUDSingleStreamExec EPPreparedExecuteIUDSingleStream.getExecutor(FilterSpecCompiled filter, java.lang.String aliasName)
           
 EPPreparedExecuteIUDSingleStreamExec EPPreparedExecuteIUDInsertInto.getExecutor(FilterSpecCompiled filter, java.lang.String aliasName)
           
protected static SubSelectStrategyCollection EPStatementStartMethodHelperSubselect.planSubSelect(EPServicesContext services, StatementContext statementContext, boolean queryPlanLogging, SubSelectActivationCollection subSelectStreamDesc, java.lang.String[] outerStreamNames, EventType[] outerEventTypesSelect, java.lang.String[] outerEventTypeNamees, ExprDeclaredNode[] declaredExpressions, ContextPropertyRegistry contextPropertyRegistry)
           
static EPStatementStartMethodSelectDesc EPStatementStartMethodSelectUtil.prepare(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext, boolean recoveringResilient, AgentInstanceContext defaultAgentInstanceContext, boolean queryPlanLogging, ViewableActivatorFactory optionalViewableActivatorFactory, OutputProcessViewCallback optionalOutputProcessViewCallback, SelectExprProcessorDeliveryCallback selectExprProcessorDeliveryCallback)
           
 EPStatementStartResult EPStatementStartMethodBase.start(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethod.start(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
          Starts the EPL statement.
 EPStatementStartResult EPStatementStartMethodUpdate.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodSelect.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodOnTrigger.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateWindow.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateVariable.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateTable.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateSchema.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateIndex.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateGraph.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateExpression.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateContext.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
abstract  EPStatementStartResult EPStatementStartMethodBase.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
protected static ExprNode EPStatementStartMethodHelperValidate.validateExprNoAgg(ExprNodeOrigin exprNodeOrigin, ExprNode exprNode, StreamTypeService streamTypeService, StatementContext statementContext, ExprEvaluatorContext exprEvaluatorContext, java.lang.String errorMsg, boolean allowTableConsumption)
           
protected static void EPPreparedExecuteMethodHelper.validateFAFQuery(StatementSpecCompiled statementSpec)
           
protected  ExprNode EPStatementStartMethodOnTrigger.validateJoinNamedWindow(java.lang.String engineURI, StatementContext statementContext, ExprNodeOrigin exprNodeOrigin, ExprNode deleteJoinExpr, EventType namedWindowType, java.lang.String namedWindowStreamName, java.lang.String namedWindowName, EventType filteredType, java.lang.String filterStreamName, java.lang.String filteredTypeName, java.lang.String optionalTableName)
           
protected static void EPStatementStartMethodHelperValidate.validateNoAggregations(ExprNode exprNode, java.lang.String errorMsg)
           
static void EPStatementStartMethodHelperValidate.validateNoDataWindowOnNamedWindow(java.util.List<ViewFactory> viewFactories)
           
static FireAndForgetProcessor FireAndForgetProcessorFactory.validateResolveProcessor(StreamSpecCompiled streamSpec, EPServicesContext services)
           
protected static void EPStatementStartMethodHelperValidate.validateSubqueryExcludeOuterStream(ExprNode matchCondition)
           
static ViewResourceDelegateVerified EPStatementStartMethodHelperViewResources.verifyPreviousAndPriorRequirements(ViewFactoryChain[] unmaterializedViewChain, ViewResourceDelegateUnverified delegate)
           
 

Constructors in com.espertech.esper.core.start that throw ExprValidationException
EPPreparedExecuteIUDInsertInto(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext)
           
EPPreparedExecuteIUDSingleStream(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext)
          Ctor.
EPPreparedExecuteIUDSingleStreamDelete(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext)
           
EPPreparedExecuteIUDSingleStreamUpdate(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext)
           
EPPreparedExecuteMethodQuery(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext)
          Ctor.
 

Uses of ExprValidationException in com.espertech.esper.dataflow.core
 

Methods in com.espertech.esper.dataflow.core that throw ExprValidationException
 void DataFlowServiceImpl.addStartGraph(CreateDataFlowDesc desc, StatementContext statementContext, EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, boolean newStatement)
           
 void DataFlowService.addStartGraph(CreateDataFlowDesc desc, StatementContext statementContext, EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, boolean newStatement)
           
 

Uses of ExprValidationException in com.espertech.esper.dataflow.ops
 

Methods in com.espertech.esper.dataflow.ops that throw ExprValidationException
 DataFlowOpInitializeResult Select.initialize(DataFlowOpInitializateContext context)
           
 

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

Methods in com.espertech.esper.epl.agg.rollup that throw ExprValidationException
static GroupByClauseExpressions GroupByExpressionHelper.getGroupByRollupExpressions(java.util.List<GroupByClauseElement> groupByElements, SelectClauseSpecRaw selectClauseSpec, ExprNode optionalHavingNode, java.util.List<OrderByItem> orderByList, ExprNodeSubselectDeclaredDotVisitor visitor)
           
 

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

Methods in com.espertech.esper.epl.agg.service that return ExprValidationException
static ExprValidationException AggregationServiceFactoryFactory.getRollupReclaimEx()
           
 

Methods in com.espertech.esper.epl.agg.service that throw ExprValidationException
 AggregationServiceFactory AggregationServiceFactoryServiceImpl.getGroupReclaimAged(ExprEvaluator[] evaluatorsArr, AggregationMethodFactory[] aggregatorsArr, Hint reclaimGroupAged, Hint reclaimGroupFrequency, VariableService variableService, AggregationAccessorSlotPair[] pairs, AggregationStateFactory[] accessAggregations, boolean join, java.lang.Object groupKeyBinding, java.lang.String optionalContextName)
           
 AggregationServiceFactory AggregationServiceFactoryService.getGroupReclaimAged(ExprEvaluator[] evaluatorsArr, AggregationMethodFactory[] aggregatorsArr, Hint reclaimGroupAged, Hint reclaimGroupFrequency, VariableService variableService, AggregationAccessorSlotPair[] pairs, AggregationStateFactory[] accessAggregations, boolean join, java.lang.Object groupKeyBinding, java.lang.String optionalContextName)
           
 ExprEvaluator AggregationMethodFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
static AggregationServiceFactoryDesc AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes, java.util.Map<ExprNode,java.lang.String> selectClauseNamedNodes, java.util.List<ExprDeclaredNode> declaredExpressions, ExprNode[] groupByNodes, java.util.List<ExprAggregateNode> havingAggregateExprNodes, java.util.List<ExprAggregateNode> orderByAggregateExprNodes, java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions, boolean hasGroupByClause, java.lang.annotation.Annotation[] annotations, VariableService variableService, boolean isJoin, boolean isDisallowNoReclaim, ExprNode whereClause, ExprNode havingClause, AggregationServiceFactoryService factoryService, EventType[] typesPerStream, MethodResolutionService methodResolutionService, AggregationGroupByRollupDesc groupByRollupDesc, java.lang.String optionalContextName, IntoTableSpec intoTableSpec, TableService tableService)
          Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on whether there are any group-by nodes.
static AggregationServiceMatchRecognizeFactoryDesc AggregationServiceFactoryFactory.getServiceMatchRecognize(int numStreams, java.util.Map<java.lang.Integer,java.util.List<ExprAggregateNode>> measureExprNodesPerStream, EventType[] typesPerStream)
          Produces an aggregation service for use with match-recognice.
static void AggregationMethodFactoryUtil.validateAggFuncName(java.lang.String requiredName, java.lang.String providedName)
           
static void AggregationMethodFactoryUtil.validateAggregationFilter(boolean requireFilter, boolean provideFilter)
           
static void AggregationMethodFactoryUtil.validateAggregationInputType(java.lang.Class requiredParam, java.lang.Class providedParam)
           
static void AggregationMethodFactoryUtil.validateAggregationType(AggregationMethodFactory requiredFactory, AggregationMethodFactory providedFactory)
           
static void AggregationMethodFactoryUtil.validateAggregationUnbound(boolean requiredHasDataWindows, boolean providedHasDataWindows)
           
static void AggregationMethodFactoryUtil.validateEventType(EventType requiredType, EventType providedType)
           
 void AggregationMethodFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
static void AggregationMethodFactoryUtil.validateStreamNumZero(int streamNum)
           
 

Constructors in com.espertech.esper.epl.agg.service that throw ExprValidationException
AggSvcGroupByReclaimAgedFactory(ExprEvaluator[] evaluators, AggregationMethodFactory[] prototypes, java.lang.Object groupKeyBinding, Hint reclaimGroupAged, Hint reclaimGroupFrequency, VariableService variableService, AggregationAccessorSlotPair[] accessors, AggregationStateFactory[] accessAggregations, boolean isJoin, java.lang.String optionalContextName)
          Ctor.
 

Uses of ExprValidationException in com.espertech.esper.epl.annotation
 

Methods in com.espertech.esper.epl.annotation that throw ExprValidationException
static java.lang.String AnnotationUtil.getExpectSingleStringValue(java.lang.String msgPrefix, java.util.List<AnnotationDesc> annotationsSameName)
           
 

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

Methods in com.espertech.esper.epl.core that throw ExprValidationException
static SelectExprProcessor SelectExprJoinWildcardProcessorFactory.create(java.util.Collection<java.lang.Integer> assignedTypeNumberStack, java.lang.String statementId, java.lang.String[] streamNames, EventType[] streamTypes, EventAdapterService eventAdapterService, InsertIntoDesc insertIntoDesc, SelectExprEventTypeRegistry selectExprEventTypeRegistry, MethodResolutionService methodResolutionService, java.lang.annotation.Annotation[] annotations, ConfigurationInformation configuration, TableService tableService)
          Ctor.
static HistoricalEventViewable MethodPollingViewableFactory.createPollMethodView(int streamNumber, MethodStreamSpec methodStreamSpec, EventAdapterService eventAdapterService, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, MethodResolutionService methodResolutionService, EngineImportService engineImportService, SchedulingService schedulingService, ScheduleBucket scheduleBucket, ExprEvaluatorContext exprEvaluatorContext, VariableService variableService, java.lang.String contextName)
          Creates a method-invocation polling view for use as a stream that calls a method, or pulls results from cache.
protected static java.util.Comparator<java.lang.Object> OrderByProcessorFactoryImpl.getComparator(OrderByElement[] orderBy, boolean isSortUsingCollator)
          Returns a comparator for order items that may sort string values using Collator.
 SelectExprProcessor SelectExprProcessorHelper.getEvaluator()
           
static SelectExprProcessor SelectExprInsertEventBeanFactory.getInsertUnderlyingJoinWildcard(EventAdapterService eventAdapterService, EventType eventType, java.lang.String[] streamNames, EventType[] streamTypes, EngineImportService engineImportService)
           
static SelectExprProcessor SelectExprInsertEventBeanFactory.getInsertUnderlyingNonJoin(EventAdapterService eventAdapterService, EventType eventType, boolean isUsingWildcard, StreamTypeService typeService, ExprEvaluator[] expressionNodes, java.lang.String[] columnNames, java.lang.Object[] expressionReturnTypes, EngineImportService engineImportService, InsertIntoDesc insertIntoDesc, java.lang.String[] columnNamesAsProvided, boolean allowNestableTargetFragmentTypes)
           
static SelectExprProcessor SelectExprProcessorFactory.getProcessor(java.util.Collection<java.lang.Integer> assignedTypeNumberStack, SelectClauseElementCompiled[] selectionList, boolean isUsingWildcard, InsertIntoDesc insertIntoDesc, EventType optionalInsertIntoEventType, ForClauseSpec forClauseSpec, StreamTypeService typeService, EventAdapterService eventAdapterService, StatementResultService statementResultService, ValueAddEventService valueAddEventService, SelectExprEventTypeRegistry selectExprEventTypeRegistry, MethodResolutionService methodResolutionService, ExprEvaluatorContext exprEvaluatorContext, VariableService variableService, TableService tableService, TimeProvider timeProvider, java.lang.String engineURI, java.lang.String statementId, java.lang.String statementName, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, ConfigurationInformation configuration, SelectExprProcessorDeliveryCallback selectExprProcessorCallback, NamedWindowService namedWindowService, IntoTableSpec intoTableClause)
          Returns the processor to use for a given select-clause.
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 ResultSetProcessorFactoryDesc ResultSetProcessorFactoryFactory.getProcessorPrototype(StatementSpecCompiled statementSpec, StatementContext stmtContext, StreamTypeService typeService, ViewResourceDelegateUnverified viewResourceDelegate, boolean[] isUnidirectionalStream, boolean allowAggregation, ContextPropertyRegistry contextPropertyRegistry, SelectExprProcessorDeliveryCallback selectExprProcessorCallback, ConfigurationInformation configurationInformation)
          Returns the result set process for the given select expression, group-by clause and having clause given a set of types describing each stream in the from-clause.
 void MethodPollingViewable.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
           
protected static void SelectExprProcessorFactory.verifyNameUniqueness(SelectClauseElementCompiled[] selectionList)
          Verify that each given name occurs exactly one.
 

Constructors in com.espertech.esper.epl.core that throw ExprValidationException
BindProcessor(SelectClauseElementCompiled[] selectionList, EventType[] typesPerStream, java.lang.String[] streamNames, TableService tableService)
          Ctor.
OrderByProcessorFactoryImpl(java.util.List<OrderByItem> orderByList, ExprNode[] groupByNodes, boolean needsGroupByKeys, boolean isSortUsingCollator)
          Ctor.
RowLimitProcessorFactory(RowLimitSpec rowLimitSpec, VariableService variableService, java.lang.String optionalContextName)
          Ctor.
SelectExprProcessorHelper(java.util.Collection<java.lang.Integer> assignedTypeNumberStack, java.util.List<SelectClauseExprCompiledSpec> selectionList, java.util.List<SelectExprStreamDesc> selectedStreams, InsertIntoDesc insertIntoDesc, EventType optionalInsertIntoOverrideType, boolean isUsingWildcard, StreamTypeService typeService, EventAdapterService eventAdapterService, ValueAddEventService valueAddEventService, SelectExprEventTypeRegistry selectExprEventTypeRegistry, MethodResolutionService methodResolutionService, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, ConfigurationInformation configuration, NamedWindowService namedWindowService, TableService tableService)
          Ctor.
SelectExprWildcardProcessor(EventType eventType)
          Ctor.
 

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

Methods in com.espertech.esper.epl.core.eval that return ExprValidationException
static ExprValidationException EvalInsertUtil.makeEventTypeCastException(java.lang.Class sourceType, EventType targetType)
           
static ExprValidationException EvalInsertUtil.makeEventTypeCastException(EventType sourceType, EventType targetType)
           
 

Methods in com.espertech.esper.epl.core.eval that throw ExprValidationException
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)
           
 

Constructors in com.espertech.esper.epl.core.eval that throw ExprValidationException
EvalInsertBeanRecast(EventType targetType, EventAdapterService eventAdapterService, int streamNumber, EventType[] typesPerStream)
           
EvalInsertBeanWrapRecast(WrapperEventType targetType, EventAdapterService eventAdapterService, int streamNumber, EventType[] typesPerStream)
           
 

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

Methods in com.espertech.esper.epl.datetime.calop that throw ExprValidationException
static CalendarFieldEnum CalendarOpUtil.getEnum(java.lang.String methodName, ExprNode exprNode)
           
 CalendarOp CalendarOpFactory.getOp(DatetimeMethodEnum method, java.lang.String methodNameUsed, java.util.List<ExprNode> parameters, ExprEvaluator[] evaluators)
           
 

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

Methods in com.espertech.esper.epl.datetime.eval that throw ExprValidationException
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)
           
 

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

Methods in com.espertech.esper.epl.datetime.interval that throw ExprValidationException
 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)
           
 

Constructors in com.espertech.esper.epl.datetime.interval that throw ExprValidationException
IntervalComputerFactory.IntervalComputerConstantCoincides(IntervalStartEndParameterPair pair)
           
IntervalOpImpl(DatetimeMethodEnum method, java.lang.String methodNameUse, StreamTypeService streamTypeService, java.util.List<ExprNode> expressions)
           
 

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

Methods in com.espertech.esper.epl.datetime.reformatop that throw ExprValidationException
 ReformatOp ReformatOpFactory.getOp(DatetimeMethodEnum method, java.lang.String methodNameUsed, java.util.List<ExprNode> parameters)
           
 

Constructors in com.espertech.esper.epl.datetime.reformatop that throw ExprValidationException
ReformatOpBetweenConstantParams(java.util.List<ExprNode> parameters)
           
ReformatOpBetweenNonConstantParams(java.util.List<ExprNode> parameters)
           
 

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

Methods in com.espertech.esper.epl.db that throw ExprValidationException
static HistoricalEventViewable DatabasePollingViewableFactory.createDBStatementView(java.lang.String statementId, int streamNumber, DBStatementStreamSpec databaseStreamSpec, DatabaseConfigService databaseConfigService, EventAdapterService eventAdapterService, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, SQLColumnTypeConversion columnTypeConversionHook, SQLOutputRowConversion outputRowConversionHook, boolean enableJDBCLogging)
          Creates the viewable for polling via database SQL query.
protected static java.lang.String DatabasePollingViewableFactory.lexSampleSQL(java.lang.String querySQL)
          Lexes the sample SQL and inserts a "where 1=0" where-clause.
 void DatabasePollingViewable.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
           
 

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

Methods in com.espertech.esper.epl.declexpr that throw ExprValidationException
 java.lang.String ExprDeclaredServiceImpl.addExpressionOrScript(CreateExpressionDesc expressionDesc)
           
 java.lang.String ExprDeclaredService.addExpressionOrScript(CreateExpressionDesc expression)
           
 java.lang.Class ExprDeclaredEvalBase.getComponentTypeCollection()
           
 EventType ExprDeclaredEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprDeclaredEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Integer> ExprDeclaredNodeImpl.getOuterStreamNames(java.util.Map<java.lang.String,java.lang.Integer> outerStreamNames)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Integer> ExprDeclaredNode.getOuterStreamNames(java.util.Map<java.lang.String,java.lang.Integer> outerStreamNames)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprDeclaredEvalBase.getRowProperties()
           
 ExprNode ExprDeclaredNodeImpl.validate(ExprValidationContext validationContext)
           
 

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

Methods in com.espertech.esper.epl.enummethod.dot that throw ExprValidationException
 java.lang.Class PropertyExprEvaluatorScalarIterable.getComponentTypeCollection()
           
 java.lang.Class PropertyExprEvaluatorScalarCollection.getComponentTypeCollection()
           
 java.lang.Class PropertyExprEvaluatorScalarArray.getComponentTypeCollection()
           
 java.lang.Class PropertyExprEvaluatorEventSingle.getComponentTypeCollection()
           
 java.lang.Class PropertyExprEvaluatorEventCollection.getComponentTypeCollection()
           
abstract  EnumEval ExprDotEvalEnumMethodBase.getEnumEval(MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, StreamTypeService streamTypeService, java.lang.String statementId, java.lang.String enumMethodUsedName, java.util.List<ExprDotEvalParam> bodiesAndParameters, EventType inputEventType, java.lang.Class collectionComponentType, int numStreamsIncoming, boolean disablePropertyExpressionEventCollCache)
           
 EventType PropertyExprEvaluatorScalarIterable.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType PropertyExprEvaluatorScalarCollection.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType PropertyExprEvaluatorScalarArray.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType PropertyExprEvaluatorEventSingle.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType PropertyExprEvaluatorEventCollection.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 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)
           
 ExprNode ExprLambdaGoesNode.validate(ExprValidationContext validationContext)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.enummethod.eval
 

Methods in com.espertech.esper.epl.enummethod.eval that throw ExprValidationException
 EnumEval ExprDotEvalSetExceptUnionIntersect.getEnumEval(MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, StreamTypeService streamTypeService, java.lang.String statementId, java.lang.String enumMethodUsedName, java.util.List<ExprDotEvalParam> bodiesAndParameters, EventType inputEventType, java.lang.Class collectionComponentType, int numStreamsIncoming, boolean disablePropertyExpressionEventCollCache)
           
 EnumEval ExprDotEvalSequenceEqual.getEnumEval(MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, StreamTypeService streamTypeService, java.lang.String statementId, java.lang.String enumMethodUsedName, java.util.List<ExprDotEvalParam> bodiesAndParameters, EventType inputEventType, java.lang.Class collectionComponentType, int numStreamsIncoming, boolean disablePropertyExpressionEventCollCache)
           
 

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

Methods in com.espertech.esper.epl.expression.accessagg that return ExprValidationException
 ExprValidationException ExprAggCountMinSketchNode.getDeclaredWrongParameterExpr()
           
 

Methods in com.espertech.esper.epl.expression.accessagg that throw ExprValidationException
static void ExprAggMultiFunctionUtil.checkWildcardNotJoinOrSubquery(StreamTypeService streamTypeService, java.lang.String aggFuncName)
           
 java.lang.Class ExprPlugInAggMultiFunctionNode.getComponentTypeCollection()
           
 java.lang.Class ExprAggMultiFunctionSortedMinMaxByNode.getComponentTypeCollection()
           
 java.lang.Class ExprAggMultiFunctionLinearAccessNode.getComponentTypeCollection()
           
 java.lang.Class ExprAggCountMinSketchNode.getComponentTypeCollection()
           
 ExprValidationException ExprAggCountMinSketchNode.getDeclaredWrongParameterExpr()
           
 EventType ExprAggCountMinSketchNode.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprPlugInAggMultiFunctionNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprAggMultiFunctionLinearAccessNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprAggCountMinSketchNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 ExprEvaluator ExprPlugInAggMultiFunctionNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAggMultiFunctionSortedMinMaxByNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAggMultiFunctionLinearAccessNodeFactoryMethod.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAggMultiFunctionLinearAccessNodeFactoryAccess.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAggCountMinSketchNodeFactoryUse.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAggCountMinSketchNodeFactoryState.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 AggregationMethodFactory ExprPlugInAggMultiFunctionNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprAggMultiFunctionSortedMinMaxByNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprAggMultiFunctionLinearAccessNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprAggCountMinSketchNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprPlugInAggMultiFunctionNode.validateAggregationParamsWBinding(ExprValidationContext validationContext, TableMetadataColumnAggregation tableAccessColumn)
           
 AggregationMethodFactory ExprAggregateAccessMultiValueNode.validateAggregationParamsWBinding(ExprValidationContext context, TableMetadataColumnAggregation tableAccessColumn)
           
 AggregationMethodFactory ExprAggMultiFunctionSortedMinMaxByNode.validateAggregationParamsWBinding(ExprValidationContext validationContext, TableMetadataColumnAggregation tableAccessColumn)
           
 AggregationMethodFactory ExprAggMultiFunctionLinearAccessNode.validateAggregationParamsWBinding(ExprValidationContext validationContext, TableMetadataColumnAggregation tableAccessColumn)
           
 AggregationMethodFactory ExprAggCountMinSketchNode.validateAggregationParamsWBinding(ExprValidationContext context, TableMetadataColumnAggregation tableAccessColumn)
           
 void ExprPlugInAggMultiFunctionNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAggMultiFunctionSortedMinMaxByNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAggMultiFunctionLinearAccessNodeFactoryMethod.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAggMultiFunctionLinearAccessNodeFactoryAccess.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAggCountMinSketchNodeFactoryUse.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAggCountMinSketchNodeFactoryState.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAggregateAccessMultiValueNode.validatePositionals()
           
static int ExprAggMultiFunctionUtil.validateStreamWildcardGetStreamNum(ExprNode node)
           
static void ExprAggMultiFunctionUtil.validateWildcardStreamNumbers(StreamTypeService streamTypeService, java.lang.String aggFuncName)
           
 

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

Methods in com.espertech.esper.epl.expression.baseagg that return ExprValidationException
protected  ExprValidationException ExprAggregateNodeBase.makeExceptionExpectedParamNum(int lower, int upper)
           
 

Methods in com.espertech.esper.epl.expression.baseagg that throw ExprValidationException
static ExprAggregateNodeParamDesc ExprAggregateNodeUtil.getValidatePositionalParams(ExprNode[] childNodes, boolean allowOnlyGroupBy)
           
 ExprNode ExprAggregateNodeGroupKey.validate(ExprValidationContext validationContext)
           
 ExprNode ExprAggregateNodeBase.validate(ExprValidationContext validationContext)
           
protected abstract  AggregationMethodFactory ExprAggregateNodeBase.validateAggregationChild(ExprValidationContext validationContext)
          Gives the aggregation node a chance to validate the sub-expression types.
 void ExprAggregateNodeBase.validateFilter(ExprEvaluator filterEvaluator)
           
protected  java.lang.Class ExprAggregateNodeBase.validateNumericChildAllowFilter(boolean hasFilter)
          For use by implementing classes, validates the aggregation node expecting a single numeric-type child node.
 void ExprAggregateNodeBase.validatePositionals()
           
 void ExprAggregateNode.validatePositionals()
           
 

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

Subclasses of ExprValidationException in com.espertech.esper.epl.expression.core
 class ExprValidationPropertyException
          Thrown to indicate a validation error in an expression originating from a property resolution error.
 

Methods in com.espertech.esper.epl.expression.core that return ExprValidationException
 ExprValidationException ExprNodeUtilResolveExceptionHandlerDefault.handle(java.lang.Exception e)
           
 ExprValidationException ExprNodeUtilResolveExceptionHandler.handle(java.lang.Exception e)
           
static ExprValidationException ExprGroupingIdNode.makeException(java.lang.String functionName)
           
 

Methods in com.espertech.esper.epl.expression.core that throw ExprValidationException
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node)
           
 java.lang.Class ExprEvaluatorEnumeration.getComponentTypeCollection()
           
 EventType ExprEvaluatorEnumeration.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprEvaluatorEnumeration.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
static ExprNodePropOrStreamSet ExprNodeUtility.getGroupByPropertiesValidateHasOne(ExprNode[] groupByNodes)
           
static java.util.Map<java.lang.String,ExprNamedParameterNode> ExprNodeUtility.getNamedExpressionsHandleDups(java.util.List<ExprNode> parameters)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprEvaluatorTypableReturn.getRowProperties()
          Return null to indicate no row-type result available, or a map of property names and types to indicate a row-type result is available.
static ExprNode ExprNodeUtility.getValidatedAssignment(OnTriggerSetAssignment assignment, ExprValidationContext validationContext)
           
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 ExprNodeUtilMethodDesc ExprNodeUtility.resolveMethodAllowWildcardAndStream(java.lang.String className, java.lang.Class optionalClass, java.lang.String methodName, java.util.List<ExprNode> parameters, MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, java.lang.String statementId, boolean allowWildcard, EventType wildcardType, ExprNodeUtilResolveExceptionHandler exceptionHandler, java.lang.String functionName, TableService tableService)
           
static ScheduleSpec ExprNodeUtility.toCrontabSchedule(ExprNodeOrigin origin, java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext context, boolean allowBindingConsumption)
           
static void ExprNodeUtility.validate(ExprNodeOrigin origin, java.util.List<ExprChainedSpec> chainSpec, ExprValidationContext validationContext)
           
 ExprNode ExprWildcardImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprVariableNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprValidator.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTypedNoEvalNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprSubstitutionNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprStreamUnderlyingNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprOrderedExpr.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetRange.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetList.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetFrequency.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNumberSetCronParam.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNodeValidated.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNamedParameterNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprIdentNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprGroupingNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprGroupingIdNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCurrentEvaluationContextNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprContextPropertyNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprConstantNodeImpl.validate(ExprValidationContext validationContext)
           
static void ExprNodeUtility.validateNamed(java.util.Map<java.lang.String,ExprNamedParameterNode> namedExpressions, java.lang.String[] namedParameters)
           
static boolean ExprNodeUtility.validateNamedExpectType(ExprNamedParameterNode namedParameterNode, java.lang.Class[] expectedTypes)
           
static void ExprNodeUtility.validateNoSpecialsGroupByExpressions(ExprNode[] groupByNodes)
           
static void ExprNodeUtility.validatePlainExpression(ExprNodeOrigin origin, java.lang.String expressionTextualName, ExprNode expression)
           
static ExprNode ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin, ExprNode expression, StatementContext statementContext, EventType optionalEventType, boolean allowBindingConsumption)
           
 

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

Methods in com.espertech.esper.epl.expression.dot that throw ExprValidationException
static ExprDotNodeRealizedChain ExprDotNodeUtility.getChainEvaluators(java.lang.Integer streamOfProviderIfApplicable, EPType inputType, java.util.List<ExprChainedSpec> chainSpec, ExprValidationContext validationContext, boolean isDuckTyping, ExprDotNodeFilterAnalyzerInput inputDesc)
           
 java.lang.Class ExprDotEvalRootChild.getComponentTypeCollection()
           
static ExprDotEnumerationSource ExprDotNodeUtility.getEnumerationSource(ExprNode inputExpression, StreamTypeService streamTypeService, EventAdapterService eventAdapterService, java.lang.String statementId, boolean hasEnumerationMethod, boolean disablePropertyExpressionEventCollCache)
           
 EventType ExprDotEvalRootChild.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprDotEvalRootChild.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 ExprNode ExprDotNode.validate(ExprValidationContext validationContext)
           
 

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

Methods in com.espertech.esper.epl.expression.funcs that throw ExprValidationException
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprCaseNode.getRowProperties()
           
 ExprNode ExprTypeofNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprPropertyExistsNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprPlugInSingleRowNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprMinMaxRowNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprIStreamNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprInstanceofNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCoalesceNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCastNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprCaseNode.validate(ExprValidationContext validationContext)
           
 

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

Methods in com.espertech.esper.epl.expression.methodagg that throw ExprValidationException
static ExprEvaluator ExprMethodAggUtil.getDefaultEvaluator(ExprNode[] childNodes, boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprSumNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprStddevNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprRateAggNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprPlugInAggFunctionFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprNthAggNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprMinMaxAggrNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprMedianNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprLeavingAggNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprLastEverNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprFirstEverNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprCountNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprCountEverNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAvgNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
 ExprEvaluator ExprAvedevNodeFactory.getMethodAggregationEvaluator(boolean join, EventType[] typesPerStream)
           
static ExprEvaluator ExprCountNodeFactory.getMethodAggregationEvaluatorCountBy(ExprNode[] childNodes, boolean join, EventType[] typesPerStream)
           
static ExprEvaluator ExprMethodAggUtil.getMultiNodeEvaluator(ExprNode[] childNodes, boolean join, EventType[] typesPerStream)
           
 AggregationMethodFactory ExprSumNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprStddevNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprRateAggNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprPlugInAggFunctionFactoryNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprNthAggNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprMinMaxAggrNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprMedianNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprLeavingAggNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprLastEverNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprFirstEverNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprCountNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprCountEverNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprAvgNode.validateAggregationChild(ExprValidationContext validationContext)
           
 AggregationMethodFactory ExprAvedevNode.validateAggregationChild(ExprValidationContext validationContext)
           
 void ExprSumNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprStddevNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprRateAggNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprPlugInAggFunctionFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprNthAggNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprMinMaxAggrNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprMedianNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprLeavingAggNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprLastEverNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprFirstEverNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprCountNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprCountEverNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAvgNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 void ExprAvedevNodeFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg)
           
 

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

Methods in com.espertech.esper.epl.expression.ops that throw ExprValidationException
 java.lang.Class ExprArrayNode.getComponentTypeCollection()
           
 EventType ExprArrayNode.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprArrayNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprNewStructNode.getRowProperties()
           
 ExprNode ExprRelationalOpNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprRelationalOpAllAnyNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprRegexpNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprOrNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNotNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNewStructNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprNewInstanceNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprMathNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprLikeNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprInNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprEqualsNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprEqualsAllAnyNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprConcatNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprBitWiseNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprBetweenNodeImpl.validate(ExprValidationContext validationContext)
           
 ExprNode ExprArrayNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprAndNodeImpl.validate(ExprValidationContext validationContext)
           
 void ExprInNodeImpl.validateWithoutContext()
           
 void ExprInNode.validateWithoutContext()
           
 

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

Methods in com.espertech.esper.epl.expression.prev that throw ExprValidationException
 java.lang.Class ExprPreviousNode.getComponentTypeCollection()
           
 EventType ExprPreviousNode.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprPreviousNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 ExprNode ExprPreviousNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprPreviousMatchRecognizeNode.validate(ExprValidationContext validationContext)
           
 

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

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

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

Methods in com.espertech.esper.epl.expression.subquery that throw ExprValidationException
static SubselectEvalStrategy SubselectEvalStrategyFactory.createStrategy(ExprSubselectNode subselectExpression, boolean isNot, boolean isAll, boolean isAny, RelationalOpEnum relationalOp)
          Create a strategy.
 java.lang.Class ExprSubselectRowNode.getComponentTypeCollection()
           
 java.lang.Class ExprSubselectInNode.getComponentTypeCollection()
           
 java.lang.Class ExprSubselectExistsNode.getComponentTypeCollection()
           
 java.lang.Class ExprSubselectAllSomeAnyNode.getComponentTypeCollection()
           
 EventType ExprSubselectRowNode.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprSubselectRowNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprSubselectInNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprSubselectExistsNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprSubselectAllSomeAnyNode.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprSubselectNode.getRowProperties()
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprSubselectRowNode.typableGetRowProperties()
           
abstract  java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprSubselectNode.typableGetRowProperties()
           
 ExprNode ExprSubselectNode.validate(ExprValidationContext validationContext)
           
 void ExprSubselectRowNode.validateSubquery(ExprValidationContext validationContext)
           
abstract  void ExprSubselectNode.validateSubquery(ExprValidationContext validationContext)
           
 void ExprSubselectInNode.validateSubquery(ExprValidationContext validationContext)
           
 void ExprSubselectExistsNode.validateSubquery(ExprValidationContext validationContext)
           
 void ExprSubselectAllSomeAnyNode.validateSubquery(ExprValidationContext validationContext)
           
 

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

Methods in com.espertech.esper.epl.expression.table that throw ExprValidationException
 java.lang.Class ExprTableIdentNodeSubpropAccessor.getComponentTypeCollection()
           
 java.lang.Class ExprTableAccessNodeSubpropAccessor.getComponentTypeCollection()
           
 java.lang.Class ExprTableAccessNodeSubprop.getComponentTypeCollection()
           
 EventType ExprTableIdentNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprTableAccessNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprTableAccessNodeSubprop.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprTableIdentNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprTableAccessNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprTableAccessNodeSubprop.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 java.util.LinkedHashMap<java.lang.String,java.lang.Object> ExprTableAccessNodeTopLevel.getRowProperties()
           
 ExprNode ExprTableIdentNodeSubpropAccessor.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTableIdentNode.validate(ExprValidationContext validationContext)
           
 ExprNode ExprTableAccessNode.validate(ExprValidationContext validationContext)
           
protected  void ExprTableAccessNodeTopLevel.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNodeSubpropAccessor.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNodeSubprop.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNodeKeys.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected abstract  void ExprTableAccessNode.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
static void ExprTableNodeUtil.validateExpressions(java.lang.String tableName, java.lang.Class[] providedTypes, java.lang.String providedName, ExprNode[] providedExpr, java.lang.Class[] expectedTypes, java.lang.String expectedName)
           
protected  void ExprTableAccessNode.validateGroupKeys(TableMetadata metadata)
           
protected  TableMetadataColumn ExprTableAccessNode.validateSubpropertyGetCol(TableMetadata tableMetadata, java.lang.String subpropName)
           
 

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

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

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

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

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

Methods in com.espertech.esper.epl.join.hint that throw ExprValidationException
static ExcludePlanHint ExcludePlanHint.getHint(java.lang.String[] streamNames, StatementContext statementContext)
           
static ExprEvaluator ExcludePlanHintExprUtil.toExpression(java.lang.String hint, StatementContext statementContext)
           
 

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

Methods in com.espertech.esper.epl.join.plan that throw ExprValidationException
protected static QueryPlan NStreamOuterQueryPlanBuilder.build(QueryGraph queryGraph, OuterJoinDesc[] outerJoinDescList, java.lang.String[] streamNames, EventType[] typesPerStream, HistoricalViewableDesc historicalViewableDesc, DependencyGraph dependencyGraph, HistoricalStreamIndexList[] historicalStreamIndexLists, ExprEvaluatorContext exprEvaluatorContext, java.lang.String[][][] indexedStreamsUniqueProps, TableMetadata[] tablesPerStream)
          Build a query plan based on the stream property relationships indicated in queryGraph.
static QueryPlan QueryPlanBuilder.getPlan(EventType[] typesPerStream, OuterJoinDesc[] outerJoinDescList, QueryGraph queryGraph, java.lang.String[] streamNames, HistoricalViewableDesc historicalViewableDesc, DependencyGraph dependencyGraph, HistoricalStreamIndexList[] historicalStreamIndexLists, StreamJoinAnalysisResult streamJoinAnalysisResult, boolean isQueryPlanLogging, java.lang.annotation.Annotation[] annotations, ExprEvaluatorContext exprEvaluatorContext)
          Build query plan using the filter.
protected static void NStreamOuterQueryPlanBuilder.recursiveBuild(int streamNum, java.util.Stack<java.lang.Integer> streamCallStack, QueryGraph queryGraph, OuterInnerDirectionalGraph outerInnerGraph, InnerJoinGraph innerJoinGraph, java.util.Set<java.lang.Integer> completedStreams, java.util.LinkedHashMap<java.lang.Integer,int[]> substreamsPerStream, boolean[] requiredPerStream, DependencyGraph dependencyGraph)
          Recusivly builds a substream-per-stream ordered tree graph using the join information supplied for outer joins and from the query graph (where clause).
protected static void NStreamOuterQueryPlanBuilder.recursiveBuildInnerJoin(int streamNum, java.util.Stack<java.lang.Integer> streamCallStack, QueryGraph queryGraph, java.util.Set<java.lang.Integer> completedStreams, java.util.LinkedHashMap<java.lang.Integer,int[]> substreamsPerStream, DependencyGraph dependencyGraph)
          Recusivly builds a substream-per-stream ordered tree graph using the join information supplied for outer joins and from the query graph (where clause).
 

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

Methods in com.espertech.esper.epl.lookup that throw ExprValidationException
 void EventTableIndexMetadata.addIndex(boolean isPrimary, IndexMultiKey indexMultiKey, java.lang.String explicitIndexName, java.lang.String statementName, boolean failIfExists)
           
static void SubordinateQueryPlannerUtil.addIndexMetaAndRef(SubordinateQueryIndexDesc[] indexDescs, EventTableIndexMetadata repo, java.lang.String statementName)
           
 void EventTableIndexRepository.validateAddExplicitIndex(boolean unique, java.lang.String indexName, java.util.List<CreateIndexItem> columns, EventType eventType, java.lang.Iterable<EventBean> dataWindowContents)
           
static EventTableCreateIndexDesc EventTableIndexUtil.validateCompileExplicitIndex(boolean unique, java.util.List<CreateIndexItem> columns, EventType eventType)
           
 

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

Methods in com.espertech.esper.epl.methodbase that throw ExprValidationException
static DotMethodFP DotMethodUtil.validateParametersDetermineFootprint(DotMethodFP[] footprints, DotMethodTypeEnum methodType, java.lang.String methodUsedName, DotMethodFPProvided providedFootprint, DotMethodInputTypeMatcher inputTypeMatcher)
           
static void DotMethodUtil.validateSpecificType(java.lang.String methodUsedName, DotMethodTypeEnum type, DotMethodFPParamTypeEnum expectedTypeEnum, java.lang.Class expectedTypeClass, java.lang.Class providedType, int parameterNum, ExprNode parameterExpression)
           
 

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

Methods in com.espertech.esper.epl.named that throw ExprValidationException
 void NamedWindowRootViewInstance.addExplicitIndex(boolean unique, java.lang.String indexName, java.util.List<CreateIndexItem> columns)
          Add an explicit index.
static NamedWindowOnExprFactory NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType, java.lang.String namedWindowName, java.lang.String namedWindowAlias, OnTriggerDesc onTriggerDesc, EventType filterEventType, java.lang.String filterStreamName, boolean addToFront, InternalEventRouter internalEventRouter, EventType outputEventType, StatementContext statementContext, StatementMetricHandle createNamedWindowMetricsHandle, boolean isDistinct, StreamSelector optionalStreamSelector, java.lang.String optionalInsertIntoTableName)
           
 void NamedWindowProcessor.validateAddIndex(java.lang.String statementName, java.lang.String indexName, IndexMultiKey imk)
           
 

Constructors in com.espertech.esper.epl.named that throw ExprValidationException
NamedWindowOnMergeHelper(StatementContext statementContext, OnTriggerMergeDesc onTriggerDesc, EventType triggeringEventType, java.lang.String triggeringStreamName, InternalEventRouter internalEventRouter, java.lang.String namedWindowName, EventTypeSPI namedWindowType)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.property
 

Methods in com.espertech.esper.epl.property that throw ExprValidationException
static PropertyEvaluator PropertyEvaluatorFactory.makeEvaluator(PropertyEvalSpec spec, EventType sourceEventType, java.lang.String optionalSourceStreamName, EventAdapterService eventAdapterService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, java.lang.String engineURI, java.lang.String statementId, java.lang.String statementName, java.lang.annotation.Annotation[] annotations, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, ConfigurationInformation configuration, NamedWindowService namedWindowService)
          Makes the property evaluator.
 

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

Methods in com.espertech.esper.epl.rettype that throw ExprValidationException
static EPType EPTypeHelper.optionalFromEnumerationExpr(java.lang.String statementId, EventAdapterService eventAdapterService, ExprNode exprNode)
           
 

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

Methods in com.espertech.esper.epl.script that throw ExprValidationException
 java.lang.Class ExprNodeScriptEvalBase.getComponentTypeCollection()
           
 EventType ExprNodeScriptEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprNodeScriptEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 ExprNode ExprNodeScript.validate(ExprValidationContext validationContext)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.script.jsr223
 

Methods in com.espertech.esper.epl.script.jsr223 that throw ExprValidationException
static javax.script.CompiledScript JSR223Helper.verifyCompileScript(ExpressionScriptProvided script, java.lang.String dialect)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.script.mvel
 

Methods in com.espertech.esper.epl.script.mvel that throw ExprValidationException
static ExpressionScriptCompiled MVELHelper.compile(java.lang.String scriptName, java.lang.String expression, java.util.Map<java.lang.String,java.lang.Class> mvelInputParamTypes)
           
static void MVELHelper.verifyScript(ExpressionScriptProvided script)
          Verify MVEL script (not compiling it).
 

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

Methods in com.espertech.esper.epl.spec that throw ExprValidationException
 StreamSpecCompiled StreamSpecRaw.compile(StatementContext statementContext, java.util.Set<java.lang.String> eventTypeReferences, boolean isInsertInto, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, boolean isJoin, boolean isContextDeclaration, boolean isOnTrigger)
          Compiles a raw stream specification consisting event type information and filter expressions to an validated, optimized form for use with filter service
 PatternStreamSpecCompiled PatternStreamSpecRaw.compile(StatementContext context, java.util.Set<java.lang.String> eventTypeReferences, boolean isInsertInto, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, boolean isJoin, boolean isContextDeclaration, boolean isOnTrigger)
           
 StreamSpecCompiled MethodStreamSpec.compile(StatementContext context, java.util.Set<java.lang.String> eventTypeReferences, boolean isInsertInto, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, boolean isJoin, boolean isContextDeclaration, boolean isOnTrigger)
           
 StreamSpecCompiled FilterStreamSpecRaw.compile(StatementContext context, java.util.Set<java.lang.String> eventTypeReferences, boolean isInsertInto, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, boolean isJoin, boolean isContextDeclaration, boolean isOnTrigger)
           
 PatternStreamSpecCompiled PatternStreamSpecRaw.compile(StatementContext context, java.util.Set<java.lang.String> eventTypeReferences, boolean isInsertInto, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, MatchEventSpec priorTags, java.util.Set<java.lang.String> priorAllTags, boolean isJoin, boolean isContextDeclaration, boolean isOnTrigger)
           
static EventType FilterStreamSpecRaw.resolveType(java.lang.String engineURI, java.lang.String eventName, EventAdapterService eventAdapterService, java.net.URI[] optionalResolutionURIs)
          Resolves a given event name to an event type.
 void MatchRecognizeInterval.validate(ExprValidationContext validationContext)
           
 

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

Methods in com.espertech.esper.epl.spec.util that throw ExprValidationException
static java.util.List<FilterSpecRaw> StatementSpecRawAnalyzer.analyzeFilters(StatementSpecRaw spec)
           
static ExprNodeSubselectDeclaredDotVisitor StatementSpecRawAnalyzer.walkSubselectAndDeclaredDotExpr(StatementSpecRaw spec)
           
 

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

Constructors in com.espertech.esper.epl.table.merge that throw ExprValidationException
TableOnMergeHelper(StatementContext statementContext, OnTriggerMergeDesc onTriggerDesc, EventType triggeringEventType, java.lang.String triggeringStreamName, InternalEventRouter internalEventRouter, TableMetadata tableMetadata)
           
 

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

Methods in com.espertech.esper.epl.table.mgmt that throw ExprValidationException
 void TableStateInstanceUngrouped.addExplicitIndex(CreateIndexDesc spec)
           
 void TableStateInstanceGroupBy.addExplicitIndex(CreateIndexDesc spec)
           
abstract  void TableStateInstance.addExplicitIndex(CreateIndexDesc spec)
           
 TableMetadata TableServiceImpl.addTable(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory tableStateRowFactory, int numberMethodAggregations, StatementContext statementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 TableMetadata TableService.addTable(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory tableStateRowFactory, int numberMethodAggregations, StatementContext statementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 ExprTableIdentNode TableServiceImpl.getTableIdentNode(StreamTypeService streamTypeService, java.lang.String unresolvedPropertyName, java.lang.String streamOrPropertyName)
           
 ExprTableIdentNode TableService.getTableIdentNode(StreamTypeService streamTypeService, java.lang.String unresolvedPropertyName, java.lang.String streamOrPropertyName)
           
 Pair<ExprNode,java.util.List<ExprChainedSpec>> TableServiceImpl.getTableNodeChainable(StreamTypeService streamTypeService, java.util.List<ExprChainedSpec> chainSpec, EngineImportService engineImportService)
           
 Pair<ExprNode,java.util.List<ExprChainedSpec>> TableService.getTableNodeChainable(StreamTypeService streamTypeService, java.util.List<ExprChainedSpec> chainSpec, EngineImportService engineImportService)
           
 TableUpdateStrategy TableServiceImpl.getTableUpdateStrategy(TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 TableUpdateStrategy TableService.getTableUpdateStrategy(TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 void TableServiceImpl.validateAddIndex(java.lang.String createIndexStatementName, TableMetadata tableMetadata, java.lang.String indexName, IndexMultiKey imk)
           
 void TableService.validateAddIndex(java.lang.String createIndexStatementName, TableMetadata tableMetadata, java.lang.String indexName, IndexMultiKey imk)
           
 void TableMetadata.validateAddIndexAssignUpdateStrategies(java.lang.String createIndexStatementName, IndexMultiKey imk, java.lang.String indexName)
           
 

Constructors in com.espertech.esper.epl.table.mgmt that throw ExprValidationException
TableMetadata(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory rowFactory, int numberMethodAggregations, StatementResourceService createTableResources, java.lang.String contextName, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging, java.lang.String createTableStatementName)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.table.onaction
 

Methods in com.espertech.esper.epl.table.onaction that throw ExprValidationException
static TableOnViewFactory TableOnViewFactoryFactory.make(TableMetadata tableMetadata, OnTriggerDesc onTriggerDesc, EventType filterEventType, java.lang.String filterStreamName, StatementContext statementContext, StatementMetricHandle metricsHandle, boolean isDistinct, InternalEventRouter internalEventRouter)
           
 

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

Methods in com.espertech.esper.epl.table.strategy that throw ExprValidationException
 java.lang.Class ExprTableExprEvaluatorAccess.getComponentTypeCollection()
           
 EventType ExprTableExprEvaluatorAccess.getEventTypeCollection(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 EventType ExprTableExprEvaluatorAccess.getEventTypeSingle(EventAdapterService eventAdapterService, java.lang.String statementId)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.table.upd
 

Methods in com.espertech.esper.epl.table.upd that throw ExprValidationException
static TableUpdateStrategy TableUpdateStrategyFactory.validateGetTableUpdateStrategy(TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.updatehelper
 

Methods in com.espertech.esper.epl.updatehelper that throw ExprValidationException
static EventBeanUpdateHelper EventBeanUpdateHelperFactory.make(java.lang.String updatedWindowOrTableName, EventTypeSPI eventTypeSPI, java.util.List<OnTriggerSetAssignment> assignments, java.lang.String updatedAlias, EventType optionalTriggeringEventType, boolean isCopyOnWrite)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.util
 

Methods in com.espertech.esper.epl.util that throw ExprValidationException
static void EPLValidationUtil.validateContextName(boolean table, java.lang.String tableOrNamedWindowName, java.lang.String tableOrNamedWindowContextName, java.lang.String optionalContextName, boolean mustMatchContext)
           
static void EPLValidationUtil.validateTableExists(TableService tableService, java.lang.String name)
           
 

Uses of ExprValidationException in com.espertech.esper.epl.variable
 

Methods in com.espertech.esper.epl.variable that throw ExprValidationException
static void VariableServiceUtil.checkAlreadyDeclaredTable(java.lang.String variableName, TableService tableService)
           
static void VariableServiceUtil.checkAlreadyDeclaredVariable(java.lang.String variableName, VariableService variableService)
           
 

Constructors in com.espertech.esper.epl.variable that throw ExprValidationException
OnSetVariableViewFactory(java.lang.String statementId, OnTriggerSetDesc desc, EventAdapterService eventAdapterService, VariableService variableService, StatementResultService statementResultService, ExprEvaluatorContext exprEvaluatorContext)
          Ctor.
VariableReadWritePackage(java.util.List<OnTriggerSetAssignment> assignments, VariableService variableService, EventAdapterService eventAdapterService)
          Ctor.
 

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

Methods in com.espertech.esper.epl.view that throw ExprValidationException
static OutputConditionPolled OutputConditionPolledFactory.createCondition(OutputLimitSpec outputLimitSpec, AgentInstanceContext agentInstanceContext)
          Creates an output condition instance.
static OutputConditionFactory OutputConditionFactoryFactory.createCondition(OutputLimitSpec outputLimitSpec, StatementContext statementContext, boolean isGrouped, boolean isWithHavingClause, boolean isStartConditionOnCreation)
          Creates an output condition instance.
static OutputProcessViewFactory OutputProcessViewFactoryFactory.make(StatementSpecCompiled statementSpec, InternalEventRouter internalEventRouter, StatementContext statementContext, EventType resultEventType, OutputProcessViewCallback optionalOutputProcessViewCallback, TableService tableService)
           
 

Constructors in com.espertech.esper.epl.view that throw ExprValidationException
OutputConditionCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext statementContext, boolean isStartConditionOnCreation)
           
OutputConditionExpressionFactory(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, StatementContext statementContext, ExprNode andWhenTerminatedExpr, java.util.List<OnTriggerSetAssignment> afterTerminateAssignments, boolean isStartConditionOnCreation)
           
OutputConditionFirstFactory(OutputLimitSpec outputLimitSpec, StatementContext statementContext, boolean isGrouped, boolean isWithHavingClause)
           
OutputConditionPolledCrontab(java.util.List<ExprNode> scheduleSpecExpressionList, AgentInstanceContext agentInstanceContext)
          Constructor.
OutputConditionPolledExpression(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, AgentInstanceContext agentInstanceContext)
          Ctor.
 

Uses of ExprValidationException in com.espertech.esper.event
 

Methods in com.espertech.esper.event that throw ExprValidationException
static java.lang.Object EventTypeUtility.buildType(ColumnDesc column, EngineImportService engineImportService)
           
static java.util.LinkedHashMap<java.lang.String,java.lang.Object> EventTypeUtility.buildType(java.util.List<ColumnDesc> columns, EventAdapterService eventAdapterService, java.util.Set<java.lang.String> copyFrom, EngineImportService engineImportService)
           
static EventType EventTypeUtility.createNonVariantType(boolean isAnonymous, CreateSchemaDesc spec, java.lang.annotation.Annotation[] annotations, ConfigurationInformation configSnapshot, EventAdapterService eventAdapterService, EngineImportService engineImportService)
           
 

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

Methods in com.espertech.esper.event.bean that throw ExprValidationException
static Pair<net.sf.cglib.reflect.FastConstructor,ExprEvaluator[]> InstanceManufacturerUtil.getManufacturer(java.lang.Class targetClass, EngineImportService engineImportService, ExprEvaluator[] exprEvaluators, java.lang.Object[] expressionReturnTypes)
           
static InstanceManufacturer InstanceManufacturerFactory.getManufacturer(java.lang.Class targetClass, EngineImportService engineImportService, ExprNode[] childNodes)
           
 

Uses of ExprValidationException in com.espertech.esper.event.vaevent
 

Methods in com.espertech.esper.event.vaevent that throw ExprValidationException
 void ValueAddEventProcessor.validateEventType(EventType eventType)
          For use in checking insert-into statements, validates that the given type is eligible for revision event.
 void VAEVariantProcessor.validateEventType(EventType eventType)
           
 void VAERevisionProcessorBase.validateEventType(EventType eventType)
           
 

Uses of ExprValidationException in com.espertech.esper.filter
 

Methods in com.espertech.esper.filter that throw ExprValidationException
static FilterSpecCompiled FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext stmtContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
           
static FilterSpecCompiled FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementId, java.lang.String statementName, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ConfigurationInformation configurationInformation, NamedWindowService namedWindowService)
           
protected static FilterSpecParam FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementName)
          For a given expression determine if this is optimizable and create the filter parameter representing the expression, or null if not optimizable.
static FilterSpecCompiled FilterSpecCompiler.makeFilterSpec(EventType eventType, java.lang.String eventTypeName, java.util.List<ExprNode> filterExpessions, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext statementContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
          Factory method for compiling filter expressions into a filter specification for use with filter service.
protected static java.util.List<FilterSpecParam>[] FilterSpecCompilerPlanner.planFilterParameters(java.util.List<ExprNode> validatedNodes, FilterSpecCompilerArgs args)
           
static java.util.List<ExprNode> FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin, java.util.List<ExprNode> exprNodes, StreamTypeService streamTypeService, StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
          Validates expression nodes and returns a list of validated nodes.
 

Uses of ExprValidationException in com.espertech.esper.rowregex
 

Methods in com.espertech.esper.rowregex that throw ExprValidationException
static StreamTypeService EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, MatchRecognizeDefineItem defineItem, java.util.Map<java.lang.String,java.util.Set<java.lang.String>> visibilityByIdentifier, EventType parentViewType)
           
static RowRegexExprNode RegexPatternExpandUtil.expand(RowRegexExprNode pattern)
           
 

Constructors in com.espertech.esper.rowregex that throw ExprValidationException
EventRowRegexNFAViewFactory(ViewFactoryChain viewChain, MatchRecognizeSpec matchRecognizeSpec, AgentInstanceContext agentInstanceContext, boolean isUnbound, java.lang.annotation.Annotation[] annotations)
          Ctor.
 

Uses of ExprValidationException in com.espertech.esper.util
 

Methods in com.espertech.esper.util that throw ExprValidationException
static java.lang.Object PopulateUtil.coerceProperty(java.lang.String propertyName, java.lang.Class containingType, java.lang.Object value, java.lang.Class type, EngineImportService engineImportService, boolean forceNumeric, boolean includeClassNameInEx)
           
static java.lang.Object JavaClassHelper.getAnnotationHook(java.lang.annotation.Annotation[] annotations, HookType hookType, java.lang.Class interfaceExpected, MethodResolutionService resolution)
          Returns an instance of a hook as specified by an annotation.
static TypeWidener TypeWidenerFactory.getCheckPropertyAssignType(java.lang.String columnName, java.lang.Class columnType, java.lang.Class writeablePropertyType, java.lang.String writeablePropertyName)
          Returns the widener.
static java.lang.Object PopulateUtil.instantiatePopulateObject(java.util.Map<java.lang.String,java.lang.Object> objectProperties, java.lang.Class topClass, EngineImportService engineImportService)
           
static java.lang.Object JsonUtil.parsePopulate(java.lang.String json, java.lang.Class topClass, EngineImportService engineImportService)
           
static void PopulateUtil.populateObject(java.lang.String operatorName, int operatorNum, java.lang.String dataFlowName, java.util.Map<java.lang.String,java.lang.Object> objectProperties, java.lang.Object top, EngineImportService engineImportService, EPDataFlowOperatorParameterProvider optionalParameterProvider, java.util.Map<java.lang.String,java.lang.Object> optionalParameterURIs)
           
static void PopulateUtil.populateSpecCheckParameters(PopulateFieldWValueDescriptor[] descriptors, java.util.Map<java.lang.String,java.lang.Object> jsonRaw, java.lang.Object spec, EngineImportService engineImportService)
           
static java.lang.Object JavaClassHelper.resolveIdentAsEnumConst(java.lang.String constant, MethodResolutionService methodResolutionService, EngineImportService engineImportService)
          Resolve a string constant as a possible enumeration value, returning null if not resolved.
 void PopulateFieldValueSetter.set(java.lang.Object value)
           
 

Uses of ExprValidationException in com.espertech.esper.view
 

Methods in com.espertech.esper.view that throw ExprValidationException
 void ValidatedView.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations)
          Validate the view.
 


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