Package | Description |
---|---|
com.espertech.esper.codegen.core |
Code-Generation Core
|
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.factory |
Aggregator factories
|
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.index.quadtree |
Quad-tree indexes
|
com.espertech.esper.epl.index.service |
Advanced index provisioning
|
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.avro |
Avro event type core interfaces.
|
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.
|
Modifier and Type | Method and Description |
---|---|
T |
CodeGenerationServiceDefault.generate(CodegenClass clazz,
Class<T> result) |
T |
CodeGenerationService.generate(CodegenClass clazz,
Class<T> result) |
Modifier and Type | Method and Description |
---|---|
protected static StatementAgentInstanceFactoryOnTriggerNamedWindow.IndexHintPair |
StatementAgentInstanceFactoryOnTriggerNamedWindow.getIndexHintPair(StatementContext statementContext,
StatementSpecCompiled statementSpec) |
Modifier and Type | Method and Description |
---|---|
void |
ContextManagementServiceImpl.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient,
EventType statementResultEventType) |
void |
ContextManagementService.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient,
EventType statementResultEventType) |
static void |
ContextPropertyEventType.addEndpointTypes(String contextName,
ContextDetailCondition endpoint,
Map<String,Object> properties,
Set<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(String contextName,
ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
void |
ContextManagementService.addStatement(String contextName,
ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
static ContextControllerHashFactoryBase.HashFunctionEnum |
ContextControllerHashFactoryBase.HashFunctionEnum.determine(String contextName,
String name) |
ContextControllerFactory[] |
ContextControllerFactoryServiceImpl.getFactory(ContextControllerFactoryServiceContext serviceContext) |
ContextControllerFactory[] |
ContextControllerFactoryService.getFactory(ContextControllerFactoryServiceContext context) |
static ContextControllerFactory[] |
ContextControllerFactoryHelper.getFactory(ContextControllerFactoryServiceContext serviceContext,
ContextStateCache contextStateCache) |
ContextManager |
ContextManagerFactoryServiceImpl.make(ContextDetail contextDetail,
ContextControllerFactoryServiceContext factoryServiceContext) |
ContextManager |
ContextManagerFactoryService.make(ContextDetail contextDetail,
ContextControllerFactoryServiceContext factoryServiceContext) |
protected static Class[] |
ContextControllerPartitionedUtil.validateContextDesc(String contextName,
ContextDetailPartitioned segmentedSpec) |
void |
ContextControllerPartitionedFactoryBase.validateFactory() |
void |
ContextControllerInitTermFactoryBase.validateFactory() |
void |
ContextControllerHashFactoryBase.validateFactory() |
void |
ContextControllerFactory.validateFactory() |
void |
ContextControllerCategoryFactoryBase.validateFactory() |
ContextControllerStatementCtxCache |
ContextControllerPartitionedFactoryBase.validateStatement(ContextControllerStatementBase statement) |
ContextControllerStatementCtxCache |
ContextControllerHashFactoryBase.validateStatement(ContextControllerStatementBase statement) |
ContextControllerStatementCtxCache |
ContextControllerFactory.validateStatement(ContextControllerStatementBase statement) |
ContextControllerStatementCtxCache |
ContextControllerCategoryFactoryBase.validateStatement(ContextControllerStatementBase statement) |
protected static void |
ContextControllerPartitionedUtil.validateStatementForContext(String contextName,
ContextControllerStatementBase statement,
StatementSpecCompiledAnalyzerResult streamAnalysis,
Collection<EventType> itemEventTypes,
NamedWindowMgmtService namedWindowMgmtService) |
Constructor and Description |
---|
ContextControllerHashedGetterSingleRow(String statementName,
String functionName,
Pair<Class,EngineImportSingleRowDesc> func,
List<ExprNode> parameters,
int granularity,
EngineImportService engineImportService,
EventType eventType,
EventAdapterService eventAdapterService,
int statementId,
TableService tableService,
String engineURI) |
ContextManagerImpl(ContextControllerFactoryServiceContext factoryServiceContext) |
ContextManagerNested(ContextControllerFactoryServiceContext factoryServiceContext) |
Constructor and Description |
---|
SubSelectStrategyFactoryIndexShare(String statementName,
int statementId,
int subqueryNum,
EventType[] outerEventTypesSelect,
NamedWindowProcessor optionalNamedWindowProcessor,
TableMetadata optionalTableMetadata,
boolean fullTableScan,
IndexHint optionalIndexHint,
SubordPropPlan joinedPropPlan,
ExprEvaluator filterExprEval,
AggregationServiceFactoryDesc aggregationServiceFactory,
ExprEvaluator[] groupByKeys,
TableService tableService,
Annotation[] annotations,
StatementStopService statementStopService,
EngineImportService engineImportService) |
Modifier and Type | Method and Description |
---|---|
static SelectClauseSpecCompiled |
StatementLifecycleSvcImpl.compileSelectAllowSubselect(SelectClauseSpecRaw spec)
Compile a select clause allowing subselects.
|
InternalEventRouterDesc |
InternalEventRouterImpl.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
Annotation[] annotations,
String statementName) |
InternalEventRouterDesc |
InternalEventRouter.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
Annotation[] annotations,
String statementName) |
static void |
StatementLifecycleSvcUtil.walkStatement(StatementSpecRaw spec,
ExprNodeSubselectDeclaredDotVisitor visitor) |
Modifier and Type | Method and Description |
---|---|
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(QueryGraph queryGraph,
String aliasName) |
EPPreparedExecuteIUDSingleStreamExec |
EPPreparedExecuteIUDInsertInto.getExecutor(QueryGraph queryGraph,
String aliasName) |
protected static SubSelectStrategyCollection |
EPStatementStartMethodHelperSubselect.planSubSelect(EPServicesContext services,
StatementContext statementContext,
boolean queryPlanLogging,
SubSelectActivationCollection subSelectStreamDesc,
String[] outerStreamNames,
EventType[] outerEventTypesSelect,
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,
String errorMsg,
boolean allowTableConsumption) |
protected static void |
EPPreparedExecuteMethodHelper.validateFAFQuery(StatementSpecCompiled statementSpec) |
protected ExprNode |
EPStatementStartMethodOnTrigger.validateJoinNamedWindow(String engineURI,
StatementContext statementContext,
ExprNodeOrigin exprNodeOrigin,
ExprNode deleteJoinExpr,
EventType namedWindowType,
String namedWindowStreamName,
String namedWindowName,
EventType filteredType,
String filterStreamName,
String filteredTypeName,
String optionalTableName) |
protected static void |
EPStatementStartMethodHelperValidate.validateNoAggregations(ExprNode exprNode,
String errorMsg) |
static void |
EPStatementStartMethodHelperValidate.validateNoDataWindowOnNamedWindow(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) |
Constructor and Description |
---|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
DataFlowOpInitializeResult |
Select.initialize(DataFlowOpInitializateContext context) |
Modifier and Type | Method and Description |
---|---|
ExprEvaluator |
AggregationMethodFactorySum.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryStddev.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryRate.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryPlugIn.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryNth.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryMinMax.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryMedian.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryLeaving.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryLastEver.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryFirstEver.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryCountEver.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryCount.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryAvg.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryAvedev.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
static ExprEvaluator |
AggregationMethodFactoryCount.getMethodAggregationEvaluatorCountBy(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream) |
void |
AggregationMethodFactorySum.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryStddev.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryRate.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryPlugIn.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryNth.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryMinMax.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryMedian.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryLeaving.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryLastEver.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryFirstEver.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryCountEver.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryCount.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryAvg.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryAvedev.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
Modifier and Type | Method and Description |
---|---|
static GroupByClauseExpressions |
GroupByExpressionHelper.getGroupByRollupExpressions(List<GroupByClauseElement> groupByElements,
SelectClauseSpecRaw selectClauseSpec,
ExprNode optionalHavingNode,
List<OrderByItem> orderByList,
ExprNodeSubselectDeclaredDotVisitor visitor) |
Modifier and Type | Method and Description |
---|---|
static ExprValidationException |
AggregationServiceFactoryFactory.getRollupReclaimEx() |
Modifier and Type | Method and Description |
---|---|
AggregationServiceFactory |
AggregationServiceFactoryServiceImpl.getGroupReclaimAged(ExprNode[] groupByNodes,
ExprEvaluator[] evaluatorsArr,
AggregationMethodFactory[] aggregatorsArr,
Hint reclaimGroupAged,
Hint reclaimGroupFrequency,
VariableService variableService,
AggregationAccessorSlotPair[] pairs,
AggregationStateFactory[] accessAggregations,
boolean join,
String optionalContextName,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect) |
AggregationServiceFactory |
AggregationServiceFactoryService.getGroupReclaimAged(ExprNode[] groupByNodes,
ExprEvaluator[] evaluatorsArr,
AggregationMethodFactory[] aggregatorsArr,
Hint reclaimGroupAged,
Hint reclaimGroupFrequency,
VariableService variableService,
AggregationAccessorSlotPair[] pairs,
AggregationStateFactory[] accessAggregations,
boolean join,
String optionalContextName,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect) |
ExprEvaluator |
AggregationMethodFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
static AggregationServiceFactoryDesc |
AggregationServiceFactoryFactory.getService(List<ExprAggregateNode> selectAggregateExprNodes,
Map<ExprNode,String> selectClauseNamedNodes,
List<ExprDeclaredNode> declaredExpressions,
ExprNode[] groupByNodes,
List<ExprAggregateNode> havingAggregateExprNodes,
List<ExprAggregateNode> orderByAggregateExprNodes,
List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
Annotation[] annotations,
VariableService variableService,
boolean isJoin,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
AggregationServiceFactoryService factoryService,
EventType[] typesPerStream,
AggregationGroupByRollupDesc groupByRollupDesc,
String optionalContextName,
IntoTableSpec intoTableSpec,
TableService tableService,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect,
EngineImportService engineImportService,
String statementName) |
static AggregationServiceMatchRecognizeFactoryDesc |
AggregationServiceFactoryFactory.getServiceMatchRecognize(int numStreams,
Map<Integer,List<ExprAggregateNode>> measureExprNodesPerStream,
EventType[] typesPerStream,
EngineImportService engineImportService,
String statementName)
Produces an aggregation service for use with match-recognice.
|
static void |
AggregationValidationUtil.validateAggFuncName(String requiredName,
String providedName) |
static void |
AggregationValidationUtil.validateAggregationFilter(boolean requireFilter,
boolean provideFilter) |
static void |
AggregationValidationUtil.validateAggregationInputType(Class requiredParam,
Class providedParam) |
static void |
AggregationValidationUtil.validateAggregationType(AggregationMethodFactory requiredFactory,
AggregationMethodFactory providedFactory) |
static void |
AggregationValidationUtil.validateAggregationUnbound(boolean requiredHasDataWindows,
boolean providedHasDataWindows) |
static void |
AggregationValidationUtil.validateEventType(EventType requiredType,
EventType providedType) |
void |
AggregationMethodFactory.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
static void |
AggregationValidationUtil.validateStreamNumZero(int streamNum) |
Constructor and Description |
---|
AggSvcGroupByReclaimAgedFactory(ExprEvaluator[] evaluators,
AggregationMethodFactory[] prototypes,
Hint reclaimGroupAged,
Hint reclaimGroupFrequency,
VariableService variableService,
AggregationAccessorSlotPair[] accessors,
AggregationStateFactory[] accessAggregations,
boolean isJoin,
String optionalContextName)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static String |
AnnotationUtil.getExpectSingleStringValue(String msgPrefix,
List<AnnotationDesc> annotationsSameName) |
Modifier and Type | Method and Description |
---|---|
static SelectExprProcessor |
SelectExprJoinWildcardProcessorFactory.create(Collection<Integer> assignedTypeNumberStack,
int statementId,
String statementName,
String[] streamNames,
EventType[] streamTypes,
EventAdapterService eventAdapterService,
InsertIntoDesc insertIntoDesc,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
EngineImportService engineImportService,
Annotation[] annotations,
ConfigurationInformation configuration,
TableService tableService,
String engineURI) |
static HistoricalEventViewable |
MethodPollingViewableFactory.createPollMethodView(int streamNumber,
MethodStreamSpec methodStreamSpec,
EventAdapterService eventAdapterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
EngineImportService engineImportService,
SchedulingService schedulingService,
ScheduleBucket scheduleBucket,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
String contextName,
DataCacheFactory dataCacheFactory,
StatementContext statementContext)
Creates a method-invocation polling view for use as a stream that calls a method, or pulls results from cache.
|
protected static Comparator<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,
String[] streamNames,
EventType[] streamTypes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingNonJoin(EventAdapterService eventAdapterService,
EventType eventType,
boolean isUsingWildcard,
StreamTypeService typeService,
ExprEvaluator[] expressionNodes,
ExprForge[] forges,
String[] columnNames,
Object[] expressionReturnTypes,
EngineImportService engineImportService,
InsertIntoDesc insertIntoDesc,
String[] columnNamesAsProvided,
boolean allowNestableTargetFragmentTypes,
String statementName) |
static SelectExprProcessor |
SelectExprProcessorFactory.getProcessor(Collection<Integer> assignedTypeNumberStack,
SelectClauseElementCompiled[] selectionList,
boolean isUsingWildcard,
InsertIntoDesc insertIntoDesc,
EventType optionalInsertIntoEventType,
ForClauseSpec forClauseSpec,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
StatementResultService statementResultService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
EngineImportService engineImportService,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
TableService tableService,
TimeProvider timeProvider,
String engineURI,
int statementId,
String statementName,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configuration,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback,
NamedWindowMgmtService namedWindowMgmtService,
IntoTableSpec intoTableClause,
com.espertech.esper.epl.core.GroupByRollupInfo groupByRollupInfo,
StatementExtensionSvcContext statementExtensionSvcContext) |
static OrderByProcessorFactory |
OrderByProcessorFactoryFactory.getProcessor(List<SelectClauseExprCompiledSpec> selectionList,
ExprEvaluator[] groupByNodeEvals,
List<OrderByItem> orderByList,
RowLimitSpec rowLimitSpec,
VariableService variableService,
boolean isSortUsingCollator,
String optionalContextName,
EngineImportService engineImportService,
boolean onDemandQuery,
String statementName)
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,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
boolean isFireAndForget,
boolean isOnSelect) |
OutputConditionFactory |
ResultSetProcessorHelperFactoryImpl.makeOutputConditionCrontab(List<ExprNode> crontabAtSchedule,
StatementContext statementContext,
boolean isStartConditionOnCreation) |
OutputConditionFactory |
ResultSetProcessorHelperFactory.makeOutputConditionCrontab(List<ExprNode> crontabAtSchedule,
StatementContext statementContext,
boolean isStartConditionOnCreation) |
OutputConditionFactory |
ResultSetProcessorHelperFactoryImpl.makeOutputConditionExpression(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> thenExpressions,
StatementContext statementContext,
ExprNode andAfterTerminateExpr,
List<OnTriggerSetAssignment> andAfterTerminateThenExpressions,
boolean isStartConditionOnCreation) |
OutputConditionFactory |
ResultSetProcessorHelperFactory.makeOutputConditionExpression(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> thenExpressions,
StatementContext statementContext,
ExprNode andAfterTerminateExpr,
List<OnTriggerSetAssignment> andAfterTerminateThenExpressions,
boolean isStartConditionOnCreation) |
SelectExprProcessor |
SelectExprProcessorRepresentationFactory.makeRecast(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
AvroSchemaEventType insertIntoTargetType,
ExprNode[] exprNodes,
String statementName,
String engineURI) |
SelectExprProcessor |
SelectExprProcessorRepresentationFactory.makeSelectNoWildcard(SelectExprContext selectExprContext,
ExprForge[] exprForges,
EventType resultEventType,
TableService tableService,
String statementName,
String engineURI) |
void |
MethodPollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
String engineURI,
Map<Integer,List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
StatementContext statementContext) |
ExprNode |
EngineImportApplicationDotMethod.validate(ExprValidationContext validationContext) |
protected static void |
SelectExprProcessorFactory.verifyNameUniqueness(SelectClauseElementCompiled[] selectionList)
Verify that each given name occurs exactly one.
|
Constructor and Description |
---|
BindProcessor(SelectClauseElementCompiled[] selectionList,
EventType[] typesPerStream,
String[] streamNames,
TableService tableService,
EngineImportService engineImportService,
boolean isFireAndForget,
Annotation[] annotations,
String statementName)
Ctor.
|
OrderByProcessorFactoryImpl(List<OrderByItem> orderByList,
ExprEvaluator[] groupByEvals,
boolean needsGroupByKeys,
boolean isSortUsingCollator,
EngineImportService engineImportService,
boolean onDemandQuery,
String statementName)
Ctor.
|
RowLimitProcessorFactory(RowLimitSpec rowLimitSpec,
VariableService variableService,
String optionalContextName)
Ctor.
|
SelectExprProcessorHelper(Collection<Integer> assignedTypeNumberStack,
List<SelectClauseExprCompiledSpec> selectionList,
List<SelectExprStreamDesc> selectedStreams,
InsertIntoDesc insertIntoDesc,
EventType optionalInsertIntoOverrideType,
boolean isUsingWildcard,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
EngineImportService engineImportService,
int statementId,
String statementName,
Annotation[] annotations,
ConfigurationInformation configuration,
NamedWindowMgmtService namedWindowMgmtService,
TableService tableService,
com.espertech.esper.epl.core.GroupByRollupInfo groupByRollupInfo) |
SelectExprWildcardProcessor(EventType eventType)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(Class sourceType,
EventType targetType) |
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(EventType sourceType,
EventType targetType) |
Modifier and Type | Method and Description |
---|---|
static SelectExprProcessor |
EvalSelectStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static SelectExprProcessor |
EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
Constructor and Description |
---|
EvalInsertBeanRecast(EventType targetType,
EventAdapterService eventAdapterService,
int streamNumber,
EventType[] typesPerStream) |
EvalInsertBeanWrapRecast(WrapperEventType targetType,
EventAdapterService eventAdapterService,
int streamNumber,
EventType[] typesPerStream) |
Modifier and Type | Method and Description |
---|---|
static CalendarFieldEnum |
CalendarOpUtil.getEnum(String methodName,
ExprNode exprNode) |
static Object |
CalendarOpUtil.getFormatter(EPType inputType,
String methodName,
ExprNode exprNode,
ExprEvaluatorContext exprEvaluatorContext) |
CalendarForge |
CalendarForgeFactory.getOp(DatetimeMethodEnum method,
String methodNameUsed,
List<ExprNode> parameters,
ExprForge[] forges) |
Modifier and Type | Method and Description |
---|---|
static ExprDotDTMethodDesc |
ExprDotDTFactory.validateMake(StreamTypeService streamTypeService,
Deque<ExprChainedSpec> chainSpecStack,
DatetimeMethodEnum dtMethod,
String dtMethodName,
EPType inputType,
List<ExprNode> parameters,
ExprDotNodeFilterAnalyzerInput inputDesc,
TimeZone timeZone,
TimeAbacus timeAbacus,
ExprEvaluatorContext exprEvaluatorContext) |
Modifier and Type | Method and Description |
---|---|
IntervalForge |
IntervalForgeFactory.getForge(StreamTypeService streamTypeService,
DatetimeMethodEnum method,
String methodNameUsed,
List<ExprNode> parameters,
TimeZone timeZone,
TimeAbacus timeAbacus) |
static IntervalComputerForge |
IntervalComputerForgeFactory.make(DatetimeMethodEnum method,
List<ExprNode> expressions,
TimeAbacus timeAbacus) |
Constructor and Description |
---|
IntervalComputerConstantCoincides(IntervalStartEndParameterPairForge pair) |
IntervalForgeImpl(DatetimeMethodEnum method,
String methodNameUse,
StreamTypeService streamTypeService,
List<ExprNode> expressions,
TimeZone timeZone,
TimeAbacus timeAbacus) |
Modifier and Type | Method and Description |
---|---|
ReformatForge |
ReformatForgeFactory.getForge(EPType inputType,
TimeZone timeZone,
TimeAbacus timeAbacus,
DatetimeMethodEnum method,
String methodNameUsed,
List<ExprNode> parameters,
ExprEvaluatorContext exprEvaluatorContext) |
Constructor and Description |
---|
ReformatBetweenConstantParamsForge(List<ExprNode> parameters,
TimeZone timeZone) |
ReformatBetweenNonConstantParamsForge(List<ExprNode> parameters,
TimeZone timeZone) |
Modifier and Type | Method and Description |
---|---|
static HistoricalEventViewable |
DatabasePollingViewableFactory.createDBStatementView(int statementId,
int streamNumber,
DBStatementStreamSpec databaseStreamSpec,
DatabaseConfigService databaseConfigService,
EventAdapterService eventAdapterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
SQLColumnTypeConversion columnTypeConversionHook,
SQLOutputRowConversion outputRowConversionHook,
boolean enableJDBCLogging,
DataCacheFactory dataCacheFactory,
StatementContext statementContext)
Creates the viewable for polling via database SQL query.
|
protected static String |
DatabasePollingViewableFactory.lexSampleSQL(String querySQL)
Lexes the sample SQL and inserts a "where 1=0" where-clause.
|
void |
DatabasePollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
String engineURI,
Map<Integer,List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
String |
ExprDeclaredServiceImpl.addExpressionOrScript(CreateExpressionDesc expressionDesc) |
String |
ExprDeclaredService.addExpressionOrScript(CreateExpressionDesc expression) |
Class |
ExprDeclaredForgeBase.getComponentTypeCollection() |
EventType |
ExprDeclaredForgeBase.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprDeclaredForgeBase.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
LinkedHashMap<String,Integer> |
ExprDeclaredNodeImpl.getOuterStreamNames(Map<String,Integer> outerStreamNames) |
LinkedHashMap<String,Integer> |
ExprDeclaredNode.getOuterStreamNames(Map<String,Integer> outerStreamNames) |
LinkedHashMap<String,Object> |
ExprDeclaredForgeBase.getRowProperties() |
ExprNode |
ExprDeclaredNodeImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
Class |
PropertyDotScalarIterable.getComponentTypeCollection() |
Class |
PropertyDotScalarCollection.getComponentTypeCollection() |
Class |
PropertyDotScalarArrayForge.getComponentTypeCollection() |
Class |
PropertyDotEventSingleForge.getComponentTypeCollection() |
Class |
PropertyDotEventCollectionForge.getComponentTypeCollection() |
abstract EnumForge |
ExprDotForgeEnumMethodBase.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EventType |
PropertyDotScalarIterable.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarArrayForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotEventSingleForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotEventCollectionForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
void |
ExprDotForgeEnumMethodBase.init(Integer streamOfProviderIfApplicable,
EnumMethodEnum enumMethodEnum,
String enumMethodUsedName,
EPType typeInfo,
List<ExprNode> parameters,
ExprValidationContext validationContext) |
void |
ExprDotForgeEnumMethod.init(Integer streamOfProviderIfApplicable,
EnumMethodEnum lambda,
String lambdaUsedName,
EPType currentInputType,
List<ExprNode> parameters,
ExprValidationContext validationContext) |
static ExprDotStaticMethodWrap |
ExprDotStaticMethodWrapFactory.make(Method method,
EventAdapterService eventAdapterService,
List<ExprChainedSpec> modifiedChain,
String optionalEventTypeName) |
ExprNode |
ExprLambdaGoesNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
EnumForge |
ExprDotForgeSetExceptUnionIntersect.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeSequenceEqual.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
Modifier and Type | Method and Description |
---|---|
ExprValidationException |
ExprAggCountMinSketchNode.getDeclaredWrongParameterExpr() |
Modifier and Type | Method and Description |
---|---|
static void |
ExprAggMultiFunctionUtil.checkWildcardNotJoinOrSubquery(StreamTypeService streamTypeService,
String aggFuncName) |
Class |
ExprPlugInAggMultiFunctionNode.getComponentTypeCollection() |
Class |
ExprAggMultiFunctionSortedMinMaxByNode.getComponentTypeCollection() |
Class |
ExprAggMultiFunctionLinearAccessNode.getComponentTypeCollection() |
Class |
ExprAggCountMinSketchNode.getComponentTypeCollection() |
ExprValidationException |
ExprAggCountMinSketchNode.getDeclaredWrongParameterExpr() |
EventType |
ExprAggCountMinSketchNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprPlugInAggMultiFunctionNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggMultiFunctionLinearAccessNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggCountMinSketchNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
ExprEvaluator |
ExprPlugInAggMultiFunctionNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
ExprAggMultiFunctionSortedMinMaxByNodeFactory.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) |
ExprEvaluator |
AggregationMethodFactoryFirstLastUnbound.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 |
ExprAggMultiFunctionLinearAccessNodeFactoryAccess.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
ExprAggCountMinSketchNodeFactoryUse.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
ExprAggCountMinSketchNodeFactoryState.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
AggregationMethodFactoryFirstLastUnbound.validateIntoTableCompatible(AggregationMethodFactory intoTableAgg) |
void |
ExprAggregateAccessMultiValueNode.validatePositionals() |
static int |
ExprAggMultiFunctionUtil.validateStreamWildcardGetStreamNum(ExprNode node) |
static void |
ExprAggMultiFunctionUtil.validateWildcardStreamNumbers(StreamTypeService streamTypeService,
String aggFuncName) |
Modifier and Type | Method and Description |
---|---|
protected ExprValidationException |
ExprAggregateNodeBase.makeExceptionExpectedParamNum(int lower,
int upper) |
Modifier and Type | Method and Description |
---|---|
static ExprAggregateNodeParamDesc |
ExprAggregateNodeUtil.getValidatePositionalParams(ExprNode[] childNodes,
boolean builtinAggregationFunc) |
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(ExprForge filterEvaluator) |
protected 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() |
Modifier and Type | Class and Description |
---|---|
class |
ExprValidationPropertyException
Thrown to indicate a validation error in an expression originating from a property resolution error.
|
Modifier and Type | Method and Description |
---|---|
ExprValidationException |
ExprNodeUtilResolveExceptionHandlerDefault.handle(Exception e) |
ExprValidationException |
ExprNodeUtilResolveExceptionHandler.handle(Exception e) |
static ExprValidationException |
ExprGroupingIdNode.makeException(String functionName) |
Modifier and Type | Method and Description |
---|---|
static Pair<String,ExprNode> |
ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node) |
static ExprEvaluator[] |
ExprNodeUtility.crontabScheduleValidate(ExprNodeOrigin origin,
List<ExprNode> scheduleSpecExpressionList,
StatementContext context,
boolean allowBindingConsumption) |
static Object |
ExprNodeUtility.evaluateValidationTimeNoStreams(ExprEvaluator evaluator,
ExprEvaluatorContext context,
String expressionName) |
Class |
ExprEnumerationForge.getComponentTypeCollection() |
EventType |
ExprEnumerationForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprEnumerationForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
static ExprNodePropOrStreamSet |
ExprNodeUtility.getGroupByPropertiesValidateHasOne(ExprNode[] groupByNodes) |
static Map<String,ExprNamedParameterNode> |
ExprNodeUtility.getNamedExpressionsHandleDups(List<ExprNode> parameters) |
LinkedHashMap<String,Object> |
ExprTypableReturnForge.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(String className,
Class optionalClass,
String methodName,
List<ExprNode> parameters,
EngineImportService engineImportService,
EventAdapterService eventAdapterService,
int statementId,
boolean allowWildcard,
EventType wildcardType,
ExprNodeUtilResolveExceptionHandler exceptionHandler,
String functionName,
TableService tableService,
String engineURI) |
static void |
ExprNodeUtility.validate(ExprNodeOrigin origin,
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 |
ExprContextPropertyNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprConstantNodeImpl.validate(ExprValidationContext validationContext) |
static void |
ExprNodeUtility.validateNamed(Map<String,ExprNamedParameterNode> namedExpressions,
String[] namedParameters) |
static boolean |
ExprNodeUtility.validateNamedExpectType(ExprNamedParameterNode namedParameterNode,
Class[] expectedTypes) |
static void |
ExprNodeUtility.validateNoSpecialsGroupByExpressions(ExprNode[] groupByNodes) |
static void |
ExprNodeUtility.validatePlainExpression(ExprNodeOrigin origin,
ExprNode expression) |
static void |
ExprNodeUtility.validatePlainExpression(ExprNodeOrigin origin,
ExprNode[] expressions) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType,
boolean allowBindingConsumption) |
Modifier and Type | Method and Description |
---|---|
static ExprDotNodeRealizedChain |
ExprDotNodeUtility.getChainEvaluators(Integer streamOfProviderIfApplicable,
EPType inputType,
List<ExprChainedSpec> chainSpec,
ExprValidationContext validationContext,
boolean isDuckTyping,
ExprDotNodeFilterAnalyzerInput inputDesc) |
Class |
ExprDotNodeForgeRootChild.getComponentTypeCollection() |
static ExprDotEnumerationSourceForge |
ExprDotNodeUtility.getEnumerationSource(ExprNode inputExpression,
StreamTypeService streamTypeService,
EventAdapterService eventAdapterService,
int statementId,
boolean hasEnumerationMethod,
boolean disablePropertyExpressionEventCollCache) |
EventType |
ExprDotNodeForgeRootChild.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprDotNodeForgeRootChild.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
ExprNode |
ExprDotNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprAppDotMethodImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Object> |
ExprCaseNodeForge.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) |
Modifier and Type | Method and Description |
---|---|
Class |
ExprArrayNodeForge.getComponentTypeCollection() |
Class |
ExprArrayNode.getComponentTypeCollection() |
EventType |
ExprArrayNodeForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprArrayNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprArrayNodeForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprArrayNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
LinkedHashMap<String,Object> |
ExprNewStructNodeForge.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() |
Modifier and Type | Method and Description |
---|---|
Class |
ExprPreviousNode.getComponentTypeCollection() |
EventType |
ExprPreviousNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprPreviousNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
ExprNode |
ExprPreviousNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprPreviousMatchRecognizeNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprPriorNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static SubselectEvalStrategyNR |
SubselectEvalStrategyNRFactory.createStrategyAnyAllIn(ExprSubselectNode subselectExpression,
boolean isNot,
boolean isAll,
boolean isAny,
RelationalOpEnum relationalOp,
EngineImportService engineImportService,
String statementName) |
Class |
ExprSubselectRowNode.getComponentTypeCollection() |
Class |
ExprSubselectInNode.getComponentTypeCollection() |
Class |
ExprSubselectExistsNode.getComponentTypeCollection() |
Class |
ExprSubselectAllSomeAnyNode.getComponentTypeCollection() |
EventType |
ExprSubselectRowNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectRowNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectInNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectExistsNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectAllSomeAnyNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
LinkedHashMap<String,Object> |
ExprSubselectNode.getRowProperties() |
LinkedHashMap<String,Object> |
ExprSubselectRowNode.typableGetRowProperties() |
abstract LinkedHashMap<String,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) |
Modifier and Type | Method and Description |
---|---|
Class |
ExprTableIdentNodeSubpropAccessor.getComponentTypeCollection() |
Class |
ExprTableAccessNodeSubpropAccessor.getComponentTypeCollection() |
Class |
ExprTableAccessNodeSubprop.getComponentTypeCollection() |
EventType |
ExprTableIdentNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubprop.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableIdentNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubprop.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
LinkedHashMap<String,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(String tableName,
Class[] providedTypes,
String providedName,
ExprNode[] providedExpr,
Class[] expectedTypes,
String expectedName) |
protected void |
ExprTableAccessNode.validateGroupKeys(TableMetadata metadata,
ExprValidationContext validationContext) |
protected TableMetadataColumn |
ExprTableAccessNode.validateSubpropertyGetCol(TableMetadata tableMetadata,
String subpropName) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprTimestampNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprTimePeriodImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
EngineImportApplicationDotMethodBase.validate(ExprValidationContext validationContext) |
protected ExprForge |
EngineImportApplicationDotMethodRectangeIntersectsRectangle.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected ExprForge |
EngineImportApplicationDotMethodPointInsideRectange.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected abstract ExprForge |
EngineImportApplicationDotMethodBase.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
AdvancedIndexConfigContextPartition |
AdvancedIndexFactoryProviderQuadTree.validateConfigureFilterIndex(String indexName,
String indexTypeName,
ExprNode[] parameters,
ExprValidationContext validationContext) |
EventAdvancedIndexProvisionDesc |
AdvancedIndexFactoryProviderPointRegionQuadTree.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
EventAdvancedIndexProvisionDesc |
AdvancedIndexFactoryProviderMXCIFQuadTree.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
protected static void |
AdvancedIndexFactoryProviderQuadTree.validateParameters(String indexTypeName,
ExprNode[] parameters) |
Modifier and Type | Method and Description |
---|---|
static void |
AdvancedIndexValidationHelper.validateColumnCount(int expected,
String indexTypeName,
int colCount) |
static void |
AdvancedIndexValidationHelper.validateColumnReturnTypeNumber(String indexTypeName,
int colnum,
ExprNode expr,
String name) |
AdvancedIndexConfigContextPartition |
AdvancedIndexFactoryProvider.validateConfigureFilterIndex(String indexName,
String indexTypeName,
ExprNode[] parameters,
ExprValidationContext validationContext) |
EventAdvancedIndexProvisionDesc |
AdvancedIndexFactoryProvider.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
static void |
AdvancedIndexValidationHelper.validateParameterCount(int minExpected,
int maxExpected,
String indexTypeName,
int paramCount) |
static void |
AdvancedIndexValidationHelper.validateParameterCountEither(int expectedOne,
int expectedTwo,
String indexTypeName,
int paramCount) |
static void |
AdvancedIndexValidationHelper.validateParameterReturnType(Class expectedReturnType,
String indexTypeName,
int paramnum,
ExprNode expr,
String name) |
static void |
AdvancedIndexValidationHelper.validateParameterReturnTypeNumber(String indexTypeName,
int paramnum,
ExprNode expr,
String name) |
Modifier and Type | Method and Description |
---|---|
static JoinSetComposerPrototype |
JoinSetComposerPrototypeFactory.makeComposerPrototype(String statementName,
int statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean queryPlanLogging,
StatementContext statementContext,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
boolean selectsRemoveStream,
boolean hasAggregations,
TableService tableService,
boolean isOnDemandQuery,
boolean allowIndexInit) |
Modifier and Type | Method and Description |
---|---|
static ExcludePlanHint |
ExcludePlanHint.getHint(String[] streamNames,
StatementContext statementContext) |
static ExprForge |
ExcludePlanHintExprUtil.toExpression(String hint,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
protected static QueryPlan |
NStreamOuterQueryPlanBuilder.build(QueryGraph queryGraph,
OuterJoinDesc[] outerJoinDescList,
String[] streamNames,
EventType[] typesPerStream,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
ExprEvaluatorContext exprEvaluatorContext,
String[][][] indexedStreamsUniqueProps,
TableMetadata[] tablesPerStream,
EngineImportService engineImportService,
boolean isFireAndForget)
Build a query plan based on the stream property relationships indicated in queryGraph.
|
static QueryPlan |
QueryPlanBuilder.getPlan(EventType[] typesPerStream,
OuterJoinDesc[] outerJoinDescList,
QueryGraph queryGraph,
String[] streamNames,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean isQueryPlanLogging,
Annotation[] annotations,
ExprEvaluatorContext exprEvaluatorContext,
EngineImportService engineImportService,
boolean isFireAndForget)
Build query plan using the filter.
|
protected static void |
NStreamOuterQueryPlanBuilder.recursiveBuild(int streamNum,
Stack<Integer> streamCallStack,
QueryGraph queryGraph,
OuterInnerDirectionalGraph outerInnerGraph,
InnerJoinGraph innerJoinGraph,
Set<Integer> completedStreams,
LinkedHashMap<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,
Stack<Integer> streamCallStack,
QueryGraph queryGraph,
Set<Integer> completedStreams,
LinkedHashMap<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).
|
Modifier and Type | Method and Description |
---|---|
void |
EventTableIndexMetadata.addIndexExplicit(boolean isPrimary,
IndexMultiKey indexMultiKey,
String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
String statementName) |
static void |
SubordinateQueryPlannerUtil.addIndexMetaAndRef(SubordinateQueryIndexDesc[] indexDescs,
EventTableIndexMetadata repo,
String statementName) |
void |
EventTableIndexMetadata.addIndexNonExplicit(IndexMultiKey indexMultiKey,
String statementName,
QueryPlanIndexItem queryPlanIndexItem) |
void |
EventTableIndexRepository.validateAddExplicitIndex(String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
boolean allowIndexExists,
Object optionalSerde) |
static QueryPlanIndexItem |
EventTableIndexUtil.validateCompileExplicitIndex(String indexName,
boolean unique,
List<CreateIndexItem> columns,
EventType eventType,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
static DotMethodFP |
DotMethodUtil.validateParametersDetermineFootprint(DotMethodFP[] footprints,
DotMethodTypeEnum methodType,
String methodUsedName,
DotMethodFPProvided providedFootprint,
DotMethodInputTypeMatcher inputTypeMatcher) |
Modifier and Type | Method and Description |
---|---|
void |
NamedWindowRootViewInstance.addExplicitIndex(String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
boolean isRecoveringResilient)
Add an explicit index.
|
static NamedWindowOnExprFactory |
NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType,
String namedWindowName,
String namedWindowAlias,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
String filterStreamName,
boolean addToFront,
InternalEventRouter internalEventRouter,
EventType outputEventType,
StatementContext statementContext,
StatementMetricHandle createNamedWindowMetricsHandle,
boolean isDistinct,
StreamSelector optionalStreamSelector,
String optionalInsertIntoTableName) |
void |
NamedWindowProcessor.validateAddIndex(String statementName,
String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
IndexMultiKey imk) |
Constructor and Description |
---|
NamedWindowOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
String triggeringStreamName,
InternalEventRouter internalEventRouter,
String namedWindowName,
EventTypeSPI namedWindowType) |
Modifier and Type | Method and Description |
---|---|
static PropertyEvaluator |
PropertyEvaluatorFactory.makeEvaluator(PropertyEvalSpec spec,
EventType sourceEventType,
String optionalSourceStreamName,
EventAdapterService eventAdapterService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
String engineURI,
int statementId,
String statementName,
Annotation[] annotations,
Collection<Integer> assignedTypeNumberStack,
ConfigurationInformation configuration,
NamedWindowMgmtService namedWindowMgmtService,
StatementExtensionSvcContext statementExtensionSvcContext) |
Modifier and Type | Method and Description |
---|---|
static EPType |
EPTypeHelper.optionalFromEnumerationExpr(int statementId,
EventAdapterService eventAdapterService,
ExprNode exprNode) |
Modifier and Type | Method and Description |
---|---|
Class |
ExprNodeScriptEvalBase.getComponentTypeCollection() |
EventType |
ExprNodeScriptEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprNodeScriptEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
ExprNode |
ExprNodeScript.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static CompiledScript |
JSR223Helper.verifyCompileScript(ExpressionScriptProvided script,
String dialect) |
Modifier and Type | Method and Description |
---|---|
static ExpressionScriptCompiled |
MVELHelper.compile(String scriptName,
String expression,
Map<String,Class> mvelInputParamTypes,
EngineImportService engineImportService) |
static void |
MVELHelper.verifyScript(ExpressionScriptProvided script,
EngineImportService engineImportService)
Verify MVEL script (not compiling it).
|
Modifier and Type | Method and Description |
---|---|
StreamSpecCompiled |
StreamSpecRaw.compile(StatementContext statementContext,
Set<String> eventTypeReferences,
boolean isInsertInto,
Collection<Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger,
String optionalStreamName)
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,
Set<String> eventTypeReferences,
boolean isInsertInto,
Collection<Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger,
String optionalStreamName) |
StreamSpecCompiled |
MethodStreamSpec.compile(StatementContext context,
Set<String> eventTypeReferences,
boolean isInsertInto,
Collection<Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger,
String optionalStreamName) |
StreamSpecCompiled |
FilterStreamSpecRaw.compile(StatementContext context,
Set<String> eventTypeReferences,
boolean isInsertInto,
Collection<Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger,
String optionalStreamName) |
PatternStreamSpecCompiled |
PatternStreamSpecRaw.compile(StatementContext context,
Set<String> eventTypeReferences,
boolean isInsertInto,
Collection<Integer> assignedTypeNumberStack,
MatchEventSpec priorTags,
Set<String> priorAllTags,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
static EventType |
FilterStreamSpecRaw.resolveType(String engineURI,
String eventName,
EventAdapterService eventAdapterService,
URI[] optionalResolutionURIs)
Resolves a given event name to an event type.
|
void |
MatchRecognizeInterval.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static List<FilterSpecRaw> |
StatementSpecRawAnalyzer.analyzeFilters(StatementSpecRaw spec) |
static ExprNodeSubselectDeclaredDotVisitor |
StatementSpecRawAnalyzer.walkSubselectAndDeclaredDotExpr(StatementSpecRaw spec) |
Constructor and Description |
---|
TableOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
String triggeringStreamName,
InternalEventRouter internalEventRouter,
TableMetadata tableMetadata) |
Modifier and Type | Method and Description |
---|---|
void |
TableStateInstanceUngroupedImpl.addExplicitIndex(String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
boolean isRecoveringResilient,
boolean allowIndexExists) |
void |
TableStateInstanceGroupedImpl.addExplicitIndex(String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
boolean isRecoveringResilient,
boolean allowIndexExists) |
abstract void |
TableStateInstance.addExplicitIndex(String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
boolean isRecoveringResilient,
boolean allowIndexExists) |
TableMetadata |
TableServiceImpl.addTable(String tableName,
String eplExpression,
String statementName,
Class[] keyTypes,
Map<String,TableMetadataColumn> tableColumns,
TableStateRowFactory tableStateRowFactory,
int numberMethodAggregations,
StatementContext statementContext,
ObjectArrayEventType internalEventType,
ObjectArrayEventType publicEventType,
TableMetadataInternalEventToPublic eventToPublic,
boolean queryPlanLogging) |
TableMetadata |
TableService.addTable(String tableName,
String eplExpression,
String statementName,
Class[] keyTypes,
Map<String,TableMetadataColumn> tableColumns,
TableStateRowFactory tableStateRowFactory,
int numberMethodAggregations,
StatementContext statementContext,
ObjectArrayEventType internalEventType,
ObjectArrayEventType publicEventType,
TableMetadataInternalEventToPublic eventToPublic,
boolean queryPlanLogging) |
ExprTableIdentNode |
TableServiceImpl.getTableIdentNode(StreamTypeService streamTypeService,
String unresolvedPropertyName,
String streamOrPropertyName) |
ExprTableIdentNode |
TableService.getTableIdentNode(StreamTypeService streamTypeService,
String unresolvedPropertyName,
String streamOrPropertyName) |
Pair<ExprNode,List<ExprChainedSpec>> |
TableServiceImpl.getTableNodeChainable(StreamTypeService streamTypeService,
List<ExprChainedSpec> chainSpec,
EngineImportService engineImportService) |
Pair<ExprNode,List<ExprChainedSpec>> |
TableService.getTableNodeChainable(StreamTypeService streamTypeService,
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(String createIndexStatementName,
TableMetadata tableMetadata,
String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
IndexMultiKey imk) |
void |
TableService.validateAddIndex(String createIndexStatementName,
TableMetadata tableMetadata,
String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
IndexMultiKey imk) |
void |
TableMetadata.validateAddIndexAssignUpdateStrategies(String createIndexStatementName,
IndexMultiKey imk,
String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc) |
Constructor and Description |
---|
TableMetadata(String tableName,
String eplExpression,
String statementName,
Class[] keyTypes,
Map<String,TableMetadataColumn> tableColumns,
TableStateRowFactory rowFactory,
int numberMethodAggregations,
StatementContext createTableStatementContext,
ObjectArrayEventType internalEventType,
ObjectArrayEventType publicEventType,
TableMetadataInternalEventToPublic eventToPublic,
boolean queryPlanLogging) |
Modifier and Type | Method and Description |
---|---|
static TableOnViewFactory |
TableOnViewFactoryFactory.make(TableMetadata tableMetadata,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
String filterStreamName,
StatementContext statementContext,
StatementMetricHandle metricsHandle,
boolean isDistinct,
InternalEventRouter internalEventRouter) |
Modifier and Type | Method and Description |
---|---|
Class |
ExprTableExprEvaluatorAccess.getComponentTypeCollection() |
EventType |
ExprTableExprEvaluatorAccess.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableExprEvaluatorAccess.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
static TableUpdateStrategy |
TableUpdateStrategyFactory.validateGetTableUpdateStrategy(TableMetadata tableMetadata,
EventBeanUpdateHelper updateHelper,
boolean isOnMerge) |
Modifier and Type | Method and Description |
---|---|
static EventBeanUpdateHelper |
EventBeanUpdateHelperFactory.make(String updatedWindowOrTableName,
EventTypeSPI eventTypeSPI,
List<OnTriggerSetAssignment> assignments,
String updatedAlias,
EventType optionalTriggeringEventType,
boolean isCopyOnWrite,
String statementName,
String engineURI,
EventAdapterService eventAdapterService,
boolean isFireAndForget) |
Modifier and Type | Method and Description |
---|---|
static void |
EPLValidationUtil.validateContextName(boolean table,
String tableOrNamedWindowName,
String tableOrNamedWindowContextName,
String optionalContextName,
boolean mustMatchContext) |
static void |
EPLValidationUtil.validateParameterNumber(String invocableName,
String invocableCategory,
boolean isFunction,
int expectedEnum,
int receivedNum) |
static void |
EPLValidationUtil.validateParametersTypePredefined(ExprNode[] expressions,
String invocableName,
String invocableCategory,
EPLExpressionParamType type) |
static void |
EPLValidationUtil.validateParameterType(String invocableName,
String invocableCategory,
boolean isFunction,
EPLExpressionParamType expectedTypeEnum,
Class[] expectedTypeClasses,
Class providedType,
int parameterNum,
ExprNode parameterExpression) |
static void |
EPLValidationUtil.validateTableExists(TableService tableService,
String name) |
Modifier and Type | Method and Description |
---|---|
static void |
VariableServiceUtil.checkAlreadyDeclaredTable(String tableName,
TableService tableService) |
static void |
VariableServiceUtil.checkAlreadyDeclaredVariable(String variableName,
VariableService variableService) |
Constructor and Description |
---|
OnSetVariableViewFactory(int statementId,
OnTriggerSetDesc desc,
EventAdapterService eventAdapterService,
VariableService variableService,
StatementResultService statementResultService,
ExprEvaluatorContext exprEvaluatorContext)
Ctor.
|
VariableReadWritePackage(List<OnTriggerSetAssignment> assignments,
VariableService variableService,
EventAdapterService eventAdapterService,
String statementName)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static OutputConditionFactory |
OutputConditionFactoryFactory.createCondition(OutputLimitSpec outputLimitSpec,
StatementContext statementContext,
boolean isGrouped,
boolean isWithHavingClause,
boolean isStartConditionOnCreation,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory) |
static OutputConditionPolledFactory |
OutputConditionPolledFactoryFactory.createConditionFactory(OutputLimitSpec outputLimitSpec,
StatementContext statementContext) |
static OutputProcessViewFactory |
OutputProcessViewFactoryFactory.make(StatementSpecCompiled statementSpec,
InternalEventRouter internalEventRouter,
StatementContext statementContext,
EventType resultEventType,
OutputProcessViewCallback optionalOutputProcessViewCallback,
TableService tableService,
ResultSetProcessorType resultSetProcessorType,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
StatementVariableRef statementVariableRef) |
Constructor and Description |
---|
OutputConditionCrontabFactory(List<ExprNode> scheduleSpecExpressionList,
StatementContext statementContext,
boolean isStartConditionOnCreation) |
OutputConditionExpressionFactory(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> assignments,
StatementContext statementContext,
ExprNode andWhenTerminatedExpr,
List<OnTriggerSetAssignment> afterTerminateAssignments,
boolean isStartConditionOnCreation) |
OutputConditionFirstFactory(OutputLimitSpec outputLimitSpec,
StatementContext statementContext,
boolean isGrouped,
boolean isWithHavingClause,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory) |
OutputConditionPolledCrontabFactory(List<ExprNode> scheduleSpecExpressionList,
StatementContext statementContext) |
OutputConditionPolledExpressionFactory(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> assignments,
StatementContext statementContext)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static Object |
EventTypeUtility.buildType(ColumnDesc column,
EngineImportService engineImportService) |
static LinkedHashMap<String,Object> |
EventTypeUtility.buildType(List<ColumnDesc> columns,
EventAdapterService eventAdapterService,
Set<String> copyFrom,
EngineImportService engineImportService) |
static EventType |
EventTypeUtility.createNonVariantType(boolean isAnonymous,
CreateSchemaDesc spec,
Annotation[] annotations,
ConfigurationInformation configSnapshot,
EventAdapterService eventAdapterService,
EngineImportService engineImportService) |
static EventType |
EventTypeUtility.requireEventType(String aspectCamel,
String aspectName,
EventAdapterService eventAdapterService,
String optionalEventTypeName) |
Modifier and Type | Method and Description |
---|---|
void |
EventAdapterAvroHandlerUnsupported.avroCompat(EventType existingType,
Map<String,Object> selPropertyTypes) |
void |
EventAdapterAvroHandler.avroCompat(EventType existingType,
Map<String,Object> selPropertyTypes) |
Modifier and Type | Method and Description |
---|---|
static Pair<net.sf.cglib.reflect.FastConstructor,ExprForge[]> |
InstanceManufacturerUtil.getManufacturer(Class targetClass,
EngineImportService engineImportService,
ExprForge[] exprForges,
Object[] expressionReturnTypes) |
static InstanceManufacturerFactory |
InstanceManufacturerFactoryFactory.getManufacturer(Class targetClass,
EngineImportService engineImportService,
ExprNode[] childNodes) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext stmtContext,
Collection<Integer> assignedTypeNumberStack) |
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(List<ExprNode> validatedFilterNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
Collection<Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
int statementId,
String statementName,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
EngineImportService engineImportService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowMgmtService namedWindowMgmtService,
StatementExtensionSvcContext statementExtensionSvcContext) |
protected static FilterSpecParam |
FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
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,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext statementContext,
Collection<Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
protected static List<FilterSpecParam>[] |
FilterSpecCompilerPlanner.planFilterParameters(List<ExprNode> validatedNodes,
FilterSpecCompilerArgs args) |
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
Modifier and Type | Method and Description |
---|---|
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
Map<String,Set<String>> visibilityByIdentifier,
EventType parentViewType) |
static RowRegexExprNode |
RegexPatternExpandUtil.expand(RowRegexExprNode pattern) |
EventRowRegexNFAViewFactory |
RegexHandlerFactoryDefault.makeViewFactory(ViewFactoryChain viewFactoryChain,
MatchRecognizeSpec matchRecognizeSpec,
AgentInstanceContext agentInstanceContext,
boolean isUnbound,
Annotation[] annotations,
ConfigurationEngineDefaults.MatchRecognize matchRecognizeConfigs) |
EventRowRegexNFAViewFactory |
RegexHandlerFactory.makeViewFactory(ViewFactoryChain viewFactoryChain,
MatchRecognizeSpec matchRecognizeSpec,
AgentInstanceContext agentInstanceContext,
boolean isUnbound,
Annotation[] annotations,
ConfigurationEngineDefaults.MatchRecognize matchRecognizeConfigs) |
Constructor and Description |
---|
EventRowRegexNFAViewFactory(ViewFactoryChain viewChain,
MatchRecognizeSpec matchRecognizeSpec,
AgentInstanceContext agentInstanceContext,
boolean isUnbound,
Annotation[] annotations,
ConfigurationEngineDefaults.MatchRecognize matchRecognizeConfig)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static Object |
PopulateUtil.coerceProperty(String propertyName,
Class containingType,
Object value,
Class type,
ExprNodeOrigin exprNodeOrigin,
ExprValidationContext exprValidationContext,
boolean forceNumeric,
boolean includeClassNameInEx) |
static Object |
JavaClassHelper.getAnnotationHook(Annotation[] annotations,
HookType hookType,
Class interfaceExpected,
EngineImportService engineImportService)
Returns an instance of a hook as specified by an annotation.
|
static TypeWidener |
TypeWidenerFactory.getCheckPropertyAssignType(String columnName,
Class columnType,
Class writeablePropertyType,
String writeablePropertyName,
boolean allowObjectArrayToCollectionConversion,
TypeWidenerCustomizer customizer,
String statementName,
String engineURI)
Returns the widener.
|
static Object |
PopulateUtil.instantiatePopulateObject(Map<String,Object> objectProperties,
Class topClass,
ExprNodeOrigin exprNodeOrigin,
ExprValidationContext exprValidationContext) |
static Object |
JsonUtil.parsePopulate(String json,
Class topClass,
ExprNodeOrigin exprNodeOrigin,
ExprValidationContext exprValidationContext) |
static void |
PopulateUtil.populateObject(String operatorName,
int operatorNum,
String dataFlowName,
Map<String,Object> objectProperties,
Object top,
ExprNodeOrigin exprNodeOrigin,
ExprValidationContext exprValidationContext,
EPDataFlowOperatorParameterProvider optionalParameterProvider,
Map<String,Object> optionalParameterURIs) |
static void |
PopulateUtil.populateSpecCheckParameters(PopulateFieldWValueDescriptor[] descriptors,
Map<String,Object> jsonRaw,
Object spec,
ExprNodeOrigin exprNodeOrigin,
ExprValidationContext exprValidationContext) |
static Object |
JavaClassHelper.resolveIdentAsEnumConst(String constant,
EngineImportService engineImportService,
boolean isAnnotation)
Resolve a string constant as a possible enumeration value, returning null if not resolved.
|
void |
PopulateFieldValueSetter.set(Object value) |
TypeWidener |
TypeWidenerCustomizer.widenerFor(String columnName,
Class columnType,
Class writeablePropertyType,
String writeablePropertyName,
String statementName,
String engineURI) |
Modifier and Type | Method and Description |
---|---|
void |
ValidatedView.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
String engineURI,
Map<Integer,List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
StatementContext statementContext)
Validate the view.
|