Package | Description |
---|---|
com.espertech.esper.client.hook |
Callback interfaces for use with statement annotations.
|
com.espertech.esper.core.context.activator |
Activation of streams for statement start.
|
com.espertech.esper.core.context.factory |
Statement agent instance factories.
|
com.espertech.esper.core.context.mgr |
Context management.
|
com.espertech.esper.core.context.subselect |
Subselect implementation.
|
com.espertech.esper.core.context.util |
Context partition utility or reference classes.
|
com.espertech.esper.core.start |
Classes related to start and stop of statements
|
com.espertech.esper.dataflow.core |
Data flow core classes.
|
com.espertech.esper.dataflow.interfaces |
Data flow operator and related interface.
|
com.espertech.esper.epl.agg.service |
Aggregation services.
|
com.espertech.esper.epl.core |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.expression |
This package contains the EPL expression nodes that represent all expressions such as used in select clauses, group-by and having clauses, or order-by clauses
|
com.espertech.esper.epl.join.base |
Join process interfaces and glue code
|
com.espertech.esper.epl.named |
Named window classes are in this package
|
com.espertech.esper.epl.spec |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.view |
Internal processing views for output rate limiting, filtering and internal event routing
|
com.espertech.esper.epl.virtualdw |
Virtual data window.
|
com.espertech.esper.metrics.instrumentation | |
com.espertech.esper.pattern |
Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active pattern instance
|
com.espertech.esper.rowregex |
Match-recognize expression tree and state objects.
|
com.espertech.esper.view.internal |
Internal management views for buffering view results and providing these to joins.
|
com.espertech.esper.view.stat |
Views computing statistical values.
|
com.espertech.esper.view.std |
Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc.
|
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
VirtualDataWindowContext.getAgentInstanceContext()
Returns the agent instance (context partition) context.
|
Constructor and Description |
---|
VirtualDataWindowContext(AgentInstanceContext agentInstanceContext,
EventType eventType,
java.lang.Object[] parameters,
ExprNode[] parameterExpressions,
EventBeanFactory eventFactory,
VirtualDataWindowOutStream outputStream,
java.lang.String namedWindowName,
ViewFactoryContext viewFactoryContext,
java.io.Serializable customConfiguration)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
ViewableActivationResult |
ViewableActivatorSubselectNone.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorStreamReuseView.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorPattern.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorNamedWindow.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorFilterProxy.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivator.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
StatementAgentInstanceFactoryResult.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryUpdateResult |
StatementAgentInstanceFactoryUpdate.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactorySelectResult |
StatementAgentInstanceFactorySelect.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryOnTriggerResult |
StatementAgentInstanceFactoryOnTrigger.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateWindowResult |
StatementAgentInstanceFactoryCreateWindow.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateVariableResult |
StatementAgentInstanceFactoryCreateVariable.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactory.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
AgentInstance.getAgentInstanceContext() |
AgentInstanceContext |
ContextControllerFactoryServiceContext.getAgentInstanceContextCreate() |
AgentInstanceContext |
ContextControllerFactoryContext.getAgentInstanceContextCreate() |
Modifier and Type | Method and Description |
---|---|
void |
ContextManagementServiceImpl.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient) |
void |
ContextManagementService.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient) |
static ContextControllerCondition |
ContextControllerConditionFactory.getEndpoint(java.lang.String contextName,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
ContextDetailCondition endpoint,
ContextControllerConditionCallback callback,
ContextInternalFilterAddendum filterAddendum,
boolean isStartEndpoint,
int nestingLevel,
int pathId,
int subpathId) |
Modifier and Type | Method and Description |
---|---|
SubSelectStrategyRealization |
SubSelectStrategyFactoryNamedWinIndexShare.instantiate(EPServicesContext services,
Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
java.util.List<StopCallback> stopCallbackList) |
SubSelectStrategyRealization |
SubSelectStrategyFactoryLocalViewPreloaded.instantiate(EPServicesContext services,
Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
java.util.List<StopCallback> stopCallbackList) |
SubSelectStrategyRealization |
SubSelectStrategyFactory.instantiate(EPServicesContext services,
Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
java.util.List<StopCallback> stopCallbackList) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
AgentInstanceViewFactoryChainContext.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
static AgentInstanceViewFactoryChainContext |
AgentInstanceViewFactoryChainContext.create(java.util.List<ViewFactory> viewFactoryChain,
AgentInstanceContext agentInstanceContext,
ViewResourceDelegateVerifiedStream viewResourceDelegate) |
static boolean |
StatementAgentInstanceUtil.evaluateFilterForStatement(EPServicesContext servicesContext,
EventBean theEvent,
AgentInstanceContext agentInstanceContext,
FilterHandle filterHandle) |
static StopCallback |
StatementAgentInstanceUtil.getStopCallback(java.util.List<StopCallback> stopCallbacks,
AgentInstanceContext agentInstanceContext) |
static void |
StatementAgentInstanceUtil.stop(StopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
Viewable finalView,
EPServicesContext servicesContext,
boolean isStatementStop,
boolean leaveLocksAcquired) |
Constructor and Description |
---|
AgentInstanceViewFactoryChainContext(AgentInstanceContext agentInstanceContext,
boolean isRemoveStream,
java.lang.Object previousNodeGetter,
ViewUpdatedCollection priorViewUpdatedCollection) |
Modifier and Type | Method and Description |
---|---|
static ResultSetProcessor |
EPStatementStartMethodHelperAssignExpr.getAssignResultSetProcessor(AgentInstanceContext agentInstanceContext,
ResultSetProcessorFactoryDesc resultSetProcessorPrototype) |
static EPStatementStartMethodSelectDesc |
EPStatementStartMethodSelectUtil.prepare(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext,
boolean recoveringResilient,
AgentInstanceContext defaultAgentInstanceContext,
boolean queryPlanLogging,
ViewableActivatorFactory optionalViewableActivatorFactory,
OutputProcessViewCallback optionalOutputProcessViewCallback,
SelectExprProcessorDeliveryCallback selectExprProcessorDeliveryCallback) |
static Pair<ResultSetProcessor,AggregationService> |
EPStatementStartMethodHelperUtil.startResultSetAndAggregation(ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
AgentInstanceContext agentInstanceContext) |
static java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> |
EPStatementStartMethodHelperSubselect.startSubselects(EPServicesContext services,
SubSelectStrategyCollection subSelectStrategyCollection,
AgentInstanceContext agentInstanceContext,
java.util.List<StopCallback> stopCallbackList) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
DataFlowStmtDesc.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
void |
DataFlowServiceImpl.addStartGraph(CreateDataFlowDesc desc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
boolean newStatement) |
void |
DataFlowService.addStartGraph(CreateDataFlowDesc desc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
boolean newStatement) |
Constructor and Description |
---|
DataFlowStmtDesc(CreateDataFlowDesc graphDesc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
java.util.Map<GraphOperatorSpec,java.lang.annotation.Annotation[]> operatorAnnotations) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
DataFlowOpInitializateContext.getAgentInstanceContext() |
Constructor and Description |
---|
DataFlowOpInitializateContext(java.lang.String dataflowName,
java.lang.String dataflowInstanceId,
java.lang.Object dataflowInstanceUserObject,
java.util.Map<java.lang.Integer,DataFlowOpInputPort> inputPorts,
java.util.Map<java.lang.Integer,DataFlowOpOutputPort> outputPorts,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
EPRuntimeEventSender runtimeEventSender,
EPServiceProvider engine,
java.lang.annotation.Annotation[] operatorAnnotations) |
Modifier and Type | Method and Description |
---|---|
AggSvcGroupByReclaimAgedEvalFunc |
AggSvcGroupByReclaimAgedEvalFuncFactory.make(AgentInstanceContext agentInstanceContext) |
AggregationServiceMatchRecognize |
AggregationServiceMatchRecognizeFactoryImpl.makeService(AgentInstanceContext agentInstanceContext) |
AggregationServiceMatchRecognize |
AggregationServiceMatchRecognizeFactory.makeService(AgentInstanceContext agentInstanceContext) |
AggregationService |
AggSvcGroupByRefcountedWAccessRollupFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupByRefcountedWAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupByRefcountedNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupByReclaimAgedFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupByNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupByMixedAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupByAccessOnlyFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupAllNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupAllMixedAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggSvcGroupAllAccessOnlyFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggregationServiceNullFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
AggregationService |
AggregationServiceFactory.makeService(AgentInstanceContext agentInstanceContext,
MethodResolutionService methodResolutionService) |
Modifier and Type | Method and Description |
---|---|
OrderByProcessor |
OrderByProcessorRowLimitFactory.instantiate(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
OrderByProcessor |
OrderByProcessorOrderedLimitFactory.instantiate(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
OrderByProcessor |
OrderByProcessorFactoryImpl.instantiate(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
OrderByProcessor |
OrderByProcessorFactory.instantiate(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorSimpleFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorRowPerGroupRollupFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorRowPerGroupFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorRowForAllFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorHandThrougFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorAggregateGroupedFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
ResultSetProcessor |
ResultSetProcessorAggregateAllFactory.instantiate(OrderByProcessor orderByProcessor,
AggregationService aggregationService,
AgentInstanceContext agentInstanceContext) |
void |
ResultSetProcessorSimple.setAgentInstanceContext(AgentInstanceContext context) |
void |
ResultSetProcessorRowPerGroupRollup.setAgentInstanceContext(AgentInstanceContext agentInstanceContext) |
void |
ResultSetProcessorRowPerGroup.setAgentInstanceContext(AgentInstanceContext agentInstanceContext) |
void |
ResultSetProcessorRowForAll.setAgentInstanceContext(AgentInstanceContext context) |
void |
ResultSetProcessorHandThrough.setAgentInstanceContext(AgentInstanceContext agentInstanceContext) |
void |
ResultSetProcessorAggregateGrouped.setAgentInstanceContext(AgentInstanceContext agentInstanceContext) |
void |
ResultSetProcessorAggregateAll.setAgentInstanceContext(AgentInstanceContext context) |
void |
ResultSetProcessor.setAgentInstanceContext(AgentInstanceContext context) |
EventBean[] |
OrderByProcessorRowLimit.sort(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
OrderByElement[][] elementsPerLevel) |
EventBean[] |
OrderByProcessorOrderedLimit.sort(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
OrderByElement[][] elementsPerLevel) |
EventBean[] |
OrderByProcessorImpl.sort(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean isNewData,
AgentInstanceContext exprEvaluatorContext,
OrderByElement[][] elementsPerLevel) |
EventBean[] |
OrderByProcessor.sort(EventBean[] outgoingEvents,
java.util.List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
OrderByElement[][] elementsPerLevel) |
Modifier and Type | Method and Description |
---|---|
long |
ExprTimePeriodEvalDeltaNonConstMsec.deltaMillisecondsUseEngineTime(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
long |
ExprTimePeriodEvalDeltaNonConstCalAdd.deltaMillisecondsUseEngineTime(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
long |
ExprTimePeriodEvalDeltaNonConst.deltaMillisecondsUseEngineTime(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
JoinSetComposerDesc |
JoinSetComposerPrototypeImpl.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext) |
JoinSetComposerDesc |
JoinSetComposerPrototypeHistorical2StreamImpl.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext) |
JoinSetComposerDesc |
JoinSetComposerPrototype.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
NamedWindowTailViewInstance.getAgentInstanceContext() |
AgentInstanceContext |
NamedWindowConsumerDesc.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
NamedWindowProcessorInstance |
NamedWindowProcessor.addInstance(AgentInstanceContext agentInstanceContext) |
NamedWindowOnExprBaseView |
NamedWindowRootViewInstance.addOnExpr(NamedWindowOnExprFactory onExprFactory,
AgentInstanceContext agentInstanceContext,
ExprNode joinExpr,
EventType filterEventType,
ResultSetProcessor resultSetProcessor,
java.lang.String streamNameOn,
ExcludePlanHint excludePlanHint,
IndexHint indexHint)
Add an on-trigger view that, using a lookup strategy, looks up from the named window and may select or delete rows.
|
SubordTableLookupStrategy |
NamedWindowRootViewInstance.getAddSubqueryLookupStrategy(AgentInstanceContext accessedByAIContext,
EventType[] eventTypesPerStream,
SubordPropPlan joinDesc,
boolean fullTableScan,
int subqueryNum,
IndexHint optionalIndexHint) |
NamedWindowProcessorInstance |
NamedWindowProcessor.getProcessorInstance(AgentInstanceContext agentInstanceContext) |
NamedWindowOnExprBaseView |
NamedWindowOnUpdateViewFactory.make(NamedWindowLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor) |
NamedWindowOnExprBaseView |
NamedWindowOnSelectViewFactory.make(NamedWindowLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor) |
NamedWindowOnExprBaseView |
NamedWindowOnMergeViewFactory.make(NamedWindowLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor) |
NamedWindowOnExprBaseView |
NamedWindowOnExprFactory.make(NamedWindowLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor) |
NamedWindowOnExprBaseView |
NamedWindowOnDeleteViewFactory.make(NamedWindowLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor) |
Constructor and Description |
---|
NamedWindowConsumerDesc(java.util.List<ExprNode> filterList,
PropertyEvaluator optPropertyEvaluator,
AgentInstanceContext agentInstanceContext) |
NamedWindowProcessorInstance(java.lang.Integer agentInstanceId,
NamedWindowProcessor processor,
AgentInstanceContext agentInstanceContext) |
NamedWindowRootViewInstance(NamedWindowRootView rootView,
AgentInstanceContext agentInstanceContext) |
NamedWindowTailViewInstance(NamedWindowRootViewInstance rootViewInstance,
NamedWindowTailView tailView,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
long |
MatchRecognizeInterval.getScheduleBackwardDelta(long fromTime,
AgentInstanceContext agentInstanceContext)
Returns the number of milliseconds.
|
long |
MatchRecognizeInterval.getScheduleForwardDelta(long fromTime,
AgentInstanceContext agentInstanceContext)
Returns the number of milliseconds.
|
Modifier and Type | Method and Description |
---|---|
static OutputConditionPolled |
OutputConditionPolledFactory.createCondition(OutputLimitSpec outputLimitSpec,
AgentInstanceContext agentInstanceContext)
Creates an output condition instance.
|
OutputStrategyPostProcess |
OutputStrategyPostProcessFactory.make(AgentInstanceContext agentInstanceContext) |
OutputCondition |
OutputConditionTimeFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionTermFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionNullFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionFirstFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionExpressionFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionCrontabFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputCondition |
OutputConditionCountFactory.make(AgentInstanceContext agentInstanceContext,
OutputCallback outputCallback) |
OutputProcessViewBase |
OutputProcessViewFactoryCallback.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewBase |
OutputProcessViewFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewBase |
OutputProcessViewDirectFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewBase |
OutputProcessViewDirectDistinctOrAfterFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewBase |
OutputProcessViewConditionFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
OutputConditionCrontab(OutputCallback outputCallback,
AgentInstanceContext context,
OutputConditionCrontabFactory factory) |
OutputConditionExpression(OutputCallback outputCallback,
AgentInstanceContext agentInstanceContext,
OutputConditionExpressionFactory parent) |
OutputConditionFirst(OutputCallback outputCallback,
AgentInstanceContext agentInstanceContext,
OutputConditionFactory innerConditionFactory) |
OutputConditionPolledCrontab(java.util.List<ExprNode> scheduleSpecExpressionList,
AgentInstanceContext agentInstanceContext)
Constructor.
|
OutputConditionPolledExpression(ExprNode whenExpressionNode,
java.util.List<OnTriggerSetAssignment> assignments,
AgentInstanceContext agentInstanceContext)
Ctor.
|
OutputConditionPolledTime(ExprTimePeriod timePeriod,
AgentInstanceContext context)
Constructor.
|
OutputConditionTime(OutputCallback outputCallback,
AgentInstanceContext context,
OutputConditionTimeFactory outputConditionTimeFactory) |
OutputProcessViewConditionDefault(ResultSetProcessor resultSetProcessor,
java.lang.Long afterConditionTime,
java.lang.Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewConditionDefaultPostProcess(ResultSetProcessor resultSetProcessor,
java.lang.Long afterConditionTime,
java.lang.Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
OutputStrategyPostProcess postProcessor) |
OutputProcessViewConditionFirst(ResultSetProcessor resultSetProcessor,
java.lang.Long afterConditionTime,
java.lang.Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewConditionFirstPostProcess(ResultSetProcessor resultSetProcessor,
java.lang.Long afterConditionTime,
java.lang.Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
OutputStrategyPostProcess postProcessor) |
OutputProcessViewConditionSnapshot(ResultSetProcessor resultSetProcessor,
java.lang.Long afterConditionTime,
java.lang.Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewConditionSnapshotPostProcess(ResultSetProcessor resultSetProcessor,
java.lang.Long afterConditionTime,
java.lang.Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
OutputStrategyPostProcess postProcessor) |
OutputStrategyPostProcess(OutputStrategyPostProcessFactory parent,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
VirtualDWView |
VirtualDWViewProviderForAgentInstance.getView(AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
void |
InstrumentationDefault.qContextPartitionAllocate(AgentInstanceContext agentInstanceContext) |
void |
Instrumentation.qContextPartitionAllocate(AgentInstanceContext agentInstanceContext) |
void |
InstrumentationDefault.qContextPartitionDestroy(AgentInstanceContext agentInstanceContext) |
void |
Instrumentation.qContextPartitionDestroy(AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
PatternAgentInstanceContext.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
PatternAgentInstanceContext |
PatternContextFactoryDefault.createPatternAgentContext(PatternContext patternContext,
AgentInstanceContext agentInstanceContext,
boolean hasConsumingFilter) |
PatternAgentInstanceContext |
PatternContextFactory.createPatternAgentContext(PatternContext patternContext,
AgentInstanceContext agentInstanceContext,
boolean hasConsumingFilter) |
Constructor and Description |
---|
PatternAgentInstanceContext(PatternContext patternContext,
AgentInstanceContext agentInstanceContext,
boolean hasConsumingFilter) |
Constructor and Description |
---|
EventRowRegexNFAView(EventRowRegexNFAViewFactory factory,
ObjectArrayEventType compositeEventType,
EventType rowEventType,
MatchRecognizeSpec matchRecognizeSpec,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
java.util.Map<java.lang.Integer,java.lang.String> streamsVariables,
java.util.Set<java.lang.String> variablesSingle,
AgentInstanceContext agentInstanceContext,
java.util.TreeMap<java.lang.Integer,java.util.List<ExprPreviousMatchRecognizeNode>> callbacksPerIndex,
AggregationServiceMatchRecognize aggregationService,
boolean isDefineAsksMultimatches,
ObjectArrayBackedEventBean defineMultimatchEventBean,
boolean[] isExprRequiresMultimatchState,
boolean isUnbound,
boolean isIterateOnly,
boolean isCollectMultimatches)
Ctor.
|
EventRowRegexNFAViewFactory(ViewFactoryChain viewChain,
MatchRecognizeSpec matchRecognizeSpec,
AgentInstanceContext agentInstanceContext,
boolean isUnbound,
java.lang.annotation.Annotation[] annotations)
Ctor.
|
Constructor and Description |
---|
RouteResultView(boolean isFirst,
EventType eventType,
EPStatementHandle epStatementHandle,
InternalEventRouter internalEventRouter,
boolean[] isNamedWindowInsert,
ResultSetProcessor[] processors,
ExprNode[] whereClauses,
AgentInstanceContext agentInstanceContext)
Ctor.
|
RouteResultViewHandlerAll(EPStatementHandle epStatementHandle,
InternalEventRouter internalEventRouter,
boolean[] isNamedWindowInsert,
ResultSetProcessor[] processors,
ExprEvaluator[] whereClauses,
AgentInstanceContext agentInstanceContext)
Ctor.
|
RouteResultViewHandlerFirst(EPStatementHandle epStatementHandle,
InternalEventRouter internalEventRouter,
boolean[] isNamedWindowInsert,
ResultSetProcessor[] processors,
ExprEvaluator[] whereClauses,
AgentInstanceContext agentInstanceContext)
Ctor.
|
Constructor and Description |
---|
BaseBivariateStatisticsView(AgentInstanceContext agentInstanceContext,
ExprNode expressionX,
ExprNode expressionY,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the two fields to use in the parent view to compute the statistics.
|
CorrelationView(AgentInstanceContext agentInstanceContext,
ExprNode xExpression,
ExprNode yExpression,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor.
|
RegressionLinestView(AgentInstanceContext agentInstanceContext,
ExprNode xFieldName,
ExprNode yFieldName,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor.
|
UnivariateStatisticsView(AgentInstanceContext agentInstanceContext,
ExprNode fieldExpression,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the field to use in the parent view to compute the statistics.
|
WeightedAverageView(AgentInstanceContext agentInstanceContext,
ExprNode fieldNameX,
ExprNode fieldNameWeight,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the field to use in the parent view to compute the weighted average on,
as well as the name of the field in the parent view to get the weight from.
|
Constructor and Description |
---|
SizeView(AgentInstanceContext agentInstanceContext,
EventType eventType,
StatViewAdditionalProps additionalProps)
Ctor.
|