Package | Description |
---|---|
com.espertech.esper.core.context.factory |
Statement agent instance factories.
|
com.espertech.esper.core.context.mgr |
Context management.
|
com.espertech.esper.core.service |
Implementation of client package interfaces, glue code
|
com.espertech.esper.core.start |
Classes related to start and stop of statements
|
com.espertech.esper.dataflow.core |
Data flow core classes.
|
com.espertech.esper.dataflow.ops |
Data flow built-in operators.
|
com.espertech.esper.epl.agg.rollup | |
com.espertech.esper.epl.agg.service |
Aggregation services.
|
com.espertech.esper.epl.core |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.core.eval |
Select expression evaluators.
|
com.espertech.esper.epl.datetime.calop |
Date-Time calendar operations.
|
com.espertech.esper.epl.datetime.eval |
Date-Time methods and related utility classes.
|
com.espertech.esper.epl.datetime.interval |
Interval algebra.
|
com.espertech.esper.epl.datetime.reformatop |
Date-Time re-formatting operations.
|
com.espertech.esper.epl.db |
Database SQL polling views and caches
|
com.espertech.esper.epl.declexpr |
Declared expression handling.
|
com.espertech.esper.epl.enummethod.dot |
Enumeration method utility classes and input data sources.
|
com.espertech.esper.epl.enummethod.eval |
Enumeration method implementations.
|
com.espertech.esper.epl.expression |
This package contains the EPL expression nodes that represent all expressions such as used in select clauses, group-by and having clauses, or order-by clauses
|
com.espertech.esper.epl.join.base |
Join process interfaces and glue code
|
com.espertech.esper.epl.join.hint |
Hints related to joins.
|
com.espertech.esper.epl.join.plan |
Inner join and outer join query planning
|
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.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.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.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.
|
Constructor and Description |
---|
StatementAgentInstanceFactoryOnTrigger(StatementContext statementContext,
StatementSpecCompiled statementSpec,
EPServicesContext services,
ViewableActivator activator,
SubSelectStrategyCollection subSelectStrategyCollection,
ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
ExprNode validatedJoin,
EventType activatorResultEventType,
StatementAgentInstanceFactoryOnTriggerSplitDesc splitDesc,
ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype,
OnSetVariableViewFactory onSetVariableViewFactory,
NamedWindowOnExprFactory onExprFactory,
OutputProcessViewFactory outputProcessViewFactory,
boolean recoveringStatement) |
Modifier and Type | Method and Description |
---|---|
void |
ContextManagementServiceImpl.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient) |
void |
ContextManagementService.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient) |
static void |
ContextPropertyEventType.addEndpointTypes(java.lang.String contextName,
ContextDetailCondition endpoint,
java.util.Map<java.lang.String,java.lang.Object> properties,
java.util.Set<java.lang.String> allTags) |
void |
ContextManagerNested.addStatement(ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
void |
ContextManagerImpl.addStatement(ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
void |
ContextManager.addStatement(ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
void |
ContextManagementServiceImpl.addStatement(java.lang.String contextName,
ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
void |
ContextManagementService.addStatement(java.lang.String contextName,
ContextControllerStatementBase statement,
boolean isRecoveringResilient) |
static ContextControllerHashFactory.HashFunctionEnum |
ContextControllerHashFactory.HashFunctionEnum.determine(java.lang.String contextName,
java.lang.String name) |
ContextControllerFactory[] |
ContextControllerFactoryServiceImpl.getFactory(ContextControllerFactoryServiceContext serviceContext) |
ContextControllerFactory[] |
ContextControllerFactoryService.getFactory(ContextControllerFactoryServiceContext context) |
static ContextControllerFactory[] |
ContextControllerFactoryHelper.getFactory(ContextControllerFactoryServiceContext serviceContext,
ContextStateCache contextStateCache) |
void |
ContextControllerPartitionedFactory.validateFactory() |
void |
ContextControllerInitTermFactory.validateFactory() |
void |
ContextControllerHashFactory.validateFactory() |
void |
ContextControllerFactory.validateFactory() |
void |
ContextControllerCategoryFactory.validateFactory() |
ContextControllerStatementCtxCache |
ContextControllerPartitionedFactory.validateStatement(ContextControllerStatementBase statement) |
ContextControllerStatementCtxCache |
ContextControllerHashFactory.validateStatement(ContextControllerStatementBase statement) |
ContextControllerStatementCtxCache |
ContextControllerFactory.validateStatement(ContextControllerStatementBase statement) |
ContextControllerStatementCtxCache |
ContextControllerCategoryFactory.validateStatement(ContextControllerStatementBase statement) |
Constructor and Description |
---|
ContextControllerHashedGetterSingleRow(java.lang.String statementName,
java.lang.String functionName,
Pair<java.lang.Class,EngineImportSingleRowDesc> func,
java.util.List<ExprNode> parameters,
int granularity,
MethodResolutionService methodResolutionService,
EventType eventType,
EventAdapterService eventAdapterService,
java.lang.String statementId) |
ContextManagerImpl(ContextControllerFactoryServiceContext factoryServiceContext) |
ContextManagerNested(ContextControllerFactoryServiceContext factoryServiceContext) |
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,
java.lang.annotation.Annotation[] annotations) |
InternalEventRouterDesc |
InternalEventRouter.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
java.lang.annotation.Annotation[] annotations) |
static void |
StatementLifecycleSvcUtil.walkStatement(StatementSpecRaw spec,
ExprNodeSubselectDeclaredDotVisitor visitor) |
Modifier and Type | Method and Description |
---|---|
abstract EPPreparedExecuteSingleStreamExec |
EPPreparedExecuteSingleStream.getExecutor(FilterSpecCompiled filter,
java.lang.String aliasName) |
EPPreparedExecuteSingleStreamExec |
EPPreparedExecuteInsertInto.getExecutor(FilterSpecCompiled filter,
java.lang.String aliasName) |
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 |
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) |
static void |
EPStatementStartMethodHelperValidate.validateNoDataWindowOnNamedWindow(java.util.List<ViewFactory> viewFactories) |
static ViewResourceDelegateVerified |
EPStatementStartMethodHelperViewResources.verifyPreviousAndPriorRequirements(ViewFactoryChain[] unmaterializedViewChain,
ViewResourceDelegateUnverified delegate) |
Constructor and Description |
---|
EPPreparedExecuteInsertInto(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext) |
EPPreparedExecuteMethodQuery(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext)
Ctor.
|
EPPreparedExecuteSingleStream(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext)
Ctor.
|
EPPreparedExecuteSingleStreamDelete(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext) |
EPPreparedExecuteSingleStreamUpdate(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext) |
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 |
---|---|
static GroupByClauseExpressions |
GroupByExpressionHelper.getGroupByRollupExpressions(java.util.List<GroupByClauseElement> groupByElements,
SelectClauseSpecRaw selectClauseSpec,
ExprNode optionalHavingNode,
java.util.List<OrderByItem> orderByList,
ExprNodeSubselectDeclaredDotVisitor visitor) |
Modifier and Type | Method and Description |
---|---|
static ExprValidationException |
AggregationServiceFactoryFactory.getRollupReclaimEx() |
Modifier and Type | Method and Description |
---|---|
AggregationServiceFactory |
AggregationServiceFactoryServiceImpl.getGroupReclaimAged(ExprEvaluator[] evaluatorsArr,
AggregationMethodFactory[] aggregatorsArr,
Hint reclaimGroupAged,
Hint reclaimGroupFrequency,
VariableService variableService,
AggregationAccessorSlotPair[] pairs,
AggregationStateFactory[] accessAggregations,
boolean join,
java.lang.Object groupKeyBinding,
java.lang.String optionalContextName) |
AggregationServiceFactory |
AggregationServiceFactoryService.getGroupReclaimAged(ExprEvaluator[] evaluatorsArr,
AggregationMethodFactory[] aggregatorsArr,
Hint reclaimGroupAged,
Hint reclaimGroupFrequency,
VariableService variableService,
AggregationAccessorSlotPair[] pairs,
AggregationStateFactory[] accessAggregations,
boolean join,
java.lang.Object groupKeyBinding,
java.lang.String optionalContextName) |
static AggregationServiceFactoryDesc |
AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes,
ExprNode[] groupByNodes,
java.util.List<ExprAggregateNode> havingAggregateExprNodes,
java.util.List<ExprAggregateNode> orderByAggregateExprNodes,
java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.annotation.Annotation[] annotations,
VariableService variableService,
boolean isJoin,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
AggregationServiceFactoryService factoryService,
EventType[] typesPerStream,
MethodResolutionService methodResolutionService,
AggregationGroupByRollupDesc groupByRollupDesc,
java.lang.String optionalContextName)
Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on
whether there are any group-by nodes.
|
Constructor and Description |
---|
AggSvcGroupByReclaimAgedFactory(ExprEvaluator[] evaluators,
AggregationMethodFactory[] prototypes,
java.lang.Object groupKeyBinding,
Hint reclaimGroupAged,
Hint reclaimGroupFrequency,
VariableService variableService,
AggregationAccessorSlotPair[] accessors,
AggregationStateFactory[] accessAggregations,
boolean isJoin,
java.lang.String optionalContextName)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static SelectExprProcessor |
SelectExprJoinWildcardProcessorFactory.create(java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
java.lang.String statementId,
java.lang.String[] streamNames,
EventType[] streamTypes,
EventAdapterService eventAdapterService,
InsertIntoDesc insertIntoDesc,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
MethodResolutionService methodResolutionService,
java.lang.annotation.Annotation[] annotations,
ConfigurationInformation configuration)
Ctor.
|
static HistoricalEventViewable |
MethodPollingViewableFactory.createPollMethodView(int streamNumber,
MethodStreamSpec methodStreamSpec,
EventAdapterService eventAdapterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
MethodResolutionService methodResolutionService,
EngineImportService engineImportService,
SchedulingService schedulingService,
ScheduleBucket scheduleBucket,
ExprEvaluatorContext exprEvaluatorContext)
Creates a method-invocation polling view for use as a stream that calls a method, or pulls results from cache.
|
SelectExprProcessor |
SelectExprProcessorHelper.getEvaluator() |
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingJoinWildcard(EventAdapterService eventAdapterService,
EventType eventType,
java.lang.String[] streamNames,
EventType[] streamTypes,
EngineImportService engineImportService) |
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingNonJoin(EventAdapterService eventAdapterService,
EventType eventType,
boolean isUsingWildcard,
StreamTypeService typeService,
ExprEvaluator[] expressionNodes,
java.lang.String[] columnNames,
java.lang.Object[] expressionReturnTypes,
EngineImportService engineImportService,
InsertIntoDesc insertIntoDesc,
java.lang.String[] columnNamesAsProvided) |
static SelectExprProcessor |
SelectExprProcessorFactory.getProcessor(java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
SelectClauseElementCompiled[] selectionList,
boolean isUsingWildcard,
InsertIntoDesc insertIntoDesc,
ForClauseSpec forClauseSpec,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
StatementResultService statementResultService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
MethodResolutionService methodResolutionService,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
TimeProvider timeProvider,
java.lang.String engineURI,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configuration,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback,
NamedWindowService namedWindowService)
Returns the processor to use for a given select-clause.
|
static OrderByProcessorFactory |
OrderByProcessorFactoryFactory.getProcessor(java.util.List<SelectClauseExprCompiledSpec> selectionList,
ExprNode[] groupByNodes,
java.util.List<OrderByItem> orderByList,
RowLimitSpec rowLimitSpec,
VariableService variableService,
boolean isSortUsingCollator,
java.lang.String optionalContextName)
Returns processor for order-by clauses.
|
static ResultSetProcessorFactoryDesc |
ResultSetProcessorFactoryFactory.getProcessorPrototype(StatementSpecCompiled statementSpec,
StatementContext stmtContext,
StreamTypeService typeService,
ViewResourceDelegateUnverified viewResourceDelegate,
boolean[] isUnidirectionalStream,
boolean allowAggregation,
ContextPropertyRegistry contextPropertyRegistry,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback)
Returns the result set process for the given select expression, group-by clause and
having clause given a set of types describing each stream in the from-clause.
|
void |
MethodPollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
java.lang.String engineURI,
java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations) |
Constructor and Description |
---|
BindProcessor(SelectClauseElementCompiled[] selectionList,
EventType[] typesPerStream,
java.lang.String[] streamNames)
Ctor.
|
OrderByProcessorFactoryImpl(java.util.List<OrderByItem> orderByList,
ExprNode[] groupByNodes,
boolean needsGroupByKeys,
boolean isSortUsingCollator)
Ctor.
|
OrderByProcessorRowLimitFactory(RowLimitSpec rowLimitSpec,
VariableService variableService,
java.lang.String optionalContextName)
Ctor.
|
SelectExprProcessorHelper(java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
java.util.List<SelectClauseExprCompiledSpec> selectionList,
java.util.List<SelectExprStreamDesc> selectedStreams,
InsertIntoDesc insertIntoDesc,
boolean isUsingWildcard,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
MethodResolutionService methodResolutionService,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
ConfigurationInformation configuration,
NamedWindowService namedWindowService)
Ctor.
|
SelectExprWildcardProcessor(EventType eventType)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(java.lang.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) |
static SelectExprProcessor |
EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService) |
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(java.lang.String methodName,
ExprNode exprNode) |
CalendarOp |
CalendarOpFactory.getOp(DatetimeMethodEnum method,
java.lang.String methodNameUsed,
java.util.List<ExprNode> parameters,
ExprEvaluator[] evaluators) |
Modifier and Type | Method and Description |
---|---|
static ExprDotEvalDTMethodDesc |
ExprDotEvalDTFactory.validateMake(StreamTypeService streamTypeService,
java.util.Deque<ExprChainedSpec> chainSpecStack,
DatetimeMethodEnum dtMethod,
java.lang.String dtMethodName,
EPType inputType,
java.util.List<ExprNode> parameters,
ExprDotNodeFilterAnalyzerInput inputDesc) |
Modifier and Type | Method and Description |
---|---|
IntervalOp |
IntervalOpFactory.getOp(StreamTypeService streamTypeService,
DatetimeMethodEnum method,
java.lang.String methodNameUsed,
java.util.List<ExprNode> parameters,
ExprEvaluator[] evaluators) |
static IntervalComputer |
IntervalComputerFactory.make(DatetimeMethodEnum method,
java.util.List<ExprNode> expressions) |
Constructor and Description |
---|
IntervalComputerConstantCoincides(IntervalStartEndParameterPair pair) |
IntervalOpImpl(DatetimeMethodEnum method,
java.lang.String methodNameUse,
StreamTypeService streamTypeService,
java.util.List<ExprNode> expressions) |
Modifier and Type | Method and Description |
---|---|
ReformatOp |
ReformatOpFactory.getOp(DatetimeMethodEnum method,
java.lang.String methodNameUsed,
java.util.List<ExprNode> parameters) |
Constructor and Description |
---|
ReformatOpBetweenConstantParams(java.util.List<ExprNode> parameters) |
ReformatOpBetweenNonConstantParams(java.util.List<ExprNode> parameters) |
Modifier and Type | Method and Description |
---|---|
static HistoricalEventViewable |
DatabasePollingViewableFactory.createDBStatementView(java.lang.String statementId,
int streamNumber,
DBStatementStreamSpec databaseStreamSpec,
DatabaseConfigService databaseConfigService,
EventAdapterService eventAdapterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
SQLColumnTypeConversion columnTypeConversionHook,
SQLOutputRowConversion outputRowConversionHook,
boolean enableJDBCLogging)
Creates the viewable for polling via database SQL query.
|
void |
DatabasePollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
java.lang.String engineURI,
java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations) |
Modifier and Type | Method and Description |
---|---|
java.lang.String |
ExprDeclaredServiceImpl.addExpressionOrScript(CreateExpressionDesc expressionDesc) |
java.lang.String |
ExprDeclaredService.addExpressionOrScript(CreateExpressionDesc expression) |
java.lang.Class |
ExprDeclaredEvalBase.getComponentTypeCollection() |
EventType |
ExprDeclaredEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprDeclaredEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
java.util.LinkedHashMap<java.lang.String,java.lang.Integer> |
ExprDeclaredNodeImpl.getOuterStreamNames(java.util.Map<java.lang.String,java.lang.Integer> outerStreamNames) |
java.util.LinkedHashMap<java.lang.String,java.lang.Integer> |
ExprDeclaredNode.getOuterStreamNames(java.util.Map<java.lang.String,java.lang.Integer> outerStreamNames) |
java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprDeclaredEvalBase.getRowProperties() |
void |
ExprDeclaredNodeImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
java.lang.Class |
PropertyExprEvaluatorScalarIterable.getComponentTypeCollection() |
java.lang.Class |
PropertyExprEvaluatorScalarCollection.getComponentTypeCollection() |
java.lang.Class |
PropertyExprEvaluatorScalarArray.getComponentTypeCollection() |
java.lang.Class |
PropertyExprEvaluatorEventCollection.getComponentTypeCollection() |
abstract EnumEval |
ExprDotEvalEnumMethodBase.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EventType |
PropertyExprEvaluatorScalarIterable.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
PropertyExprEvaluatorScalarCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
PropertyExprEvaluatorScalarArray.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
PropertyExprEvaluatorEventCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
void |
ExprDotEvalEnumMethodBase.init(java.lang.Integer streamOfProviderIfApplicable,
EnumMethodEnum enumMethodEnum,
java.lang.String enumMethodUsedName,
EPType typeInfo,
java.util.List<ExprNode> parameters,
ExprValidationContext validationContext) |
void |
ExprDotEvalEnumMethod.init(java.lang.Integer streamOfProviderIfApplicable,
EnumMethodEnum lambda,
java.lang.String lambdaUsedName,
EPType currentInputType,
java.util.List<ExprNode> parameters,
ExprValidationContext validationContext) |
void |
ExprLambdaGoesNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
EnumEval |
ExprDotEvalSetExceptUnionIntersect.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalSequenceEqual.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
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(java.lang.Exception e) |
ExprValidationException |
ExprNodeUtilResolveExceptionHandler.handle(java.lang.Exception e) |
static ExprValidationException |
ExprGroupingIdNode.makeException(java.lang.String functionName) |
Modifier and Type | Method and Description |
---|---|
static SubselectEvalStrategy |
SubselectEvalStrategyFactory.createStrategy(ExprSubselectNode subselectExpression,
boolean isNot,
boolean isAll,
boolean isAny,
RelationalOpEnum relationalOp)
Create a strategy.
|
static ExprDotNodeRealizedChain |
ExprDotNodeUtility.getChainEvaluators(java.lang.Integer streamOfProviderIfApplicable,
EPType inputType,
java.util.List<ExprChainedSpec> chainSpec,
ExprValidationContext validationContext,
boolean isDuckTyping,
ExprDotNodeFilterAnalyzerInput inputDesc) |
java.lang.Class |
ExprSubselectRowNode.getComponentTypeCollection() |
java.lang.Class |
ExprSubselectInNode.getComponentTypeCollection() |
java.lang.Class |
ExprSubselectExistsNode.getComponentTypeCollection() |
java.lang.Class |
ExprSubselectAllSomeAnyNode.getComponentTypeCollection() |
java.lang.Class |
ExprPreviousNode.getComponentTypeCollection() |
java.lang.Class |
ExprPlugInAggMultiFunctionNode.getComponentTypeCollection() |
java.lang.Class |
ExprEvaluatorEnumeration.getComponentTypeCollection() |
java.lang.Class |
ExprDotEvalRootChild.getComponentTypeCollection() |
java.lang.Class |
ExprArrayNode.getComponentTypeCollection() |
java.lang.Class |
ExprAggMultiFunctionSortedMinMaxByNode.getComponentTypeCollection() |
java.lang.Class |
ExprAggMultiFunctionLinearAccessNode.getComponentTypeCollection() |
static ExprDotNode.EnumerationSource |
ExprDotNode.getEnumerationSource(ExprNode inputExpression,
StreamTypeService streamTypeService,
EventAdapterService eventAdapterService,
java.lang.String statementId,
boolean hasEnumerationMethod,
boolean disablePropertyExpressionEventCollCache) |
EventType |
ExprSubselectRowNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprPreviousNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprEvaluatorEnumeration.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprDotEvalRootChild.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprArrayNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprSubselectRowNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprSubselectInNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprSubselectExistsNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprSubselectAllSomeAnyNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprPreviousNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprPlugInAggMultiFunctionNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprEvaluatorEnumeration.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprDotEvalRootChild.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprArrayNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprAggMultiFunctionLinearAccessNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
static java.util.Set<Pair<java.lang.Integer,java.lang.String>> |
ExprNodeUtility.getGroupByPropertiesValidateHasOne(ExprNode[] groupByNodes) |
java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprSubselectNode.getRowProperties() |
java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprNewNode.getRowProperties() |
java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprEvaluatorTypableReturn.getRowProperties()
Return null to indicate no row-type result available,
or a map of property names and types to indicate a row-type result is available.
|
java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprCaseNode.getRowProperties() |
static ExprNode |
ExprNodeUtility.getValidatedAssignment(OnTriggerSetAssignment assignment,
ExprValidationContext validationContext) |
static void |
ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode[][] exprNode,
ExprValidationContext validationContext) |
static void |
ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode[] exprNode,
ExprValidationContext validationContext) |
static ExprNode |
ExprNodeUtility.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode exprNode,
ExprValidationContext validationContext)
Validates the expression node subtree that has this
node as root.
|
static ExprNodeUtilMethodDesc |
ExprNodeUtility.resolveMethodAllowWildcardAndStream(java.lang.String className,
java.lang.Class optionalClass,
java.lang.String methodName,
java.util.List<ExprNode> parameters,
MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
java.lang.String statementId,
boolean allowWildcard,
EventType wildcardType,
ExprNodeUtilResolveExceptionHandler exceptionHandler,
java.lang.String functionName) |
static ScheduleSpec |
ExprNodeUtility.toCrontabSchedule(ExprNodeOrigin origin,
java.util.List<ExprNode> scheduleSpecExpressionList,
StatementContext context) |
java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprSubselectRowNode.typableGetRowProperties() |
abstract java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExprSubselectNode.typableGetRowProperties() |
static void |
ExprNodeUtility.validate(ExprNodeOrigin origin,
java.util.List<ExprChainedSpec> chainSpec,
ExprValidationContext validationContext) |
void |
ExprVariableNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprValidator.validate(ExprValidationContext validationContext) |
void |
ExprTypeofNode.validate(ExprValidationContext validationContext) |
void |
ExprTimestampNode.validate(ExprValidationContext validationContext) |
void |
ExprTimePeriodImpl.validate(ExprValidationContext validationContext) |
void |
ExprSubstitutionNode.validate(ExprValidationContext validationContext) |
void |
ExprSubselectNode.validate(ExprValidationContext validationContext) |
void |
ExprStreamUnderlyingNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprRelationalOpNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprRelationalOpAllAnyNode.validate(ExprValidationContext validationContext) |
void |
ExprRegexpNode.validate(ExprValidationContext validationContext) |
void |
ExprPropertyExistsNode.validate(ExprValidationContext validationContext) |
void |
ExprPriorNode.validate(ExprValidationContext validationContext) |
void |
ExprPreviousNode.validate(ExprValidationContext validationContext) |
void |
ExprPreviousMatchRecognizeNode.validate(ExprValidationContext validationContext) |
void |
ExprPlugInSingleRowNode.validate(ExprValidationContext validationContext) |
void |
ExprOrNode.validate(ExprValidationContext validationContext) |
void |
ExprOrderedExpr.validate(ExprValidationContext validationContext) |
void |
ExprNumberSetWildcard.validate(ExprValidationContext validationContext) |
void |
ExprNumberSetRange.validate(ExprValidationContext validationContext) |
void |
ExprNumberSetList.validate(ExprValidationContext validationContext) |
void |
ExprNumberSetFrequency.validate(ExprValidationContext validationContext) |
void |
ExprNumberSetCronParam.validate(ExprValidationContext validationContext) |
void |
ExprNotNode.validate(ExprValidationContext validationContext) |
void |
ExprNodeValidated.validate(ExprValidationContext validationContext) |
void |
ExprNewNode.validate(ExprValidationContext validationContext) |
void |
ExprMinMaxRowNode.validate(ExprValidationContext validationContext) |
void |
ExprMathNode.validate(ExprValidationContext validationContext) |
void |
ExprLikeNode.validate(ExprValidationContext validationContext) |
void |
ExprIStreamNode.validate(ExprValidationContext validationContext) |
void |
ExprInstanceofNode.validate(ExprValidationContext validationContext) |
void |
ExprInNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprIdentNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprGroupingNode.validate(ExprValidationContext validationContext) |
void |
ExprGroupingIdNode.validate(ExprValidationContext validationContext) |
void |
ExprEqualsNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprEqualsAllAnyNode.validate(ExprValidationContext validationContext) |
void |
ExprDotNode.validate(ExprValidationContext validationContext) |
void |
ExprContextPropertyNode.validate(ExprValidationContext validationContext) |
void |
ExprConstantNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprConcatNode.validate(ExprValidationContext validationContext) |
void |
ExprCoalesceNode.validate(ExprValidationContext validationContext) |
void |
ExprCastNode.validate(ExprValidationContext validationContext) |
void |
ExprCaseNode.validate(ExprValidationContext validationContext) |
void |
ExprBitWiseNode.validate(ExprValidationContext validationContext) |
void |
ExprBetweenNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprArrayNode.validate(ExprValidationContext validationContext) |
void |
ExprAndNodeImpl.validate(ExprValidationContext validationContext) |
void |
ExprAggregateNodeGroupKey.validate(ExprValidationContext validationContext) |
void |
ExprAggregateNodeBase.validate(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprSumNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprStddevNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprRateAggNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprPlugInAggMultiFunctionNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprPlugInAggFunctionFactoryNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprNthAggNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprMinMaxAggrNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprMedianNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprLeavingAggNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprLastEverNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprFirstEverNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprCountNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprAvgNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprAvedevNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprAggMultiFunctionSortedMinMaxByNode.validateAggregationChild(ExprValidationContext validationContext) |
AggregationMethodFactory |
ExprAggMultiFunctionLinearAccessNode.validateAggregationChild(ExprValidationContext validationContext) |
void |
ExprAggregateNodeBase.validateFilter(ExprEvaluator filterEvaluator) |
static void |
ExprNodeUtility.validatePlainExpression(ExprNodeOrigin origin,
java.lang.String expressionTextualName,
ExprNode expression) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType) |
void |
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) |
void |
ExprInNodeImpl.validateWithoutContext() |
void |
ExprInNode.validateWithoutContext() |
Modifier and Type | Method and Description |
---|---|
static JoinSetComposerPrototype |
JoinSetComposerPrototypeFactory.makeComposerPrototype(java.lang.String statementName,
java.lang.String statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
java.lang.String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean queryPlanLogging,
StatementContext statementContext,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
boolean selectsRemoveStream,
boolean hasAggregations)
Builds join tuple composer.
|
Modifier and Type | Method and Description |
---|---|
static ExcludePlanHint |
ExcludePlanHint.getHint(java.lang.String[] streamNames,
StatementContext statementContext) |
static ExprEvaluator |
ExcludePlanHintExprUtil.toExpression(java.lang.String hint,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
static QueryPlan |
QueryPlanBuilder.getPlan(EventType[] typesPerStream,
OuterJoinDesc[] outerJoinDescList,
QueryGraph queryGraph,
java.lang.String[] streamNames,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean isQueryPlanLogging,
java.lang.annotation.Annotation[] annotations,
ExprEvaluatorContext exprEvaluatorContext)
Build query plan using the filter.
|
Modifier and Type | Method and Description |
---|---|
static DotMethodFP |
DotMethodUtil.validateParametersDetermineFootprint(DotMethodFP[] footprints,
DotMethodTypeEnum methodType,
java.lang.String methodUsedName,
DotMethodFPProvided providedFootprint,
DotMethodInputTypeMatcher inputTypeMatcher) |
static void |
DotMethodUtil.validateSpecificType(java.lang.String methodUsedName,
DotMethodTypeEnum type,
DotMethodFPParamTypeEnum expectedTypeEnum,
java.lang.Class expectedTypeClass,
java.lang.Class providedType,
int parameterNum,
ExprNode parameterExpression) |
Modifier and Type | Method and Description |
---|---|
void |
NamedWindowRootViewInstance.addExplicitIndex(boolean unique,
java.lang.String namedWindowName,
java.lang.String indexName,
java.util.List<CreateIndexItem> columns)
Add an explicit index.
|
static NamedWindowOnExprFactory |
NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType,
java.lang.String namedWindowName,
java.lang.String namedWindowAlias,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
java.lang.String filterStreamName,
boolean addToFront,
InternalEventRouter internalEventRouter,
EventType outputEventType,
StatementContext statementContext,
StatementMetricHandle createNamedWindowMetricsHandle,
boolean isDistinct) |
static NamedWindowUpdateHelper |
NamedWindowUpdateHelper.make(java.lang.String namedWindowName,
EventTypeSPI eventTypeSPI,
java.util.List<OnTriggerSetAssignment> assignments,
java.lang.String namedWindowAlias,
EventType optionalTriggeringEventType) |
void |
NamedWindowProcessor.validateOnExpressionContext(java.lang.String onExprContextName) |
Constructor and Description |
---|
NamedWindowOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
java.lang.String triggeringStreamName,
InternalEventRouter internalEventRouter,
java.lang.String namedWindowName,
EventTypeSPI namedWindowType) |
Modifier and Type | Method and Description |
---|---|
static PropertyEvaluator |
PropertyEvaluatorFactory.makeEvaluator(PropertyEvalSpec spec,
EventType sourceEventType,
java.lang.String optionalSourceStreamName,
EventAdapterService eventAdapterService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
java.lang.String engineURI,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
ConfigurationInformation configuration,
NamedWindowService namedWindowService)
Makes the property evaluator.
|
Modifier and Type | Method and Description |
---|---|
java.lang.Class |
ExprNodeScriptEvalBase.getComponentTypeCollection() |
EventType |
ExprNodeScriptEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId) |
EventType |
ExprNodeScriptEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId) |
void |
ExprNodeScript.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static javax.script.CompiledScript |
JSR223Helper.verifyCompileScript(ExpressionScriptProvided script,
java.lang.String dialect) |
Modifier and Type | Method and Description |
---|---|
static ExpressionScriptCompiled |
MVELHelper.compile(java.lang.String scriptName,
java.lang.String expression,
java.util.Map<java.lang.String,java.lang.Class> mvelInputParamTypes) |
static void |
MVELHelper.verifyScript(ExpressionScriptProvided script)
Verify MVEL script (not compiling it).
|
Modifier and Type | Method and Description |
---|---|
StreamSpecCompiled |
StreamSpecRaw.compile(StatementContext statementContext,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger)
Compiles a raw stream specification consisting event type information and filter expressions
to an validated, optimized form for use with filter service
|
PatternStreamSpecCompiled |
PatternStreamSpecRaw.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
StreamSpecCompiled |
MethodStreamSpec.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
StreamSpecCompiled |
FilterStreamSpecRaw.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
PatternStreamSpecCompiled |
PatternStreamSpecRaw.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
MatchEventSpec priorTags,
java.util.Set<java.lang.String> priorAllTags,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
static EventType |
FilterStreamSpecRaw.resolveType(java.lang.String engineURI,
java.lang.String eventName,
EventAdapterService eventAdapterService,
java.net.URI[] optionalResolutionURIs)
Resolves a given event name to an event type.
|
void |
MatchRecognizeInterval.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static java.util.List<FilterSpecRaw> |
StatementSpecRawAnalyzer.analyzeFilters(StatementSpecRaw spec) |
static ExprNodeSubselectDeclaredDotVisitor |
StatementSpecRawAnalyzer.walkSubselectAndDeclaredDotExpr(StatementSpecRaw spec) |
Constructor and Description |
---|
OnSetVariableViewFactory(java.lang.String statementId,
OnTriggerSetDesc desc,
EventAdapterService eventAdapterService,
VariableService variableService,
StatementResultService statementResultService,
ExprEvaluatorContext exprEvaluatorContext)
Ctor.
|
VariableReadWritePackage(java.util.List<OnTriggerSetAssignment> assignments,
VariableService variableService,
EventAdapterService eventAdapterService)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static OutputConditionPolled |
OutputConditionPolledFactory.createCondition(OutputLimitSpec outputLimitSpec,
AgentInstanceContext agentInstanceContext)
Creates an output condition instance.
|
static OutputConditionFactory |
OutputConditionFactoryFactory.createCondition(OutputLimitSpec outputLimitSpec,
StatementContext statementContext,
boolean isGrouped,
boolean isWithHavingClause)
Creates an output condition instance.
|
static OutputProcessViewFactory |
OutputProcessViewFactoryFactory.make(StatementSpecCompiled statementSpec,
InternalEventRouter internalEventRouter,
StatementContext statementContext,
EventType resultEventType,
OutputProcessViewCallback optionalOutputProcessViewCallback) |
Constructor and Description |
---|
OutputConditionCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList,
StatementContext statementContext) |
OutputConditionExpressionFactory(ExprNode whenExpressionNode,
java.util.List<OnTriggerSetAssignment> assignments,
StatementContext statementContext,
ExprNode andWhenTerminatedExpr,
java.util.List<OnTriggerSetAssignment> afterTerminateAssignments) |
OutputConditionFirstFactory(OutputLimitSpec outputLimitSpec,
StatementContext statementContext,
boolean isGrouped,
boolean isWithHavingClause) |
OutputConditionPolledCrontab(java.util.List<ExprNode> scheduleSpecExpressionList,
AgentInstanceContext agentInstanceContext)
Constructor.
|
OutputConditionPolledExpression(ExprNode whenExpressionNode,
java.util.List<OnTriggerSetAssignment> assignments,
AgentInstanceContext agentInstanceContext)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
EventTypeUtility.buildType(java.util.List<ColumnDesc> columns,
EventAdapterService eventAdapterService,
java.util.Set<java.lang.String> copyFrom,
EngineImportService engineImportService) |
static EventType |
EventTypeUtility.createNonVariantType(boolean isAnonymous,
CreateSchemaDesc spec,
java.lang.annotation.Annotation[] annotations,
ConfigurationInformation configSnapshot,
EventAdapterService eventAdapterService,
EngineImportService engineImportService) |
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(java.util.List<ExprNode> validatedNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext stmtContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack) |
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
TimeProvider timeProvider,
VariableService variableService,
ConfigurationInformation configurationInformation,
NamedWindowService namedWindowService) |
static java.util.List<ExprNode> |
FilterSpecCompiler.decomposeCheckAggregation(java.util.List<ExprNode> validatedNodes) |
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
java.lang.String eventTypeName,
java.util.List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext statementContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
static java.util.List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
java.util.List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
Modifier and Type | Method and Description |
---|---|
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
java.util.Map<java.lang.String,java.util.Set<java.lang.String>> visibilityByIdentifier,
EventType parentViewType) |
Constructor and Description |
---|
EventRowRegexNFAViewFactory(ViewFactoryChain viewChain,
MatchRecognizeSpec matchRecognizeSpec,
AgentInstanceContext agentInstanceContext,
boolean isUnbound,
java.lang.annotation.Annotation[] annotations)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static java.lang.Object |
JavaClassHelper.getAnnotationHook(java.lang.annotation.Annotation[] annotations,
HookType hookType,
java.lang.Class interfaceExpected,
MethodResolutionService resolution)
Returns an instance of a hook as specified by an annotation.
|
static TypeWidener |
TypeWidenerFactory.getCheckPropertyAssignType(java.lang.String columnName,
java.lang.Class columnType,
java.lang.Class writeablePropertyType,
java.lang.String writeablePropertyName)
Returns the widener.
|
static java.lang.Object |
PopulateUtil.instantiatePopulateObject(java.util.Map<java.lang.String,java.lang.Object> objectProperties,
java.lang.Class topClass,
EngineImportService engineImportService) |
static java.lang.Object |
JsonUtil.parsePopulate(java.lang.String json,
java.lang.Class topClass,
EngineImportService engineImportService) |
static void |
PopulateUtil.populateObject(java.lang.String operatorName,
int operatorNum,
java.lang.String dataFlowName,
java.util.Map<java.lang.String,java.lang.Object> objectProperties,
java.lang.Object top,
EngineImportService engineImportService,
EPDataFlowOperatorParameterProvider optionalParameterProvider,
java.util.Map<java.lang.String,java.lang.Object> optionalParameterURIs) |
static java.lang.Object |
JavaClassHelper.resolveIdentAsEnumConst(java.lang.String constant,
MethodResolutionService methodResolutionService,
EngineImportService engineImportService)
Resolve a string constant as a possible enumeration value, returning null if not resolved.
|
Modifier and Type | Method and Description |
---|---|
void |
ValidatedView.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
java.lang.String engineURI,
java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations)
Validate the view.
|