Package | Description |
---|---|
com.espertech.esper.client.hook |
Callback interfaces for use with statement annotations.
|
com.espertech.esper.core.context.activator |
Activation of streams for statement start.
|
com.espertech.esper.core.context.factory |
Statement agent instance factories.
|
com.espertech.esper.core.context.mgr |
Context management.
|
com.espertech.esper.core.context.util |
Context partition utility or reference classes.
|
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.core.support |
Internal-use-only services for unit and regression testing
|
com.espertech.esper.dataflow.core |
Data flow core classes.
|
com.espertech.esper.dataflow.interfaces |
Data flow operator and related interface.
|
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.db |
Database SQL polling views and caches
|
com.espertech.esper.epl.expression.core |
Core expression classes.
|
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.pollindex |
Poll result indexing strategies.
|
com.espertech.esper.epl.join.table |
Indexes for views
|
com.espertech.esper.epl.lookup |
Subquery execution strategies and lookup indexes
|
com.espertech.esper.epl.named |
Named window classes are in this package
|
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.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.view |
Internal processing views for output rate limiting, filtering and internal event routing
|
com.espertech.esper.epl.virtualdw |
Virtual data window.
|
com.espertech.esper.filter |
Main switchboard filtering and routing of incoming events to interested statements is performed in this package.
|
com.espertech.esper.pattern |
Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active
pattern instance
|
com.espertech.esper.rowregex |
Match-recognize expression tree and state objects.
|
com.espertech.esper.view |
View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering.
|
com.espertech.esper.view.ext |
Extension views that providing services such as sorting, which don't fit much into other categories.
|
com.espertech.esper.view.internal |
Internal management views for buffering view results and providing these to joins.
|
com.espertech.esper.view.stat |
Views computing statistical values.
|
com.espertech.esper.view.std |
Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc.
|
com.espertech.esper.view.window |
Window views are in this package
|
Modifier and Type | Method and Description |
---|---|
StatementContext |
VirtualDataWindowFactoryContext.getStatementContext()
Returns the statement contextual information and services.
|
StatementContext |
VirtualDataWindowContext.getStatementContext()
Returns the statement context which holds statement information (name, expression, id) and statement-level services.
|
Modifier and Type | Method and Description |
---|---|
ViewableActivator |
ViewableActivatorFactoryDefault.createNamedWindow(NamedWindowProcessor processor,
NamedWindowConsumerStreamSpec streamSpec,
StatementContext statementContext) |
ViewableActivator |
ViewableActivatorFactory.createNamedWindow(NamedWindowProcessor processor,
NamedWindowConsumerStreamSpec streamSpec,
StatementContext statementContext) |
ViewableActivator |
ViewableActivatorFactoryDefault.createStreamReuseView(EPServicesContext services,
StatementContext statementContext,
StatementSpecCompiled statementSpec,
FilterStreamSpecCompiled filterStreamSpec,
boolean isJoin,
ExprEvaluatorContextStatement evaluatorContextStmt,
boolean filterSubselectSameStream,
int streamNum,
boolean isCanIterateUnbound) |
ViewableActivator |
ViewableActivatorFactory.createStreamReuseView(EPServicesContext services,
StatementContext statementContext,
StatementSpecCompiled statementSpec,
FilterStreamSpecCompiled filterStreamSpec,
boolean isJoin,
ExprEvaluatorContextStatement evaluatorContextStmt,
boolean filterSubselectSameStream,
int streamNum,
boolean isCanIterateUnbound) |
Constructor and Description |
---|
ViewableActivatorStreamReuseView(EPServicesContext services,
StatementContext statementContext,
StatementSpecCompiled statementSpec,
FilterStreamSpecCompiled filterStreamSpec,
boolean join,
ExprEvaluatorContextStatement evaluatorContextStmt,
boolean filterSubselectSameStream,
int streamNum,
boolean isCanIterateUnbound) |
Modifier and Type | Field and Description |
---|---|
protected StatementContext |
StatementAgentInstanceFactorySelect.statementContext |
protected StatementContext |
StatementAgentInstanceFactoryOnTriggerBase.statementContext |
protected StatementContext |
StatementAgentInstanceFactoryCreateWindow.statementContext |
Modifier and Type | Method and Description |
---|---|
StatementContext |
StatementAgentInstanceFactorySelect.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
protected static StatementAgentInstanceFactoryOnTriggerNamedWindow.IndexHintPair |
StatementAgentInstanceFactoryOnTriggerNamedWindow.getIndexHintPair(StatementContext statementContext,
StatementSpecCompiled statementSpec) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
ContextControllerStatementBase.getStatementContext() |
StatementContext |
ContextControllerInitTermFactoryBase.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
StatementContext |
AgentInstanceViewFactoryChainContext.getStatementContext() |
StatementContext |
AgentInstanceContext.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
static void |
StatementAgentInstanceUtil.stopSafe(Collection<StopCallback> terminationCallbacks,
StopCallback[] stopCallbacks,
StatementContext statementContext) |
static void |
StatementAgentInstanceUtil.stopSafe(StopCallback[] stopMethods,
StatementContext statementContext) |
static void |
StatementAgentInstanceUtil.stopSafe(StopCallback stopMethod,
StatementContext statementContext) |
Constructor and Description |
---|
AgentInstanceContext(StatementContext statementContext,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
int agentInstanceId,
AgentInstanceFilterProxy agentInstanceFilterProxy,
MappedEventBean agentInstanceProperties,
AgentInstanceScriptContext agentInstanceScriptContext) |
Modifier and Type | Field and Description |
---|---|
protected StatementContext |
ExprEvaluatorContextStatement.statementContext |
protected StatementContext |
EPStatementImpl.statementContext |
Modifier and Type | Method and Description |
---|---|
StatementContext |
StatementContextCPPair.getOptionalStatementContext() |
StatementContext |
StatementMetadataFactoryContext.getStatementContext() |
StatementContext |
StatementLifecycleSvcImpl.EPStatementDesc.getStatementContext()
Returns the statement context.
|
StatementContext |
EPStatementSPI.getStatementContext()
Returns the statement context.
|
StatementContext |
EPStatementImpl.getStatementContext() |
StatementContext |
StatementLifecycleSvcImpl.getStatementContextById(int statementId) |
StatementContext |
StatementLifecycleStmtContextResolver.getStatementContextById(int statementId) |
StatementContext |
StatementContextFactoryDefault.makeContext(int statementId,
String statementName,
String expression,
StatementType statementType,
EPServicesContext engineServices,
Map<String,Object> optAdditionalContext,
boolean isFireAndForget,
Annotation[] annotations,
EPIsolationUnitServices isolationUnitServices,
boolean stateless,
StatementSpecRaw statementSpecRaw,
List<ExprSubselectNode> subselectNodes,
boolean writesToTables,
Object statementUserObject) |
StatementContext |
StatementContextFactory.makeContext(int statementId,
String statementName,
String expression,
StatementType statementType,
EPServicesContext engineServices,
Map<String,Object> optAdditionalContext,
boolean isFireAndForget,
Annotation[] annotations,
EPIsolationUnitServices isolationUnitServices,
boolean stateless,
StatementSpecRaw statementSpecRaw,
List<ExprSubselectNode> subselectNodes,
boolean writesToTables,
Object statementUserObject) |
Modifier and Type | Method and Description |
---|---|
protected static StatementSpecCompiled |
StatementLifecycleSvcImpl.compile(StatementSpecRaw spec,
String eplStatement,
StatementContext statementContext,
boolean isSubquery,
boolean isOnDemandQuery,
Annotation[] annotations,
List<ExprSubselectNode> subselectNodes,
List<ExprDeclaredNode> declaredNodes,
Set<ExprTableAccessNode> tableAccessNodes,
EPServicesContext servicesContext)
Compiles a statement returning the compile (verified, non-serializable) form of a statement.
|
EPStatementSPI |
EPStatementFactoryDefault.make(String expressionNoAnnotations,
boolean isPattern,
DispatchService dispatchService,
StatementLifecycleSvcImpl statementLifecycleSvc,
long timeLastStateChange,
boolean preserveDispatchOrder,
boolean isSpinLocks,
long blockingTimeout,
TimeSourceService timeSource,
StatementMetadata statementMetadata,
Object statementUserObject,
StatementContext statementContext,
boolean isFailed,
boolean nameProvided) |
EPStatementSPI |
EPStatementFactory.make(String expressionNoAnnotations,
boolean isPattern,
DispatchService dispatchService,
StatementLifecycleSvcImpl statementLifecycleSvc,
long timeLastStateChange,
boolean preserveDispatchOrder,
boolean isSpinLocks,
long blockingTimeout,
TimeSourceService timeSource,
StatementMetadata statementMetadata,
Object statementUserObject,
StatementContext statementContext,
boolean isFailed,
boolean nameProvided) |
Constructor and Description |
---|
EPStatementDesc(EPStatementSPI epStatement,
EPStatementStartMethod startMethod,
StatementContext statementContext)
Ctor.
|
EPStatementImpl(String expressionNoAnnotations,
boolean isPattern,
DispatchService dispatchService,
StatementLifecycleSvc statementLifecycleSvc,
long timeLastStateChange,
boolean isBlockingDispatch,
boolean isSpinBlockingDispatch,
long msecBlockingTimeout,
TimeSourceService timeSourceService,
StatementMetadata statementMetadata,
Object userObject,
StatementContext statementContext,
boolean isFailed,
boolean nameProvided)
Ctor.
|
ExprEvaluatorContextStatement(StatementContext statementContext,
boolean allowTableAccess) |
StatementContextCPPair(int statementId,
int agentInstanceId,
StatementContext optionalStatementContext) |
StatementMetadataFactoryContext(String statementName,
int statementId,
StatementContext statementContext,
StatementSpecRaw statementSpec,
String expression,
boolean pattern,
EPStatementObjectModel optionalModel) |
Modifier and Type | Field and Description |
---|---|
protected StatementContext |
EPPreparedExecuteIUDSingleStream.statementContext |
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) |
static PriorEventViewFactory |
EPStatementStartMethodHelperPrior.getPriorEventViewFactory(StatementContext statementContext,
int streamNum,
boolean unboundStream,
boolean isSubquery,
int subqueryNumber) |
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 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.validateNodes(StatementSpecCompiled statementSpec,
StatementContext statementContext,
StreamTypeService typeService,
ViewResourceDelegateUnverified viewResourceDelegate)
Validate filter and join expression nodes.
|
protected static UniformPair<Integer> |
EPStatementStartMethodHelperValidate.validateOuterJoinPropertyPair(StatementContext statementContext,
ExprIdentNode leftNode,
ExprIdentNode rightNode,
int outerJoinCount,
StreamTypeService typeService,
ViewResourceDelegateUnverified viewResourceDelegate) |
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.
|
EPStatementStopMethodImpl(StatementContext statementContext,
List<StopCallback> stopCallbacks) |
Modifier and Type | Method and Description |
---|---|
static StatementContext |
SupportStatementContextFactory.makeContext() |
static StatementContext |
SupportStatementContextFactory.makeContext(int statementId) |
static StatementContext |
SupportStatementContextFactory.makeContext(int statementId,
SchedulingService stub) |
static StatementContext |
SupportStatementContextFactory.makeContext(SchedulingService stub) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
DataFlowStmtDesc.getStatementContext() |
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) |
static DataflowStartDesc |
RealizationFactoryInterface.realize(String dataFlowName,
Map<Integer,Object> operators,
Map<Integer,OperatorMetadataDescriptor> operatorMetadata,
Set<Integer> operatorBuildOrder,
List<LogicalChannelBinding> bindings,
DataFlowSignalManager dataFlowSignalManager,
EPDataFlowInstantiationOptions options,
EPServicesContext services,
StatementContext statementContext) |
Constructor and Description |
---|
DataFlowStmtDesc(CreateDataFlowDesc graphDesc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
Map<GraphOperatorSpec,Annotation[]> operatorAnnotations) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
DataFlowOpInitializeContext.getStatementContext() |
StatementContext |
DataFlowOpInitializateContext.getStatementContext() |
Constructor and Description |
---|
DataFlowOpInitializateContext(String dataflowName,
String dataflowInstanceId,
Object dataflowInstanceUserObject,
Map<Integer,DataFlowOpInputPort> inputPorts,
Map<Integer,DataFlowOpOutputPort> outputPorts,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
EPRuntimeEventSender runtimeEventSender,
EPServiceProvider engine,
Annotation[] operatorAnnotations) |
DataFlowOpInitializeContext(StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
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.
|
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.makeOutputConditionCount(int rate,
VariableMetaData variableMetaData,
StatementContext statementContext) |
OutputConditionFactory |
ResultSetProcessorHelperFactory.makeOutputConditionCount(int rate,
VariableMetaData variableMetaData,
StatementContext statementContext) |
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) |
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) |
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.
|
DataCache |
DataCacheFactory.getDataCache(ConfigurationDataCache cacheDesc,
StatementContext statementContext,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
SchedulingService schedulingService,
ScheduleBucket scheduleBucket,
int streamNum)
Creates a cache implementation for the strategy as defined by the cache descriptor.
|
DataCache |
DatabaseConfigServiceImpl.getDataCache(String databaseName,
StatementContext statementContext,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
DataCacheFactory dataCacheFactory,
int streamNumber) |
DataCache |
DatabaseConfigService.getDataCache(String databaseName,
StatementContext statementContext,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
DataCacheFactory dataCacheFactory,
int streamNumber)
Returns a new cache implementation for this database.
|
protected DataCache |
DataCacheFactory.makeTimeCache(ConfigurationExpiryTimeCache expCache,
StatementContext statementContext,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
SchedulingService schedulingService,
ScheduleBucket scheduleBucket,
int streamNum) |
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 |
---|---|
static ExprEvaluator[] |
ExprNodeUtility.crontabScheduleValidate(ExprNodeOrigin origin,
List<ExprNode> scheduleSpecExpressionList,
StatementContext context,
boolean allowBindingConsumption) |
static ExprValidationContext |
ExprNodeUtility.getExprValidationContextStatementOnly(StatementContext statementContext) |
static QueryGraph |
ExprNodeUtility.validateFilterGetQueryGraphSafe(ExprNode filterExpression,
StatementContext statementContext,
StreamTypeServiceImpl typeService) |
static void |
ExprNodeUtility.validateFilterWQueryGraphSafe(QueryGraph queryGraph,
ExprNode filterExpression,
StatementContext statementContext,
StreamTypeServiceImpl typeService) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType,
boolean allowBindingConsumption) |
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) |
Constructor and Description |
---|
ExcludePlanHint(String[] streamNames,
List<ExprEvaluator> evaluators,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
PollResultIndexingStrategySorted.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyNoIndex.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyIndexSingleArray.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyIndexSingle.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyIndexCoerceSingle.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyIndexCoerce.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyIndex.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategyComposite.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext) |
EventTable[] |
PollResultIndexingStrategy.index(List<EventBean> pollResult,
boolean isActiveCache,
StatementContext statementContext)
Build and index of a poll result.
|
Modifier and Type | Method and Description |
---|---|
StatementContext |
EventTableFactoryTableIdentStmt.getStatementContext() |
StatementContext |
EventTableFactoryTableIdentAgentInstance.getStatementContext() |
StatementContext |
EventTableFactoryTableIdent.getStatementContext() |
Constructor and Description |
---|
EventTableFactoryTableIdentStmt(StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
static QueryPlanIndexItem |
EventTableIndexUtil.validateCompileExplicitIndex(String indexName,
boolean unique,
List<CreateIndexItem> columns,
EventType eventType,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
NamedWindowProcessor.getStatementContextCreateWindow() |
Modifier and Type | Method and Description |
---|---|
void |
NamedWindowConsumerMgmtServiceImpl.addConsumer(StatementContext statementContext,
NamedWindowConsumerStreamSpec namedSpec) |
void |
NamedWindowConsumerMgmtService.addConsumer(StatementContext statementContext,
NamedWindowConsumerStreamSpec namedSpec) |
NamedWindowProcessor |
NamedWindowMgmtServiceImpl.addProcessor(String name,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow,
NamedWindowDispatchService namedWindowDispatchService) |
NamedWindowProcessor |
NamedWindowMgmtService.addProcessor(String name,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow,
NamedWindowDispatchService namedWindowDispatchService) |
NamedWindowProcessor |
NamedWindowDispatchServiceImpl.createProcessor(String name,
NamedWindowMgmtServiceImpl namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow) |
NamedWindowProcessor |
NamedWindowDispatchService.createProcessor(String name,
NamedWindowMgmtServiceImpl namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow) |
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) |
Constructor and Description |
---|
NamedWindowOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
String triggeringStreamName,
InternalEventRouter internalEventRouter,
String namedWindowName,
EventTypeSPI namedWindowType) |
NamedWindowProcessor(String namedWindowName,
NamedWindowMgmtService namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow) |
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) |
StreamSpecCompiled |
DBStatementStreamSpec.compile(StatementContext statementContext,
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) |
Constructor and Description |
---|
TableOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
String triggeringStreamName,
InternalEventRouter internalEventRouter,
TableMetadata tableMetadata) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
TableMetadata.getStatementContextCreateTable() |
Modifier and Type | Method and Description |
---|---|
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) |
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 |
---|---|
StatementContext |
OutputProcessViewDirectFactory.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
boolean |
OutputProcessViewBaseWAfter.checkAfterCondition(EventBean[] newEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewBaseWAfter.checkAfterCondition(Set<MultiKey<EventBean>> newEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewBaseWAfter.checkAfterCondition(UniformPair<EventBean[]> newOldEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewAfterStateNone.checkUpdateAfterCondition(EventBean[] newEvents,
StatementContext statementContext) |
boolean |
OutputProcessViewAfterStateImpl.checkUpdateAfterCondition(EventBean[] newEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewAfterState.checkUpdateAfterCondition(EventBean[] newEvents,
StatementContext statementContext) |
boolean |
OutputProcessViewAfterStateNone.checkUpdateAfterCondition(Set<MultiKey<EventBean>> newEvents,
StatementContext statementContext) |
boolean |
OutputProcessViewAfterStateImpl.checkUpdateAfterCondition(Set<MultiKey<EventBean>> newEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewAfterState.checkUpdateAfterCondition(Set<MultiKey<EventBean>> newEvents,
StatementContext statementContext) |
boolean |
OutputProcessViewAfterStateNone.checkUpdateAfterCondition(UniformPair<EventBean[]> newOldEvents,
StatementContext statementContext) |
boolean |
OutputProcessViewAfterStateImpl.checkUpdateAfterCondition(UniformPair<EventBean[]> newOldEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewAfterState.checkUpdateAfterCondition(UniformPair<EventBean[]> newOldEvents,
StatementContext statementContext) |
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 void |
OutputStrategyUtil.indicateEarlyReturn(StatementContext statementContext,
UniformPair<EventBean[]> newOldEvents)
Indicate statement result.
|
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) |
OutputConditionPolledCountFactory(int eventRate,
StatementContext statementContext,
String variableName)
Constructor.
|
OutputConditionPolledCrontabFactory(List<ExprNode> scheduleSpecExpressionList,
StatementContext statementContext) |
OutputConditionPolledExpressionFactory(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> assignments,
StatementContext statementContext)
Ctor.
|
OutputConditionPolledTimeFactory(ExprTimePeriod timePeriod,
StatementContext statementContext) |
OutputProcessViewConditionFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
Integer afterConditionNumberOfEvents,
EventType resultEventType,
OutputConditionFactory outputConditionFactory,
int streamCount,
OutputProcessViewConditionFactory.ConditionType conditionType,
OutputLimitLimitType outputLimitLimitType,
boolean terminable,
boolean hasAfter,
boolean isUnaggregatedUngrouped,
SelectClauseStreamSelectorEnum selectClauseStreamSelectorEnum,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory) |
OutputProcessViewDirectDistinctOrAfterFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
Integer afterConditionNumberOfEvents,
EventType resultEventType) |
OutputProcessViewDirectFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory) |
Modifier and Type | Method and Description |
---|---|
void |
VirtualDWViewFactoryImpl.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
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) |
protected ExprNodeAdapterBase |
FilterBooleanExpressionFactoryImpl.getLockableSingle(int filterSpecId,
int filterSpecParamPathNum,
ExprNode exprNode,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
StatementContext statementContext,
int agentInstanceId) |
ExprNodeAdapterBase |
FilterBooleanExpressionFactoryImpl.make(FilterSpecParamExprNode node,
EventBean[] events,
ExprEvaluatorContext exprEvaluatorContext,
StatementContext statementContext,
int agentInstanceId) |
ExprNodeAdapterBase |
FilterBooleanExpressionFactory.make(FilterSpecParamExprNode filterSpecParamExprNode,
EventBean[] events,
ExprEvaluatorContext exprEvaluatorContext,
StatementContext statementContext,
int agentInstanceId) |
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.
|
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 |
---|---|
StatementContext |
PatternContext.getStatementContext() |
StatementContext |
PatternAgentInstanceContext.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
PatternContext |
PatternContextFactoryDefault.createContext(StatementContext statementContext,
int streamId,
EvalRootFactoryNode rootNode,
MatchedEventMapMeta matchedEventMapMeta,
boolean allowResilient) |
PatternContext |
PatternContextFactory.createContext(StatementContext statementContext,
int streamId,
EvalRootFactoryNode rootNode,
MatchedEventMapMeta matchedEventMapMeta,
boolean allowResilient)
Create a pattern context.
|
Constructor and Description |
---|
PatternContext(StatementContext statementContext,
int streamNumber,
MatchedEventMapMeta matchedEventMapMeta,
boolean isResilient) |
Modifier and Type | Method and Description |
---|---|
void |
EventRowRegexNFAViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
Map<String,Set<String>> visibilityByIdentifier,
EventType parentViewType) |
static ObjectArrayBackedEventBean |
EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
EventType parentViewType) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
ViewFactoryContext.getStatementContext()
Returns the statement context.
|
Modifier and Type | Method and Description |
---|---|
void |
ViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories)
Attaches the factory to a parent event type such that the factory can validate
attach requirements and determine an event type for resulting views.
|
ViewFactoryChain |
ViewServiceImpl.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecDefinitions,
StreamSpecOptions options,
StatementContext context,
boolean isSubquery,
int subqueryNumber) |
ViewFactoryChain |
ViewService.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecList,
StreamSpecOptions options,
StatementContext context,
boolean isSubquery,
int subqueryNumber)
Returns a chain of view factories that can be used to obtain the final event type,
and that can later be used to actually create the chain of views or reuse existing views.
|
static Object |
ViewFactorySupport.evaluate(ExprEvaluator evaluator,
int expressionNumber,
String viewName,
StatementContext statementContext) |
static List<ViewFactory> |
ViewServiceHelper.instantiateFactories(int streamNum,
List<ViewSpec> viewSpecList,
StatementContext statementContext,
boolean isSubquery,
int subqueryNumber)
Given a list of view specifications obtained from by parsing this method instantiates a list of view factories.
|
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.
|
static ExprNode[] |
ViewFactorySupport.validate(String viewName,
EventType eventType,
StatementContext statementContext,
List<ExprNode> expressions,
boolean allowConstantResult)
Validate the view parameter expressions and return the validated expression for later execution.
|
static ExprNode[] |
ViewFactorySupport.validate(String viewName,
StatementContext statementContext,
List<ExprNode> expressions) |
static Object |
ViewFactorySupport.validateAndEvaluate(String viewName,
StatementContext statementContext,
ExprNode expression)
Validate the view parameter expression and evaluate the expression returning the result object.
|
static Object |
ViewFactorySupport.validateAndEvaluateExpr(String viewName,
StatementContext statementContext,
ExprNode expression,
StreamTypeService streamTypeService,
int expressionNumber) |
static ExprTimePeriodEvalDeltaConstFactory |
ViewFactoryTimePeriodHelper.validateAndEvaluateTimeDeltaFactory(String viewName,
StatementContext statementContext,
ExprNode expression,
String expectedMessage,
int expressionNumber) |
static ExprNode |
ViewFactorySupport.validateExpr(String viewName,
StatementContext statementContext,
ExprNode expression,
StreamTypeService streamTypeService,
int expressionNumber) |
static ExprEvaluator |
ViewFactorySupport.validateSizeParam(String viewName,
StatementContext statementContext,
ExprNode sizeNode,
int expressionNumber) |
Constructor and Description |
---|
ViewFactoryContext(StatementContext statementContext,
int streamNum,
String namespaceName,
String viewName,
boolean isSubquery,
int subqueryNumber,
boolean isGrouped)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
void |
TimeToLiveViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeOrderViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
SortWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
RankWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
Modifier and Type | Method and Description |
---|---|
void |
UnionViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
PriorEventViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
NoopViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
IntersectViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
Modifier and Type | Method and Description |
---|---|
void |
WeightedAverageViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
UnivariateStatisticsViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
RegressionLinestViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
CorrelationViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
static EventType |
WeightedAverageView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
static EventType |
UnivariateStatisticsView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
protected static EventType |
RegressionLinestView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
protected static EventType |
CorrelationView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
Modifier and Type | Method and Description |
---|---|
void |
UniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
SizeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
MergeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
LastElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
GroupByViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstUniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
static EventType |
SizeView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
Modifier and Type | Method and Description |
---|---|
void |
TimeWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeLengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeAccumViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
LengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
LengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
KeepAllViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstTimeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstLengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
ExternallyTimedWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
ExternallyTimedBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
ExpressionViewFactoryBase.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |