Uses of Class
com.espertech.esper.common.internal.context.util.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
Modifier and TypeMethodDescriptionVirtualDataWindowContext.getAgentInstanceContext()
Returns the agent instance (context partition) context. -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.activator
Modifier 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
Modifier and TypeMethodDescriptionStatementAgentInstanceFactory.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionprotected
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
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateClass.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateClassResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createcontext
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateContext.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateContextResult
(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
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateDataflow.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateDataflowResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, DataflowDesc dataflow) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createexpression
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateExpression.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateExpressionResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createindex
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateIndex.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateIndexResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createschema
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateSchema.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateSchemaResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createtable
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateTable.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateTableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, TableInstance tableInstance) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createvariable
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateVariable.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateVariableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.createwindow
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateNW.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateNWResult
(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
Modifier 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) ModifierConstructorDescriptionStatementAgentInstanceFactoryOnTriggerResult
(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
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryOnTriggerSet.determineFinalOutputView
(AgentInstanceContext agentInstanceContext, View onExprView) StatementAgentInstanceFactoryOnTriggerSet.determineOnExprView
(AgentInstanceContext agentInstanceContext, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringReslient) ModifierConstructorDescriptionOnSetVariableView
(StatementAgentInstanceFactoryOnTriggerSet factory, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
RouteResultViewHandlerBase.agentInstanceContext
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryOnTriggerSplitStream.determineFinalOutputView
(AgentInstanceContext agentInstanceContext, View onExprView) StatementAgentInstanceFactoryOnTriggerSplitStream.determineOnExprView
(AgentInstanceContext agentInstanceContext, List<AgentInstanceMgmtCallback> stopCallbacks, boolean isRecoveringReslient) ModifierConstructorDescriptionRouteResultView
(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
Modifier 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
Modifier and TypeMethodDescriptionStatementAgentInstanceFactorySelect.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactorySelectResult
(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
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryUpdate.newContext
(AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionStatementAgentInstanceFactoryUpdateResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Map<Integer, SubSelectFactoryResult> subselectActivations) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.controller.category
Modifier 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
Modifier 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
Modifier 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
Modifier 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
Modifier 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
Modifier 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) ModifierConstructorDescriptionContextManagerRealization
(ContextManagerResident contextManager, AgentInstanceContext agentInstanceContextCreate) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.context.util
Modifier and TypeMethodDescriptionAgentInstance.getAgentInstanceContext()
AgentInstanceStopServices.getAgentInstanceContext()
AgentInstanceTransferServices.getAgentInstanceContext()
StatementContext.makeAgentInstanceContextUnpartitioned()
Modifier 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) ModifierConstructorDescriptionAgentInstance
(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
ModifierConstructorDescriptionEPDataFlowInstanceImpl
(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
Modifier 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
ModifierConstructorDescriptionDataFlowOpInitializeContext
(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
Modifier and TypeMethodDescriptionstatic OperatorStatisticsProvider
DataflowInstantiatorHelper.realize
(DataflowDesc dataflow, Map<Integer, Object> operators, List<LogicalChannelBinding> bindings, DataFlowSignalManager dataFlowSignalManager, EPDataFlowInstantiationOptions options, AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionEPDataFlowEmitterExceptionHandler
(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
ModifierConstructorDescriptionGraphSourceRunnable
(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
Modifier and TypeMethodDescriptionabstract AgentInstanceContext
FireAndForgetInstance.getAgentInstanceContext()
FireAndForgetInstanceNamedWindow.getAgentInstanceContext()
FireAndForgetInstanceTable.getAgentInstanceContext()
Modifier 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
Modifier and TypeMethodDescriptionHistoricalEventViewableFactory.activate
(AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.database.connection
Modifier 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
Modifier and TypeMethodDescriptionHistoricalEventViewableDatabaseFactory.activate
(AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionHistoricalEventViewableDatabase
(HistoricalEventViewableDatabaseFactory factory, PollExecStrategy pollExecStrategy, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.datacache
Modifier 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) ModifierConstructorDescriptionHistoricalDataCacheExpiringImpl
(double maxAgeSec, double purgeIntervalSec, CacheReferenceType cacheReferenceType, AgentInstanceContext agentInstanceContext, long scheduleSlot) Ctor. -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.method.core
Modifier and TypeMethodDescriptionHistoricalEventViewableMethodFactory.activate
(AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionHistoricalEventViewableMethod
(HistoricalEventViewableMethodFactory factory, PollExecStrategy pollExecStrategy, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.historical.method.poll
Modifier 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
Modifier 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
Modifier 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) ModifierConstructorDescriptionJoinExecStrategyDispatchable
(JoinExecutionStrategy joinExecutionStrategy, int numStreams, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.join.queryplan
Modifier 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
Modifier 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
Modifier 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
Modifier 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
ModifierConstructorDescriptionNamedWindowConsumerDesc
(int namedWindowConsumerId, ExprEvaluator filterEvaluator, PropertyEvaluator optPropertyEvaluator, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.namedwindow.core
Modifier and TypeMethodDescriptionNamedWindowRootViewInstance.getAgentInstanceContext()
NamedWindowTailViewInstance.getAgentInstanceContext()
Modifier 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) ModifierConstructorDescriptionNamedWindowInstance
(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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
OnExprViewNameWindowBase.agentInstanceContext
protected final AgentInstanceContext
OnExprViewTableBase.agentInstanceContext
Modifier 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) ModifierConstructorDescriptionOnExprViewNamedWindowDelete
(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
Modifier 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) ModifierConstructorDescriptionOutputConditionCrontab
(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
Modifier and TypeMethodDescriptionOutputProcessViewDirectSimpleFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionOutputProcessViewConditionLastAllUnordPostProcessAll
(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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
OutputProcessViewBaseWAfter.agentInstanceContext
Modifier and TypeMethodDescriptionOutputStrategyPostProcessFactory.make
(AgentInstanceContext agentInstanceContext) OutputProcessViewConditionFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewDirectDistinctOrAfterFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) OutputProcessViewDirectFactory.makeView
(ResultSetProcessor resultSetProcessor, AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionprotected
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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
EvalRootNode.agentInstanceContext
protected final AgentInstanceContext
PatternAgentInstanceContext.agentInstanceContext
Modifier and TypeMethodDescriptionEvalRootNode.getAgentInstanceContext()
PatternAgentInstanceContext.getAgentInstanceContext()
Modifier and TypeMethodDescriptionstatic Object
PatternExpressionUtil.getKeys
(MatchedEventMap matchEvent, MatchedEventConvertor convertor, ExprEvaluator expression, AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionPatternAgentInstanceContext
(PatternContext patternContext, AgentInstanceContext agentInstanceContext, boolean hasConsumingFilter, Function<FilterSpecActivatable, FilterValueSetParam[][]> contextAddendumFunction) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.pattern.pool
Modifier 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
Modifier 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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
RowRecogNFAView.agentInstanceContext
Modifier and TypeMethodDescriptionvoid
RowRecogNFAViewScheduler.setScheduleCallback
(AgentInstanceContext agentInstanceContext, RowRecogNFAViewScheduleCallback scheduleCallback) void
RowRecogNFAViewSchedulerImpl.setScheduleCallback
(AgentInstanceContext agentInstanceContext, RowRecogNFAViewScheduleCallback scheduleCallback) ModifierConstructorDescriptionRowRecogNFAView
(RowRecogNFAViewFactory factory, AgentInstanceContext agentInstanceContext, RowRecogNFAViewScheduler scheduler) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.rowrecog.nfa
Modifier 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
Modifier 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) ModifierConstructorDescriptionRowRecogPartitionStateRepoGroupMeta
(boolean hasInterval, ExprEvaluator partitionExpression, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.epl.subselect
Modifier 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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
TableInstanceBase.agentInstanceContext
Modifier and TypeMethodDescriptionTableInstance.getAgentInstanceContext()
TableInstanceBase.getAgentInstanceContext()
Modifier and TypeMethodDescriptionTableManagementService.allocateTableInstance
(Table table, AgentInstanceContext agentInstanceContext) TableManagementServiceImpl.allocateTableInstance
(Table table, AgentInstanceContext agentInstanceContext) ModifierConstructorDescriptionTableInstanceBase
(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
Modifier and TypeMethodDescriptionVirtualDWView.getJoinLookupStrategy
(TableLookupPlan tableLookupPlan, AgentInstanceContext agentInstanceContext, EventTable[] eventTables, int lookupStream) VirtualDWViewImpl.getJoinLookupStrategy
(TableLookupPlan tableLookupPlan, AgentInstanceContext agentInstanceContext, EventTable[] eventTables, int lookupStream) ModifierConstructorDescriptionVirtualDWViewImpl
(VirtualDWViewFactory factory, AgentInstanceContext agentInstanceContext, VirtualDataWindow dataExternal) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.metrics.audit
Modifier 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
Modifier 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
Modifier and TypeMethodDescriptionStatementResourceHolderBuilder.build
(AgentInstanceContext agentInstanceContext, StatementAgentInstanceFactoryResult resultOfStart) StatementResourceHolderBuilderImpl.build
(AgentInstanceContext agentInstanceContext, StatementAgentInstanceFactoryResult resultOfStart) static StatementResourceHolder
StatementResourceHolderUtil.populateHolder
(AgentInstanceContext agentInstanceContext, StatementAgentInstanceFactoryResult startResult) ModifierConstructorDescriptionStatementResourceHolder
(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
Modifier and TypeMethodDescriptionAgentInstanceViewFactoryChainContext.create
(ViewFactory[] viewFactoryChain, AgentInstanceContext agentInstanceContext, ViewResourceDelegateDesc viewResourceDelegate) static int
ViewFactoryUtil.evaluateSizeParam
(String viewName, ExprEvaluator sizeEvaluator, AgentInstanceContext context) ModifierConstructorDescriptionAgentInstanceViewFactoryChainContext
(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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
BaseBivariateStatisticsView.agentInstanceContext
Services required by implementing classes.protected final AgentInstanceContext
UnivariateStatisticsView.agentInstanceContext
ModifierConstructorDescriptionBaseBivariateStatisticsView
(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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
ExpressionViewBase.agentInstanceContext
Modifier and TypeMethodDescriptionstatic boolean
ExpressionBatchViewUtil.evaluate
(EventBean[] eventsPerStream, AgentInstanceContext agentInstanceContext, ExpressionViewFactoryBase factory, AggregationService aggregationService) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.exttimedbatch
Modifier and TypeFieldDescriptionprotected AgentInstanceContext
ExternallyTimedBatchView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.firstevent
ModifierConstructorDescriptionFirstEventView
(FirstEventViewFactory viewFactory, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.firstlength
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
FirstLengthWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.firstunique
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
FirstUniqueByPropertyView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.intersect
Modifier 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
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
KeepAllView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.lastevent
ModifierConstructorDescriptionLastEventView
(LastEventViewFactory viewFactory, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.length
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
LengthWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.lengthbatch
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
LengthBatchView.agentInstanceContext
protected final AgentInstanceContext
LengthBatchViewRStream.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.prior
Modifier and TypeMethodDescriptionPriorEventViewFactory.makeViewUpdatedCollection
(SortedSet<Integer> priorRequests, AgentInstanceContext agentInstanceContext) -
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.rank
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
RankWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.sort
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
SortWindowView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.union
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
UnionAsymetricView.agentInstanceContext
protected final AgentInstanceContext
UnionView.agentInstanceContext
-
Uses of AgentInstanceContext in com.espertech.esper.common.internal.view.unique
Modifier and TypeFieldDescriptionprotected final AgentInstanceContext
UniqueByPropertyView.agentInstanceContext