Uses of Class
com.espertech.esper.common.internal.context.util.AgentInstanceContext
Packages that use AgentInstanceContext
Package
Description
Virtual data window extension API classes.
Data flow operator and related interface.
Polled executions for use with method-invocation joins
Pattern subexpression pool management
Match-recognize core.
Match-recognize NFA.
Match-recognize state management.
-
Uses of AgentInstanceContext in com.espertech.esper.common.client.hook.vdw
Methods in com.espertech.esper.common.client.hook.vdw that return AgentInstanceContextModifier and TypeMethodDescriptionVirtualDataWindowContext.getAgentInstanceContext()
Returns the agent instance (context partition) context. -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.activator
Methods in com.espertech.esper.common.internal.context.activator with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionViewableActivator.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorDataFlow.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorFilter.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorHistorical.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorNamedWindow.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorPattern.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorSubselectNone.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) ViewableActivatorTable.activate
(AgentInstanceContext agentInstanceContext, boolean isSubselect, boolean isRecoveringResilient) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.core
Methods in com.espertech.esper.common.internal.context.aifactory.core that return AgentInstanceContextMethods in com.espertech.esper.common.internal.context.aifactory.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactory.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.core with parameters of type AgentInstanceContextModifierConstructorDescriptionprotected
StatementAgentInstanceFactoryResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy rowRecogPreviousStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, Runnable postContextMergeRunnable) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createclass
Methods in com.espertech.esper.common.internal.context.aifactory.createclass with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateClass.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createclass with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateClassResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createcontext
Methods in com.espertech.esper.common.internal.context.aifactory.createcontext with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateContext.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createcontext with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateContextResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy regexExprPreviousEvalStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, ContextManagerRealization contextManagerRealization) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createdataflow
Methods in com.espertech.esper.common.internal.context.aifactory.createdataflow with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateDataflow.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createdataflow with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateDataflowResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, DataflowDesc dataflow) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createexpression
Methods in com.espertech.esper.common.internal.context.aifactory.createexpression with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateExpression.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createexpression with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateExpressionResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createindex
Methods in com.espertech.esper.common.internal.context.aifactory.createindex with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateIndex.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createindex with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateIndexResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createschema
Methods in com.espertech.esper.common.internal.context.aifactory.createschema with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateSchema.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createschema with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateSchemaResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createtable
Methods in com.espertech.esper.common.internal.context.aifactory.createtable with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateTable.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createtable with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateTableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, TableInstance tableInstance) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createvariable
Methods in com.espertech.esper.common.internal.context.aifactory.createvariable with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateVariable.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createvariable with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateVariableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createwindow
Methods in com.espertech.esper.common.internal.context.aifactory.createwindow with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateNW.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.createwindow with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryCreateNWResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable eventStreamParentViewable, Viewable topView, NamedWindowInstance namedWindowInstance, ViewableActivationResult viewableActivationResult) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.ontrigger.core
Methods in com.espertech.esper.common.internal.context.aifactory.ontrigger.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionabstract View
StatementAgentInstanceFactoryOnTriggerBase.determineFinalOutputView
(AgentInstanceContext agentInstanceContext, View onExprView) abstract InfraOnExprBaseViewResult
StatementAgentInstanceFactoryOnTriggerBase.determineOnExprView
(AgentInstanceContext agentInstanceContext, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringReslient) StatementAgentInstanceFactoryOnTriggerBase.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.ontrigger.core with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryOnTriggerResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy regexExprPreviousEvalStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, Runnable postContextMergeRunnable, EvalRootState optPatternRoot, ViewableActivationResult viewableActivationResult) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.ontrigger.onset
Methods in com.espertech.esper.common.internal.context.aifactory.ontrigger.onset with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryOnTriggerSet.determineFinalOutputView
(AgentInstanceContext agentInstanceContext, View onExprView) StatementAgentInstanceFactoryOnTriggerSet.determineOnExprView
(AgentInstanceContext agentInstanceContext, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringReslient) Constructors in com.espertech.esper.common.internal.context.aifactory.ontrigger.onset with parameters of type AgentInstanceContextModifierConstructorDescriptionOnSetVariableView
(StatementAgentInstanceFactoryOnTriggerSet factory, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit
Fields in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
RouteResultViewHandlerBase.agentInstanceContext
Methods in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryOnTriggerSplitStream.determineFinalOutputView
(AgentInstanceContext agentInstanceContext, View onExprView) StatementAgentInstanceFactoryOnTriggerSplitStream.determineOnExprView
(AgentInstanceContext agentInstanceContext, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringReslient) Constructors in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit with parameters of type AgentInstanceContextModifierConstructorDescriptionRouteResultView
(boolean isFirst, EventType eventType, EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableInstance[] tableInstances, OnSplitItemEval[] items, ResultSetProcessor[] processors, AgentInstanceContext agentInstanceContext) RouteResultViewHandlerAll
(EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableInstance[] tableStateInstances, OnSplitItemEval[] items, ResultSetProcessor[] processors, AgentInstanceContext agentInstanceContext) RouteResultViewHandlerBase
(EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableInstance[] tableStateInstances, OnSplitItemEval[] items, ResultSetProcessor[] processors, AgentInstanceContext agentInstanceContext) RouteResultViewHandlerFirst
(EPStatementHandle epStatementHandle, InternalEventRouter internalEventRouter, TableInstance[] tableInstances, OnSplitItemEval[] items, ResultSetProcessor[] processors, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.ontrigger.ontrigger
Methods in com.espertech.esper.common.internal.context.aifactory.ontrigger.ontrigger with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryOnTriggerInfraBase.determineFinalOutputView
(AgentInstanceContext agentInstanceContext, View onExprView) StatementAgentInstanceFactoryOnTriggerInfraBase.determineOnExprView
(AgentInstanceContext agentInstanceContext, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringResilient) InfraOnExprFactory.makeNamedWindow
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext) InfraOnExprFactory.makeTable
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.select
Methods in com.espertech.esper.common.internal.context.aifactory.select with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactorySelect.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.select with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactorySelectResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy regexExprPreviousEvalStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, Runnable postContextMergeRunnable, EvalRootState[] patternRoots, JoinSetComposer joinSetComposer, Viewable[] topViews, Viewable[] eventStreamViewables, ViewableActivationResult[] viewableActivationResults, ResultSetProcessor resultSetProcessor) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.update
Methods in com.espertech.esper.common.internal.context.aifactory.update with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementAgentInstanceFactoryUpdate.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.context.aifactory.update with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementAgentInstanceFactoryUpdateResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Map<Integer, SubSelectFactoryResult> subselectActivations) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.controller.category
Methods in com.espertech.esper.common.internal.context.controller.category with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionContextControllerCategoryFactory.populateFilterAddendum
(FilterSpecActivatable filterSpec, boolean forStatement, int nestingLevel, Object partitionKey, ContextControllerStatementDesc optionalStatementDesc, Map<Integer, ContextControllerStatementDesc> statements, AgentInstanceContext agentInstanceContextStatement) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.controller.core
Methods in com.espertech.esper.common.internal.context.controller.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionContextControllerFactory.populateFilterAddendum
(FilterSpecActivatable filterSpec, boolean forStatement, int nestingLevel, Object partitionKey, ContextControllerStatementDesc optionalStatementDesc, Map<Integer, ContextControllerStatementDesc> statements, AgentInstanceContext agentInstanceContextStatement) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.controller.hash
Methods in com.espertech.esper.common.internal.context.controller.hash that return AgentInstanceContextMethods in com.espertech.esper.common.internal.context.controller.hash with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionContextControllerHashFactory.populateFilterAddendum
(FilterSpecActivatable filterSpec, boolean forStatement, int nestingLevel, Object partitionKey, ContextControllerStatementDesc optionalStatementDesc, Map<Integer, ContextControllerStatementDesc> statements, AgentInstanceContext agentInstanceContextStatement) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.controller.initterm
Methods in com.espertech.esper.common.internal.context.controller.initterm with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionContextControllerInitTermFactory.populateFilterAddendum
(FilterSpecActivatable filterSpec, boolean forStatement, int nestingLevel, Object partitionKey, ContextControllerStatementDesc optionalStatementDesc, Map<Integer, ContextControllerStatementDesc> statements, AgentInstanceContext agentInstanceContextStatement) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.controller.keyed
Methods in com.espertech.esper.common.internal.context.controller.keyed that return AgentInstanceContextMethods in com.espertech.esper.common.internal.context.controller.keyed with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic FilterValueSetParam[][]
ContextControllerKeyedUtil.getAddendumFilters
(Object getterKey, FilterSpecActivatable filtersSpec, ContextControllerDetailKeyed keyedSpec, boolean includePartition, ContextControllerStatementDesc optionalStatementDesc, Map<Integer, ContextControllerStatementDesc> statements, AgentInstanceContext agentInstanceContext) ContextControllerKeyedFactory.populateFilterAddendum
(FilterSpecActivatable filterSpec, boolean forStatement, int nestingLevel, Object partitionKey, ContextControllerStatementDesc optionalStatementDesc, Map<Integer, ContextControllerStatementDesc> statements, AgentInstanceContext agentInstanceContextStatement) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.mgr
Methods in com.espertech.esper.common.internal.context.mgr that return AgentInstanceContextMethods in com.espertech.esper.common.internal.context.mgr with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionContextManager.allocateNewRealization
(AgentInstanceContext agentInstanceContext) ContextManagerResident.allocateNewRealization
(AgentInstanceContext agentInstanceContext) static IdentityHashMap<FilterSpecActivatable,
FilterValueSetParam[][]> ContextManagerUtil.computeAddendumForStatement
(ContextControllerStatementDesc statementDesc, Map<Integer, ContextControllerStatementDesc> statements, ContextControllerFactory[] controllerFactories, Object[] allPartitionKeys, AgentInstanceContext agentInstanceContextCreate) void
ContextStatementEventEvaluator.evaluateEventForStatement
(EventBean theEvent, List<AgentInstance> agentInstances, AgentInstanceContext agentInstanceContextCreate) void
ContextStatementEventEvaluatorDefault.evaluateEventForStatement
(EventBean theEvent, List<AgentInstance> agentInstances, AgentInstanceContext agentInstanceContextCreate) Constructors in com.espertech.esper.common.internal.context.mgr with parameters of type AgentInstanceContextModifierConstructorDescriptionContextManagerRealization
(ContextManagerResident contextManager, AgentInstanceContext agentInstanceContextCreate) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.util
Methods in com.espertech.esper.common.internal.context.util that return AgentInstanceContextModifier and TypeMethodDescriptionAgentInstance.getAgentInstanceContext()
AgentInstanceStopServices.getAgentInstanceContext()
AgentInstanceTransferServices.getAgentInstanceContext()
StatementContext.makeAgentInstanceContextUnpartitioned()
Methods in com.espertech.esper.common.internal.context.util with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic void
AgentInstanceUtil.evaluateEventForStatement
(EventBean theEvent, Map<String, Object> optionalTriggeringPattern, List<AgentInstance> agentInstances, AgentInstanceContext agentInstanceContextCreate) static boolean
AgentInstanceUtil.evaluateFilterForStatement
(EventBean theEvent, AgentInstanceContext agentInstanceContext, FilterHandle filterHandle) AgentInstanceFilterProxy.getAddendumFilters
(FilterSpecActivatable filterSpec, AgentInstanceContext agentInstanceContext) AgentInstanceFilterProxyImpl.getAddendumFilters
(FilterSpecActivatable filterSpec, AgentInstanceContext agentInstanceContext) void
InternalEventRouter.route
(EventBean theEvent, AgentInstanceContext agentInstanceContext, boolean addToFront, int precedence) Route the event such that the event is processed as required.void
InternalEventRouterImpl.route
(EventBean theEvent, AgentInstanceContext agentInstanceContext, boolean addToFront, int precedence) static void
AgentInstanceUtil.stop
(AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView, boolean isStatementStop, boolean leaveLocksAcquired) static void
AgentInstanceUtil.stopSafe
(AgentInstanceMgmtCallback stopMethod, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.context.util with parameters of type AgentInstanceContextModifierConstructorDescriptionAgentInstance
(AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView) AgentInstanceStopServices
(AgentInstanceContext agentInstanceContext) AgentInstanceTransferServices
(AgentInstanceContext agentInstanceContext, FilterService targetFilterService, SchedulingService targetSchedulingService, InternalEventRouter targetInternalEventRouter) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.dataflow.core
Constructors in com.espertech.esper.common.internal.epl.dataflow.core with parameters of type AgentInstanceContextModifierConstructorDescriptionEPDataFlowInstanceImpl
(Object dataFlowInstanceUserObject, String dataFlowInstanceId, OperatorStatisticsProvider statistics, Map<Integer, Object> operators, List<GraphSourceRunnable> sourceRunnables, DataflowDesc dataflowDesc, AgentInstanceContext agentInstanceContext, EPDataFlowInstanceStatistics statisticsProvider, Map<String, Object> parametersURIs) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.dataflow.filtersvcadapter
Methods in com.espertech.esper.common.internal.epl.dataflow.filtersvcadapter with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
DataFlowFilterServiceAdapter.addFilterCallback
(FilterHandleCallback filterHandleCallback, AgentInstanceContext agentInstanceContext, EventType eventType, FilterValueSetParam[][] params, int filterCallbackId) void
DataFlowFilterServiceAdapterNonHA.addFilterCallback
(FilterHandleCallback filterHandleCallback, AgentInstanceContext agentInstanceContext, EventType eventType, FilterValueSetParam[][] params, int filterCallbackId) void
DataFlowFilterServiceAdapter.removeFilterCallback
(FilterHandleCallback filterHandleCallback, AgentInstanceContext agentInstanceContext, EventType eventType, FilterValueSetParam[][] params, int filterCallbackId) void
DataFlowFilterServiceAdapterNonHA.removeFilterCallback
(FilterHandleCallback filterHandleCallback, AgentInstanceContext agentInstanceContext, EventType eventType, FilterValueSetParam[][] params, int filterCallbackId) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.dataflow.interfaces
Methods in com.espertech.esper.common.internal.epl.dataflow.interfaces that return AgentInstanceContextConstructors in com.espertech.esper.common.internal.epl.dataflow.interfaces with parameters of type AgentInstanceContextModifierConstructorDescriptionDataFlowOpInitializeContext
(String dataFlowName, String operatorName, int operatorNumber, AgentInstanceContext agentInstanceContext, Map<String, Object> additionalParameters, String dataFlowInstanceId, EPDataFlowOperatorParameterProvider parameterProvider, DataFlowOperatorFactory dataFlowOperatorFactory, Object dataflowInstanceUserObject) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.dataflow.realize
Methods in com.espertech.esper.common.internal.epl.dataflow.realize with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic OperatorStatisticsProvider
DataflowInstantiatorHelper.realize
(DataflowDesc dataflow, Map<Integer, Object> operators, List<LogicalChannelBinding> bindings, DataFlowSignalManager dataFlowSignalManager, EPDataFlowInstantiationOptions options, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.dataflow.realize with parameters of type AgentInstanceContextModifierConstructorDescriptionEPDataFlowEmitterExceptionHandler
(AgentInstanceContext agentInstanceContext, String dataFlowName, String instanceId, String operatorName, int operatorNumber, String operatorPrettyPrint, EPDataFlowExceptionHandler optionalExceptionHandler) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.dataflow.runnables
Constructors in com.espertech.esper.common.internal.epl.dataflow.runnables with parameters of type AgentInstanceContextModifierConstructorDescriptionGraphSourceRunnable
(AgentInstanceContext agentInstanceContext, DataFlowSourceOperator graphSource, String dataFlowName, String instanceId, String operatorName, int operatorNumber, String operatorPrettyPrint, EPDataFlowExceptionHandler optionalExceptionHandler, boolean audit) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.fafquery.processor
Methods in com.espertech.esper.common.internal.epl.fafquery.processor that return AgentInstanceContextModifier and TypeMethodDescriptionabstract AgentInstanceContext
FireAndForgetInstance.getAgentInstanceContext()
FireAndForgetInstanceNamedWindow.getAgentInstanceContext()
FireAndForgetInstanceTable.getAgentInstanceContext()
Methods in com.espertech.esper.common.internal.epl.fafquery.processor with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionFireAndForgetProcessorDB.getProcessorInstance
(AgentInstanceContext agentInstanceContext) FireAndForgetProcessorNamedWindow.getProcessorInstance
(AgentInstanceContext agentInstanceContext) FireAndForgetProcessorTable.getProcessorInstance
(AgentInstanceContext agentInstanceContext) static Collection<EventBean>
FireAndForgetQueryExec.snapshot
(QueryGraph filterQueryGraph, Annotation[] annotations, VirtualDWView virtualDataWindow, EventTableIndexRepository indexRepository, String objectName, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.common
Methods in com.espertech.esper.common.internal.epl.historical.common with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionHistoricalEventViewableFactory.activate
(AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.database.connection
Methods in com.espertech.esper.common.internal.epl.historical.database.connection with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionDatabaseConfigServiceImpl.getDataCache
(String databaseName, AgentInstanceContext agentInstanceContext, int streamNumber, int scheduleCallbackId) DatabaseConfigServiceRuntime.getDataCache
(String databaseName, AgentInstanceContext agentInstanceContext, int streamNumber, int scheduleCallbackId) Returns a new cache implementation for this database. -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.database.core
Methods in com.espertech.esper.common.internal.epl.historical.database.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionHistoricalEventViewableDatabaseFactory.activate
(AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.historical.database.core with parameters of type AgentInstanceContextModifierConstructorDescriptionHistoricalEventViewableDatabase
(HistoricalEventViewableDatabaseFactory factory, PollExecStrategy pollExecStrategy, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.datacache
Methods in com.espertech.esper.common.internal.epl.historical.datacache with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionHistoricalDataCacheFactory.getDataCache
(ConfigurationCommonCache cacheDesc, AgentInstanceContext agentInstanceContext, int streamNum, int scheduleCallbackId) Creates a cache implementation for the strategy as defined by the cache descriptor.protected HistoricalDataCache
HistoricalDataCacheFactory.makeTimeCache
(ConfigurationCommonCacheExpiryTime expCache, AgentInstanceContext agentInstanceContext, int streamNum, int scheduleCallbackId) Constructors in com.espertech.esper.common.internal.epl.historical.datacache with parameters of type AgentInstanceContextModifierConstructorDescriptionHistoricalDataCacheExpiringImpl
(double maxAgeSec, double purgeIntervalSec, CacheReferenceType cacheReferenceType, AgentInstanceContext agentInstanceContext, long scheduleSlot) Ctor. -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.method.core
Methods in com.espertech.esper.common.internal.epl.historical.method.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionHistoricalEventViewableMethodFactory.activate
(AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.historical.method.core with parameters of type AgentInstanceContextModifierConstructorDescriptionHistoricalEventViewableMethod
(HistoricalEventViewableMethodFactory factory, PollExecStrategy pollExecStrategy, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.method.poll
Methods in com.espertech.esper.common.internal.epl.historical.method.poll with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionMethodTargetStrategyFactory.make
(AgentInstanceContext agentInstanceContext) MethodTargetStrategyScript.make
(AgentInstanceContext agentInstanceContext) MethodTargetStrategyStaticMethod.make
(AgentInstanceContext agentInstanceContext) MethodTargetStrategyVariableFactory.make
(AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.index.base
Methods in com.espertech.esper.common.internal.epl.index.base with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic EventTable
EventTableUtil.buildIndex
(AgentInstanceContext agentInstanceContext, int indexedStreamNum, QueryPlanIndexItem item, EventType eventType, boolean unique, String optionalIndexName, DataInputOutputSerde optionalValueSerde, boolean isFireAndForget) Build an index/table instance using the event properties for the event type. -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.join.base
Methods in com.espertech.esper.common.internal.epl.join.base with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionJoinSetComposerPrototype.create
(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) JoinSetComposerPrototypeGeneral.create
(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) JoinSetComposerPrototypeHistorical2Stream.create
(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) Constructors in com.espertech.esper.common.internal.epl.join.base with parameters of type AgentInstanceContextModifierConstructorDescriptionJoinExecStrategyDispatchable
(JoinExecutionStrategy joinExecutionStrategy, int numStreams, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.join.queryplan
Methods in com.espertech.esper.common.internal.epl.join.queryplan with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionHistoricalDataPlanNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) LookupInstructionQueryPlanNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) NestedIterationNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) abstract ExecNode
QueryPlanNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) QueryPlanNodeAllUnidirectionalOuter.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) QueryPlanNodeNoOp.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) TableLookupNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) TableOuterLookupNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) TableLookupPlan.makeStrategy
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] eventTypes, VirtualDWView[] viewExternals) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.join.queryplanouter
Methods in com.espertech.esper.common.internal.epl.join.queryplanouter with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionLookupInstructionPlan.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.lookupplansubord
Methods in com.espertech.esper.common.internal.epl.lookupplansubord with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
EventTableIndexRepository.addExplicitIndex
(String explicitIndexName, String explicitIndexModuleName, QueryPlanIndexItem desc, EventType eventType, Iterable<EventBean> dataWindowContents, AgentInstanceContext agentInstanceContext, DataInputOutputSerde optionalSerde) EventTableIndexRepository.addExplicitIndexOrReuse
(QueryPlanIndexItem desc, Iterable<EventBean> prefilledEvents, EventType indexedType, String indexName, String indexModuleName, AgentInstanceContext agentInstanceContext, DataInputOutputSerde optionalValueSerde) SubordWMatchExprLookupStrategyFactory.realize
(EventTable[] indexes, AgentInstanceContext agentInstanceContext, Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow) static EventTable[]
SubordinateQueryPlannerUtil.realizeTables
(SubordinateQueryIndexDesc[] indexDescriptors, EventType eventType, EventTableIndexRepository indexRepository, Iterable<EventBean> contents, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) void
EventTableIndexRepository.validateAddExplicitIndex
(String explicitIndexName, String explicitIndexModuleName, QueryPlanIndexItem explicitIndexDesc, EventType eventType, Iterable<EventBean> dataWindowContents, AgentInstanceContext agentInstanceContext, boolean allowIndexExists, DataInputOutputSerde optionalValueSerde) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.lookupsubord
Methods in com.espertech.esper.common.internal.epl.lookupsubord with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionSubordWMatchExprLookupStrategyAllFilteredFactory.realize
(EventTable[] indexes, AgentInstanceContext agentInstanceContext, Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow) SubordWMatchExprLookupStrategyAllUnfilteredFactory.realize
(EventTable[] indexes, AgentInstanceContext agentInstanceContext, Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow) SubordWMatchExprLookupStrategyIndexedFilteredFactory.realize
(EventTable[] indexes, AgentInstanceContext agentInstanceContext, Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow) SubordWMatchExprLookupStrategyIndexedUnfilteredFactory.realize
(EventTable[] indexes, AgentInstanceContext agentInstanceContext, Iterable<EventBean> scanIterable, VirtualDWView virtualDataWindow) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.namedwindow.consume
Methods in com.espertech.esper.common.internal.epl.namedwindow.consume that return AgentInstanceContextConstructors in com.espertech.esper.common.internal.epl.namedwindow.consume with parameters of type AgentInstanceContextModifierConstructorDescriptionNamedWindowConsumerDesc
(int namedWindowConsumerId, ExprEvaluator filterEvaluator, PropertyEvaluator optPropertyEvaluator, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.namedwindow.core
Methods in com.espertech.esper.common.internal.epl.namedwindow.core that return AgentInstanceContextModifier and TypeMethodDescriptionNamedWindowRootViewInstance.getAgentInstanceContext()
NamedWindowTailViewInstance.getAgentInstanceContext()
Methods in com.espertech.esper.common.internal.epl.namedwindow.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
NamedWindowTailView.addDispatches
(NamedWindowConsumerLatchFactory latchFactory, Map<EPStatementAgentInstanceHandle, List<NamedWindowConsumerView>> consumersInContext, NamedWindowDeltaData delta, AgentInstanceContext agentInstanceContext) void
NamedWindowTailViewImpl.addDispatches
(NamedWindowConsumerLatchFactory latchFactory, Map<EPStatementAgentInstanceHandle, List<NamedWindowConsumerView>> consumersInContext, NamedWindowDeltaData delta, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.namedwindow.core with parameters of type AgentInstanceContextModifierConstructorDescriptionNamedWindowInstance
(NamedWindow processor, AgentInstanceContext agentInstanceContext) NamedWindowRootViewInstance
(NamedWindowRootView rootView, AgentInstanceContext agentInstanceContext, EventTableIndexMetadata eventTableIndexMetadata) NamedWindowTailViewInstance
(NamedWindowRootViewInstance rootViewInstance, NamedWindowTailView tailView, NamedWindow namedWindow, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.ontrigger
Fields in com.espertech.esper.common.internal.epl.ontrigger declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
OnExprViewNameWindowBase.agentInstanceContext
protected final AgentInstanceContext
OnExprViewTableBase.agentInstanceContext
Methods in com.espertech.esper.common.internal.epl.ontrigger with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionabstract void
InfraOnMergeAction.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, OneEventCollection newData, OneEventCollection oldData, AgentInstanceContext agentInstanceContext) abstract void
InfraOnMergeAction.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, TableInstance tableStateInstance, OnExprViewTableChangeHandler changeHandlerAdded, OnExprViewTableChangeHandler changeHandlerRemoved, AgentInstanceContext agentInstanceContext) void
InfraOnMergeActionDel.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, OneEventCollection newData, OneEventCollection oldData, AgentInstanceContext agentInstanceContext) void
InfraOnMergeActionDel.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, TableInstance tableStateInstance, OnExprViewTableChangeHandler changeHandlerAdded, OnExprViewTableChangeHandler changeHandlerRemoved, AgentInstanceContext agentInstanceContext) void
InfraOnMergeActionIns.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, OneEventCollection newData, OneEventCollection oldData, AgentInstanceContext agentInstanceContext) void
InfraOnMergeActionIns.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, TableInstance tableStateInstance, OnExprViewTableChangeHandler changeHandlerAdded, OnExprViewTableChangeHandler changeHandlerRemoved, AgentInstanceContext agentInstanceContext) void
InfraOnMergeActionUpd.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, OneEventCollection newData, OneEventCollection oldData, AgentInstanceContext agentInstanceContext) void
InfraOnMergeActionUpd.apply
(EventBean matchingEvent, EventBean[] eventsPerStream, TableInstance tableStateInstance, OnExprViewTableChangeHandler changeHandlerAdded, OnExprViewTableChangeHandler changeHandlerRemoved, AgentInstanceContext agentInstanceContext) void
InfraOnMergeMatch.applyNamedWindow
(EventBean matchingEvent, EventBean[] eventsPerStream, OneEventCollection newData, OneEventCollection oldData, AgentInstanceContext agentInstanceContext) void
InfraOnMergeMatch.applyTable
(EventBean matchingEvent, EventBean[] eventsPerStream, TableInstance stateInstance, OnExprViewTableChangeHandler changeHandlerAdded, OnExprViewTableChangeHandler changeHandlerRemoved, AgentInstanceContext agentInstanceContext) static EventBean[]
InfraOnSelectUtil.handleDistintAndInsert
(EventBean[] newData, InfraOnSelectViewFactory parent, AgentInstanceContext agentInstanceContext, TableInstance tableInstanceInsertInto, boolean audit, ExprEvaluator eventPrecedence) InfraOnDeleteViewFactory.makeNamedWindow
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext) InfraOnMergeViewFactory.makeNamedWindow
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext) InfraOnSelectViewFactory.makeNamedWindow
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext) InfraOnUpdateViewFactory.makeNamedWindow
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance namedWindowRootViewInstance, AgentInstanceContext agentInstanceContext) InfraOnDeleteViewFactory.makeTable
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext) InfraOnMergeViewFactory.makeTable
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext) InfraOnSelectViewFactory.makeTable
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext) InfraOnUpdateViewFactory.makeTable
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.ontrigger with parameters of type AgentInstanceContextModifierConstructorDescriptionOnExprViewNamedWindowDelete
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance rootView, AgentInstanceContext agentInstanceContext) OnExprViewNamedWindowMerge
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance rootView, AgentInstanceContext agentInstanceContext, InfraOnMergeViewFactory parent) OnExprViewNamedWindowMergeInsertUnmatched
(NamedWindowRootViewInstance rootView, AgentInstanceContext agentInstanceContext, InfraOnMergeViewFactory factory) Ctor.OnExprViewNamedWindowSelect
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance rootView, AgentInstanceContext agentInstanceContext, InfraOnSelectViewFactory parent, ResultSetProcessor resultSetProcessor, boolean audit, boolean isDelete, TableInstance tableInstanceInsertInto, ExprEvaluator eventPrecedence) OnExprViewNamedWindowUpdate
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance rootView, AgentInstanceContext agentInstanceContext, InfraOnUpdateViewFactory parent) OnExprViewNameWindowBase
(SubordWMatchExprLookupStrategy lookupStrategy, NamedWindowRootViewInstance rootView, AgentInstanceContext agentInstanceContext) Ctor.protected
OnExprViewTableBase
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext, boolean acquireWriteLock) OnExprViewTableDelete
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance rootView, AgentInstanceContext agentInstanceContext) OnExprViewTableMerge
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext, InfraOnMergeViewFactory parent) OnExprViewTableMergeInsertUnmatched
(TableInstance tableInstance, AgentInstanceContext agentInstanceContext, InfraOnMergeViewFactory parent) OnExprViewTableSelect
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor, InfraOnSelectViewFactory parent, boolean audit, boolean deleteAndSelect, TableInstance tableInstanceInsertInto, ExprEvaluator eventPrecedence) OnExprViewTableUpdate
(SubordWMatchExprLookupStrategy lookupStrategy, TableInstance tableInstance, AgentInstanceContext agentInstanceContext, InfraOnUpdateViewFactory parent) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.output.condition
Methods in com.espertech.esper.common.internal.epl.output.condition with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionOutputConditionCountFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) OutputConditionCrontabFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) OutputConditionExpressionFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) OutputConditionFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) OutputConditionNullFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) OutputConditionTermFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) OutputConditionTimeFactory.instantiateOutputCondition
(AgentInstanceContext agentInstanceContext, OutputCallback outputCallback) Constructors in com.espertech.esper.common.internal.epl.output.condition with parameters of type AgentInstanceContextModifierConstructorDescriptionOutputConditionCrontab
(OutputCallback outputCallback, AgentInstanceContext context, boolean isStartConditionOnCreation, ScheduleSpec scheduleSpec) OutputConditionExpression
(OutputCallback outputCallback, AgentInstanceContext agentInstanceContext, OutputConditionExpressionFactory parent) OutputConditionTime
(OutputCallback outputCallback, AgentInstanceContext context, OutputConditionTimeFactory outputConditionTimeFactory, boolean isStartConditionOnCreation) OutputProcessViewConditionDefaultPostProcess
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor, EventType[] eventTypes, StateMgmtSetting stateMgmtSettings) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.output.core
Methods in com.espertech.esper.common.internal.epl.output.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionOutputProcessViewDirectSimpleFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.output.core with parameters of type AgentInstanceContextModifierConstructorDescriptionOutputProcessViewConditionLastAllUnordPostProcessAll
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor) OutputProcessViewConditionSnapshot
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext) OutputProcessViewDirectSimpleImpl
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewSimple
(AgentInstanceContext agentInstanceContext) OutputProcessViewSimpleWProcessor
(AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.output.view
Fields in com.espertech.esper.common.internal.epl.output.view declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
OutputProcessViewBaseWAfter.agentInstanceContext
Methods in com.espertech.esper.common.internal.epl.output.view with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionOutputStrategyPostProcessFactory.make
(AgentInstanceContext agentInstanceContext) OutputProcessViewConditionFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewDirectDistinctOrAfterFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewDirectFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.output.view with parameters of type AgentInstanceContextModifierConstructorDescriptionprotected
OutputProcessViewBaseWAfter
(AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied) OutputProcessViewConditionDefault
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, EventType[] eventTypes, StateMgmtSetting stateMgmtSettings) OutputProcessViewConditionFirst
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, StateMgmtSetting stateMgmtSetting) OutputProcessViewConditionFirstPostProcess
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor, StateMgmtSetting stateMgmtSetting) OutputProcessViewConditionLastAllUnord
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext) OutputProcessViewConditionSnapshotPostProcess
(ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewConditionFactory parent, AgentInstanceContext agentInstanceContext, OutputStrategyPostProcess postProcessor) OutputProcessViewDirect
(AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor) OutputProcessViewDirectDistinctOrAfter
(AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewDirectDistinctOrAfterFactory parent) OutputProcessViewDirectDistinctOrAfterPostProcess
(AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor, Long afterConditionTime, Integer afterConditionNumberOfEvents, boolean afterConditionSatisfied, OutputProcessViewDirectDistinctOrAfterFactory parent, OutputStrategyPostProcess postProcessor) OutputProcessViewDirectPostProcess
(AgentInstanceContext agentInstanceContext, ResultSetProcessor resultSetProcessor, OutputStrategyPostProcess postProcessor) OutputStrategyPostProcess
(OutputStrategyPostProcessFactory parent, AgentInstanceContext agentInstanceContext, TableInstance tableInstance) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.pattern.core
Fields in com.espertech.esper.common.internal.epl.pattern.core declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
EvalRootNode.agentInstanceContext
protected final AgentInstanceContext
PatternAgentInstanceContext.agentInstanceContext
Methods in com.espertech.esper.common.internal.epl.pattern.core that return AgentInstanceContextModifier and TypeMethodDescriptionEvalRootNode.getAgentInstanceContext()
PatternAgentInstanceContext.getAgentInstanceContext()
Methods in com.espertech.esper.common.internal.epl.pattern.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic Object
PatternExpressionUtil.getKeys
(MatchedEventMap matchEvent, MatchedEventConvertor convertor, ExprEvaluator expression, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.pattern.core with parameters of type AgentInstanceContextModifierConstructorDescriptionPatternAgentInstanceContext
(PatternContext patternContext, AgentInstanceContext agentInstanceContext, boolean hasConsumingFilter, Function<FilterSpecActivatable, FilterValueSetParam[][]> contextAddendumFunction) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.pattern.pool
Methods in com.espertech.esper.common.internal.epl.pattern.pool with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
PatternSubexpressionPoolRuntimeSvc.decreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) void
PatternSubexpressionPoolRuntimeSvcImpl.decreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) void
PatternSubexpressionPoolRuntimeSvcNoOp.decreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) void
PatternSubexpressionPoolRuntimeSvc.forceIncreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) void
PatternSubexpressionPoolRuntimeSvcImpl.forceIncreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) void
PatternSubexpressionPoolRuntimeSvcNoOp.forceIncreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) boolean
PatternSubexpressionPoolRuntimeSvc.tryIncreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) boolean
PatternSubexpressionPoolRuntimeSvcImpl.tryIncreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) boolean
PatternSubexpressionPoolRuntimeSvcNoOp.tryIncreaseCount
(EvalNode evalNode, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.resultset.core
Methods in com.espertech.esper.common.internal.epl.resultset.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic EventBean[]
ResultSetProcessorUtil.outputFromCountMaySort
(int count, EventBean[] events, Object[] keys, EventBean[][] currentGenerators, boolean isNewData, OrderByProcessor orderByProcessor, AgentInstanceContext agentInstanceContext, AggregationService aggregationService) NOTE: Code-generation-invoked method, method name and parameter order matters -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.rowrecog.core
Fields in com.espertech.esper.common.internal.epl.rowrecog.core declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
RowRecogNFAView.agentInstanceContext
Methods in com.espertech.esper.common.internal.epl.rowrecog.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
RowRecogNFAViewScheduler.setScheduleCallback
(AgentInstanceContext agentInstanceContext, RowRecogNFAViewScheduleCallback scheduleCallback) void
RowRecogNFAViewSchedulerImpl.setScheduleCallback
(AgentInstanceContext agentInstanceContext, RowRecogNFAViewScheduleCallback scheduleCallback) Constructors in com.espertech.esper.common.internal.epl.rowrecog.core with parameters of type AgentInstanceContextModifierConstructorDescriptionRowRecogNFAView
(RowRecogNFAViewFactory factory, AgentInstanceContext agentInstanceContext, RowRecogNFAViewScheduler scheduler) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.rowrecog.nfa
Methods in com.espertech.esper.common.internal.epl.rowrecog.nfa with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionboolean
RowRecogNFAState.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) Evaluate a match.boolean
RowRecogNFAStateAnyOneEval.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateEndEval.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateFilterEval.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateOneOptionalEvalCond.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateOneOptionalEvalNoCond.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateOneToManyEvalCond.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateOneToManyEvalNoCond.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateZeroToManyEvalCond.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) boolean
RowRecogNFAStateZeroToManyEvalNoCond.matches
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.rowrecog.state
Methods in com.espertech.esper.common.internal.epl.rowrecog.state that return AgentInstanceContextMethods in com.espertech.esper.common.internal.epl.rowrecog.state with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
RowRecogStatePoolRuntimeSvc.decreaseCount
(AgentInstanceContext agentInstanceContext) void
RowRecogStatePoolRuntimeSvc.decreaseCount
(AgentInstanceContext agentInstanceContext, int numRemoved) RowRecogStateRepoFactory.makePartitioned
(RowRecogPreviousStrategyImpl prevGetter, RowRecogPartitionStateRepoGroupMeta stateRepoGroupMeta, AgentInstanceContext agentInstanceContext, RowRecogNFAView view, boolean keepScheduleState, RowRecogPartitionTerminationStateComparator terminationStateCompare, StateMgmtSetting partitionMgmtStateMgmtSettings, StateMgmtSetting scheduleMgmtStateMgmtSettings) RowRecogStateRepoFactoryDefault.makePartitioned
(RowRecogPreviousStrategyImpl prevGetter, RowRecogPartitionStateRepoGroupMeta stateRepoGroupMeta, AgentInstanceContext agentInstanceContext, RowRecogNFAView view, boolean keepScheduleState, RowRecogPartitionTerminationStateComparator terminationStateCompare, StateMgmtSetting partitionMgmtStateMgmtSettings, StateMgmtSetting scheduleMgmtStateMgmtSettings) RowRecogStateRepoFactory.makeSingle
(RowRecogPreviousStrategyImpl prevGetter, AgentInstanceContext agentInstanceContext, RowRecogNFAView view, boolean keepScheduleState, RowRecogPartitionTerminationStateComparator terminationStateCompare, StateMgmtSetting unpartitionedStateMgmtSettings, StateMgmtSetting scheduleMgmtStateMgmtSettings) RowRecogStateRepoFactoryDefault.makeSingle
(RowRecogPreviousStrategyImpl prevGetter, AgentInstanceContext agentInstanceContext, RowRecogNFAView view, boolean keepScheduleState, RowRecogPartitionTerminationStateComparator terminationStateCompare, StateMgmtSetting unpartitionedStateMgmtSettings, StateMgmtSetting scheduleMgmtStateMgmtSettings) boolean
RowRecogStatePoolRuntimeSvc.tryIncreaseCount
(AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.rowrecog.state with parameters of type AgentInstanceContextModifierConstructorDescriptionRowRecogPartitionStateRepoGroupMeta
(boolean hasInterval, ExprEvaluator partitionExpression, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.subselect
Methods in com.espertech.esper.common.internal.epl.subselect with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic Map<Integer,
SubSelectFactoryResult> SubSelectHelperStart.startSubselects
(Map<Integer, SubSelectFactory> subselects, ExprEvaluatorContext exprEvaluatorContext, AgentInstanceContext agentInstanceContextOpt, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringResilient) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.table.core
Fields in com.espertech.esper.common.internal.epl.table.core declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
TableInstanceBase.agentInstanceContext
Methods in com.espertech.esper.common.internal.epl.table.core that return AgentInstanceContextModifier and TypeMethodDescriptionTableInstance.getAgentInstanceContext()
TableInstanceBase.getAgentInstanceContext()
Methods in com.espertech.esper.common.internal.epl.table.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionTableManagementService.allocateTableInstance
(Table table, AgentInstanceContext agentInstanceContext) TableManagementServiceImpl.allocateTableInstance
(Table table, AgentInstanceContext agentInstanceContext) Constructors in com.espertech.esper.common.internal.epl.table.core with parameters of type AgentInstanceContextModifierConstructorDescriptionTableInstanceBase
(Table table, AgentInstanceContext agentInstanceContext) TableInstanceGroupedBase
(Table table, AgentInstanceContext agentInstanceContext) TableInstanceGroupedImpl
(Table table, AgentInstanceContext agentInstanceContext) TableInstanceUngroupedBase
(Table table, AgentInstanceContext agentInstanceContext) TableInstanceUngroupedImpl
(Table table, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.virtualdw
Methods in com.espertech.esper.common.internal.epl.virtualdw with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionVirtualDWView.getJoinLookupStrategy
(TableLookupPlan tableLookupPlan, AgentInstanceContext agentInstanceContext, EventTable[] eventTables, int lookupStream) VirtualDWViewImpl.getJoinLookupStrategy
(TableLookupPlan tableLookupPlan, AgentInstanceContext agentInstanceContext, EventTable[] eventTables, int lookupStream) Constructors in com.espertech.esper.common.internal.epl.virtualdw with parameters of type AgentInstanceContextModifierConstructorDescriptionVirtualDWViewImpl
(VirtualDWViewFactory factory, AgentInstanceContext agentInstanceContext, VirtualDataWindow dataExternal) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.metrics.audit
Methods in com.espertech.esper.common.internal.metrics.audit with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic void
AuditPath.auditContextPartition
(boolean allocate, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditDataflowOp
(String dataflowName, String dataFlowInstanceId, String operatorName, int operatorNumber, Object[] params, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditDataflowSource
(String dataflowName, String dataFlowInstanceId, String operatorName, int operatorNumber, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditDataflowTransition
(String dataflowName, String dataFlowInstanceId, EPDataFlowState state, EPDataFlowState newState, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditPatternFalse
(EvalFactoryNode factoryNode, Object from, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditPatternInstance
(boolean increase, EvalFactoryNode factoryNode, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditPatternTrue
(EvalFactoryNode factoryNode, Object from, MatchedEventMapMinimal matchEvent, boolean isQuitted, AgentInstanceContext agentInstanceContext) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditScheduleAdd
(long nextScheduledTime, AgentInstanceContext agentInstanceContext, ScheduleHandle scheduleHandle, ScheduleObjectType objectType, String name) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditScheduleFire
(AgentInstanceContext agentInstanceContext, ScheduleObjectType objectType, String name) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic void
AuditPath.auditScheduleRemove
(AgentInstanceContext agentInstanceContext, ScheduleHandle scheduleHandle, ScheduleObjectType objectType, String name) NOTE: Code-generation-invoked method, method name and parameter order mattersvoid
AuditProviderContextPartition.contextPartition
(boolean allocate, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.contextPartition
(boolean allocate, AgentInstanceContext agentInstanceContext) void
AuditProviderDataflowOp.dataflowOp
(String dataFlowName, String instanceId, String operatorName, int operatorNumber, Object[] parameters, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.dataflowOp
(String dataFlowName, String instanceId, String operatorName, int operatorNumber, Object[] parameters, AgentInstanceContext agentInstanceContext) void
AuditProviderDataflowSource.dataflowSource
(String dataFlowName, String dataFlowInstanceId, String operatorName, int operatorNumber, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.dataflowSource
(String dataFlowName, String dataFlowInstanceId, String operatorName, int operatorNumber, AgentInstanceContext agentInstanceContext) void
AuditProviderDataflowTransition.dataflowTransition
(String dataflowName, String dataFlowInstanceId, EPDataFlowState state, EPDataFlowState newState, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.dataflowTransition
(String dataflowName, String dataFlowInstanceId, EPDataFlowState state, EPDataFlowState newState, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.patternFalse
(EvalFactoryNode factoryNode, Object from, AgentInstanceContext agentInstanceContext) void
AuditProviderPattern.patternFalse
(EvalFactoryNode factoryNode, Object from, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.patternInstance
(boolean increase, EvalFactoryNode factoryNode, AgentInstanceContext agentInstanceContext) void
AuditProviderPatternInstances.patternInstance
(boolean increase, EvalFactoryNode factoryNode, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.patternTrue
(EvalFactoryNode factoryNode, Object from, MatchedEventMapMinimal matchEvent, boolean isQuitted, AgentInstanceContext agentInstanceContext) void
AuditProviderPattern.patternTrue
(EvalFactoryNode factoryNode, Object from, MatchedEventMapMinimal matchEvent, boolean isQuitted, AgentInstanceContext agentInstanceContext) void
AuditProviderDefault.scheduleAdd
(long nextScheduledTime, AgentInstanceContext agentInstanceContext, ScheduleHandle scheduleHandle, ScheduleObjectType type, String name) void
AuditProviderSchedule.scheduleAdd
(long nextScheduledTime, AgentInstanceContext agentInstanceContext, ScheduleHandle scheduleHandle, ScheduleObjectType objectType, String name) void
AuditProviderDefault.scheduleFire
(AgentInstanceContext agentInstanceContext, ScheduleObjectType type, String name) void
AuditProviderSchedule.scheduleFire
(AgentInstanceContext agentInstanceContext, ScheduleObjectType objectType, String name) void
AuditProviderDefault.scheduleRemove
(AgentInstanceContext agentInstanceContext, ScheduleHandle scheduleHandle, ScheduleObjectType type, String name) void
AuditProviderSchedule.scheduleRemove
(AgentInstanceContext agentInstanceContext, ScheduleHandle scheduleHandle, ScheduleObjectType objectType, String name) void
AuditProviderDefault.view
(EventBean[] newData, EventBean[] oldData, AgentInstanceContext agentInstanceContext, ViewFactory viewFactory) void
AuditProviderView.view
(EventBean[] newData, EventBean[] oldData, AgentInstanceContext agentInstanceContext, ViewFactory viewFactory) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.metrics.instrumentation
Methods in com.espertech.esper.common.internal.metrics.instrumentation with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionvoid
InstrumentationCommon.aFilterActivationStream
(AgentInstanceContext agentInstanceContext, boolean subselect, int subselectNumber) void
InstrumentationCommonDefault.aFilterActivationStream
(AgentInstanceContext agentInstanceContext, boolean subselect, int subselectNumber) void
InstrumentationCommon.qContextPartitionAllocate
(AgentInstanceContext agentInstanceContext) void
InstrumentationCommonDefault.qContextPartitionAllocate
(AgentInstanceContext agentInstanceContext) void
InstrumentationCommon.qContextPartitionDestroy
(AgentInstanceContext agentInstanceContext) void
InstrumentationCommonDefault.qContextPartitionDestroy
(AgentInstanceContext agentInstanceContext) void
InstrumentationCommon.qFilterActivationStream
(String eventTypeName, int streamNumber, AgentInstanceContext agentInstanceContext, boolean subselect, int subselectNumber) void
InstrumentationCommonDefault.qFilterActivationStream
(String eventTypeName, int streamNumber, AgentInstanceContext agentInstanceContext, boolean subselect, int subselectNumber) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.statement.resource
Methods in com.espertech.esper.common.internal.statement.resource that return AgentInstanceContextMethods in com.espertech.esper.common.internal.statement.resource with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionStatementResourceHolderBuilder.build
(AgentInstanceContext agentInstanceContext, StatementAgentInstanceFactoryResult resultOfStart) StatementResourceHolderBuilderImpl.build
(AgentInstanceContext agentInstanceContext, StatementAgentInstanceFactoryResult resultOfStart) static StatementResourceHolder
StatementResourceHolderUtil.populateHolder
(AgentInstanceContext agentInstanceContext, StatementAgentInstanceFactoryResult startResult) Constructors in com.espertech.esper.common.internal.statement.resource with parameters of type AgentInstanceContextModifierConstructorDescriptionStatementResourceHolder
(AgentInstanceContext agentInstanceContext, AgentInstanceMgmtCallback agentInstanceStopCallback, Viewable finalView, AggregationService aggregationService, PriorEvalStrategy[] priorEvalStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy rowRecogPreviousStrategy) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.core
Methods in com.espertech.esper.common.internal.view.core that return AgentInstanceContextMethods in com.espertech.esper.common.internal.view.core with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionAgentInstanceViewFactoryChainContext.create
(ViewFactory[] viewFactoryChain, AgentInstanceContext agentInstanceContext, ViewResourceDelegateDesc viewResourceDelegate) static int
ViewFactoryUtil.evaluateSizeParam
(String viewName, ExprEvaluator sizeEvaluator, AgentInstanceContext context) Constructors in com.espertech.esper.common.internal.view.core with parameters of type AgentInstanceContextModifierConstructorDescriptionAgentInstanceViewFactoryChainContext
(AgentInstanceContext agentInstanceContext, boolean isRemoveStream, PreviousGetterStrategy previousNodeGetter, StateMgmtSetting previousStateSettings, ViewUpdatedCollection priorViewUpdatedCollection) ZeroDepthStreamIterableWAudit
(EventType eventType, AgentInstanceContext agentInstanceContext, FilterSpecActivatable filterSpec, int streamNumber, boolean subselect, int subselectNumber) ZeroDepthStreamNoIterateWAudit
(EventType eventType, AgentInstanceContext agentInstanceContext, FilterSpecActivatable filterSpec, int streamNumber, boolean subselect, int subselectNumber) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.derived
Fields in com.espertech.esper.common.internal.view.derived declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
BaseBivariateStatisticsView.agentInstanceContext
Services required by implementing classes.protected final AgentInstanceContext
UnivariateStatisticsView.agentInstanceContext
Constructors in com.espertech.esper.common.internal.view.derived with parameters of type AgentInstanceContextModifierConstructorDescriptionBaseBivariateStatisticsView
(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprEvaluator expressionXEval, ExprEvaluator expressionYEval, EventType eventType, StatViewAdditionalPropsEval additionalProps) Constructor requires the name of the two fields to use in the parent view to compute the statistics.CorrelationView
(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprEvaluator xExpressionEval, ExprEvaluator yExpressionEval, EventType eventType, StatViewAdditionalPropsEval additionalProps) RegressionLinestView
(ViewFactory viewFactory, AgentInstanceContext agentInstanceContext, ExprEvaluator xEval, ExprEvaluator yEval, EventType eventType, StatViewAdditionalPropsEval additionalProps) SizeView
(SizeViewFactory sizeViewFactory, AgentInstanceContext agentInstanceContext, EventType eventType, StatViewAdditionalPropsEval additionalProps) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.expression
Fields in com.espertech.esper.common.internal.view.expression declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
ExpressionViewBase.agentInstanceContext
Methods in com.espertech.esper.common.internal.view.expression with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionstatic boolean
ExpressionBatchViewUtil.evaluate
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext, ExpressionViewFactoryBase factory, AggregationService aggregationService) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.exttimedbatch
Fields in com.espertech.esper.common.internal.view.exttimedbatch declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected AgentInstanceContext
ExternallyTimedBatchView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.firstevent
Constructors in com.espertech.esper.common.internal.view.firstevent with parameters of type AgentInstanceContextModifierConstructorDescriptionFirstEventView
(FirstEventViewFactory viewFactory, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.firstlength
Fields in com.espertech.esper.common.internal.view.firstlength declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
FirstLengthWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.firstunique
Fields in com.espertech.esper.common.internal.view.firstunique declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
FirstUniqueByPropertyView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.intersect
Fields in com.espertech.esper.common.internal.view.intersect declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
IntersectAsymetricView.agentInstanceContext
protected final AgentInstanceContext
IntersectBatchView.agentInstanceContext
protected final AgentInstanceContext
IntersectDefaultView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.keepall
Fields in com.espertech.esper.common.internal.view.keepall declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
KeepAllView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.lastevent
Constructors in com.espertech.esper.common.internal.view.lastevent with parameters of type AgentInstanceContextModifierConstructorDescriptionLastEventView
(LastEventViewFactory viewFactory, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.length
Fields in com.espertech.esper.common.internal.view.length declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
LengthWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.lengthbatch
Fields in com.espertech.esper.common.internal.view.lengthbatch declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
LengthBatchView.agentInstanceContext
protected final AgentInstanceContext
LengthBatchViewRStream.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.prior
Methods in com.espertech.esper.common.internal.view.prior with parameters of type AgentInstanceContextModifier and TypeMethodDescriptionPriorEventViewFactory.makeViewUpdatedCollection
(SortedSet<Integer> priorRequests, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.rank
Fields in com.espertech.esper.common.internal.view.rank declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
RankWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.sort
Fields in com.espertech.esper.common.internal.view.sort declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
SortWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.union
Fields in com.espertech.esper.common.internal.view.union declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
UnionAsymetricView.agentInstanceContext
protected final AgentInstanceContext
UnionView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.unique
Fields in com.espertech.esper.common.internal.view.unique declared as AgentInstanceContextModifier and TypeFieldDescriptionprotected final AgentInstanceContext
UniqueByPropertyView.agentInstanceContext