Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
VirtualDataWindowContext.getAgentInstanceContext()
Returns the agent instance (context partition) context.
|
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 |
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 |
ViewableActivatorFilter.activate(AgentInstanceContext agentInstanceContext,
boolean isSubselect,
boolean isRecoveringResilient) |
ViewableActivationResult |
ViewableActivatorDataFlow.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 |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactory.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
static Pair<ResultSetProcessor,AggregationService> |
StatementAgentInstanceFactoryUtil.startResultSetAndAggregation(ResultSetProcessorFactoryProvider resultSetProcessorPrototype,
AgentInstanceContext agentInstanceContext,
boolean isSubquery,
Integer subqueryNumber) |
Constructor and Description |
---|
StatementAgentInstanceFactoryResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
AggregationService optionalAggegationService,
Map<Integer,SubSelectFactoryResult> subselectStrategies,
PriorEvalStrategy[] priorStrategies,
PreviousGetterStrategy[] previousGetterStrategies,
RowRecogPreviousStrategy rowRecogPreviousStrategy,
Map<Integer,ExprTableEvalStrategy> tableAccessStrategies,
List<StatementAgentInstancePreload> preloadList) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateContext.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateContextResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
AggregationService optionalAggegationService,
Map<Integer,SubSelectFactoryResult> subselectStrategies,
PriorEvalStrategy[] priorStrategies,
PreviousGetterStrategy[] previousGetterStrategies,
RowRecogPreviousStrategy regexExprPreviousEvalStrategy,
Map<Integer,ExprTableEvalStrategy> tableAccessStrategies,
List<StatementAgentInstancePreload> preloadList,
ContextManagerRealization contextManagerRealization) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateDataflow.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateDataflowResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
DataflowDesc dataflow) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateExpression.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateExpressionResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateIndex.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateIndexResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateSchema.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateSchemaResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateTable.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateTableResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
TableInstance tableInstance) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateVariable.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateVariableResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryCreateNW.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateNWResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
Viewable eventStreamParentViewable,
Viewable topView,
NamedWindowInstance namedWindowInstance,
ViewableActivationResult viewableActivationResult) |
Modifier and Type | Method and Description |
---|---|
abstract View |
StatementAgentInstanceFactoryOnTriggerBase.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
abstract InfraOnExprBaseViewResult |
StatementAgentInstanceFactoryOnTriggerBase.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbacks,
boolean isRecoveringReslient) |
StatementAgentInstanceFactoryOnTriggerResult |
StatementAgentInstanceFactoryOnTriggerBase.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryOnTriggerResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
AggregationService optionalAggegationService,
Map<Integer,SubSelectFactoryResult> subselectStrategies,
PriorEvalStrategy[] priorStrategies,
PreviousGetterStrategy[] previousGetterStrategies,
RowRecogPreviousStrategy regexExprPreviousEvalStrategy,
Map<Integer,ExprTableEvalStrategy> tableAccessStrategies,
List<StatementAgentInstancePreload> preloadList,
EvalRootState optPatternRoot,
ViewableActivationResult viewableActivationResult) |
Modifier and Type | Method and Description |
---|---|
View |
StatementAgentInstanceFactoryOnTriggerSet.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
InfraOnExprBaseViewResult |
StatementAgentInstanceFactoryOnTriggerSet.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbacks,
boolean isRecoveringReslient) |
Constructor and Description |
---|
OnSetVariableView(StatementAgentInstanceFactoryOnTriggerSet factory,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
RouteResultViewHandlerBase.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
View |
StatementAgentInstanceFactoryOnTriggerSplitStream.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
InfraOnExprBaseViewResult |
StatementAgentInstanceFactoryOnTriggerSplitStream.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbacks,
boolean isRecoveringReslient) |
Modifier and Type | Method and Description |
---|---|
View |
StatementAgentInstanceFactoryOnTriggerInfraBase.determineFinalOutputView(AgentInstanceContext agentInstanceContext,
View onExprView) |
InfraOnExprBaseViewResult |
StatementAgentInstanceFactoryOnTriggerInfraBase.determineOnExprView(AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbacks,
boolean isRecoveringResilient) |
InfraOnExprBaseViewResult |
InfraOnExprFactory.makeNamedWindow(SubordWMatchExprLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnExprFactory.makeTable(SubordWMatchExprLookupStrategy lookupStrategy,
TableInstance tableInstance,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactorySelectResult |
StatementAgentInstanceFactorySelect.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactorySelectResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
AggregationService optionalAggegationService,
Map<Integer,SubSelectFactoryResult> subselectStrategies,
PriorEvalStrategy[] priorStrategies,
PreviousGetterStrategy[] previousGetterStrategies,
RowRecogPreviousStrategy regexExprPreviousEvalStrategy,
Map<Integer,ExprTableEvalStrategy> tableAccessStrategies,
List<StatementAgentInstancePreload> preloadList,
EvalRootState[] patternRoots,
JoinSetComposer joinSetComposer,
Viewable[] topViews,
Viewable[] eventStreamViewables,
ViewableActivationResult[] viewableActivationResults,
ResultSetProcessor resultSetProcessor) |
Modifier and Type | Method and Description |
---|---|
StatementAgentInstanceFactoryResult |
StatementAgentInstanceFactoryUpdate.newContext(AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
StatementAgentInstanceFactoryUpdateResult(Viewable finalView,
AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
Map<Integer,SubSelectFactoryResult> subselectActivations) |
Modifier and Type | Method and Description |
---|---|
FilterValueSetParam[][] |
ContextControllerCategoryFactory.populateFilterAddendum(FilterSpecActivatable filterSpec,
boolean forStatement,
int nestingLevel,
Object partitionKey,
ContextControllerStatementDesc optionalStatementDesc,
AgentInstanceContext agentInstanceContextStatement) |
Modifier and Type | Method and Description |
---|---|
FilterValueSetParam[][] |
ContextControllerFactory.populateFilterAddendum(FilterSpecActivatable filterSpec,
boolean forStatement,
int nestingLevel,
Object partitionKey,
ContextControllerStatementDesc optionalStatementDesc,
AgentInstanceContext agentInstanceContextStatement) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
ContextControllerHash.getAgentInstanceContextCreate() |
Modifier and Type | Method and Description |
---|---|
FilterValueSetParam[][] |
ContextControllerHashFactory.populateFilterAddendum(FilterSpecActivatable filterSpec,
boolean forStatement,
int nestingLevel,
Object partitionKey,
ContextControllerStatementDesc optionalStatementDesc,
AgentInstanceContext agentInstanceContextStatement) |
Modifier and Type | Method and Description |
---|---|
FilterValueSetParam[][] |
ContextControllerInitTermFactory.populateFilterAddendum(FilterSpecActivatable filterSpec,
boolean forStatement,
int nestingLevel,
Object partitionKey,
ContextControllerStatementDesc optionalStatementDesc,
AgentInstanceContext agentInstanceContextStatement) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
ContextControllerKeyed.getAgentInstanceContextCreate() |
Modifier and Type | Method and Description |
---|---|
static FilterValueSetParam[][] |
ContextControllerKeyedUtil.getAddendumFilters(Object getterKey,
FilterSpecActivatable filtersSpec,
ContextControllerDetailKeyed keyedSpec,
boolean includePartition,
ContextControllerStatementDesc optionalStatementDesc,
AgentInstanceContext agentInstanceContext) |
FilterValueSetParam[][] |
ContextControllerKeyedFactory.populateFilterAddendum(FilterSpecActivatable filterSpec,
boolean forStatement,
int nestingLevel,
Object partitionKey,
ContextControllerStatementDesc optionalStatementDesc,
AgentInstanceContext agentInstanceContextStatement) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
ContextManagerRealization.getAgentInstanceContextCreate() |
Modifier and Type | Method and Description |
---|---|
ContextManagerRealization |
ContextManagerResident.allocateNewRealization(AgentInstanceContext agentInstanceContext) |
ContextManagerRealization |
ContextManager.allocateNewRealization(AgentInstanceContext agentInstanceContext) |
static IdentityHashMap<FilterSpecActivatable,FilterValueSetParam[][]> |
ContextManagerUtil.computeAddendumForStatement(ContextControllerStatementDesc statementDesc,
ContextControllerFactory[] controllerFactories,
Object[] allPartitionKeys,
AgentInstanceContext agentInstanceContextCreate) |
void |
ContextStatementEventEvaluatorDefault.evaluateEventForStatement(EventBean theEvent,
List<AgentInstance> agentInstances,
AgentInstanceContext agentInstanceContextCreate) |
void |
ContextStatementEventEvaluator.evaluateEventForStatement(EventBean theEvent,
List<AgentInstance> agentInstances,
AgentInstanceContext agentInstanceContextCreate) |
Constructor and Description |
---|
ContextManagerRealization(ContextManagerResident contextManager,
AgentInstanceContext agentInstanceContextCreate) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
AgentInstanceStopServices.getAgentInstanceContext() |
AgentInstanceContext |
AgentInstance.getAgentInstanceContext() |
AgentInstanceContext |
StatementContext.makeAgentInstanceContextUnpartitioned() |
Modifier and Type | Method and Description |
---|---|
static void |
AgentInstanceUtil.evaluateEventForStatement(EventBean theEvent,
Map<String,Object> optionalTriggeringPattern,
List<AgentInstance> agentInstances,
AgentInstanceContext agentInstanceContextCreate) |
static boolean |
AgentInstanceUtil.evaluateFilterForStatement(EventBean theEvent,
AgentInstanceContext agentInstanceContext,
FilterHandle filterHandle) |
FilterValueSetParam[][] |
AgentInstanceFilterProxyImpl.getAddendumFilters(FilterSpecActivatable filterSpec,
AgentInstanceContext agentInstanceContext) |
FilterValueSetParam[][] |
AgentInstanceFilterProxy.getAddendumFilters(FilterSpecActivatable filterSpec,
AgentInstanceContext agentInstanceContext) |
void |
InternalEventRouterImpl.route(EventBean theEvent,
AgentInstanceContext agentInstanceContext,
boolean addToFront) |
void |
InternalEventRouter.route(EventBean theEvent,
AgentInstanceContext agentInstanceContext,
boolean addToFront)
Route the event such that the event is processed as required.
|
static void |
AgentInstanceUtil.stop(AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
Viewable finalView,
boolean isStatementStop,
boolean leaveLocksAcquired) |
static void |
AgentInstanceUtil.stopSafe(AgentInstanceStopCallback stopMethod,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
AgentInstance(AgentInstanceStopCallback stopCallback,
AgentInstanceContext agentInstanceContext,
Viewable finalView) |
AgentInstanceStopServices(AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
AgentInstanceFilterProxyImpl(Function<AgentInstanceContext,IdentityHashMap<FilterSpecActivatable,FilterValueSetParam[][]>> generator) |
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggregationServiceNullFactory.makeService(AgentInstanceContext agentInstanceContext,
ClasspathImportServiceRuntime classpathImportService,
boolean isSubquery,
Integer subqueryNumber,
int[] groupId) |
AggregationService |
AggregationServiceFactory.makeService(AgentInstanceContext agentInstanceContext,
ClasspathImportServiceRuntime classpathImportService,
boolean isSubquery,
Integer subqueryNumber,
int[] groupId) |
Modifier and Type | Method and Description |
---|---|
AggSvcGroupByReclaimAgedEvalFunc |
AggSvcGroupByReclaimAgedEvalFuncFactoryVariable.make(AgentInstanceContext agentInstanceContext) |
AggSvcGroupByReclaimAgedEvalFunc |
AggSvcGroupByReclaimAgedEvalFuncFactoryConst.make(AgentInstanceContext agentInstanceContext) |
AggSvcGroupByReclaimAgedEvalFunc |
AggSvcGroupByReclaimAgedEvalFuncFactory.make(AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
AggregationService |
AggregationServiceFactoryTable.makeService(AgentInstanceContext agentInstanceContext,
ClasspathImportServiceRuntime classpathImportService,
boolean isSubquery,
Integer subqueryNumber,
int[] groupId) |
Constructor and Description |
---|
EPDataFlowInstanceImpl(Object dataFlowInstanceUserObject,
String dataFlowInstanceId,
OperatorStatisticsProvider statistics,
Map<Integer,Object> operators,
List<GraphSourceRunnable> sourceRunnables,
DataflowDesc dataflowDesc,
AgentInstanceContext agentInstanceContext,
EPDataFlowInstanceStatistics statisticsProvider,
Map<String,Object> parametersURIs) |
Modifier and Type | Method and Description |
---|---|
void |
DataFlowFilterServiceAdapterNonHA.addFilterCallback(FilterHandleCallback filterHandleCallback,
AgentInstanceContext agentInstanceContext,
EventType eventType,
FilterValueSetParam[][] params,
int filterCallbackId) |
void |
DataFlowFilterServiceAdapter.addFilterCallback(FilterHandleCallback filterHandleCallback,
AgentInstanceContext agentInstanceContext,
EventType eventType,
FilterValueSetParam[][] params,
int filterCallbackId) |
void |
DataFlowFilterServiceAdapterNonHA.removeFilterCallback(FilterHandleCallback filterHandleCallback,
AgentInstanceContext agentInstanceContext,
EventType eventType,
FilterValueSetParam[][] params,
int filterCallbackId) |
void |
DataFlowFilterServiceAdapter.removeFilterCallback(FilterHandleCallback filterHandleCallback,
AgentInstanceContext agentInstanceContext,
EventType eventType,
FilterValueSetParam[][] params,
int filterCallbackId) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
DataFlowOpInitializeContext.getAgentInstanceContext() |
Constructor and Description |
---|
DataFlowOpInitializeContext(String dataFlowName,
String operatorName,
int operatorNumber,
AgentInstanceContext agentInstanceContext,
Map<String,Object> additionalParameters,
String dataFlowInstanceId,
EPDataFlowOperatorParameterProvider parameterProvider,
DataFlowOperatorFactory dataFlowOperatorFactory,
Object dataflowInstanceUserObject) |
Modifier and Type | Method and Description |
---|---|
static OperatorStatisticsProvider |
DataflowInstantiatorHelper.realize(DataflowDesc dataflow,
Map<Integer,Object> operators,
List<LogicalChannelBinding> bindings,
DataFlowSignalManager dataFlowSignalManager,
EPDataFlowInstantiationOptions options,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
EPDataFlowEmitterExceptionHandler(AgentInstanceContext agentInstanceContext,
String dataFlowName,
String instanceId,
String operatorName,
int operatorNumber,
String operatorPrettyPrint,
EPDataFlowExceptionHandler optionalExceptionHandler) |
Constructor and Description |
---|
GraphSourceRunnable(AgentInstanceContext agentInstanceContext,
DataFlowSourceOperator graphSource,
String dataFlowName,
String instanceId,
String operatorName,
int operatorNumber,
String operatorPrettyPrint,
EPDataFlowExceptionHandler optionalExceptionHandler,
boolean audit) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
FireAndForgetInstanceTable.getAgentInstanceContext() |
AgentInstanceContext |
FireAndForgetInstanceNamedWindow.getAgentInstanceContext() |
abstract AgentInstanceContext |
FireAndForgetInstance.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
FireAndForgetInstance |
FireAndForgetProcessorTable.getProcessorInstance(AgentInstanceContext agentInstanceContext) |
FireAndForgetInstance |
FireAndForgetProcessorNamedWindow.getProcessorInstance(AgentInstanceContext agentInstanceContext) |
static Collection<EventBean> |
FireAndForgetQueryExec.snapshot(QueryGraph filterQueryGraph,
Annotation[] annotations,
VirtualDWView virtualDataWindow,
EventTableIndexRepository indexRepository,
String objectName,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
HistoricalEventViewableBase.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
HistoricalEventViewable |
HistoricalEventViewableFactory.activate(AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
HistoricalEventViewableBase(HistoricalEventViewableFactoryBase factory,
PollExecStrategy pollExecStrategy,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
HistoricalDataCache |
DatabaseConfigServiceRuntime.getDataCache(String databaseName,
AgentInstanceContext agentInstanceContext,
int streamNumber,
int scheduleCallbackId)
Returns a new cache implementation for this database.
|
HistoricalDataCache |
DatabaseConfigServiceImpl.getDataCache(String databaseName,
AgentInstanceContext agentInstanceContext,
int streamNumber,
int scheduleCallbackId) |
Modifier and Type | Method and Description |
---|---|
HistoricalEventViewable |
HistoricalEventViewableDatabaseFactory.activate(AgentInstanceContext agentInstanceContext) |
List<EventBean> |
PollExecStrategyDBQuery.poll(Object lookupValues,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
HistoricalEventViewableDatabase(HistoricalEventViewableDatabaseFactory factory,
PollExecStrategy pollExecStrategy,
AgentInstanceContext agentInstanceContext) |
PollExecStrategyDBQuery(HistoricalEventViewableDatabaseFactory factory,
AgentInstanceContext agentInstanceContext,
ConnectionCache connectionCache) |
Modifier and Type | Method and Description |
---|---|
HistoricalDataCache |
HistoricalDataCacheFactory.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) |
Constructor and Description |
---|
HistoricalDataCacheExpiringImpl(double maxAgeSec,
double purgeIntervalSec,
CacheReferenceType cacheReferenceType,
AgentInstanceContext agentInstanceContext,
long scheduleSlot)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
List<EventBean> |
PollExecStrategy.poll(Object lookupValues,
AgentInstanceContext agentInstanceContext)
Poll events using the keys provided.
|
Modifier and Type | Method and Description |
---|---|
EventTable[] |
PollResultIndexingStrategySorted.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext) |
EventTable[] |
PollResultIndexingStrategyNoIndex.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext) |
EventTable[] |
PollResultIndexingStrategyMulti.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext) |
EventTable[] |
PollResultIndexingStrategyInKeywordMulti.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext) |
EventTable[] |
PollResultIndexingStrategyHash.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext) |
EventTable[] |
PollResultIndexingStrategyComposite.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext) |
EventTable[] |
PollResultIndexingStrategy.index(List<EventBean> pollResult,
boolean isActiveCache,
AgentInstanceContext agentInstanceContext)
Build and index of a poll result.
|
Modifier and Type | Method and Description |
---|---|
HistoricalEventViewable |
HistoricalEventViewableMethodFactory.activate(AgentInstanceContext agentInstanceContext) |
List<EventBean> |
PollExecStrategyMethod.poll(Object lookupValues,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
HistoricalEventViewableMethod(HistoricalEventViewableMethodFactory factory,
PollExecStrategy pollExecStrategy,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
List<EventBean> |
MethodConversionStrategyScript.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyPlainPOJO.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyPlainOA.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyPlainMap.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyIterator.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyEventBeans.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyCollection.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategyArray.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
List<EventBean> |
MethodConversionStrategy.convert(Object invocationResult,
MethodTargetStrategy origin,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyIteratorPOJO.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyIteratorOA.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyIteratorMap.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected abstract EventBean |
MethodConversionStrategyIterator.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyCollectionPOJO.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyCollectionOA.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyCollectionMap.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected abstract EventBean |
MethodConversionStrategyCollection.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyArrayPOJO.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyArrayOA.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected EventBean |
MethodConversionStrategyArrayMap.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
protected abstract EventBean |
MethodConversionStrategyArray.getEventBean(Object value,
AgentInstanceContext agentInstanceContext) |
Object |
MethodTargetStrategyVariable.invoke(Object lookupValues,
AgentInstanceContext agentInstanceContext) |
Object |
MethodTargetStrategyStaticMethod.invoke(Object lookupValues,
AgentInstanceContext agentInstanceContext) |
Object |
MethodTargetStrategyScript.invoke(Object lookupValues,
AgentInstanceContext agentInstanceContext) |
Object |
MethodTargetStrategy.invoke(Object lookupValues,
AgentInstanceContext agentInstanceContext) |
MethodTargetStrategy |
MethodTargetStrategyVariableFactory.make(AgentInstanceContext agentInstanceContext) |
MethodTargetStrategy |
MethodTargetStrategyStaticMethod.make(AgentInstanceContext agentInstanceContext) |
MethodTargetStrategy |
MethodTargetStrategyScript.make(AgentInstanceContext agentInstanceContext) |
MethodTargetStrategy |
MethodTargetStrategyFactory.make(AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
AdvancedIndexConfigContextPartition |
EventAdvancedIndexFactoryForgeQuadTreeFactory.configureContextPartition(AgentInstanceContext agentInstanceContext,
EventType eventType,
EventAdvancedIndexProvisionRuntime advancedIndexProvisionDesc,
EventTableOrganization organization) |
SubordTableLookupStrategy |
SubordTableLookupStrategyFactoryQuadTree.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
EventTableFactoryCustomIndex.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
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.
|
EventTable[] |
EventTableFactory.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
PropertyCompositeEventTableFactory.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
PropertyHashedEventTableFactory.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
PropertyHashedArrayFactory.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
PropertySortedEventTableFactory.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
EventTable[] |
UnindexedEventTableFactory.makeEventTables(AgentInstanceContext agentInstanceContext,
Integer subqueryNumber) |
Modifier and Type | Method and Description |
---|---|
JoinSetComposerDesc |
JoinSetComposerPrototypeHistorical2Stream.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
JoinSetComposerDesc |
JoinSetComposerPrototypeGeneral.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
JoinSetComposerDesc |
JoinSetComposerPrototype.create(Viewable[] streamViews,
boolean isFireAndForget,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
Constructor and Description |
---|
JoinExecStrategyDispatchable(JoinExecutionStrategy joinExecutionStrategy,
int numStreams,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
ExecNode |
TableOuterLookupNode.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
TableLookupNode.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
QueryPlanNodeNoOp.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
QueryPlanNodeAllUnidirectionalOuter.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) |
ExecNode |
NestedIterationNode.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
LookupInstructionQueryPlanNode.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
HistoricalDataPlanNode.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
JoinExecTableLookupStrategy |
TableLookupPlan.makeStrategy(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] eventTypes,
VirtualDWView[] viewExternals) |
Modifier and Type | Method and Description |
---|---|
LookupInstructionExec |
LookupInstructionPlan.makeExec(AgentInstanceContext agentInstanceContext,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
VirtualDWView[] viewExternal) |
Modifier and Type | Method and Description |
---|---|
AdvancedIndexConfigContextPartition |
EventAdvancedIndexFactory.configureContextPartition(AgentInstanceContext agentInstanceContext,
EventType eventType,
EventAdvancedIndexProvisionRuntime advancedIndexProvisionDesc,
EventTableOrganization organization) |
SubordTableLookupStrategy |
SubordTableLookupStrategyFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordTableLookupStrategy |
SubordSortedTableLookupStrategyFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordTableLookupStrategy |
SubordInKeywordSingleTableLookupStrategyFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordTableLookupStrategy |
SubordInKeywordMultiTableLookupStrategyFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordTableLookupStrategy |
SubordHashedTableLookupStrategyPropFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordTableLookupStrategy |
SubordHashedTableLookupStrategyExprFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordFullTableScanLookupStrategy |
SubordFullTableScanLookupStrategyFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
SubordTableLookupStrategy |
SubordCompositeTableLookupStrategyFactory.makeStrategy(EventTable[] eventTable,
AgentInstanceContext agentInstanceContext,
VirtualDWView vdw) |
Modifier and Type | Method and Description |
---|---|
void |
EventTableIndexRepository.addExplicitIndex(String explicitIndexName,
String explicitIndexModuleName,
QueryPlanIndexItem desc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.addExplicitIndexOrReuse(QueryPlanIndexItem desc,
Iterable<EventBean> prefilledEvents,
EventType indexedType,
String indexName,
String indexModuleName,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
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,
String explicitIndexModuleName,
QueryPlanIndexItem explicitIndexDesc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
boolean allowIndexExists,
Object optionalSerde) |
Modifier and Type | Method and Description |
---|---|
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyIndexedUnfilteredFactory.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyIndexedFilteredFactory.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyAllUnfilteredFactory.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
SubordWMatchExprLookupStrategy |
SubordWMatchExprLookupStrategyAllFilteredFactory.realize(EventTable[] indexes,
AgentInstanceContext agentInstanceContext,
Iterable<EventBean> scanIterable,
VirtualDWView virtualDataWindow) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
NamedWindowConsumerDesc.getAgentInstanceContext() |
Constructor and Description |
---|
NamedWindowConsumerDesc(int namedWindowConsumerId,
ExprEvaluator filterEvaluator,
PropertyEvaluator optPropertyEvaluator,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
NamedWindowTailViewInstance.getAgentInstanceContext() |
AgentInstanceContext |
NamedWindowRootViewInstance.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
void |
NamedWindowTailViewImpl.addDispatches(NamedWindowConsumerLatchFactory latchFactory,
Map<EPStatementAgentInstanceHandle,List<NamedWindowConsumerView>> consumersInContext,
NamedWindowDeltaData delta,
AgentInstanceContext agentInstanceContext) |
void |
NamedWindowTailView.addDispatches(NamedWindowConsumerLatchFactory latchFactory,
Map<EPStatementAgentInstanceHandle,List<NamedWindowConsumerView>> consumersInContext,
NamedWindowDeltaData delta,
AgentInstanceContext agentInstanceContext) |
NamedWindowInstance |
NamedWindowImpl.getNamedWindowInstance(AgentInstanceContext agentInstanceContext) |
NamedWindowInstance |
NamedWindow.getNamedWindowInstance(AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
NamedWindowInstance(NamedWindow processor,
AgentInstanceContext agentInstanceContext) |
NamedWindowRootViewInstance(NamedWindowRootView rootView,
AgentInstanceContext agentInstanceContext,
EventTableIndexMetadata eventTableIndexMetadata) |
NamedWindowTailViewInstance(NamedWindowRootViewInstance rootViewInstance,
NamedWindowTailView tailView,
NamedWindow namedWindow,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
OnExprViewTableBase.agentInstanceContext |
protected AgentInstanceContext |
OnExprViewNameWindowBase.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
void |
InfraOnMergeActionUpd.apply(EventBean matchingEvent,
EventBean[] eventsPerStream,
OneEventCollection newData,
OneEventCollection oldData,
AgentInstanceContext agentInstanceContext) |
void |
InfraOnMergeActionIns.apply(EventBean matchingEvent,
EventBean[] eventsPerStream,
OneEventCollection newData,
OneEventCollection oldData,
AgentInstanceContext agentInstanceContext) |
void |
InfraOnMergeActionDel.apply(EventBean matchingEvent,
EventBean[] eventsPerStream,
OneEventCollection newData,
OneEventCollection oldData,
AgentInstanceContext agentInstanceContext) |
abstract void |
InfraOnMergeAction.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 |
InfraOnMergeActionIns.apply(EventBean matchingEvent,
EventBean[] eventsPerStream,
TableInstance tableStateInstance,
OnExprViewTableChangeHandler changeHandlerAdded,
OnExprViewTableChangeHandler changeHandlerRemoved,
AgentInstanceContext agentInstanceContext) |
void |
InfraOnMergeActionDel.apply(EventBean matchingEvent,
EventBean[] eventsPerStream,
TableInstance tableStateInstance,
OnExprViewTableChangeHandler changeHandlerAdded,
OnExprViewTableChangeHandler changeHandlerRemoved,
AgentInstanceContext agentInstanceContext) |
abstract void |
InfraOnMergeAction.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) |
InfraOnExprBaseViewResult |
InfraOnUpdateViewFactory.makeNamedWindow(SubordWMatchExprLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnSelectViewFactory.makeNamedWindow(SubordWMatchExprLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnMergeViewFactory.makeNamedWindow(SubordWMatchExprLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnDeleteViewFactory.makeNamedWindow(SubordWMatchExprLookupStrategy lookupStrategy,
NamedWindowRootViewInstance namedWindowRootViewInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnUpdateViewFactory.makeTable(SubordWMatchExprLookupStrategy lookupStrategy,
TableInstance tableInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnSelectViewFactory.makeTable(SubordWMatchExprLookupStrategy lookupStrategy,
TableInstance tableInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnMergeViewFactory.makeTable(SubordWMatchExprLookupStrategy lookupStrategy,
TableInstance tableInstance,
AgentInstanceContext agentInstanceContext) |
InfraOnExprBaseViewResult |
InfraOnDeleteViewFactory.makeTable(SubordWMatchExprLookupStrategy lookupStrategy,
TableInstance tableInstance,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
OutputConditionCrontab(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,
boolean isJoin,
EventType[] eventTypes) |
Modifier and Type | Method and Description |
---|---|
OutputProcessView |
OutputProcessViewFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
OutputProcessViewConditionLastAllUnordPostProcessAll(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) |
OutputProcessViewSimple(AgentInstanceContext agentInstanceContext) |
OutputProcessViewSimpleWProcessor(AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor) |
Constructor and Description |
---|
OutputConditionPolledCrontab(AgentInstanceContext agentInstanceContext,
OutputConditionPolledCrontabState state) |
OutputConditionPolledExpression(OutputConditionPolledExpressionFactory factory,
OutputConditionPolledExpressionState state,
AgentInstanceContext agentInstanceContext,
ObjectArrayEventBean builtinProperties) |
OutputConditionPolledTime(OutputConditionPolledTimeFactory factory,
AgentInstanceContext context,
OutputConditionPolledTimeState state) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
OutputProcessViewBaseWAfter.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
OutputStrategyPostProcess |
OutputStrategyPostProcessFactory.make(AgentInstanceContext agentInstanceContext) |
OutputProcessView |
OutputProcessViewDirectFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
OutputProcessView |
OutputProcessViewDirectDistinctOrAfterFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
OutputProcessView |
OutputProcessViewConditionFactory.makeView(ResultSetProcessor resultSetProcessor,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
OutputProcessViewBaseWAfter(AgentInstanceContext agentInstanceContext,
ResultSetProcessor resultSetProcessor,
Long afterConditionTime,
Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied) |
OutputProcessViewConditionDefault(ResultSetProcessor resultSetProcessor,
Long afterConditionTime,
Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
boolean isJoin,
EventType[] eventTypes) |
OutputProcessViewConditionFirst(ResultSetProcessor resultSetProcessor,
Long afterConditionTime,
Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext) |
OutputProcessViewConditionFirstPostProcess(ResultSetProcessor resultSetProcessor,
Long afterConditionTime,
Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
OutputStrategyPostProcess postProcessor) |
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) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
PatternAgentInstanceContext.agentInstanceContext |
protected AgentInstanceContext |
EvalRootNode.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
PatternAgentInstanceContext.getAgentInstanceContext() |
AgentInstanceContext |
EvalRootNode.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
static Object |
PatternExpressionUtil.getKeys(MatchedEventMap matchEvent,
MatchedEventConvertor convertor,
ExprEvaluator expression,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
PatternAgentInstanceContext(PatternContext patternContext,
AgentInstanceContext agentInstanceContext,
boolean hasConsumingFilter,
Function<FilterSpecActivatable,FilterValueSetParam[][]> contextAddendumFunction) |
Modifier and Type | Method and Description |
---|---|
void |
PatternSubexpressionPoolRuntimeSvcNoOp.decreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
void |
PatternSubexpressionPoolRuntimeSvcImpl.decreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
void |
PatternSubexpressionPoolRuntimeSvc.decreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
void |
PatternSubexpressionPoolRuntimeSvcNoOp.forceIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
void |
PatternSubexpressionPoolRuntimeSvcImpl.forceIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
void |
PatternSubexpressionPoolRuntimeSvc.forceIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
boolean |
PatternSubexpressionPoolRuntimeSvcNoOp.tryIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
boolean |
PatternSubexpressionPoolRuntimeSvcImpl.tryIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
boolean |
PatternSubexpressionPoolRuntimeSvc.tryIncreaseCount(EvalNode evalNode,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
static void |
ResultSetProcessorGroupedUtil.applyAggJoinResultKeyedJoin(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext,
Set<MultiKey<EventBean>> newEvents,
Object[] newDataMultiKey,
Set<MultiKey<EventBean>> oldEvents,
Object[] oldDataMultiKey)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
ResultSetProcessorGroupedUtil.applyAggViewResultKeyedView(AggregationService aggregationService,
AgentInstanceContext agentInstanceContext,
EventBean[] newData,
Object[] newDataMultiKey,
EventBean[] oldData,
Object[] oldDataMultiKey,
EventBean[] eventsPerStream)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
OutputConditionPolled |
ResultSetProcessorGroupedOutputFirstHelperImpl.getOrAllocate(Object mk,
AgentInstanceContext agentInstanceContext,
OutputConditionPolledFactory factory) |
OutputConditionPolled |
ResultSetProcessorGroupedOutputFirstHelper.getOrAllocate(Object mk,
AgentInstanceContext agentInstanceContext,
OutputConditionPolledFactory optionalOutputFirstConditionFactory) |
Modifier and Type | Method and Description |
---|---|
RowLimitProcessor |
RowLimitProcessorFactory.instantiate(AgentInstanceContext agentInstanceContext) |
OrderByProcessor |
OrderByProcessorFactory.instantiate(AgentInstanceContext agentInstanceContext) |
EventBean[] |
OrderByProcessor.sortRollup(EventBean[] outgoingEvents,
List<GroupByRollupKey> currentGenerators,
boolean newData,
AgentInstanceContext agentInstanceContext,
AggregationService aggregationService)
Sort the output events, using the provided group-by keys for
evaluating grouped aggregation functions, and avoiding the cost of
recomputing the keys.
|
Modifier and Type | Method and Description |
---|---|
static ResultSetProcessorGroupedOutputFirstHelper[] |
ResultSetProcessorRowPerGroupRollupUtil.initializeOutputFirstHelpers(ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
AgentInstanceContext agentInstanceContext,
Class[] groupKeyTypes,
AggregationGroupByRollupDesc groupByRollupDesc,
OutputConditionPolledFactory outputConditionPolledFactory)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
RowRecogNFAView.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
void |
RowRecogNFAViewSchedulerImpl.setScheduleCallback(AgentInstanceContext agentInstanceContext,
RowRecogNFAViewScheduleCallback scheduleCallback) |
void |
RowRecogNFAViewScheduler.setScheduleCallback(AgentInstanceContext agentInstanceContext,
RowRecogNFAViewScheduleCallback scheduleCallback) |
Constructor and Description |
---|
RowRecogNFAView(RowRecogNFAViewFactory factory,
AgentInstanceContext agentInstanceContext,
RowRecogNFAViewScheduler scheduler) |
Modifier and Type | Method and Description |
---|---|
boolean |
RowRecogNFAStateZeroToManyEvalNoCond.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateZeroToManyEvalCond.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateOneToManyEvalNoCond.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateOneToManyEvalCond.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateOneOptionalEvalNoCond.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateOneOptionalEvalCond.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateFilterEval.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateEndEval.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAStateAnyOneEval.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext) |
boolean |
RowRecogNFAState.matches(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext)
Evaluate a match.
|
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
RowRecogPartitionStateRepoGroupMeta.getAgentInstanceContext() |
Constructor and Description |
---|
RowRecogPartitionStateRepoGroupMeta(boolean hasInterval,
ExprEvaluator partitionExpression,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
SubSelectStrategyRealization |
SubSelectStrategyFactoryLocalViewPreloaded.instantiate(Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbackList,
int subqueryNumber,
boolean isRecoveringResilient) |
SubSelectStrategyRealization |
SubSelectStrategyFactoryIndexShare.instantiate(Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbackList,
int subqueryNumber,
boolean isRecoveringResilient) |
SubSelectStrategyRealization |
SubSelectStrategyFactory.instantiate(Viewable viewableRoot,
AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbackList,
int subqueryNumber,
boolean isRecoveringResilient) |
static Map<Integer,SubSelectFactoryResult> |
SubSelectHelperStart.startSubselects(Map<Integer,SubSelectFactory> subselects,
AgentInstanceContext agentInstanceContext,
List<AgentInstanceStopCallback> stopCallbacks,
boolean isRecoveringResilient) |
Constructor and Description |
---|
SubselectBufferObserver(EventTable[] eventIndex,
AgentInstanceContext agentInstanceContext)
Ctor.
|
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
TableInstanceBase.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
TableInstanceBase.getAgentInstanceContext() |
AgentInstanceContext |
TableInstance.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
TableInstance |
TableManagementServiceImpl.allocateTableInstance(Table table,
AgentInstanceContext agentInstanceContext) |
TableInstance |
TableManagementService.allocateTableInstance(Table table,
AgentInstanceContext agentInstanceContext) |
Constructor and Description |
---|
TableInstanceBase(Table table,
AgentInstanceContext agentInstanceContext) |
TableInstanceGroupedBase(Table table,
AgentInstanceContext agentInstanceContext) |
TableInstanceGroupedImpl(Table table,
AgentInstanceContext agentInstanceContext) |
TableInstanceUngroupedBase(Table table,
AgentInstanceContext agentInstanceContext) |
TableInstanceUngroupedImpl(Table table,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
static Map<Integer,ExprTableEvalStrategy> |
ExprTableEvalHelperStart.startTableAccess(Map<Integer,ExprTableEvalStrategyFactory> tableAccesses,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
void |
VariableReadWritePackage.writeVariables(EventBean[] eventsPerStream,
Map<String,Object> valuesWritten,
AgentInstanceContext agentInstanceContext)
Write new variable values and commit, evaluating assignment expressions using the given
events per stream.
|
Constructor and Description |
---|
VirtualDWViewImpl(VirtualDWViewFactory factory,
AgentInstanceContext agentInstanceContext,
VirtualDataWindow dataExternal) |
Modifier and Type | Method and Description |
---|---|
static FilterValueSetParam[][] |
FilterSpecActivatable.evaluateValueSet(FilterSpecParam[][] parameters,
MatchedEventMap matchedEvents,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Method and Description |
---|---|
static void |
AuditPath.auditContextPartition(boolean allocate,
AgentInstanceContext agentInstanceContext)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static 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 matters
|
static void |
AuditPath.auditDataflowSource(String dataflowName,
String dataFlowInstanceId,
String operatorName,
int operatorNumber,
AgentInstanceContext agentInstanceContext)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditDataflowTransition(String dataflowName,
String dataFlowInstanceId,
EPDataFlowState state,
EPDataFlowState newState,
AgentInstanceContext agentInstanceContext)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditPatternFalse(EvalFactoryNode factoryNode,
Object from,
AgentInstanceContext agentInstanceContext)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditPatternInstance(boolean increase,
EvalFactoryNode factoryNode,
AgentInstanceContext agentInstanceContext)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditPatternTrue(EvalFactoryNode factoryNode,
Object from,
MatchedEventMapMinimal matchEvent,
boolean isQuitted,
AgentInstanceContext agentInstanceContext)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditScheduleAdd(long nextScheduledTime,
AgentInstanceContext agentInstanceContext,
ScheduleHandle scheduleHandle,
ScheduleObjectType objectType,
String name)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditScheduleFire(AgentInstanceContext agentInstanceContext,
ScheduleObjectType objectType,
String name)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static void |
AuditPath.auditScheduleRemove(AgentInstanceContext agentInstanceContext,
ScheduleHandle scheduleHandle,
ScheduleObjectType objectType,
String name)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
void |
AuditProviderDefault.contextPartition(boolean allocate,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderContextPartition.contextPartition(boolean allocate,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDefault.dataflowOp(String dataFlowName,
String instanceId,
String operatorName,
int operatorNumber,
Object[] parameters,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDataflowOp.dataflowOp(String dataFlowName,
String instanceId,
String operatorName,
int operatorNumber,
Object[] parameters,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDefault.dataflowSource(String dataFlowName,
String dataFlowInstanceId,
String operatorName,
int operatorNumber,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDataflowSource.dataflowSource(String dataFlowName,
String dataFlowInstanceId,
String operatorName,
int operatorNumber,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDefault.dataflowTransition(String dataflowName,
String dataFlowInstanceId,
EPDataFlowState state,
EPDataFlowState newState,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDataflowTransition.dataflowTransition(String dataflowName,
String dataFlowInstanceId,
EPDataFlowState state,
EPDataFlowState newState,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderPattern.patternFalse(EvalFactoryNode factoryNode,
Object from,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDefault.patternFalse(EvalFactoryNode factoryNode,
Object from,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderPatternInstances.patternInstance(boolean increase,
EvalFactoryNode factoryNode,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDefault.patternInstance(boolean increase,
EvalFactoryNode factoryNode,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderPattern.patternTrue(EvalFactoryNode factoryNode,
Object from,
MatchedEventMapMinimal matchEvent,
boolean isQuitted,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderDefault.patternTrue(EvalFactoryNode factoryNode,
Object from,
MatchedEventMapMinimal matchEvent,
boolean isQuitted,
AgentInstanceContext agentInstanceContext) |
void |
AuditProviderSchedule.scheduleAdd(long nextScheduledTime,
AgentInstanceContext agentInstanceContext,
ScheduleHandle scheduleHandle,
ScheduleObjectType objectType,
String name) |
void |
AuditProviderDefault.scheduleAdd(long nextScheduledTime,
AgentInstanceContext agentInstanceContext,
ScheduleHandle scheduleHandle,
ScheduleObjectType type,
String name) |
void |
AuditProviderSchedule.scheduleFire(AgentInstanceContext agentInstanceContext,
ScheduleObjectType objectType,
String name) |
void |
AuditProviderDefault.scheduleFire(AgentInstanceContext agentInstanceContext,
ScheduleObjectType type,
String name) |
void |
AuditProviderSchedule.scheduleRemove(AgentInstanceContext agentInstanceContext,
ScheduleHandle scheduleHandle,
ScheduleObjectType objectType,
String name) |
void |
AuditProviderDefault.scheduleRemove(AgentInstanceContext agentInstanceContext,
ScheduleHandle scheduleHandle,
ScheduleObjectType type,
String name) |
void |
AuditProviderView.view(EventBean[] newData,
EventBean[] oldData,
AgentInstanceContext agentInstanceContext,
ViewFactory viewFactory) |
void |
AuditProviderDefault.view(EventBean[] newData,
EventBean[] oldData,
AgentInstanceContext agentInstanceContext,
ViewFactory viewFactory) |
Modifier and Type | Method and Description |
---|---|
void |
InstrumentationCommonDefault.aFilterActivationStream(AgentInstanceContext agentInstanceContext,
boolean subselect,
int subselectNumber) |
void |
InstrumentationCommon.aFilterActivationStream(AgentInstanceContext agentInstanceContext,
boolean subselect,
int subselectNumber) |
void |
InstrumentationCommonDefault.qContextPartitionAllocate(AgentInstanceContext agentInstanceContext) |
void |
InstrumentationCommon.qContextPartitionAllocate(AgentInstanceContext agentInstanceContext) |
void |
InstrumentationCommonDefault.qContextPartitionDestroy(AgentInstanceContext agentInstanceContext) |
void |
InstrumentationCommon.qContextPartitionDestroy(AgentInstanceContext agentInstanceContext) |
void |
InstrumentationCommonDefault.qFilterActivationStream(String eventTypeName,
int streamNumber,
AgentInstanceContext agentInstanceContext,
boolean subselect,
int subselectNumber) |
void |
InstrumentationCommon.qFilterActivationStream(String eventTypeName,
int streamNumber,
AgentInstanceContext agentInstanceContext,
boolean subselect,
int subselectNumber) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
StatementResourceHolder.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
StatementResourceHolder |
StatementResourceHolderBuilderImpl.build(AgentInstanceContext agentInstanceContext,
StatementAgentInstanceFactoryResult resultOfStart) |
StatementResourceHolder |
StatementResourceHolderBuilder.build(AgentInstanceContext agentInstanceContext,
StatementAgentInstanceFactoryResult resultOfStart) |
static StatementResourceHolder |
StatementResourceHolderUtil.populateHolder(AgentInstanceContext agentInstanceContext,
StatementAgentInstanceFactoryResult startResult) |
Constructor and Description |
---|
StatementResourceHolder(AgentInstanceContext agentInstanceContext,
AgentInstanceStopCallback agentInstanceStopCallback,
Viewable finalView,
AggregationService aggregationService,
PriorEvalStrategy[] priorEvalStrategies,
PreviousGetterStrategy[] previousGetterStrategies,
RowRecogPreviousStrategy rowRecogPreviousStrategy) |
Modifier and Type | Method and Description |
---|---|
AgentInstanceContext |
AgentInstanceViewFactoryChainContext.getAgentInstanceContext() |
Modifier and Type | Method and Description |
---|---|
static AgentInstanceViewFactoryChainContext |
AgentInstanceViewFactoryChainContext.create(ViewFactory[] viewFactoryChain,
AgentInstanceContext agentInstanceContext,
ViewResourceDelegateDesc viewResourceDelegate) |
static int |
ViewFactoryUtil.evaluateSizeParam(String viewName,
ExprEvaluator sizeEvaluator,
AgentInstanceContext context) |
Constructor and Description |
---|
AgentInstanceViewFactoryChainContext(AgentInstanceContext agentInstanceContext,
boolean isRemoveStream,
PreviousGetterStrategy previousNodeGetter,
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) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
UnivariateStatisticsView.agentInstanceContext |
protected AgentInstanceContext |
BaseBivariateStatisticsView.agentInstanceContext
Services required by implementing classes.
|
Constructor and Description |
---|
BaseBivariateStatisticsView(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) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
ExpressionViewBase.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
static boolean |
ExpressionBatchViewUtil.evaluate(EventBean[] eventsPerStream,
AgentInstanceContext agentInstanceContext,
ExpressionViewFactoryBase factory,
AggregationService aggregationService) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
ExternallyTimedBatchView.agentInstanceContext |
Constructor and Description |
---|
FirstEventView(FirstEventViewFactory viewFactory,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
FirstLengthWindowView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
FirstUniqueByPropertyView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
IntersectDefaultView.agentInstanceContext |
protected AgentInstanceContext |
IntersectBatchView.agentInstanceContext |
protected AgentInstanceContext |
IntersectAsymetricView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
KeepAllView.agentInstanceContext |
Constructor and Description |
---|
LastEventView(LastEventViewFactory viewFactory,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
LengthWindowView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
LengthBatchViewRStream.agentInstanceContext |
protected AgentInstanceContext |
LengthBatchView.agentInstanceContext |
Modifier and Type | Method and Description |
---|---|
ViewUpdatedCollection |
PriorEventViewFactory.makeViewUpdatedCollection(SortedSet<Integer> priorRequests,
AgentInstanceContext agentInstanceContext) |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
RankWindowView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
SortWindowView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
UnionView.agentInstanceContext |
protected AgentInstanceContext |
UnionAsymetricView.agentInstanceContext |
Modifier and Type | Field and Description |
---|---|
protected AgentInstanceContext |
UniqueByPropertyView.agentInstanceContext |
Copyright © 2005–2018. All rights reserved.