/// <summary>
 ///     Ctor.
 /// </summary>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="statementResultServiceImpl">handles result delivery</param>
 /// <param name="eventType">event type</param>
 public UpdateDispatchViewNonBlocking(
     EventType eventType,
     StatementResultService statementResultServiceImpl,
     DispatchService dispatchService)
     : base(eventType, statementResultServiceImpl, dispatchService)
 {
 }
Ejemplo n.º 2
0
 public TableOnUpdateViewFactory(StatementResultService statementResultService, TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, TableUpdateStrategy tableUpdateStrategy)
 {
     StatementResultService = statementResultService;
     TableMetadata          = tableMetadata;
     UpdateHelper           = updateHelper;
     TableUpdateStrategy    = tableUpdateStrategy;
 }
Ejemplo n.º 3
0
 public EPStatementInitServicesImpl(
     String statementName,
     IDictionary<StatementProperty, Object> statementProperties,
     Attribute[] annotations,
     String deploymentId,
     EventTypeResolver eventTypeResolver,
     FilterSpecActivatableRegistry filterSpecActivatableRegistry,
     FilterSharedBoolExprRegistery filterSharedBoolExprRegistery,
     FilterSharedLookupableRegistery filterSharedLookupableRegistery,
     ModuleIncidentals moduleIncidentals,
     bool recovery,
     StatementResourceService statementResourceService,
     StatementResultService statementResultService,
     EPServicesContext servicesContext)
 {
     StatementName = statementName;
     StatementProperties = statementProperties;
     Annotations = annotations;
     DeploymentId = deploymentId;
     EventTypeResolver = eventTypeResolver;
     FilterSpecActivatableRegistry = filterSpecActivatableRegistry;
     FilterSharedBoolExprRegistery = filterSharedBoolExprRegistery;
     FilterSharedLookupableRegistery = filterSharedLookupableRegistery;
     ModuleIncidentals = moduleIncidentals;
     IsRecovery = recovery;
     StatementResourceService = statementResourceService;
     StatementResultService = statementResultService;
     ServicesContext = servicesContext;
 }
Ejemplo n.º 4
0
        // settable for view-sharing

        /// <summary>
        /// Constructor.
        /// </summary>
        /// <param name="stmtEngineServices">is the engine services for the statement</param>
        /// <param name="schedulingService">implementation for schedule registration</param>
        /// <param name="scheduleBucket">is for ordering scheduled callbacks within the view statements</param>
        /// <param name="epStatementHandle">is the statements-own handle for use in registering callbacks with services</param>
        /// <param name="viewResultionService">is a service for resolving view namespace and name to a view factory</param>
        /// <param name="patternResolutionService">is the service that resolves pattern objects for the statement</param>
        /// <param name="statementExtensionSvcContext">provide extension points for custom statement resources</param>
        /// <param name="statementStopService">for registering a callback invoked when a statement is stopped</param>
        /// <param name="methodResolutionService">is a service for resolving static methods and aggregation functions</param>
        /// <param name="patternContextFactory">is the pattern-level services and context information factory</param>
        /// <param name="filterService">is the filtering service</param>
        /// <param name="statementResultService">handles awareness of listeners/subscriptions for a statement customizing output produced</param>
        /// <param name="internalEventEngineRouteDest">routing destination</param>
        /// <param name="annotations">The annotations.</param>
        /// <param name="statementAgentInstanceRegistry">The statement agent instance registry.</param>
        /// <param name="defaultAgentInstanceLock">The default agent instance lock.</param>
        /// <param name="contextDescriptor">The context descriptor.</param>
        /// <param name="patternSubexpressionPoolSvc">The pattern subexpression pool SVC.</param>
        /// <param name="matchRecognizeStatePoolStmtSvc">The match recognize state pool statement SVC.</param>
        /// <param name="statelessSelect">if set to <c>true</c> [stateless select].</param>
        /// <param name="contextControllerFactoryService">The context controller factory service.</param>
        /// <param name="defaultAgentInstanceScriptContext">The default agent instance script context.</param>
        /// <param name="aggregationServiceFactoryService">The aggregation service factory service.</param>
        /// <param name="scriptingService">The scripting service.</param>
        /// <param name="writesToTables">if set to <c>true</c> [writes to tables].</param>
        /// <param name="statementUserObject">The statement user object.</param>
        /// <param name="statementSemiAnonymousTypeRegistry">The statement semi anonymous type registry.</param>
        /// <param name="priority">The priority.</param>
        public StatementContext(
            StatementContextEngineServices stmtEngineServices,
            SchedulingService schedulingService,
            ScheduleBucket scheduleBucket,
            EPStatementHandle epStatementHandle,
            ViewResolutionService viewResultionService,
            PatternObjectResolutionService patternResolutionService,
            StatementExtensionSvcContext statementExtensionSvcContext,
            StatementStopService statementStopService,
            MethodResolutionService methodResolutionService,
            PatternContextFactory patternContextFactory,
            FilterService filterService,
            StatementResultService statementResultService,
            InternalEventRouteDest internalEventEngineRouteDest,
            Attribute[] annotations,
            StatementAIResourceRegistry statementAgentInstanceRegistry,
            IReaderWriterLock defaultAgentInstanceLock,
            ContextDescriptor contextDescriptor,
            PatternSubexpressionPoolStmtSvc patternSubexpressionPoolSvc,
            MatchRecognizeStatePoolStmtSvc matchRecognizeStatePoolStmtSvc,
            bool statelessSelect,
            ContextControllerFactoryService contextControllerFactoryService,
            AgentInstanceScriptContext defaultAgentInstanceScriptContext,
            AggregationServiceFactoryService aggregationServiceFactoryService,
            ScriptingService scriptingService,
            bool writesToTables,
            object statementUserObject,
            StatementSemiAnonymousTypeRegistry statementSemiAnonymousTypeRegistry,
            int priority)
        {
            _stmtEngineServices               = stmtEngineServices;
            SchedulingService                 = schedulingService;
            ScheduleBucket                    = scheduleBucket;
            EpStatementHandle                 = epStatementHandle;
            ViewResolutionService             = viewResultionService;
            PatternResolutionService          = patternResolutionService;
            StatementExtensionServicesContext = statementExtensionSvcContext;
            StatementStopService              = statementStopService;
            MethodResolutionService           = methodResolutionService;
            PatternContextFactory             = patternContextFactory;
            FilterService                = filterService;
            _statementResultService      = statementResultService;
            InternalEventEngineRouteDest = internalEventEngineRouteDest;
            ScheduleAdjustmentService    = stmtEngineServices.ConfigSnapshot.EngineDefaults.ExecutionConfig.IsAllowIsolatedService ? new ScheduleAdjustmentService() : null;
            Annotations = annotations;
            StatementAgentInstanceRegistry = statementAgentInstanceRegistry;
            DefaultAgentInstanceLock       = defaultAgentInstanceLock;
            ContextDescriptor                 = contextDescriptor;
            PatternSubexpressionPoolSvc       = patternSubexpressionPoolSvc;
            MatchRecognizeStatePoolStmtSvc    = matchRecognizeStatePoolStmtSvc;
            IsStatelessSelect                 = statelessSelect;
            ContextControllerFactoryService   = contextControllerFactoryService;
            DefaultAgentInstanceScriptContext = defaultAgentInstanceScriptContext;
            AggregationServiceFactoryService  = aggregationServiceFactoryService;
            ScriptingService    = scriptingService;
            IsWritesToTables    = writesToTables;
            StatementUserObject = statementUserObject;
            StatementSemiAnonymousTypeRegistry = statementSemiAnonymousTypeRegistry;
            Priority = priority;
        }
Ejemplo n.º 5
0
 /// <summary>Ctor. </summary>
 /// <param name="eventType">the type of event to indicator</param>
 /// <param name="statementResultService">determines whether listeners or subscribers are attached.</param>
 public InternalRoutePreprocessView(
     EventType eventType,
     StatementResultService statementResultService)
 {
     _eventType             = eventType;
     StatementResultService = statementResultService;
 }
Ejemplo n.º 6
0
 /// <summary>
 /// Ctor.
 /// </summary>
 /// <param name="statementResultServiceImpl">handles result delivery</param>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="threadLocalManager">The thread local manager.</param>
 public UpdateDispatchViewNonBlocking(
     StatementResultService statementResultServiceImpl,
     DispatchService dispatchService,
     IThreadLocalManager threadLocalManager)
     : base(statementResultServiceImpl, dispatchService, threadLocalManager)
 {
 }
 /// <summary>
 /// Ctor.
 /// </summary>
 /// <param name="statementResultService">handles result delivery</param>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="msecTimeout">timeout for preserving dispatch order through blocking</param>
 /// <param name="timeSourceService">time source provider</param>
 /// <param name="threadLocalManager">The thread local manager.</param>
 public UpdateDispatchViewBlockingSpin(StatementResultService statementResultService, DispatchService dispatchService, long msecTimeout, TimeSourceService timeSourceService, IThreadLocalManager threadLocalManager)
     : base(statementResultService, dispatchService, threadLocalManager)
 {
     _currentFutureSpin = new UpdateDispatchFutureSpin(timeSourceService); // use a completed future as a start
     _msecTimeout       = msecTimeout;
     _timeSourceService = timeSourceService;
 }
Ejemplo n.º 8
0
 public NamedWindowProcessor CreateProcessor(
     string name,
     NamedWindowMgmtServiceImpl namedWindowMgmtService,
     NamedWindowDispatchService namedWindowDispatchService,
     string contextName,
     EventType eventType,
     StatementResultService statementResultService,
     ValueAddEventProcessor revisionProcessor,
     string eplExpression,
     string statementName,
     bool isPrioritized,
     bool isEnableSubqueryIndexShare,
     bool enableQueryPlanLog,
     MetricReportingService metricReportingService,
     bool isBatchingDataWindow,
     bool isVirtualDataWindow,
     ICollection <string> optionalUniqueKeyProps,
     string eventTypeAsName,
     StatementContext statementContextCreateWindow)
 {
     return(new NamedWindowProcessor(
                name, namedWindowMgmtService, namedWindowDispatchService, contextName, eventType, statementResultService,
                revisionProcessor, eplExpression, statementName, isPrioritized, isEnableSubqueryIndexShare,
                enableQueryPlanLog, metricReportingService, isBatchingDataWindow, isVirtualDataWindow,
                optionalUniqueKeyProps, eventTypeAsName, statementContextCreateWindow));
 }
Ejemplo n.º 9
0
 /// <summary>
 /// Ctor.
 /// </summary>
 /// <param name="statementId">The statement id.</param>
 /// <param name="eventAdapterService">for creating events</param>
 /// <param name="variableService">for looking up variables</param>
 /// <param name="variableName">is the name of the variable to create</param>
 /// <param name="statementResultService">for coordinating on whether insert and remove stream events should be posted</param>
 /// <param name="agentInstanceId"></param>
 public CreateVariableView(int statementId, EventAdapterService eventAdapterService, VariableService variableService, string variableName, StatementResultService statementResultService, int agentInstanceId)
 {
     _eventAdapterService    = eventAdapterService;
     _variableName           = variableName;
     _statementResultService = statementResultService;
     _reader    = variableService.GetReader(variableName, agentInstanceId);
     _eventType = GetEventType(statementId, eventAdapterService, _reader.VariableMetaData);
 }
Ejemplo n.º 10
0
 /// <summary>
 /// Ctor.
 /// </summary>
 /// <param name="statementId">The statement id.</param>
 /// <param name="eventAdapterService">for creating events</param>
 /// <param name="variableService">for looking up variables</param>
 /// <param name="variableName">is the name of the variable to create</param>
 /// <param name="statementResultService">for coordinating on whether insert and remove stream events should be posted</param>
 public CreateVariableView(String statementId, EventAdapterService eventAdapterService, VariableService variableService, String variableName, StatementResultService statementResultService)
 {
     _eventAdapterService    = eventAdapterService;
     _variableName           = variableName;
     _statementResultService = statementResultService;
     _reader    = variableService.GetReader(variableName, VariableServiceConstants.NOCONTEXT_AGENTINSTANCEID);
     _eventType = GetEventType(statementId, eventAdapterService, _reader.VariableMetaData);
 }
Ejemplo n.º 11
0
 /// <summary>Ctor. </summary>
 /// <param name="statementResultService">for awareness of listeners and subscribers handles output results</param>
 /// <param name="syntheticProcessor">is the processor generating synthetic events according to the select clause</param>
 /// <param name="bindProcessor">for generating natural object column results</param>
 public SelectExprResultProcessor(StatementResultService statementResultService,
                                  SelectExprProcessor syntheticProcessor,
                                  BindProcessor bindProcessor)
 {
     _statementResultService = statementResultService;
     _syntheticProcessor     = syntheticProcessor;
     _bindProcessor          = bindProcessor;
 }
Ejemplo n.º 12
0
 /// <summary>
 /// Ctor.
 /// </summary>
 /// <param name="statementResultService">handles result delivery</param>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="threadLocalManager">The thread local manager.</param>
 protected UpdateDispatchViewBase(
     StatementResultService statementResultService,
     DispatchService dispatchService,
     IThreadLocalManager threadLocalManager)
 {
     _isDispatchWaiting     = threadLocalManager.Create(() => new Mutable <bool>());
     DispatchService        = dispatchService;
     StatementResultService = statementResultService;
 }
Ejemplo n.º 13
0
 public override void NewResult(UniformPair <EventBean[]> results)
 {
     StatementResultService.Indicate(results);
     if (!IsDispatchWaiting.Value)
     {
         DispatchService.AddExternal(this);
         IsDispatchWaiting.Value = true;
     }
 }
Ejemplo n.º 14
0
 /// <summary>
 ///     Ctor.
 /// </summary>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="statementResultServiceImpl">handles result delivery</param>
 /// <param name="eventType">event type</param>
 public UpdateDispatchViewBase(
     EventType eventType,
     StatementResultService statementResultServiceImpl,
     DispatchService dispatchService)
 {
     this.dispatchService = dispatchService;
     statementResultService = statementResultServiceImpl;
     this.eventType = eventType;
 }
Ejemplo n.º 15
0
 public void SetUp()
 {
     _container = SupportContainer.Reset();
     _statementResultService = new StatementResultServiceImpl(
         "name", null, null, new ThreadingServiceImpl(new ConfigurationEngineDefaults.ThreadingConfig()),
         _container.ThreadLocalManager());
     _selectExprEventTypeRegistry = new SelectExprEventTypeRegistry(
         "abc", new StatementEventTypeRefImpl(_container.RWLockManager()));
 }
Ejemplo n.º 16
0
        public NamedWindowProcessor AddProcessor(
            string name,
            string contextName,
            EventType eventType,
            StatementResultService statementResultService,
            ValueAddEventProcessor revisionProcessor,
            string eplExpression,
            string statementName,
            bool isPrioritized,
            bool isEnableSubqueryIndexShare,
            bool isBatchingDataWindow,
            bool isVirtualDataWindow,
            ICollection <string> optionalUniqueKeyProps,
            string eventTypeAsName,
            StatementContext statementContextCreateWindow,
            NamedWindowDispatchService namedWindowDispatchService,
            ILockManager lockManager)
        {
            if (_processors.ContainsKey(name))
            {
                throw new ViewProcessingException("A named window by name '" + name + "' has already been created");
            }

            var processor = namedWindowDispatchService.CreateProcessor(
                name, this,
                namedWindowDispatchService,
                contextName,
                eventType,
                statementResultService,
                revisionProcessor,
                eplExpression,
                statementName,
                isPrioritized,
                isEnableSubqueryIndexShare,
                _enableQueryPlanLog,
                _metricReportingService,
                isBatchingDataWindow,
                isVirtualDataWindow,
                optionalUniqueKeyProps,
                eventTypeAsName,
                statementContextCreateWindow,
                lockManager);

            _processors.Put(name, processor);

            if (!_observers.IsEmpty())
            {
                var theEvent = new NamedWindowLifecycleEvent(name, processor, NamedWindowLifecycleEvent.LifecycleEventType.CREATE);
                foreach (var observer in _observers)
                {
                    observer.Observe(theEvent);
                }
            }

            return(processor);
        }
Ejemplo n.º 17
0
 public OutputProcessViewDirectFactory(
     StatementContext statementContext,
     OutputStrategyPostProcessFactory postProcessFactory,
     ResultSetProcessorHelperFactory resultSetProcessorHelperFactory)
 {
     _statementContext               = statementContext;
     _statementResultService         = statementContext.StatementResultService;
     PostProcessFactory              = postProcessFactory;
     ResultSetProcessorHelperFactory = resultSetProcessorHelperFactory;
 }
Ejemplo n.º 18
0
 /// <summary>
 ///     Ctor.
 /// </summary>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="msecTimeout">timeout for preserving dispatch order through blocking</param>
 /// <param name="statementResultServiceImpl">handles result delivery</param>
 /// <param name="eventType">event type</param>
 public UpdateDispatchViewBlockingWait(
     EventType eventType,
     StatementResultService statementResultServiceImpl,
     DispatchService dispatchService,
     long msecTimeout)
     : base(eventType, statementResultServiceImpl, dispatchService)
 {
     currentFutureWait = new UpdateDispatchFutureWait(); // use a completed future as a start
     this.msecTimeout = msecTimeout;
 }
Ejemplo n.º 19
0
        private volatile IDictionary <EPStatementAgentInstanceHandle, IList <NamedWindowConsumerView> > _consumersNonContext;  // handles as copy-on-write

        public NamedWindowTailView(EventType eventType, NamedWindowService namedWindowService, StatementResultService statementResultService, ValueAddEventProcessor revisionProcessor, bool prioritized, bool parentBatchWindow)
        {
            _eventType              = eventType;
            _namedWindowService     = namedWindowService;
            _statementResultService = statementResultService;
            _revisionProcessor      = revisionProcessor;
            _isPrioritized          = prioritized;
            _isParentBatchWindow    = parentBatchWindow;
            _consumersNonContext    = NamedWindowUtil.CreateConsumerMap(_isPrioritized);
        }
Ejemplo n.º 20
0
 public TableOnSelectViewFactory(TableMetadata tableMetadata, InternalEventRouter internalEventRouter, EPStatementHandle statementHandle, EventBeanReader eventBeanReader, bool distinct, StatementResultService statementResultService, InternalEventRouteDest internalEventRouteDest, bool deleteAndSelect)
 {
     _tableMetadata = tableMetadata;
     InternalEventRouter = internalEventRouter;
     StatementHandle = statementHandle;
     EventBeanReader = eventBeanReader;
     IsDistinct = distinct;
     StatementResultService = statementResultService;
     InternalEventRouteDest = internalEventRouteDest;
     _deleteAndSelect = deleteAndSelect;
 }
Ejemplo n.º 21
0
        /// <summary>
        /// Ctor.
        /// </summary>
        /// <param name="statementId">The statement identifier.</param>
        /// <param name="desc">specification for the on-set statement</param>
        /// <param name="eventAdapterService">for creating statements</param>
        /// <param name="variableService">for setting variables</param>
        /// <param name="statementResultService">for coordinating on whether insert and remove stream events should be posted</param>
        /// <param name="exprEvaluatorContext">context for expression evalauation</param>
        /// <throws>com.espertech.esper.epl.expression.core.ExprValidationException if the assignment expressions are invalid</throws>
        public OnSetVariableViewFactory(string statementId, OnTriggerSetDesc desc, EventAdapterService eventAdapterService, VariableService variableService, StatementResultService statementResultService, ExprEvaluatorContext exprEvaluatorContext)
        {
            EventAdapterService    = eventAdapterService;
            VariableService        = variableService;
            StatementResultService = statementResultService;

            VariableReadWritePackage = new VariableReadWritePackage(desc.Assignments, variableService, eventAdapterService);
            var outputEventTypeName = statementId + "_outsetvar";

            EventType = eventAdapterService.CreateAnonymousMapType(outputEventTypeName, VariableReadWritePackage.VariableTypes);
        }
Ejemplo n.º 22
0
 public StatementLightweight(
     StatementProvider statementProvider,
     StatementInformationalsRuntime statementInformationals,
     StatementResultService statementResultService,
     StatementContext statementContext)
 {
     StatementProvider = statementProvider;
     StatementInformationals = statementInformationals;
     StatementResultService = statementResultService;
     StatementContext = statementContext;
 }
Ejemplo n.º 23
0
 public NamedWindowOnMergeViewFactory(EventType namedWindowEventType,
                                      NamedWindowOnMergeHelper namedWindowOnMergeHelper,
                                      StatementResultService statementResultService,
                                      StatementMetricHandle createNamedWindowMetricHandle,
                                      MetricReportingService metricReportingService)
     : base(namedWindowEventType)
 {
     _namedWindowOnMergeHelper      = namedWindowOnMergeHelper;
     _statementResultService        = statementResultService;
     _createNamedWindowMetricHandle = createNamedWindowMetricHandle;
     _metricReportingService        = metricReportingService;
 }
 /// <summary>
 ///     Ctor.
 /// </summary>
 /// <param name="dispatchService">for performing the dispatch</param>
 /// <param name="msecTimeout">timeout for preserving dispatch order through blocking</param>
 /// <param name="statementResultService">handles result delivery</param>
 /// <param name="timeSourceService">time source provider</param>
 /// <param name="eventType">event type</param>
 public UpdateDispatchViewBlockingSpin(
     EventType eventType,
     StatementResultService statementResultService,
     DispatchService dispatchService,
     long msecTimeout,
     TimeSourceService timeSourceService)
     : base(eventType, statementResultService, dispatchService)
 {
     currentFutureSpin = new UpdateDispatchFutureSpin(timeSourceService); // use a completed future as a start
     this.msecTimeout = msecTimeout;
     this.timeSourceService = timeSourceService;
 }
Ejemplo n.º 25
0
        public override void HandleMatching(
            EventBean[] triggerEvents,
            EventBean[] matchingEvents)
        {
            agentInstanceContext.InstrumentationProvider.QInfraOnAction(
                OnTriggerType.ON_SELECT,
                triggerEvents,
                matchingEvents);

            // clear state from prior results
            resultSetProcessor.Clear();

            // build join result
            // use linked hash set to retain order of join results for last/first/window to work most intuitively
            ISet<MultiKeyArrayOfKeys<EventBean>> newEvents =
                OnExprViewNamedWindowSelect.BuildJoinResult(triggerEvents, matchingEvents);

            // process matches
            UniformPair<EventBean[]> pair = resultSetProcessor.ProcessJoinResult(
                newEvents,
                Collections.GetEmptySet<MultiKeyArrayOfKeys<EventBean>>(),
                false);
            EventBean[] newData = pair?.First;

            // handle distinct and insert
            newData = InfraOnSelectUtil.HandleDistintAndInsert(
                newData,
                parent,
                agentInstanceContext,
                tableInstanceInsertInto,
                audit);

            // The on-select listeners receive the events selected
            if ((newData != null) && (newData.Length > 0)) {
                // And post only if we have listeners/subscribers that need the data
                StatementResultService statementResultService = agentInstanceContext.StatementResultService;
                if (statementResultService.IsMakeNatural || statementResultService.IsMakeSynthetic) {
                    Child.Update(newData, null);
                }
            }

            // clear state from prior results
            resultSetProcessor.Clear();

            // Events to delete are indicated via old data
            if (deleteAndSelect) {
                foreach (EventBean @event in matchingEvents) {
                    tableInstance.DeleteEvent(@event);
                }
            }

            agentInstanceContext.InstrumentationProvider.AInfraOnAction();
        }
Ejemplo n.º 26
0
 public StatementContext(
     IContainer container,
     ContextRuntimeDescriptor contextRuntimeDescriptor,
     string deploymentId,
     int statementId,
     string statementName,
     string moduleName,
     StatementInformationalsRuntime statementInformationals,
     object userObjectRuntime,
     StatementContextRuntimeServices statementContextRuntimeServices,
     EPStatementHandle epStatementHandle,
     IDictionary<int, FilterSpecActivatable> filterSpecActivatables,
     PatternSubexpressionPoolStmtSvc patternSubexpressionPoolSvc,
     RowRecogStatePoolStmtSvc rowRecogStatePoolStmtSvc,
     ScheduleBucket scheduleBucket,
     StatementAIResourceRegistry statementAIResourceRegistry,
     StatementCPCacheService statementCPCacheService,
     StatementAIFactoryProvider statementAIFactoryProvider,
     StatementResultService statementResultService,
     UpdateDispatchView updateDispatchView,
     FilterService filterService,
     SchedulingService schedulingService,
     InternalEventRouteDest internalEventRouteDest)
 {
     Container = container;
     ContextRuntimeDescriptor = contextRuntimeDescriptor;
     DeploymentId = deploymentId;
     StatementId = statementId;
     StatementName = statementName;
     ModuleName = moduleName;
     StatementInformationals = statementInformationals;
     UserObjectRuntime = userObjectRuntime;
     StatementContextRuntimeServices = statementContextRuntimeServices;
     EpStatementHandle = epStatementHandle;
     FilterSpecActivatables = filterSpecActivatables;
     PatternSubexpressionPoolSvc = patternSubexpressionPoolSvc;
     RowRecogStatePoolStmtSvc = rowRecogStatePoolStmtSvc;
     ScheduleBucket = scheduleBucket;
     StatementAIResourceRegistry = statementAIResourceRegistry;
     StatementCPCacheService = statementCPCacheService;
     StatementAIFactoryProvider = statementAIFactoryProvider;
     StatementResultService = statementResultService;
     UpdateDispatchView = updateDispatchView;
     StatementContextFilterEvalEnv = new StatementContextFilterEvalEnv(
         statementContextRuntimeServices.ImportServiceRuntime,
         statementInformationals.Annotations,
         statementContextRuntimeServices.VariableManagementService,
         statementContextRuntimeServices.TableExprEvaluatorContext);
     this.FilterService = filterService;
     this.SchedulingService = schedulingService;
     this.InternalEventRouteDest = internalEventRouteDest;
 }
Ejemplo n.º 27
0
 public TableOnMergeViewFactory(
     TableMetadata tableMetadata,
     TableOnMergeHelper onMergeHelper,
     StatementResultService statementResultService,
     StatementMetricHandle metricsHandle,
     MetricReportingServiceSPI metricReportingService)
 {
     TableMetadata          = tableMetadata;
     OnMergeHelper          = onMergeHelper;
     StatementResultService = statementResultService;
     MetricsHandle          = metricsHandle;
     MetricReportingService = metricReportingService;
 }
Ejemplo n.º 28
0
 public NamedWindowOnSelectViewFactory(EventType namedWindowEventType, InternalEventRouter internalEventRouter, bool addToFront, EPStatementHandle statementHandle, EventBeanReader eventBeanReader, bool distinct, StatementResultService statementResultService, InternalEventRouteDest internalEventRouteDest, bool deleteAndSelect, StreamSelector?optionalStreamSelector, string optionalInsertIntoTableName)
     : base(namedWindowEventType)
 {
     InternalEventRouter          = internalEventRouter;
     IsAddToFront                 = addToFront;
     StatementHandle              = statementHandle;
     EventBeanReader              = eventBeanReader;
     IsDistinct                   = distinct;
     StatementResultService       = statementResultService;
     InternalEventRouteDest       = internalEventRouteDest;
     _deleteAndSelect             = deleteAndSelect;
     OptionalStreamSelector       = optionalStreamSelector;
     _optionalInsertIntoTableName = optionalInsertIntoTableName;
 }
Ejemplo n.º 29
0
 public NamedWindowTailView CreateTailView(
     EventType eventType,
     NamedWindowMgmtService namedWindowMgmtService,
     NamedWindowDispatchService namedWindowDispatchService,
     StatementResultService statementResultService,
     ValueAddEventProcessor revisionProcessor,
     bool prioritized,
     bool parentBatchWindow,
     string contextName,
     TimeSourceService timeSourceService,
     ConfigurationEngineDefaults.Threading threadingConfig)
 {
     return(new NamedWindowTailView(eventType, namedWindowMgmtService, namedWindowDispatchService, statementResultService, revisionProcessor, _isPrioritized, parentBatchWindow, timeSourceService, threadingConfig));
 }
Ejemplo n.º 30
0
 public NamedWindowTailViewBase(
     EventType eventType,
     bool isParentBatchWindow,
     EPStatementInitServices services)
 {
     this.eventType = eventType;
     namedWindowManagementService = services.NamedWindowManagementService;
     namedWindowDispatchService = services.NamedWindowDispatchService;
     statementResultService = services.StatementResultService;
     isPrioritized = services.RuntimeSettingsService.ConfigurationRuntime.Execution.IsPrioritized;
     this.isParentBatchWindow = isParentBatchWindow;
     threadingConfig = services.RuntimeSettingsService.ConfigurationRuntime.Threading;
     timeSourceService = services.TimeSourceService;
 }