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.service.resource |
Core service statement resource holders.
|
com.espertech.esper.core.start |
Classes related to start and stop of statements
|
com.espertech.esper.core.support |
Internal-use-only services for unit and regression testing
|
com.espertech.esper.dataflow.core |
Data flow core classes.
|
com.espertech.esper.dataflow.interfaces |
Data flow operator and related interface.
|
com.espertech.esper.dataflow.ops |
Data flow built-in operators.
|
com.espertech.esper.epl.agg.service |
Aggregation services.
|
com.espertech.esper.epl.core |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.expression.time |
Time-related expressions.
|
com.espertech.esper.epl.fafquery |
Fire-and-forget query execution planning.
|
com.espertech.esper.epl.join.base |
Join process interfaces and glue code
|
com.espertech.esper.epl.join.table |
Indexes for views
|
com.espertech.esper.epl.lookup |
Subquery execution strategies and lookup indexes
|
com.espertech.esper.epl.named |
Named window classes are in this package
|
com.espertech.esper.epl.spec |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.subquery |
Subquery helper classes are found here.
|
com.espertech.esper.epl.table.mgmt |
Table-related services and metadata.
|
com.espertech.esper.epl.table.onaction |
Table on-action handlers.
|
com.espertech.esper.epl.view |
Internal processing views for output rate limiting, filtering and internal event routing
|
com.espertech.esper.epl.virtualdw |
Virtual data window.
|
com.espertech.esper.event.vaevent |
Value added events are revision events and variant events.
|
com.espertech.esper.filter |
Main switchboard filtering and routing of incoming events to interested statements is performed in this package.
|
com.espertech.esper.metrics.instrumentation |
EPL instrumentation helpers.
|
com.espertech.esper.pattern |
Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active
pattern instance
|
com.espertech.esper.pattern.pool |
Pattern subexpression pool management
|
com.espertech.esper.rowregex |
Match-recognize expression tree and state objects.
|
com.espertech.esper.view |
View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering.
|
com.espertech.esper.view.ext |
Extension views that providing services such as sorting, which don't fit much into other categories.
|
com.espertech.esper.view.internal |
Internal management views for buffering view results and providing these to joins.
|
com.espertech.esper.view.stat |
Views computing statistical values.
|
com.espertech.esper.view.std |
Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc.
|
com.espertech.esper.view.stream |
View to event stream relationship service
|
com.espertech.esper.view.window |
Window views are in this package
|
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
VirtualDataWindowContext.getAgentInstanceContext()
Returns the agent instance (context partition) context.
|
Constructor and Description |
---|
VirtualDataWindowContext(AgentInstanceContext agentInstanceContext,
EventType eventType,
Object[] parameters,
ExprNode[] parameterExpressions,
EventBeanFactory eventFactory,
VirtualDataWindowOutStream outputStream,
String namedWindowName,
ViewFactoryContext viewFactoryContext,
Serializable customConfiguration)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
ViewableActivationResult |
ViewableActivatorTable.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorSubselectNone.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorStreamReuseView.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorPattern.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorNamedWindow.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorHistorical.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 |
---|---|
View |
StatementAgentInstanceFactoryOnTriggerTable.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
View |
StatementAgentInstanceFactoryOnTriggerSplit.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
View |
StatementAgentInstanceFactoryOnTriggerSetVariable.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
View |
StatementAgentInstanceFactoryOnTriggerNamedWindow.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
abstract View |
StatementAgentInstanceFactoryOnTriggerBase.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult |
StatementAgentInstanceFactoryOnTriggerTable.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbacks,
boolean isRecoveringReslient) |
StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult |
StatementAgentInstanceFactoryOnTriggerSplit.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbacks,
boolean isRecoveringReslient) |
StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult |
StatementAgentInstanceFactoryOnTriggerSetVariable.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbacks,
boolean isRecoveringReslient) |
StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult |
StatementAgentInstanceFactoryOnTriggerNamedWindow.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbacks,
boolean isRecoveringReslient) |
abstract StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult |
StatementAgentInstanceFactoryOnTriggerBase.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbacks,
boolean isRecoveringReslient) |
StatementAgentInstanceFactoryOnTriggerResult |
StatementAgentInstanceFactoryOnTriggerBase.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateSchemaResult |
StatementAgentInstanceFactoryNoAgentInstance.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateTableResult |
StatementAgentInstanceFactoryCreateTable.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateIndexResult |
StatementAgentInstanceFactoryCreateIndex.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryBase.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactory.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryUpdateResult |
StatementAgentInstanceFactoryUpdate.newContextInternal(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactorySelectResult |
StatementAgentInstanceFactorySelect.newContextInternal(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateWindowResult |
StatementAgentInstanceFactoryCreateWindow.newContextInternal(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
StatementAgentInstanceFactoryCreateVariableResult |
StatementAgentInstanceFactoryCreateVariable.newContextInternal(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
protected abstract StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryBase.newContextInternal(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
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,
EventType statementResultEventType) |
void |
ContextManagementService.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient,
EventType statementResultEventType) |
static ContextControllerCondition |
ContextControllerConditionFactory.getEndpoint(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 |
SubSelectStrategyFactoryLocalViewPreloaded.instantiate(EPServicesContext services,
Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbackList,
int subqueryNumber,
boolean isRecoveringResilient) |
SubSelectStrategyRealization |
SubSelectStrategyFactoryIndexShare.instantiate(EPServicesContext services,
Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbackList,
int subqueryNumber,
boolean isRecoveringResilient) |
SubSelectStrategyRealization |
SubSelectStrategyFactory.instantiate(EPServicesContext services,
Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbackList,
int subqueryNumber,
boolean isRecoveringResilient) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
AgentInstanceViewFactoryChainContext.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
static AgentInstanceViewFactoryChainContext |
AgentInstanceViewFactoryChainContext.create(List<ViewFactory> viewFactoryChain,
AgentInstanceContext agentInstanceContext,
ViewResourceDelegateVerifiedStream viewResourceDelegate) |
static boolean |
StatementAgentInstanceUtil.evaluateFilterForStatement(EPServicesContext servicesContext,
EventBean theEvent,
AgentInstanceContext agentInstanceContext,
FilterHandle filterHandle) |
static StopCallback |
StatementAgentInstanceUtil.getStopCallback(List<StopCallback> stopCallbacks,
AgentInstanceContext agentInstanceContext) |
static void |
StatementAgentInstanceUtil.stop(StopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
Viewable finalView,
EPServicesContext servicesContext,
boolean isStatementStop,
boolean leaveLocksAcquired,
boolean removedStatementResources) |
Constructor and Description |
---|
AgentInstanceViewFactoryChainContext(AgentInstanceContext agentInstanceContext,
boolean isRemoveStream,
Object previousNodeGetter,
ViewUpdatedCollection priorViewUpdatedCollection) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
StatementResourceHolder.getAgentInstanceContext() |
Constructor and Description |
---|
StatementResourceHolder(AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
FireAndForgetInstanceTable.getAgentInstanceContext() |
AgentInstanceContext |
FireAndForgetInstanceNamedWindow.getAgentInstanceContext() |
abstract AgentInstanceContext |
FireAndForgetInstance.getAgentInstanceContext() |
AgentInstanceContext |
EPPreparedExecuteMethodQuery.getAgentInstanceContext() |
protected AgentInstanceContext |
EPStatementStartMethodBase.getDefaultAgentInstanceContext(StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
static void |
EPPreparedExecuteTableHelper.assignTableAccessStrategies(EPServicesContext services,
ExprTableAccessNode[] optionalTableNodes,
AgentInstanceContext agentInstanceContext) |
static Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> |
EPStatementStartMethodHelperTableAccess.attachTableAccess(EPServicesContext services,
AgentInstanceContext agentInstanceContext,
ExprTableAccessNode[] tableNodes) |
static ResultSetProcessor |
EPStatementStartMethodHelperAssignExpr.getAssignResultSetProcessor(AgentInstanceContext agentInstanceContext,
ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
boolean isSubquery,
Integer subqueryNumber,
boolean isFireAndForget) |
FireAndForgetInstance |
FireAndForgetProcessorTable.getProcessorInstance(AgentInstanceContext agentInstanceContext) |
FireAndForgetInstance |
FireAndForgetProcessorNamedWindow.getProcessorInstance(AgentInstanceContext agentInstanceContext) |
abstract FireAndForgetInstance |
FireAndForgetProcessor.getProcessorInstance(AgentInstanceContext agentInstanceContext) |
static EPStatementStartMethodSelectDesc |
EPStatementStartMethodSelectUtil.prepare(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext,
boolean recoveringResilient,
AgentInstanceContext defaultAgentInstanceContext,
boolean queryPlanLogging,
ViewableActivatorFactory optionalViewableActivatorFactory,
OutputProcessViewCallback optionalOutputProcessViewCallback,
SelectExprProcessorDeliveryCallback selectExprProcessorDeliveryCallback) |
static Pair<ResultSetProcessor,AggregationService> |
EPStatementStartMethodHelperUtil.startResultSetAndAggregation(ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
AgentInstanceContext agentInstanceContext,
boolean isSubquery,
Integer subqueryNumber) |
static Map<ExprSubselectNode,SubSelectStrategyHolder> |
EPStatementStartMethodHelperSubselect.startSubselects(EPServicesContext services,
SubSelectStrategyCollection subSelectStrategyCollection,
AgentInstanceContext agentInstanceContext,
List<StopCallback> stopCallbackList,
boolean isRecoveringResilient) |
Modifier and Type | Method and Description |
---|---|
static AgentInstanceContext |
SupportStatementContextFactory.makeAgentInstanceContext() |
static AgentInstanceContext |
SupportStatementContextFactory.makeAgentInstanceContext(SchedulingService stub) |
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,
Map<GraphOperatorSpec,Annotation[]> operatorAnnotations) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
DataFlowOpInitializateContext.getAgentInstanceContext() |
Constructor and Description |
---|
DataFlowOpInitializateContext(String dataflowName,
String dataflowInstanceId,
Object dataflowInstanceUserObject,
Map<Integer,DataFlowOpInputPort> inputPorts,
Map<Integer,DataFlowOpOutputPort> outputPorts,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
EPRuntimeEventSender runtimeEventSender,
EPServiceProvider engine,
Annotation[] operatorAnnotations) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
EventBusSource.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
AggSvcGroupByReclaimAgedEvalFunc |
AggSvcGroupByReclaimAgedEvalFuncFactory.make(AgentInstanceContext agentInstanceContext) |
AggregationServiceMatchRecognize |
AggregationServiceMatchRecognizeFactoryImpl.makeService(AgentInstanceContext agentInstanceContext) |
AggregationServiceMatchRecognize |
AggregationServiceMatchRecognizeFactory.makeService(AgentInstanceContext agentInstanceContext) |
AggregationService |
AggSvcGroupByWTableFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByRefcountedWAccessRollupFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByRefcountedWAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByRefcountedNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByReclaimAgedFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByMixedAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByLocalGroupByFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupByAccessOnlyFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllNoAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllMixedAccessWTableFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllMixedAccessFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllLocalGroupByFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggSvcGroupAllAccessOnlyFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggregationServiceNullFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
AggregationService |
AggregationServiceFactory.makeService(AgentInstanceContext agentInstanceContext,
EngineImportService engineImportService,
boolean isSubquery,
Integer subqueryNumber) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
ResultSetProcessorRowPerGroupRollup.agentInstanceContext |
protected AgentInstanceContext |
ResultSetProcessorRowPerGroup.agentInstanceContext |
protected AgentInstanceContext |
ResultSetProcessorAggregateGrouped.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
long |
ExprTimePeriodEvalDeltaNonConstMsec.deltaUseEngineTime(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
long |
ExprTimePeriodEvalDeltaNonConstCalAdd.deltaUseEngineTime(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
long |
ExprTimePeriodEvalDeltaNonConst.deltaUseEngineTime(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
ExprTimePeriodEvalDeltaConst |
ExprTimePeriodEvalDeltaConstZero.make(String validateMsgName,
String validateMsgValue,
AgentInstanceContext agentInstanceContext) |
ExprTimePeriodEvalDeltaConst |
ExprTimePeriodEvalDeltaConstGivenDelta.make(String validateMsgName,
String validateMsgValue,
AgentInstanceContext agentInstanceContext) |
ExprTimePeriodEvalDeltaConst |
ExprTimePeriodEvalDeltaConstGivenCalAdd.make(String validateMsgName,
String validateMsgValue,
AgentInstanceContext agentInstanceContext) |
ExprTimePeriodEvalDeltaConst |
ExprTimePeriodEvalDeltaConstFactoryMsec.make(String validateMsgName,
String validateMsgValue,
AgentInstanceContext agentInstanceContext) |
ExprTimePeriodEvalDeltaConst |
ExprTimePeriodEvalDeltaConstFactory.make(String validateMsgName,
String validateMsgValue,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
static Collection<EventBean> |
FireAndForgetQueryExec.snapshot(QueryGraph queryGraph,
Annotation[] annotations,
VirtualDWView virtualDataWindow,
EventTableIndexRepository indexRepository,
boolean queryPlanLogging,
org.slf4j.Logger queryPlanLogDestination,
String objectName,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
JoinSetComposerDesc |
JoinSetComposerPrototypeImpl.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
JoinSetComposerDesc |
JoinSetComposerPrototypeHistorical2StreamImpl.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
JoinSetComposerDesc |
JoinSetComposerPrototype.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
EventTableFactoryTableIdentAgentInstance.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
static EventTable |
EventTableUtil.buildIndex(AgentInstanceContext agentInstanceContext,
int indexedStreamNum,
QueryPlanIndexItem item,
EventType eventType,
boolean coerceOnAddOnly,
boolean unique,
String optionalIndexName,
Object optionalSerde,
boolean isFireAndForget)
Build an index/table instance using the event properties for the event type.
|
Constructor and Description |
---|
EventTableFactoryTableIdentAgentInstance(AgentInstanceContext agentInstanceContext) |
EventTableFactoryTableIdentAgentInstanceSubq(AgentInstanceContext agentInstanceContext,
int subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
void |
EventTableIndexRepository.addExplicitIndex(String explicitIndexName,
QueryPlanIndexItem desc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.addExplicitIndexOrReuse(boolean unique,
List<IndexedPropDesc> hashProps,
List<IndexedPropDesc> btreeProps,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc,
Iterable<EventBean> prefilledEvents,
EventType indexedType,
String indexName,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyFactoryIndexedUnfiltered.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyFactoryIndexedFiltered.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyFactoryAllUnfiltered.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyFactoryAllFiltered.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
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,
QueryPlanIndexItem explicitIndexDesc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
boolean allowIndexExists,
Object optionalSerde) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
NamedWindowTailViewInstance.getAgentInstanceContext() |
AgentInstanceContext |
NamedWindowRootViewInstance.getAgentInstanceContext() |
AgentInstanceContext |
NamedWindowConsumerDesc.getAgentInstanceContext() |
Constructor and Description |
---|
NamedWindowConsumerDesc(List<ExprNode> filterList,
PropertyEvaluator optPropertyEvaluator,
AgentInstanceContext agentInstanceContext) |
NamedWindowProcessorInstance(Integer agentInstanceId,
NamedWindowProcessor processor,
AgentInstanceContext agentInstanceContext) |
NamedWindowRootViewInstance(NamedWindowRootView rootView,
AgentInstanceContext agentInstanceContext,
EventTableIndexMetadata eventTableIndexMetadata) |
NamedWindowTailViewInstance(NamedWindowRootViewInstance rootViewInstance,
NamedWindowTailView tailView,
NamedWindowProcessor namedWindowProcessor,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
Long |
ContextDetailConditionTimePeriod.getExpectedEndTime(AgentInstanceContext agentInstanceContext) |
long |
MatchRecognizeInterval.getScheduleBackwardDelta(long fromTime,
AgentInstanceContext agentInstanceContext)
Returns the number of milliseconds.
|
long |
MatchRecognizeInterval.getScheduleForwardDelta(long fromTime,
AgentInstanceContext agentInstanceContext)
Returns the number of milliseconds.
|
void |
ContextDetailCategoryItem.setCompiledFilter(FilterSpecCompiled filterSpec,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
SubselectBufferObserver(EventTable[] eventIndex,
AgentInstanceContext agentInstanceContext)
Ctor.
|
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
TableStateInstance.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
TableStateInstance.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
TableStateInstance |
TableStateFactory.makeTableState(AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
TableStateInstance(TableMetadata tableMetadata,
AgentInstanceContext agentInstanceContext) |
TableStateInstanceGroupedImpl(TableMetadata tableMetadata,
AgentInstanceContext agentInstanceContext) |
TableStateInstanceUngroupedImpl(TableMetadata tableMetadata,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
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) |
OutputConditionPolled |
OutputConditionPolledTimeFactory.makeFromState(AgentInstanceContext agentInstanceContext,
OutputConditionPolledState state) |
OutputConditionPolled |
OutputConditionPolledFactory.makeFromState(AgentInstanceContext agentInstanceContext,
OutputConditionPolledState state) |
OutputConditionPolled |
OutputConditionPolledExpressionFactory.makeFromState(AgentInstanceContext agentInstanceContext,
OutputConditionPolledState state) |
OutputConditionPolled |
OutputConditionPolledCrontabFactory.makeFromState(AgentInstanceContext agentInstanceContext,
OutputConditionPolledState state) |
OutputConditionPolled |
OutputConditionPolledCountFactory.makeFromState(AgentInstanceContext agentInstanceContext,
OutputConditionPolledState state) |
OutputConditionPolled |
OutputConditionPolledTimeFactory.makeNew(AgentInstanceContext agentInstanceContext) |
OutputConditionPolled |
OutputConditionPolledFactory.makeNew(AgentInstanceContext agentInstanceContext) |
OutputConditionPolled |
OutputConditionPolledExpressionFactory.makeNew(AgentInstanceContext agentInstanceContext) |
OutputConditionPolled |
OutputConditionPolledCrontabFactory.makeNew(AgentInstanceContext agentInstanceContext) |
OutputConditionPolled |
OutputConditionPolledCountFactory.makeNew(AgentInstanceContext agentInstanceContext) |
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) |
Modifier and Type | Method and Description |
---|---|
boolean |
VirtualDWViewFactoryImpl.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
VirtualDWView |
VirtualDWViewProviderForAgentInstance.getView(AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
void |
ValueAddEventProcessor.removeOldData(EventBean[] oldData,
EventTableIndexRepository indexRepository,
AgentInstanceContext agentInstanceContext)
Called each time a data window posts a remove stream event, to indicate that a data window
remove an event as it expired according to a specified expiration policy.
|
void |
VAEVariantProcessor.removeOldData(EventBean[] oldData,
EventTableIndexRepository indexRepository,
AgentInstanceContext agentInstanceContext) |
void |
VAERevisionProcessorMerge.removeOldData(EventBean[] oldData,
EventTableIndexRepository indexRepository,
AgentInstanceContext agentInstanceContext) |
void |
VAERevisionProcessorDeclared.removeOldData(EventBean[] oldData,
EventTableIndexRepository indexRepository,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
Object |
FilterSpecParamRange.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamIn.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
ExprNodeAdapterBase |
FilterSpecParamExprNode.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamEventPropIndexed.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamEventProp.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamContextProp.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamConstant.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamAdvancedIndexQuadTreePointRegion.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Object |
FilterSpecParamAdvancedIndexQuadTreeMXCIF.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
abstract Object |
FilterSpecParam.getFilterValue(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext)
Return the filter parameter constant to filter for.
|
FilterValueSet |
FilterSpecCompiled.getValueSet(MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext,
FilterValueSetParam[][] addendum)
Returns the values for the filter, using the supplied result events to ask filter parameters
for the value to filter for.
|
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) |
static Object |
PatternExpressionUtil.getKeys(MatchedEventMap matchEvent,
MatchedEventConvertor convertor,
ExprEvaluator[] expressions,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
PatternAgentInstanceContext(PatternContext patternContext,
AgentInstanceContext agentInstanceContext,
boolean hasConsumingFilter) |
Modifier and Type | Method and Description |
---|---|
void |
PatternSubexpressionPoolEngineSvc.decreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
void |
PatternSubexpressionPoolEngineSvc.forceIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
boolean |
PatternSubexpressionPoolEngineSvc.tryIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
EventRowRegexNFAView(EventRowRegexNFAViewFactory factory,
ObjectArrayEventType compositeEventType,
EventType rowEventType,
MatchRecognizeSpec matchRecognizeSpec,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
Map<Integer,String> streamsVariables,
Set<String> variablesSingle,
AgentInstanceContext agentInstanceContext,
TreeMap<Integer,List<ExprPreviousMatchRecognizeNode>> callbacksPerIndex,
AggregationServiceMatchRecognize aggregationService,
boolean isDefineAsksMultimatches,
ObjectArrayBackedEventBean defineMultimatchEventBean,
boolean[] isExprRequiresMultimatchState,
boolean isUnbound,
boolean isIterateOnly,
boolean isCollectMultimatches,
RowRegexExprNode expandedPatternNode,
ConfigurationEngineDefaults.MatchRecognize matchRecognizeConfig,
EventRowRegexNFAViewScheduler scheduler) |
EventRowRegexNFAViewFactory(ViewFactoryChain viewChain,
MatchRecognizeSpec matchRecognizeSpec,
AgentInstanceContext agentInstanceContext,
boolean isUnbound,
Annotation[] annotations,
ConfigurationEngineDefaults.MatchRecognize matchRecognizeConfig)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ViewFactorySupport.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
ViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext)
Determines if the given view could be used instead of creating a new view,
requires the view factory to compare view type, parameters and other capabilities provided.
|
static int |
ViewFactorySupport.evaluateSizeParam(String viewName,
ExprEvaluator sizeEvaluator,
AgentInstanceContext context) |
protected static Pair<Viewable,List<View>> |
ViewServiceHelper.matchExistingViews(Viewable rootViewable,
List<ViewFactory> viewFactories,
AgentInstanceContext agentInstanceContext)
Match the views under the stream to the list of view specications passed in.
|
Modifier and Type | Method and Description |
---|---|
boolean |
TimeToLiveViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
TimeOrderViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
SortWindowViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
RankWindowViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
RouteResultViewHandlerBase.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
boolean |
UnionViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
PriorEventViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
NoopViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
IntersectViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
BaseBivariateStatisticsView.agentInstanceContext
Services required by implementing classes.
|
Modifier and Type | Method and Description |
---|---|
boolean |
WeightedAverageViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
UnivariateStatisticsViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
RegressionLinestViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
CorrelationViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
BaseBivariateStatisticsView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode expressionX,
ExprNode expressionY,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the two fields to use in the parent view to compute the statistics.
|
CorrelationView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode xExpression,
ExprNode yExpression,
EventType eventType,
StatViewAdditionalProps additionalProps) |
RegressionLinestView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode xFieldName,
ExprNode yFieldName,
EventType eventType,
StatViewAdditionalProps additionalProps) |
Modifier and Type | Method and Description |
---|---|
boolean |
UniqueByPropertyViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
SizeViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
MergeViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
LastElementViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
GroupByViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
FirstUniqueByPropertyViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
FirstElementViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
SizeView(AgentInstanceContext agentInstanceContext,
EventType eventType,
StatViewAdditionalProps additionalProps) |
Modifier and Type | Method and Description |
---|---|
Pair<EventStream,StatementAgentInstanceLock> |
StreamFactorySvcImpl.createStream(int statementId,
FilterSpecCompiled filterSpec,
FilterService filterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
boolean isJoin,
AgentInstanceContext agentInstanceContext,
boolean hasOrderBy,
boolean filterWithSameTypeSubselect,
Annotation[] annotations,
boolean stateless,
int streamNum,
boolean isCanIterateUnbound)
See the method of the same name in
StreamFactoryService . |
Pair<EventStream,StatementAgentInstanceLock> |
StreamFactoryService.createStream(int statementId,
FilterSpecCompiled filterSpec,
FilterService filterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
boolean isJoin,
AgentInstanceContext agentInstanceContext,
boolean hasOrderBy,
boolean filterWithSameTypeSubselect,
Annotation[] annotations,
boolean stateless,
int streamNum,
boolean isCanIterateUnbound)
Create or reuse existing EventStream instance representing that event filter.
|
Modifier and Type | Method and Description |
---|---|
boolean |
TimeWindowViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
TimeLengthBatchViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
TimeBatchViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
TimeAccumViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
LengthWindowViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
LengthBatchViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
KeepAllViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
FirstTimeViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
FirstLengthWindowViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
ExternallyTimedWindowViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
ExternallyTimedBatchViewFactory.canReuse(View view,
AgentInstanceContext agentInstanceContext) |
boolean |
ExpressionViewFactoryBase.canReuse(View view,
AgentInstanceContext agentInstanceContext) |