Uses of Class
com.espertech.esper.core.context.util.AgentInstanceContext

Packages that use AgentInstanceContext
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.subselect Subselect implementation. 
com.espertech.esper.core.context.util Context partition utility or reference classes. 
com.espertech.esper.core.start Classes related to start and stop of statements 
com.espertech.esper.dataflow.core Data flow core classes. 
com.espertech.esper.dataflow.interfaces Data flow operator and related interface. 
com.espertech.esper.epl.agg.service Aggregation services. 
com.espertech.esper.epl.core Contains EPL statement specification classes define the constructs that make up an EPL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
com.espertech.esper.epl.expression.time Time-related expressions. 
com.espertech.esper.epl.fafquery Fire-and-forget query execution planning. 
com.espertech.esper.epl.join.base Join process interfaces and glue code 
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.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.metrics.instrumentation EPL instrumentation helpers. 
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.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. 
 

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

Methods in com.espertech.esper.client.hook that return AgentInstanceContext
 AgentInstanceContext VirtualDataWindowContext.getAgentInstanceContext()
          Returns the agent instance (context partition) context.
 

Constructors in com.espertech.esper.client.hook with parameters of type AgentInstanceContext
VirtualDataWindowContext(AgentInstanceContext agentInstanceContext, EventType eventType, java.lang.Object[] parameters, ExprNode[] parameterExpressions, EventBeanFactory eventFactory, VirtualDataWindowOutStream outputStream, java.lang.String namedWindowName, ViewFactoryContext viewFactoryContext, java.io.Serializable customConfiguration)
          Ctor.
 

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

Methods in com.espertech.esper.core.context.activator with parameters of type AgentInstanceContext
 ViewableActivationResult ViewableActivatorTable.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 ViewableActivationResult ViewableActivatorSubselectNone.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 ViewableActivationResult ViewableActivatorStreamReuseView.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 ViewableActivationResult ViewableActivatorPattern.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 ViewableActivationResult ViewableActivatorNamedWindow.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 ViewableActivationResult ViewableActivatorFilterProxy.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 ViewableActivationResult ViewableActivator.activate(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient)
           
 

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

Methods in com.espertech.esper.core.context.factory that return AgentInstanceContext
 AgentInstanceContext StatementAgentInstanceFactoryResult.getAgentInstanceContext()
           
 

Methods in com.espertech.esper.core.context.factory with parameters of type AgentInstanceContext
 View StatementAgentInstanceFactoryOnTriggerTable.determineFinalOutputView(AgentInstanceContext agentInstanceContext, View onExprView)
           
 View StatementAgentInstanceFactoryOnTriggerSplit.determineFinalOutputView(AgentInstanceContext agentInstanceContext, View onExprView)
           
 View StatementAgentInstanceFactoryOnTriggerSetVariable.determineFinalOutputView(AgentInstanceContext agentInstanceContext, View onExprView)
           
 View StatementAgentInstanceFactoryOnTriggerNamedWindow.determineFinalOutputView(AgentInstanceContext agentInstanceContext, View onExprView)
           
abstract  View StatementAgentInstanceFactoryOnTriggerBase.determineFinalOutputView(AgentInstanceContext agentInstanceContext, View onExprView)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerTable.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerSplit.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerSetVariable.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerNamedWindow.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks)
           
abstract  StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerBase.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks)
           
 StatementAgentInstanceFactoryOnTriggerResult StatementAgentInstanceFactoryOnTriggerBase.newContext(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryCreateTableResult StatementAgentInstanceFactoryCreateTable.newContext(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryCreateIndexResult StatementAgentInstanceFactoryCreateIndex.newContext(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryResult StatementAgentInstanceFactoryBase.newContext(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryResult StatementAgentInstanceFactory.newContext(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryUpdateResult StatementAgentInstanceFactoryUpdate.newContextInternal(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactorySelectResult StatementAgentInstanceFactorySelect.newContextInternal(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryCreateWindowResult StatementAgentInstanceFactoryCreateWindow.newContextInternal(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 StatementAgentInstanceFactoryCreateVariableResult StatementAgentInstanceFactoryCreateVariable.newContextInternal(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
protected abstract  StatementAgentInstanceFactoryResult StatementAgentInstanceFactoryBase.newContextInternal(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient)
           
 

Constructors in com.espertech.esper.core.context.factory with parameters of type AgentInstanceContext
StatementAgentInstanceFactoryCreateIndexResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext)
           
StatementAgentInstanceFactoryCreateTableResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationServiceTable aggregationReportingService)
           
StatementAgentInstanceFactoryCreateVariableResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext)
           
StatementAgentInstanceFactoryCreateWindowResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable eventStreamParentViewable, StatementAgentInstancePostLoad postLoad, Viewable topView)
           
StatementAgentInstanceFactoryOnTriggerResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService aggregationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, EvalRootState optPatternRoot, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies)
           
StatementAgentInstanceFactoryResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorNodeStrategies, java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies, RegexExprPreviousEvalStrategy regexExprPreviousEvalStrategy, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies, java.util.List<StatementAgentInstancePreload> preloadList)
           
StatementAgentInstanceFactorySelectResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorNodeStrategies, java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies, RegexExprPreviousEvalStrategy regexExprPreviousEvalStrategy, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies, java.util.List<StatementAgentInstancePreload> preloadList, EvalRootState[] patternRoots, StatementAgentInstancePostLoad optionalPostLoadJoin, Viewable[] topViews, Viewable[] eventStreamViewables)
           
StatementAgentInstanceFactoryUpdateResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies)
           
 

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

Methods in com.espertech.esper.core.context.mgr that return AgentInstanceContext
 AgentInstanceContext AgentInstance.getAgentInstanceContext()
           
 AgentInstanceContext ContextControllerFactoryServiceContext.getAgentInstanceContextCreate()
           
 AgentInstanceContext ContextControllerFactoryContext.getAgentInstanceContextCreate()
           
 

Methods in com.espertech.esper.core.context.mgr with parameters of type AgentInstanceContext
 void ContextManagementServiceImpl.addContextSpec(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, CreateContextDesc contextDesc, boolean isRecoveringResilient)
           
 void ContextManagementService.addContextSpec(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, CreateContextDesc contextDesc, boolean isRecoveringResilient)
           
static ContextControllerCondition ContextControllerConditionFactory.getEndpoint(java.lang.String contextName, EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, ContextDetailCondition endpoint, ContextControllerConditionCallback callback, ContextInternalFilterAddendum filterAddendum, boolean isStartEndpoint, int nestingLevel, int pathId, int subpathId)
           
 

Constructors in com.espertech.esper.core.context.mgr with parameters of type AgentInstanceContext
AgentInstance(StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView)
           
ContextControllerConditionFilter(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, ContextDetailConditionFilter endpointFilterSpec, ContextControllerConditionCallback callback, ContextInternalFilterAddendum filterAddendum)
           
ContextControllerConditionPattern(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContext, ContextDetailConditionPattern endpointPatternSpec, ContextControllerConditionCallback callback, ContextInternalFilterAddendum filterAddendum, boolean startEndpoint, ContextStatePathKey contextStatePathKey)
           
ContextControllerConditionTimePeriod(java.lang.String contextName, AgentInstanceContext agentInstanceContext, ScheduleSlot scheduleSlot, ContextDetailConditionTimePeriod spec, ContextControllerConditionCallback callback, ContextInternalFilterAddendum filterAddendum)
           
ContextControllerFactoryContext(java.lang.String outermostContextName, java.lang.String contextName, EPServicesContext servicesContext, AgentInstanceContext agentInstanceContextCreate, int nestingLevel, boolean isRecoveringResilient)
           
ContextControllerFactoryServiceContext(java.lang.String contextName, EPServicesContext servicesContext, ContextDetail detail, AgentInstanceContext agentInstanceContextCreate, boolean isRecoveringResilient)
           
ContextControllerHashedFilterCallback(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContextCreateContext, ContextDetailHashItem hashItem, ContextControllerHashedInstanceCallback callback, ContextInternalFilterAddendum filterAddendum)
           
ContextControllerPartitionedFilterCallback(EPServicesContext servicesContext, AgentInstanceContext agentInstanceContextCreateContext, ContextDetailPartitionItem partitionItem, ContextControllerPartitionedInstanceCreateCallback callback, ContextInternalFilterAddendum filterAddendum)
           
 

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

Methods in com.espertech.esper.core.context.subselect with parameters of type AgentInstanceContext
 SubSelectStrategyRealization SubSelectStrategyFactoryLocalViewPreloaded.instantiate(EPServicesContext services, Viewable viewableRoot, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList)
           
 SubSelectStrategyRealization SubSelectStrategyFactoryIndexShare.instantiate(EPServicesContext services, Viewable viewableRoot, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList)
           
 SubSelectStrategyRealization SubSelectStrategyFactory.instantiate(EPServicesContext services, Viewable viewableRoot, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList)
           
 

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

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

Methods in com.espertech.esper.core.context.util with parameters of type AgentInstanceContext
static AgentInstanceViewFactoryChainContext AgentInstanceViewFactoryChainContext.create(java.util.List<ViewFactory> viewFactoryChain, AgentInstanceContext agentInstanceContext, ViewResourceDelegateVerifiedStream viewResourceDelegate)
           
static boolean StatementAgentInstanceUtil.evaluateFilterForStatement(EPServicesContext servicesContext, EventBean theEvent, AgentInstanceContext agentInstanceContext, FilterHandle filterHandle)
           
static StopCallback StatementAgentInstanceUtil.getStopCallback(java.util.List<StopCallback> stopCallbacks, AgentInstanceContext agentInstanceContext)
           
static void StatementAgentInstanceUtil.stop(StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView, EPServicesContext servicesContext, boolean isStatementStop, boolean leaveLocksAcquired)
           
 

Constructors in com.espertech.esper.core.context.util with parameters of type AgentInstanceContext
AgentInstanceViewFactoryChainContext(AgentInstanceContext agentInstanceContext, boolean isRemoveStream, java.lang.Object previousNodeGetter, ViewUpdatedCollection priorViewUpdatedCollection)
           
 

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

Methods in com.espertech.esper.core.start that return AgentInstanceContext
 AgentInstanceContext FireAndForgetInstanceTable.getAgentInstanceContext()
           
 AgentInstanceContext FireAndForgetInstanceNamedWindow.getAgentInstanceContext()
           
abstract  AgentInstanceContext FireAndForgetInstance.getAgentInstanceContext()
           
 AgentInstanceContext EPPreparedExecuteMethodQuery.getAgentInstanceContext()
           
protected  AgentInstanceContext EPStatementStartMethodBase.getDefaultAgentInstanceContext(StatementContext statementContext)
           
 

Methods in com.espertech.esper.core.start with parameters of type AgentInstanceContext
static void EPPreparedExecuteTableHelper.assignTableAccessStrategies(EPServicesContext services, ExprTableAccessNode[] optionalTableNodes, AgentInstanceContext agentInstanceContext)
           
static java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> EPStatementStartMethodHelperTableAccess.attachTableAccess(EPServicesContext services, AgentInstanceContext agentInstanceContext, ExprTableAccessNode[] tableNodes)
           
static ResultSetProcessor EPStatementStartMethodHelperAssignExpr.getAssignResultSetProcessor(AgentInstanceContext agentInstanceContext, ResultSetProcessorFactoryDesc resultSetProcessorPrototype)
           
 FireAndForgetInstance FireAndForgetProcessorTable.getProcessorInstance(AgentInstanceContext agentInstanceContext)
           
 FireAndForgetInstance FireAndForgetProcessorNamedWindow.getProcessorInstance(AgentInstanceContext agentInstanceContext)
           
abstract  FireAndForgetInstance FireAndForgetProcessor.getProcessorInstance(AgentInstanceContext agentInstanceContext)
           
static EPStatementStartMethodSelectDesc EPStatementStartMethodSelectUtil.prepare(StatementSpecCompiled statementSpec, EPServicesContext services, StatementContext statementContext, boolean recoveringResilient, AgentInstanceContext defaultAgentInstanceContext, boolean queryPlanLogging, ViewableActivatorFactory optionalViewableActivatorFactory, OutputProcessViewCallback optionalOutputProcessViewCallback, SelectExprProcessorDeliveryCallback selectExprProcessorDeliveryCallback)
           
static Pair<ResultSetProcessor,AggregationService> EPStatementStartMethodHelperUtil.startResultSetAndAggregation(ResultSetProcessorFactoryDesc resultSetProcessorPrototype, AgentInstanceContext agentInstanceContext)
           
static java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> EPStatementStartMethodHelperSubselect.startSubselects(EPServicesContext services, SubSelectStrategyCollection subSelectStrategyCollection, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList)
           
 

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

Methods in com.espertech.esper.dataflow.core that return AgentInstanceContext
 AgentInstanceContext DataFlowStmtDesc.getAgentInstanceContext()
           
 

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

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

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

Methods in com.espertech.esper.dataflow.interfaces that return AgentInstanceContext
 AgentInstanceContext DataFlowOpInitializateContext.getAgentInstanceContext()
           
 

Constructors in com.espertech.esper.dataflow.interfaces with parameters of type AgentInstanceContext
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)
           
 

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

Methods in com.espertech.esper.epl.agg.service with parameters of type AgentInstanceContext
 AggSvcGroupByReclaimAgedEvalFunc AggSvcGroupByReclaimAgedEvalFuncFactory.make(AgentInstanceContext agentInstanceContext)
           
 AggregationServiceMatchRecognize AggregationServiceMatchRecognizeFactoryImpl.makeService(AgentInstanceContext agentInstanceContext)
           
 AggregationServiceMatchRecognize AggregationServiceMatchRecognizeFactory.makeService(AgentInstanceContext agentInstanceContext)
           
 AggregationService AggSvcGroupByWTableFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByRefcountedWAccessRollupFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByRefcountedWAccessFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByRefcountedNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByReclaimAgedFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByMixedAccessFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByLocalGroupByFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupByAccessOnlyFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupAllNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupAllMixedAccessWTableFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupAllMixedAccessFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupAllLocalGroupByFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggSvcGroupAllAccessOnlyFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggregationServiceNullFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 AggregationService AggregationServiceFactory.makeService(AgentInstanceContext agentInstanceContext, MethodResolutionService methodResolutionService)
           
 

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

Fields in com.espertech.esper.epl.core declared as AgentInstanceContext
protected  AgentInstanceContext ResultSetProcessorRowPerGroupRollup.agentInstanceContext
           
protected  AgentInstanceContext ResultSetProcessorRowPerGroup.agentInstanceContext
           
 

Methods in com.espertech.esper.epl.core with parameters of type AgentInstanceContext
 RowLimitProcessor RowLimitProcessorFactory.instantiate(AgentInstanceContext agentInstanceContext)
           
 OrderByProcessor OrderByProcessorRowLimitOnlyFactory.instantiate(AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 OrderByProcessor OrderByProcessorOrderedLimitFactory.instantiate(AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 OrderByProcessor OrderByProcessorFactoryImpl.instantiate(AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 OrderByProcessor OrderByProcessorFactory.instantiate(AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorSimpleFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorRowPerGroupRollupFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorRowPerGroupFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorRowForAllFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorHandThrougFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorAggregateGroupedFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 ResultSetProcessor ResultSetProcessorAggregateAllFactory.instantiate(OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 void ResultSetProcessorSimple.setAgentInstanceContext(AgentInstanceContext context)
           
 void ResultSetProcessorRowPerGroupRollup.setAgentInstanceContext(AgentInstanceContext agentInstanceContext)
           
 void ResultSetProcessorRowPerGroup.setAgentInstanceContext(AgentInstanceContext agentInstanceContext)
           
 void ResultSetProcessorRowForAll.setAgentInstanceContext(AgentInstanceContext context)
           
 void ResultSetProcessorHandThrough.setAgentInstanceContext(AgentInstanceContext agentInstanceContext)
           
 void ResultSetProcessorAggregateGrouped.setAgentInstanceContext(AgentInstanceContext agentInstanceContext)
           
 void ResultSetProcessorAggregateAll.setAgentInstanceContext(AgentInstanceContext context)
           
 void ResultSetProcessor.setAgentInstanceContext(AgentInstanceContext context)
           
 EventBean[] OrderByProcessorRowLimitOnly.sort(EventBean[] outgoingEvents, java.util.List<GroupByRollupKey> currentGenerators, boolean newData, AgentInstanceContext agentInstanceContext, OrderByElement[][] elementsPerLevel)
           
 EventBean[] OrderByProcessorOrderedLimit.sort(EventBean[] outgoingEvents, java.util.List<GroupByRollupKey> currentGenerators, boolean newData, AgentInstanceContext agentInstanceContext, OrderByElement[][] elementsPerLevel)
           
 EventBean[] OrderByProcessorImpl.sort(EventBean[] outgoingEvents, java.util.List<GroupByRollupKey> currentGenerators, boolean isNewData, AgentInstanceContext exprEvaluatorContext, OrderByElement[][] elementsPerLevel)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, java.util.List<GroupByRollupKey> currentGenerators, boolean newData, AgentInstanceContext agentInstanceContext, OrderByElement[][] elementsPerLevel)
           
 

Constructors in com.espertech.esper.epl.core with parameters of type AgentInstanceContext
ResultSetProcessorAggregateGrouped(ResultSetProcessorAggregateGroupedFactory prototype, SelectExprProcessor selectExprProcessor, OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
ResultSetProcessorHandThrough(ResultSetProcessorHandThrougFactory prototype, SelectExprProcessor selectExprProcessor, AgentInstanceContext agentInstanceContext)
           
ResultSetProcessorRowPerGroup(ResultSetProcessorRowPerGroupFactory prototype, SelectExprProcessor selectExprProcessor, OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
ResultSetProcessorRowPerGroupRollup(ResultSetProcessorRowPerGroupRollupFactory prototype, OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
ResultSetProcessorRowPerGroupRollupUnbound(ResultSetProcessorRowPerGroupRollupFactory prototype, OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
ResultSetProcessorRowPerGroupUnbound(ResultSetProcessorRowPerGroupFactory prototype, SelectExprProcessor selectExprProcessor, OrderByProcessor orderByProcessor, AggregationService aggregationService, AgentInstanceContext agentInstanceContext)
           
 

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

Methods in com.espertech.esper.epl.expression.time with parameters of type AgentInstanceContext
 long ExprTimePeriodEvalDeltaNonConstMsec.deltaMillisecondsUseEngineTime(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext)
           
 long ExprTimePeriodEvalDeltaNonConstCalAdd.deltaMillisecondsUseEngineTime(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext)
           
 long ExprTimePeriodEvalDeltaNonConst.deltaMillisecondsUseEngineTime(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext)
           
 

Uses of AgentInstanceContext in com.espertech.esper.epl.fafquery
 

Methods in com.espertech.esper.epl.fafquery with parameters of type AgentInstanceContext
static java.util.Collection<EventBean> FireAndForgetQueryExec.snapshot(FilterSpecCompiled optionalFilter, java.lang.annotation.Annotation[] annotations, VirtualDWView virtualDataWindow, EventTableIndexRepository indexRepository, boolean queryPlanLogging, org.apache.commons.logging.Log queryPlanLogDestination, java.lang.String objectName, AgentInstanceContext agentInstanceContext)
           
 

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

Methods in com.espertech.esper.epl.join.base with parameters of type AgentInstanceContext
 JoinSetComposerDesc JoinSetComposerPrototypeImpl.create(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext)
           
 JoinSetComposerDesc JoinSetComposerPrototypeHistorical2StreamImpl.create(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext)
           
 JoinSetComposerDesc JoinSetComposerPrototype.create(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext)
           
 

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

Methods in com.espertech.esper.epl.lookup with parameters of type AgentInstanceContext
 SubordWMatchExprLookupStrategy SubordWMatchExprLookupStrategyFactoryIndexedUnfiltered.realize(EventTable[] indexes, AgentInstanceContext agentInstanceContext, java.lang.Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow)
           
 SubordWMatchExprLookupStrategy SubordWMatchExprLookupStrategyFactoryIndexedFiltered.realize(EventTable[] indexes, AgentInstanceContext agentInstanceContext, java.lang.Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow)
           
 SubordWMatchExprLookupStrategy SubordWMatchExprLookupStrategyFactoryAllUnfiltered.realize(EventTable[] indexes, AgentInstanceContext agentInstanceContext, java.lang.Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow)
           
 SubordWMatchExprLookupStrategy SubordWMatchExprLookupStrategyFactoryAllFiltered.realize(EventTable[] indexes, AgentInstanceContext agentInstanceContext, java.lang.Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow)
           
 SubordWMatchExprLookupStrategy SubordWMatchExprLookupStrategyFactory.realize(EventTable[] indexes, AgentInstanceContext agentInstanceContext, java.lang.Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow)
           
 

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

Methods in com.espertech.esper.epl.named that return AgentInstanceContext
 AgentInstanceContext NamedWindowTailViewInstance.getAgentInstanceContext()
           
 AgentInstanceContext NamedWindowConsumerDesc.getAgentInstanceContext()
           
 

Methods in com.espertech.esper.epl.named with parameters of type AgentInstanceContext
 NamedWindowProcessorInstance NamedWindowProcessor.addInstance(AgentInstanceContext agentInstanceContext)
           
 NamedWindowProcessorInstance NamedWindowProcessor.getProcessorInstance(AgentInstanceContext agentInstanceContext)
           
 NamedWindowOnExprBaseView NamedWindowOnUpdateViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 NamedWindowOnExprBaseView NamedWindowOnSelectViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 NamedWindowOnExprBaseView NamedWindowOnMergeViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 NamedWindowOnExprBaseView NamedWindowOnExprFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 NamedWindowOnExprBaseView NamedWindowOnDeleteViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 

Constructors in com.espertech.esper.epl.named with parameters of type AgentInstanceContext
NamedWindowConsumerDesc(java.util.List<ExprNode> filterList, PropertyEvaluator optPropertyEvaluator, AgentInstanceContext agentInstanceContext)
           
NamedWindowProcessorInstance(java.lang.Integer agentInstanceId, NamedWindowProcessor processor, AgentInstanceContext agentInstanceContext)
           
NamedWindowRootViewInstance(NamedWindowRootView rootView, AgentInstanceContext agentInstanceContext)
           
NamedWindowTailViewInstance(NamedWindowRootViewInstance rootViewInstance, NamedWindowTailView tailView, AgentInstanceContext agentInstanceContext)
           
 

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

Methods in com.espertech.esper.epl.spec with parameters of type AgentInstanceContext
 long MatchRecognizeInterval.getScheduleBackwardDelta(long fromTime, AgentInstanceContext agentInstanceContext)
          Returns the number of milliseconds.
 long MatchRecognizeInterval.getScheduleForwardDelta(long fromTime, AgentInstanceContext agentInstanceContext)
          Returns the number of milliseconds.
 

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

Fields in com.espertech.esper.epl.table.mgmt declared as AgentInstanceContext
protected  AgentInstanceContext TableStateInstance.agentInstanceContext
           
 

Methods in com.espertech.esper.epl.table.mgmt that return AgentInstanceContext
 AgentInstanceContext TableStateInstance.getAgentInstanceContext()
           
 

Methods in com.espertech.esper.epl.table.mgmt with parameters of type AgentInstanceContext
 TableStateInstance TableStateFactory.makeTableState(AgentInstanceContext agentInstanceContext)
           
 

Constructors in com.espertech.esper.epl.table.mgmt with parameters of type AgentInstanceContext
TableStateInstance(TableMetadata tableMetadata, AgentInstanceContext agentInstanceContext)
           
TableStateInstanceGroupBy(TableMetadata tableMetadata, AgentInstanceContext agentInstanceContext)
           
TableStateInstanceUngrouped(TableMetadata tableMetadata, AgentInstanceContext agentInstanceContext)
           
 

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

Methods in com.espertech.esper.epl.table.onaction with parameters of type AgentInstanceContext
 TableOnViewBase TableOnViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance tableState, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 TableOnViewBase TableOnUpdateViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance tableState, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 TableOnViewBase TableOnSelectViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance tableState, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 TableOnViewBase TableOnMergeViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance tableState, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 TableOnViewBase TableOnDeleteViewFactory.make(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance tableState, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor)
           
 

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

Methods in com.espertech.esper.epl.view with parameters of type AgentInstanceContext
static OutputConditionPolled OutputConditionPolledFactory.createCondition(OutputLimitSpec outputLimitSpec, AgentInstanceContext agentInstanceContext)
          Creates an output condition instance.
 OutputStrategyPostProcess OutputStrategyPostProcessFactory.make(AgentInstanceContext agentInstanceContext)
           
 OutputCondition OutputConditionTimeFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionTermFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionNullFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionFirstFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionExpressionFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionCrontabFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputCondition OutputConditionCountFactory.make(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback)
           
 OutputProcessViewBase OutputProcessViewFactoryCallback.makeView(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext)
           
 OutputProcessViewBase OutputProcessViewFactory.makeView(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext)
           
 OutputProcessViewBase OutputProcessViewDirectFactory.makeView(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext)
           
 OutputProcessViewBase OutputProcessViewDirectDistinctOrAfterFactory.makeView(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext)
           
 OutputProcessViewBase OutputProcessViewConditionFactory.makeView(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext)
           
 

Constructors in com.espertech.esper.epl.view with parameters of type AgentInstanceContext
OutputConditionCrontab(OutputCallback outputCallback, AgentInstanceContext context, OutputConditionCrontabFactory factory, boolean isStartConditionOnCreation)
           
OutputConditionExpression(OutputCallback outputCallback, AgentInstanceContext agentInstanceContext, OutputConditionExpressionFactory parent, boolean isStartConditionOnCreation)
           
OutputConditionFirst(OutputCallback outputCallback, AgentInstanceContext agentInstanceContext, OutputConditionFactory innerConditionFactory)
           
OutputConditionPolledCrontab(java.util.List<ExprNode> scheduleSpecExpressionList, AgentInstanceContext agentInstanceContext)
          Constructor.
OutputConditionPolledExpression(ExprNode whenExpressionNode, java.util.List<OnTriggerSetAssignment> assignments, AgentInstanceContext agentInstanceContext)
          Ctor.
OutputConditionPolledTime(ExprTimePeriod timePeriod, AgentInstanceContext context)
          Constructor.
OutputConditionTime(OutputCallback outputCallback, AgentInstanceContext context, OutputConditionTimeFactory outputConditionTimeFactory, boolean isStartConditionOnCreation)
           
OutputProcessViewConditionDefault(ResultSetProcessor resultSetProcessor, java.lang.Long afterConditionTime, java.lang.Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext)
           
OutputProcessViewConditionDefaultPostProcess(ResultSetProcessor resultSetProcessor, java.lang.Long afterConditionTime, java.lang.Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor)
           
OutputProcessViewConditionFirst(ResultSetProcessor resultSetProcessor, java.lang.Long afterConditionTime, java.lang.Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext)
           
OutputProcessViewConditionFirstPostProcess(ResultSetProcessor resultSetProcessor, java.lang.Long afterConditionTime, java.lang.Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor)
           
OutputProcessViewConditionSnapshot(ResultSetProcessor resultSetProcessor, java.lang.Long afterConditionTime, java.lang.Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext)
           
OutputProcessViewConditionSnapshotPostProcess(ResultSetProcessor resultSetProcessor, java.lang.Long afterConditionTime, java.lang.Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor)
           
OutputStrategyPostProcess(OutputStrategyPostProcessFactory parent, AgentInstanceContext agentInstanceContext, TableStateInstance tableStateInstance)
           
 

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

Methods in com.espertech.esper.epl.virtualdw with parameters of type AgentInstanceContext
 VirtualDWView VirtualDWViewProviderForAgentInstance.getView(AgentInstanceContext agentInstanceContext)
           
 

Uses of AgentInstanceContext in com.espertech.esper.metrics.instrumentation
 

Methods in com.espertech.esper.metrics.instrumentation with parameters of type AgentInstanceContext
 void InstrumentationDefault.qContextPartitionAllocate(AgentInstanceContext agentInstanceContext)
           
 void Instrumentation.qContextPartitionAllocate(AgentInstanceContext agentInstanceContext)
           
 void InstrumentationDefault.qContextPartitionDestroy(AgentInstanceContext agentInstanceContext)
           
 void Instrumentation.qContextPartitionDestroy(AgentInstanceContext agentInstanceContext)
           
 

Uses of AgentInstanceContext in com.espertech.esper.pattern
 

Methods in com.espertech.esper.pattern that return AgentInstanceContext
 AgentInstanceContext PatternAgentInstanceContext.getAgentInstanceContext()
           
 

Methods in com.espertech.esper.pattern with parameters of type AgentInstanceContext
 PatternAgentInstanceContext PatternContextFactoryDefault.createPatternAgentContext(PatternContext patternContext, AgentInstanceContext agentInstanceContext, boolean hasConsumingFilter)
           
 PatternAgentInstanceContext PatternContextFactory.createPatternAgentContext(PatternContext patternContext, AgentInstanceContext agentInstanceContext, boolean hasConsumingFilter)
           
 

Constructors in com.espertech.esper.pattern with parameters of type AgentInstanceContext
PatternAgentInstanceContext(PatternContext patternContext, AgentInstanceContext agentInstanceContext, boolean hasConsumingFilter)
           
 

Uses of AgentInstanceContext in com.espertech.esper.rowregex
 

Constructors in com.espertech.esper.rowregex with parameters of type AgentInstanceContext
EventRowRegexNFAView(EventRowRegexNFAViewFactory factory, ObjectArrayEventType compositeEventType, EventType rowEventType, MatchRecognizeSpec matchRecognizeSpec, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, java.util.Map<java.lang.Integer,java.lang.String> streamsVariables, java.util.Set<java.lang.String> variablesSingle, AgentInstanceContext agentInstanceContext, java.util.TreeMap<java.lang.Integer,java.util.List<ExprPreviousMatchRecognizeNode>> callbacksPerIndex, AggregationServiceMatchRecognize aggregationService, boolean isDefineAsksMultimatches, ObjectArrayBackedEventBean defineMultimatchEventBean, boolean[] isExprRequiresMultimatchState, boolean isUnbound, boolean isIterateOnly, boolean isCollectMultimatches, RowRegexExprNode expandedPatternNode)
          Ctor.
EventRowRegexNFAViewFactory(ViewFactoryChain viewChain, MatchRecognizeSpec matchRecognizeSpec, AgentInstanceContext agentInstanceContext, boolean isUnbound, java.lang.annotation.Annotation[] annotations)
          Ctor.
 

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

Constructors in com.espertech.esper.view.internal with parameters of type AgentInstanceContext
RouteResultView(boolean isFirst, EventType eventType, EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableStateInstance[] tableStateInstances, boolean[] isNamedWindowInsert, ResultSetProcessor[] processors, ExprNode[] whereClauses, AgentInstanceContext agentInstanceContext)
          Ctor.
RouteResultViewHandlerAll(EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableStateInstance[] tableStateInstances, boolean[] isNamedWindowInsert, ResultSetProcessor[] processors, ExprEvaluator[] whereClauses, AgentInstanceContext agentInstanceContext)
          Ctor.
RouteResultViewHandlerFirst(EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableStateInstance[] tableStateInstances, boolean[] isNamedWindowInsert, ResultSetProcessor[] processors, ExprEvaluator[] whereClauses, AgentInstanceContext agentInstanceContext)
          Ctor.
 

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

Fields in com.espertech.esper.view.stat declared as AgentInstanceContext
protected  AgentInstanceContext BaseBivariateStatisticsView.agentInstanceContext
          Services required by implementing classes.
 

Constructors in com.espertech.esper.view.stat with parameters of type AgentInstanceContext
BaseBivariateStatisticsView(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprNode expressionX, ExprNode expressionY, EventType eventType, StatViewAdditionalProps additionalProps)
          Constructor requires the name of the two fields to use in the parent view to compute the statistics.
CorrelationView(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprNode xExpression, ExprNode yExpression, EventType eventType, StatViewAdditionalProps additionalProps)
          Constructor.
RegressionLinestView(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprNode xFieldName, ExprNode yFieldName, EventType eventType, StatViewAdditionalProps additionalProps)
          Constructor.
 

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

Constructors in com.espertech.esper.view.std with parameters of type AgentInstanceContext
SizeView(AgentInstanceContext agentInstanceContext, EventType eventType, StatViewAdditionalProps additionalProps)
          Ctor.
 


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