Uses of Class
com.espertech.esper.core.service.StatementContext

Packages that use StatementContext
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   
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.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 
 

Uses of StatementContext in com.espertech.esper.client.hook
 

Methods in com.espertech.esper.client.hook that return StatementContext
 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.
 

Uses of StatementContext in com.espertech.esper.core.context.activator
 

Methods in com.espertech.esper.core.context.activator with parameters of type StatementContext
 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)
           
 

Constructors in com.espertech.esper.core.context.activator with parameters of type StatementContext
ViewableActivatorStreamReuseView(EPServicesContext services, StatementContext statementContext, StatementSpecCompiled statementSpec, FilterStreamSpecCompiled filterStreamSpec, boolean join, ExprEvaluatorContextStatement evaluatorContextStmt, boolean filterSubselectSameStream, int streamNum, boolean isCanIterateUnbound)
           
 

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

Fields in com.espertech.esper.core.context.factory declared as StatementContext
protected  StatementContext StatementAgentInstanceFactorySelect.statementContext
           
protected  StatementContext StatementAgentInstanceFactoryOnTriggerBase.statementContext
           
protected  StatementContext StatementAgentInstanceFactoryCreateWindow.statementContext
           
 

Methods in com.espertech.esper.core.context.factory that return StatementContext
 StatementContext StatementAgentInstanceFactorySelect.getStatementContext()
           
 

Methods in com.espertech.esper.core.context.factory with parameters of type StatementContext
protected static StatementAgentInstanceFactoryOnTriggerNamedWindow.IndexHintPair StatementAgentInstanceFactoryOnTriggerNamedWindow.getIndexHintPair(StatementContext statementContext, StatementSpecCompiled statementSpec)
           
 

Constructors in com.espertech.esper.core.context.factory with parameters of type StatementContext
StatementAgentInstanceFactoryCreateVariable(CreateVariableDesc createDesc, StatementSpecCompiled statementSpec, StatementContext statementContext, EPServicesContext services, VariableMetaData variableMetaData, EventType eventType)
           
StatementAgentInstanceFactoryCreateWindow(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, ViewFactoryChain unmaterializedViewChain, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, OutputProcessViewFactory outputProcessViewFactory, boolean recoveringStatement)
           
StatementAgentInstanceFactoryOnTriggerBase(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection)
           
StatementAgentInstanceFactoryOnTriggerNamedWindow(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, NamedWindowOnExprFactory onExprFactory, OutputProcessViewFactory outputProcessViewFactory, EventType activatorResultEventType, NamedWindowProcessor processor, java.util.List<StopCallback> stopCallbacks)
           
StatementAgentInstanceFactoryOnTriggerSetVariable(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, OnSetVariableViewFactory onSetVariableViewFactory, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, OutputProcessViewFactory outputProcessViewFactory)
           
StatementAgentInstanceFactoryOnTriggerSplit(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, StatementAgentInstanceFactoryOnTriggerSplitDesc splitDesc, EventType activatorResultEventType, java.lang.String[] insertIntoTableNames)
           
StatementAgentInstanceFactoryOnTriggerTable(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, TableOnViewFactory onExprFactory, EventType activatorResultEventType, TableMetadata tableMetadata, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, OutputProcessViewFactory outputProcessViewFactory)
           
StatementAgentInstanceFactorySelect(int numStreams, ViewableActivator[] eventStreamParentViewableActivators, StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, StreamTypeService typeService, ViewFactoryChain[] unmaterializedViewChain, ResultSetProcessorFactoryDesc resultSetProcessorFactoryDesc, StreamJoinAnalysisResult joinAnalysisResult, boolean recoveringResilient, JoinSetComposerPrototype joinSetComposerPrototype, SubSelectStrategyCollection subSelectStrategyCollection, ViewResourceDelegateVerified viewResourceDelegate, OutputProcessViewFactory outputProcessViewFactory)
           
StatementAgentInstanceFactoryUpdate(StatementContext statementContext, EPServicesContext services, EventType streamEventType, UpdateDesc desc, InternalRoutePreprocessView onExprView, InternalEventRouterDesc routerDesc, SubSelectStrategyCollection subSelectStrategyCollection)
           
 

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

Methods in com.espertech.esper.core.context.mgr that return StatementContext
 StatementContext ContextControllerStatementBase.getStatementContext()
           
 StatementContext ContextControllerInitTermFactoryBase.getStatementContext()
           
 

Constructors in com.espertech.esper.core.context.mgr with parameters of type StatementContext
ContextControllerConditionCrontab(StatementContext statementContext, ScheduleSlot scheduleSlot, ContextDetailConditionCrontab spec, ContextControllerConditionCallback callback, ContextInternalFilterAddendum filterAddendum)
           
ContextControllerStatementBase(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory)
           
ContextManagedStatementCreateAggregationVariableDesc(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory)
           
ContextManagedStatementCreateIndexDesc(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory)
           
ContextManagedStatementCreateVariableDesc(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory)
           
ContextManagedStatementCreateWindowDesc(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory)
           
ContextManagedStatementOnTriggerDesc(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory)
           
ContextManagedStatementSelectDesc(StatementSpecCompiled statementSpec, StatementContext statementContext, ContextMergeView mergeView, StatementAgentInstanceFactory factory, java.util.List<AggregationServiceAggExpressionDesc> aggregationExpressions, SubSelectStrategyCollection subSelectPrototypeCollection)
           
 

Uses of StatementContext in com.espertech.esper.core.context.util
 

Methods in com.espertech.esper.core.context.util that return StatementContext
 StatementContext AgentInstanceViewFactoryChainContext.getStatementContext()
           
 StatementContext AgentInstanceContext.getStatementContext()
           
 

Methods in com.espertech.esper.core.context.util with parameters of type StatementContext
static void StatementAgentInstanceUtil.stopSafe(java.util.Collection<StopCallback> terminationCallbacks, StopCallback[] stopCallbacks, StatementContext statementContext)
           
static void StatementAgentInstanceUtil.stopSafe(StopCallback[] stopMethods, StatementContext statementContext)
           
static void StatementAgentInstanceUtil.stopSafe(StopCallback stopMethod, StatementContext statementContext)
           
 

Constructors in com.espertech.esper.core.context.util with parameters of type StatementContext
AgentInstanceContext(StatementContext statementContext, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, int agentInstanceId, AgentInstanceFilterProxy agentInstanceFilterProxy, MappedEventBean agentInstanceProperties, AgentInstanceScriptContext agentInstanceScriptContext)
           
 

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

Fields in com.espertech.esper.core.service declared as StatementContext
protected  StatementContext ExprEvaluatorContextStatement.statementContext
           
protected  StatementContext EPStatementImpl.statementContext
           
 

Methods in com.espertech.esper.core.service that return StatementContext
 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, java.lang.String statementName, java.lang.String expression, StatementType statementType, EPServicesContext engineServices, java.util.Map<java.lang.String,java.lang.Object> optAdditionalContext, boolean isFireAndForget, java.lang.annotation.Annotation[] annotations, EPIsolationUnitServices isolationUnitServices, boolean stateless, StatementSpecRaw statementSpecRaw, java.util.List<ExprSubselectNode> subselectNodes, boolean writesToTables, java.lang.Object statementUserObject)
           
 StatementContext StatementContextFactory.makeContext(int statementId, java.lang.String statementName, java.lang.String expression, StatementType statementType, EPServicesContext engineServices, java.util.Map<java.lang.String,java.lang.Object> optAdditionalContext, boolean isFireAndForget, java.lang.annotation.Annotation[] annotations, EPIsolationUnitServices isolationUnitServices, boolean stateless, StatementSpecRaw statementSpecRaw, java.util.List<ExprSubselectNode> subselectNodes, boolean writesToTables, java.lang.Object statementUserObject)
          Create a new statement context consisting of statement-level services.
 

Methods in com.espertech.esper.core.service with parameters of type StatementContext
protected static StatementSpecCompiled StatementLifecycleSvcImpl.compile(StatementSpecRaw spec, java.lang.String eplStatement, StatementContext statementContext, boolean isSubquery, boolean isOnDemandQuery, java.lang.annotation.Annotation[] annotations, java.util.List<ExprSubselectNode> subselectNodes, java.util.List<ExprDeclaredNode> declaredNodes, java.util.Set<ExprTableAccessNode> tableAccessNodes, EPServicesContext servicesContext)
          Compiles a statement returning the compile (verified, non-serializable) form of a statement.
 EPStatementSPI EPStatementFactoryDefault.make(java.lang.String expressionNoAnnotations, boolean isPattern, DispatchService dispatchService, StatementLifecycleSvcImpl statementLifecycleSvc, long timeLastStateChange, boolean preserveDispatchOrder, boolean isSpinLocks, long blockingTimeout, TimeSourceService timeSource, StatementMetadata statementMetadata, java.lang.Object statementUserObject, StatementContext statementContext, boolean isFailed, boolean nameProvided)
           
 EPStatementSPI EPStatementFactory.make(java.lang.String expressionNoAnnotations, boolean isPattern, DispatchService dispatchService, StatementLifecycleSvcImpl statementLifecycleSvc, long timeLastStateChange, boolean preserveDispatchOrder, boolean isSpinLocks, long blockingTimeout, TimeSourceService timeSource, StatementMetadata statementMetadata, java.lang.Object statementUserObject, StatementContext statementContext, boolean isFailed, boolean nameProvided)
           
 

Constructors in com.espertech.esper.core.service with parameters of type StatementContext
EPStatementImpl(java.lang.String expressionNoAnnotations, boolean isPattern, DispatchService dispatchService, StatementLifecycleSvc statementLifecycleSvc, long timeLastStateChange, boolean isBlockingDispatch, boolean isSpinBlockingDispatch, long msecBlockingTimeout, TimeSourceService timeSourceService, StatementMetadata statementMetadata, java.lang.Object userObject, StatementContext statementContext, boolean isFailed, boolean nameProvided)
          Ctor.
ExprEvaluatorContextStatement(StatementContext statementContext, boolean allowTableAccess)
           
StatementLifecycleSvcImpl.EPStatementDesc(EPStatementSPI epStatement, EPStatementStartMethod startMethod, StatementContext statementContext)
          Ctor.
StatementMetadataFactoryContext(java.lang.String statementName, int statementId, StatementContext statementContext, StatementSpecRaw statementSpec, java.lang.String expression, boolean pattern, EPStatementObjectModel optionalModel)
           
 

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

Fields in com.espertech.esper.core.start declared as StatementContext
protected  StatementContext EPPreparedExecuteIUDSingleStream.statementContext
           
 

Methods in com.espertech.esper.core.start with parameters of type StatementContext
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, java.lang.String[] outerStreamNames, EventType[] outerEventTypesSelect, java.lang.String[] outerEventTypeNamees, ExprDeclaredNode[] declaredExpressions, ContextPropertyRegistry contextPropertyRegistry)
           
static EPStatementStartMethodSelectDesc EPStatementStartMethodSelectUtil.prepare(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext, boolean recoveringResilient, AgentInstanceContext defaultAgentInstanceContext, boolean queryPlanLogging, ViewableActivatorFactory optionalViewableActivatorFactory, OutputProcessViewCallback optionalOutputProcessViewCallback, SelectExprProcessorDeliveryCallback selectExprProcessorDeliveryCallback)
           
 EPStatementStartResult EPStatementStartMethodBase.start(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethod.start(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
          Starts the EPL statement.
 EPStatementStartResult EPStatementStartMethodUpdate.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodSelect.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodOnTrigger.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateWindow.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateVariable.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateTable.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateSchema.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateIndex.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateGraph.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateExpression.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
 EPStatementStartResult EPStatementStartMethodCreateContext.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
abstract  EPStatementStartResult EPStatementStartMethodBase.startInternal(EPServicesContext services, StatementContext statementContext, boolean isNewStatement, boolean isRecoveringStatement, boolean isRecoveringResilient)
           
protected static ExprNode EPStatementStartMethodHelperValidate.validateExprNoAgg(ExprNodeOrigin exprNodeOrigin, ExprNode exprNode, StreamTypeService streamTypeService, StatementContext statementContext, ExprEvaluatorContext exprEvaluatorContext, java.lang.String errorMsg, boolean allowTableConsumption)
           
protected  ExprNode EPStatementStartMethodOnTrigger.validateJoinNamedWindow(java.lang.String engineURI, StatementContext statementContext, ExprNodeOrigin exprNodeOrigin, ExprNode deleteJoinExpr, EventType namedWindowType, java.lang.String namedWindowStreamName, java.lang.String namedWindowName, EventType filteredType, java.lang.String filterStreamName, java.lang.String filteredTypeName, java.lang.String optionalTableName)
           
protected static void EPStatementStartMethodHelperValidate.validateNodes(StatementSpecCompiled statementSpec, StatementContext statementContext, StreamTypeService typeService, ViewResourceDelegateUnverified viewResourceDelegate)
          Validate filter and join expression nodes.
protected static UniformPair<java.lang.Integer> EPStatementStartMethodHelperValidate.validateOuterJoinPropertyPair(StatementContext statementContext, ExprIdentNode leftNode, ExprIdentNode rightNode, int outerJoinCount, StreamTypeService typeService, ViewResourceDelegateUnverified viewResourceDelegate)
           
 

Constructors in com.espertech.esper.core.start with parameters of type StatementContext
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, java.util.List<StopCallback> stopCallbacks)
           
 

Uses of StatementContext in com.espertech.esper.core.support
 

Methods in com.espertech.esper.core.support that return StatementContext
static StatementContext SupportStatementContextFactory.makeContext()
           
static StatementContext SupportStatementContextFactory.makeContext(int statementId)
           
static StatementContext SupportStatementContextFactory.makeContext(int statementId, SchedulingService stub)
           
static StatementContext SupportStatementContextFactory.makeContext(SchedulingService stub)
           
 

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

Methods in com.espertech.esper.dataflow.core that return StatementContext
 StatementContext DataFlowStmtDesc.getStatementContext()
           
 

Methods in com.espertech.esper.dataflow.core with parameters of type StatementContext
 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(java.lang.String dataFlowName, java.util.Map<java.lang.Integer,java.lang.Object> operators, java.util.Map<java.lang.Integer,OperatorMetadataDescriptor> operatorMetadata, java.util.Set<java.lang.Integer> operatorBuildOrder, java.util.List<LogicalChannelBinding> bindings, DataFlowSignalManager dataFlowSignalManager, EPDataFlowInstantiationOptions options, EPServicesContext services, StatementContext statementContext)
           
 

Constructors in com.espertech.esper.dataflow.core with parameters of type StatementContext
DataFlowStmtDesc(CreateDataFlowDesc graphDesc, StatementContext statementContext, EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, java.util.Map<GraphOperatorSpec,java.lang.annotation.Annotation[]> operatorAnnotations)
           
 

Uses of StatementContext in com.espertech.esper.dataflow.interfaces
 

Methods in com.espertech.esper.dataflow.interfaces that return StatementContext
 StatementContext DataFlowOpInitializeContext.getStatementContext()
           
 StatementContext DataFlowOpInitializateContext.getStatementContext()
           
 

Constructors in com.espertech.esper.dataflow.interfaces with parameters of type StatementContext
DataFlowOpInitializateContext(java.lang.String dataflowName, java.lang.String dataflowInstanceId, java.lang.Object dataflowInstanceUserObject, java.util.Map<java.lang.Integer,DataFlowOpInputPort> inputPorts, java.util.Map<java.lang.Integer,DataFlowOpOutputPort> outputPorts, StatementContext statementContext, EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, EPRuntimeEventSender runtimeEventSender, EPServiceProvider engine, java.lang.annotation.Annotation[] operatorAnnotations)
           
DataFlowOpInitializeContext(StatementContext statementContext)
           
 

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

Methods in com.espertech.esper.epl.core with parameters of type StatementContext
static HistoricalEventViewable MethodPollingViewableFactory.createPollMethodView(int streamNumber, MethodStreamSpec methodStreamSpec, EventAdapterService eventAdapterService, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, MethodResolutionService methodResolutionService, EngineImportService engineImportService, SchedulingService schedulingService, ScheduleBucket scheduleBucket, ExprEvaluatorContext exprEvaluatorContext, VariableService variableService, java.lang.String contextName, 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)
          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.
 OutputConditionFactory ResultSetProcessorHelperFactoryImpl.makeOutputConditionCount(int rate, VariableMetaData variableMetaData, StatementContext statementContext)
           
 OutputConditionFactory ResultSetProcessorHelperFactory.makeOutputConditionCount(int rate, VariableMetaData variableMetaData, StatementContext statementContext)
           
 OutputConditionFactory ResultSetProcessorHelperFactoryImpl.makeOutputConditionCrontab(java.util.List<ExprNode> crontabAtSchedule, StatementContext statementContext, boolean isStartConditionOnCreation)
           
 OutputConditionFactory ResultSetProcessorHelperFactory.makeOutputConditionCrontab(java.util.List<ExprNode> crontabAtSchedule, StatementContext statementContext, boolean isStartConditionOnCreation)
           
 OutputConditionFactory ResultSetProcessorHelperFactoryImpl.makeOutputConditionExpression(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> thenExpressions, StatementContext statementContext, ExprNode andAfterTerminateExpr, java.util.List<OnTriggerSetAssignment> andAfterTerminateThenExpressions, boolean isStartConditionOnCreation)
           
 OutputConditionFactory ResultSetProcessorHelperFactory.makeOutputConditionExpression(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> thenExpressions, StatementContext statementContext, ExprNode andAfterTerminateExpr, java.util.List<OnTriggerSetAssignment> andAfterTerminateThenExpressions, boolean isStartConditionOnCreation)
           
 void MethodPollingViewable.validate(EngineImportService engineImportService, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, StatementContext statementContext)
           
 

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

Methods in com.espertech.esper.epl.db with parameters of type StatementContext
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(java.lang.String databaseName, StatementContext statementContext, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, DataCacheFactory dataCacheFactory, int streamNumber)
           
 DataCache DatabaseConfigService.getDataCache(java.lang.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, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, StatementContext statementContext)
           
 

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

Methods in com.espertech.esper.epl.expression.core with parameters of type StatementContext
static ScheduleSpec ExprNodeUtility.toCrontabSchedule(ExprNodeOrigin origin, java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext context, boolean allowBindingConsumption)
           
static ExprNode ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin, ExprNode expression, StatementContext statementContext, EventType optionalEventType, boolean allowBindingConsumption)
           
 

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

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

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

Methods in com.espertech.esper.epl.join.hint with parameters of type StatementContext
static ExcludePlanHint ExcludePlanHint.getHint(java.lang.String[] streamNames, StatementContext statementContext)
           
static ExprEvaluator ExcludePlanHintExprUtil.toExpression(java.lang.String hint, StatementContext statementContext)
           
 

Constructors in com.espertech.esper.epl.join.hint with parameters of type StatementContext
ExcludePlanHint(java.lang.String[] streamNames, java.util.List<ExprEvaluator> evaluators, StatementContext statementContext)
           
 

Uses of StatementContext in com.espertech.esper.epl.join.pollindex
 

Methods in com.espertech.esper.epl.join.pollindex with parameters of type StatementContext
 EventTable[] PollResultIndexingStrategySorted.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyNoIndex.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyIndexSingleArray.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyIndexSingle.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyIndexCoerceSingle.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyIndexCoerce.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyIndex.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategyComposite.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
           
 EventTable[] PollResultIndexingStrategy.index(java.util.List<EventBean> pollResult, boolean isActiveCache, StatementContext statementContext)
          Build and index of a poll result.
 

Uses of StatementContext in com.espertech.esper.epl.join.table
 

Methods in com.espertech.esper.epl.join.table that return StatementContext
 StatementContext EventTableFactoryTableIdentStmt.getStatementContext()
           
 StatementContext EventTableFactoryTableIdentAgentInstance.getStatementContext()
           
 StatementContext EventTableFactoryTableIdent.getStatementContext()
           
 

Constructors in com.espertech.esper.epl.join.table with parameters of type StatementContext
EventTableFactoryTableIdentStmt(StatementContext statementContext)
           
 

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

Methods in com.espertech.esper.epl.named that return StatementContext
 StatementContext NamedWindowProcessor.getStatementContextCreateWindow()
           
 

Methods in com.espertech.esper.epl.named with parameters of type StatementContext
 void NamedWindowConsumerMgmtServiceImpl.addConsumer(StatementContext statementContext, NamedWindowConsumerStreamSpec namedSpec)
           
 void NamedWindowConsumerMgmtService.addConsumer(StatementContext statementContext, NamedWindowConsumerStreamSpec namedSpec)
           
 NamedWindowProcessor NamedWindowMgmtServiceImpl.addProcessor(java.lang.String name, java.lang.String contextName, EventType eventType, StatementResultService statementResultService, ValueAddEventProcessor revisionProcessor, java.lang.String eplExpression, java.lang.String statementName, boolean isPrioritized, boolean isEnableSubqueryIndexShare, boolean isBatchingDataWindow, boolean isVirtualDataWindow, java.util.Set<java.lang.String> optionalUniqueKeyProps, java.lang.String eventTypeAsName, StatementContext statementContextCreateWindow, NamedWindowDispatchService namedWindowDispatchService)
           
 NamedWindowProcessor NamedWindowMgmtService.addProcessor(java.lang.String name, java.lang.String contextName, EventType eventType, StatementResultService statementResultService, ValueAddEventProcessor revisionProcessor, java.lang.String eplExpression, java.lang.String statementName, boolean isPrioritized, boolean isEnableSubqueryIndexShare, boolean isBatchingDataWindow, boolean isVirtualDataWindow, java.util.Set<java.lang.String> optionalUniqueKeyProps, java.lang.String eventTypeAsName, StatementContext statementContextCreateWindow, NamedWindowDispatchService namedWindowDispatchService)
          Create a new named window.
 NamedWindowProcessor NamedWindowDispatchServiceImpl.createProcessor(java.lang.String name, NamedWindowMgmtServiceImpl namedWindowMgmtService, NamedWindowDispatchService namedWindowDispatchService, java.lang.String contextName, EventType eventType, StatementResultService statementResultService, ValueAddEventProcessor revisionProcessor, java.lang.String eplExpression, java.lang.String statementName, boolean isPrioritized, boolean isEnableSubqueryIndexShare, boolean enableQueryPlanLog, MetricReportingService metricReportingService, boolean isBatchingDataWindow, boolean isVirtualDataWindow, java.util.Set<java.lang.String> optionalUniqueKeyProps, java.lang.String eventTypeAsName, StatementContext statementContextCreateWindow)
           
 NamedWindowProcessor NamedWindowDispatchService.createProcessor(java.lang.String name, NamedWindowMgmtServiceImpl namedWindowMgmtService, NamedWindowDispatchService namedWindowDispatchService, java.lang.String contextName, EventType eventType, StatementResultService statementResultService, ValueAddEventProcessor revisionProcessor, java.lang.String eplExpression, java.lang.String statementName, boolean isPrioritized, boolean isEnableSubqueryIndexShare, boolean enableQueryPlanLog, MetricReportingService metricReportingService, boolean isBatchingDataWindow, boolean isVirtualDataWindow, java.util.Set<java.lang.String> optionalUniqueKeyProps, java.lang.String eventTypeAsName, StatementContext statementContextCreateWindow)
           
static NamedWindowOnExprFactory NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType, java.lang.String namedWindowName, java.lang.String namedWindowAlias, OnTriggerDesc onTriggerDesc, EventType filterEventType, java.lang.String filterStreamName, boolean addToFront, InternalEventRouter internalEventRouter, EventType outputEventType, StatementContext statementContext, StatementMetricHandle createNamedWindowMetricsHandle, boolean isDistinct, StreamSelector optionalStreamSelector, java.lang.String optionalInsertIntoTableName)
           
 

Constructors in com.espertech.esper.epl.named with parameters of type StatementContext
NamedWindowOnMergeHelper(StatementContext statementContext, OnTriggerMergeDesc onTriggerDesc, EventType triggeringEventType, java.lang.String triggeringStreamName, InternalEventRouter internalEventRouter, java.lang.String namedWindowName, EventTypeSPI namedWindowType)
           
NamedWindowProcessor(java.lang.String namedWindowName, NamedWindowMgmtService namedWindowMgmtService, NamedWindowDispatchService namedWindowDispatchService, java.lang.String contextName, EventType eventType, StatementResultService statementResultService, ValueAddEventProcessor revisionProcessor, java.lang.String eplExpression, java.lang.String statementName, boolean isPrioritized, boolean isEnableSubqueryIndexShare, boolean enableQueryPlanLog, MetricReportingService metricReportingService, boolean isBatchingDataWindow, boolean isVirtualDataWindow, java.util.Set<java.lang.String> optionalUniqueKeyProps, java.lang.String eventTypeAsName, StatementContext statementContextCreateWindow)
          Ctor.
 

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

Methods in com.espertech.esper.epl.spec with parameters of type StatementContext
 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, java.lang.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, java.util.Set<java.lang.String> eventTypeReferences, boolean isInsertInto, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, boolean isJoin, boolean isContextDeclaration, boolean isOnTrigger, java.lang.String optionalStreamName)
           
 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, java.lang.String optionalStreamName)
           
 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, java.lang.String optionalStreamName)
           
 StreamSpecCompiled DBStatementStreamSpec.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, java.lang.String optionalStreamName)
           
 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)
           
 

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

Constructors in com.espertech.esper.epl.table.merge with parameters of type StatementContext
TableOnMergeHelper(StatementContext statementContext, OnTriggerMergeDesc onTriggerDesc, EventType triggeringEventType, java.lang.String triggeringStreamName, InternalEventRouter internalEventRouter, TableMetadata tableMetadata)
           
 

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

Methods in com.espertech.esper.epl.table.mgmt that return StatementContext
 StatementContext TableMetadata.getStatementContextCreateTable()
           
 

Methods in com.espertech.esper.epl.table.mgmt with parameters of type StatementContext
 TableMetadata TableServiceImpl.addTable(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory tableStateRowFactory, int numberMethodAggregations, StatementContext statementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 TableMetadata TableService.addTable(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory tableStateRowFactory, int numberMethodAggregations, StatementContext statementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 

Constructors in com.espertech.esper.epl.table.mgmt with parameters of type StatementContext
TableMetadata(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory rowFactory, int numberMethodAggregations, StatementContext createTableStatementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 

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

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

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

Methods in com.espertech.esper.epl.view that return StatementContext
 StatementContext OutputProcessViewDirectFactory.getStatementContext()
           
 

Methods in com.espertech.esper.epl.view with parameters of type StatementContext
 boolean OutputProcessViewBaseWAfter.checkAfterCondition(EventBean[] newEvents, StatementContext statementContext)
          Returns true if the after-condition is satisfied.
 boolean OutputProcessViewBaseWAfter.checkAfterCondition(java.util.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(java.util.Set<MultiKey<EventBean>> newEvents, StatementContext statementContext)
           
 boolean OutputProcessViewAfterStateImpl.checkUpdateAfterCondition(java.util.Set<MultiKey<EventBean>> newEvents, StatementContext statementContext)
          Returns true if the after-condition is satisfied.
 boolean OutputProcessViewAfterState.checkUpdateAfterCondition(java.util.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)
          Creates an output condition instance.
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)
           
 

Constructors in com.espertech.esper.epl.view with parameters of type StatementContext
OutputConditionCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext statementContext, boolean isStartConditionOnCreation)
           
OutputConditionExpressionFactory(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, StatementContext statementContext, ExprNode andWhenTerminatedExpr, java.util.List<OnTriggerSetAssignment> afterTerminateAssignments, boolean isStartConditionOnCreation)
           
OutputConditionFirstFactory(OutputLimitSpec outputLimitSpec, StatementContext statementContext, boolean isGrouped, boolean isWithHavingClause, ResultSetProcessorHelperFactory resultSetProcessorHelperFactory)
           
OutputConditionPolledCountFactory(int eventRate, StatementContext statementContext, java.lang.String variableName)
          Constructor.
OutputConditionPolledCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList, StatementContext statementContext)
           
OutputConditionPolledExpressionFactory(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, StatementContext statementContext)
          Ctor.
OutputConditionPolledTimeFactory(ExprTimePeriod timePeriod, StatementContext statementContext)
           
OutputProcessViewConditionFactory(StatementContext statementContext, OutputStrategyPostProcessFactory postProcessFactory, boolean distinct, ExprTimePeriod afterTimePeriod, java.lang.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, java.lang.Integer afterConditionNumberOfEvents, EventType resultEventType)
           
OutputProcessViewDirectFactory(StatementContext statementContext, OutputStrategyPostProcessFactory postProcessFactory, ResultSetProcessorHelperFactory resultSetProcessorHelperFactory)
           
 

Uses of StatementContext in com.espertech.esper.epl.virtualdw
 

Methods in com.espertech.esper.epl.virtualdw with parameters of type StatementContext
 void VirtualDWViewFactoryImpl.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 

Uses of StatementContext in com.espertech.esper.filter
 

Methods in com.espertech.esper.filter with parameters of type StatementContext
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)
           
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, 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.
 

Uses of StatementContext in com.espertech.esper.pattern
 

Methods in com.espertech.esper.pattern that return StatementContext
 StatementContext PatternContext.getStatementContext()
           
 StatementContext PatternAgentInstanceContext.getStatementContext()
           
 

Methods in com.espertech.esper.pattern with parameters of type StatementContext
 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.
 

Constructors in com.espertech.esper.pattern with parameters of type StatementContext
PatternContext(StatementContext statementContext, int streamNumber, MatchedEventMapMeta matchedEventMapMeta, boolean isResilient)
          Constructor.
 

Uses of StatementContext in com.espertech.esper.rowregex
 

Methods in com.espertech.esper.rowregex with parameters of type StatementContext
 void EventRowRegexNFAViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
static StreamTypeService EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, MatchRecognizeDefineItem defineItem, java.util.Map<java.lang.String,java.util.Set<java.lang.String>> visibilityByIdentifier, EventType parentViewType)
           
static ObjectArrayBackedEventBean EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, EventType parentViewType)
           
 

Uses of StatementContext in com.espertech.esper.view
 

Methods in com.espertech.esper.view that return StatementContext
 StatementContext ViewFactoryContext.getStatementContext()
          Returns the statement context.
 

Methods in com.espertech.esper.view with parameters of type StatementContext
 void ViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.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 java.util.List<ViewFactory> ViewServiceHelper.instantiateFactories(int streamNum, java.util.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, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ExprEvaluatorContext exprEvaluatorContext, ConfigurationInformation configSnapshot, SchedulingService schedulingService, java.lang.String engineURI, java.util.Map<java.lang.Integer,java.util.List<ExprNode>> sqlParameters, EventAdapterService eventAdapterService, StatementContext statementContext)
          Validate the view.
static ExprNode[] ViewFactorySupport.validate(java.lang.String viewName, EventType eventType, StatementContext statementContext, java.util.List<ExprNode> expressions, boolean allowConstantResult)
          Validate the view parameter expressions and return the validated expression for later execution.
static java.lang.Object ViewFactorySupport.validateAndEvaluate(java.lang.String viewName, StatementContext statementContext, ExprNode expression)
          Validate the view parameter expression and evaluate the expression returning the result object.
static java.util.List<java.lang.Object> ViewFactorySupport.validateAndEvaluate(java.lang.String viewName, StatementContext statementContext, java.util.List<ExprNode> expressions)
          Validate the view parameter expressions and evaluate the expressions returning the result object.
static java.lang.Object ViewFactorySupport.validateAndEvaluateExpr(java.lang.String viewName, StatementContext statementContext, ExprNode expression, StreamTypeService streamTypeService, int expressionNumber)
           
static ExprTimePeriodEvalDeltaConst ViewFactoryTimePeriodHelper.validateAndEvaluateTimeDelta(java.lang.String viewName, StatementContext statementContext, ExprNode expression, java.lang.String expectedMessage, int expressionNumber)
           
static ExprNode ViewFactorySupport.validateExpr(java.lang.String viewName, StatementContext statementContext, ExprNode expression, StreamTypeService streamTypeService, int expressionNumber)
           
 

Constructors in com.espertech.esper.view with parameters of type StatementContext
ViewFactoryContext(StatementContext statementContext, int streamNum, java.lang.String namespaceName, java.lang.String viewName, boolean isSubquery, int subqueryNumber, boolean isGrouped)
          Ctor.
 

Uses of StatementContext in com.espertech.esper.view.ext
 

Methods in com.espertech.esper.view.ext with parameters of type StatementContext
 void TimeOrderViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void SortWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void RankWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 

Uses of StatementContext in com.espertech.esper.view.internal
 

Methods in com.espertech.esper.view.internal with parameters of type StatementContext
 void UnionViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void PriorEventViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void IntersectViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 

Uses of StatementContext in com.espertech.esper.view.stat
 

Methods in com.espertech.esper.view.stat with parameters of type StatementContext
 void WeightedAverageViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void UnivariateStatisticsViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void RegressionLinestViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void CorrelationViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
static EventType WeightedAverageView.createEventType(StatementContext statementContext, StatViewAdditionalProps additionalProps, int streamNum)
          Creates the event type for this view.
static EventType UnivariateStatisticsView.createEventType(StatementContext statementContext, StatViewAdditionalProps additionalProps, int streamNum)
          Creates the event type for this view.
protected static EventType RegressionLinestView.createEventType(StatementContext statementContext, StatViewAdditionalProps additionalProps, int streamNum)
          Creates the event type for this view.
protected static EventType CorrelationView.createEventType(StatementContext statementContext, StatViewAdditionalProps additionalProps, int streamNum)
          Creates the event type for this view.
 

Uses of StatementContext in com.espertech.esper.view.std
 

Methods in com.espertech.esper.view.std with parameters of type StatementContext
 void UniqueByPropertyViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void SizeViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void MergeViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void LastElementViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void GroupByViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void FirstUniqueByPropertyViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void FirstElementViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
static EventType SizeView.createEventType(StatementContext statementContext, StatViewAdditionalProps additionalProps, int streamNum)
          Creates the event type for this view
 

Uses of StatementContext in com.espertech.esper.view.window
 

Methods in com.espertech.esper.view.window with parameters of type StatementContext
 void TimeWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void TimeLengthBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void TimeBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void TimeAccumViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void LengthWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void LengthBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void KeepAllViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void FirstTimeViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void FirstLengthWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void ExternallyTimedWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void ExternallyTimedBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 void ExpressionViewFactoryBase.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, java.util.List<ViewFactory> parentViewFactories)
           
 


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