Class EPServicesContextFactoryDefault

java.lang.Object
com.espertech.esper.runtime.internal.kernel.service.EPServicesContextFactoryBase
com.espertech.esper.runtime.internal.kernel.service.EPServicesContextFactoryDefault
All Implemented Interfaces:
EPServicesContextFactory

public class EPServicesContextFactoryDefault extends EPServicesContextFactoryBase
  • Constructor Summary

    Constructors
    Constructor
    Description
     
  • Method Summary

    Modifier and Type
    Method
    Description
    createEPRuntime(EPServicesContext services, AtomicBoolean serviceStatusProvider)
     
    protected EPServicesHA
    initHA(String runtimeURI, com.espertech.esper.common.client.configuration.Configuration configurationSnapshot, RuntimeEnvContext runtimeEnvContext, com.espertech.esper.common.internal.util.ManagedReadWriteLock eventProcessingRWLock, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, EPRuntimeOptions options, com.espertech.esper.common.internal.context.util.ParentClassLoader classLoaderParent)
     
    protected com.espertech.esper.common.internal.context.activator.ViewableActivatorFactory
     
    protected com.espertech.esper.common.internal.epl.agg.core.AggregationServiceFactoryService
    makeAggregationServiceFactoryService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt)
     
    protected com.espertech.esper.common.internal.context.mgr.ContextServiceFactory
    makeContextServiceFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
     
    protected com.espertech.esper.common.internal.epl.dataflow.filtersvcadapter.DataFlowFilterServiceAdapter
     
     
    protected com.espertech.esper.common.internal.event.core.EventBeanTypedEventFactory
    makeEventBeanTypedEventFactory(com.espertech.esper.common.internal.event.avro.EventTypeAvroHandler eventTypeAvroHandler)
     
    protected com.espertech.esper.common.internal.serde.runtime.event.EventSerdeFactory
    makeEventSerdeFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices ext)
     
    protected com.espertech.esper.common.internal.epl.index.base.EventTableIndexService
    makeEventTableIndexService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
     
    protected com.espertech.esper.common.internal.event.avro.EventTypeAvroHandler
    makeEventTypeAvroHandler(com.espertech.esper.common.internal.settings.ClasspathImportServiceRuntime classpathImportServiceRuntime, com.espertech.esper.common.client.configuration.common.ConfigurationCommonEventTypeMeta.AvroSettings avroSettings, com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt)
     
    protected com.espertech.esper.common.internal.event.eventtypefactory.EventTypeFactory
    makeEventTypeFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepositoryImpl eventTypeRepositoryPreconfigured, DeploymentLifecycleServiceImpl deploymentLifecycleService, com.espertech.esper.common.internal.event.core.EventBeanTypedEventFactory eventBeanTypedEventFactory)
     
    protected com.espertech.esper.common.internal.event.core.EventTypeResolvingBeanFactory
    makeEventTypeResolvingBeanFactory(com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepository eventTypeRepository, com.espertech.esper.common.internal.event.avro.EventTypeAvroHandler eventTypeAvroHandler)
     
    protected com.espertech.esper.common.internal.serde.runtime.eventtype.EventTypeSerdeRepository
    makeEventTypeSerdeRepository(com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepository preconfigureds, com.espertech.esper.common.internal.collection.PathRegistry<String,com.espertech.esper.common.client.EventType> eventTypePathRegistry)
     
    protected com.espertech.esper.common.internal.filterspec.FilterBooleanExpressionFactory
     
    makeFilterService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepository eventTypeRepository, StatementLifecycleServiceImpl statementLifecycleService, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, com.espertech.esper.common.internal.event.core.EventTypeIdResolver eventTypeIdResolver, com.espertech.esper.common.internal.filterspec.FilterSharedLookupableRepository filterSharedLookupableRepository)
     
    protected com.espertech.esper.common.internal.filterspec.FilterSharedBoolExprRepository
     
    protected com.espertech.esper.common.internal.filterspec.FilterSharedLookupableRepository
     
    protected com.espertech.esper.common.internal.epl.historical.datacache.HistoricalDataCacheFactory
    makeHistoricalDataCacheFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
     
    protected com.espertech.esper.common.internal.statement.multimatch.MultiMatchHandlerFactory
    makeMultiMatchHandlerFactory(com.espertech.esper.common.client.configuration.Configuration configurationInformation)
     
    protected com.espertech.esper.common.internal.epl.namedwindow.consume.NamedWindowConsumerManagementService
    makeNamedWindowConsumerManagementService(com.espertech.esper.common.internal.epl.namedwindow.core.NamedWindowManagementService namedWindowManagementService)
     
    protected com.espertech.esper.common.internal.epl.namedwindow.consume.NamedWindowDispatchService
    makeNamedWindowDispatchService(SchedulingServiceSPI schedulingService, com.espertech.esper.common.client.configuration.Configuration configurationSnapshot, com.espertech.esper.common.internal.util.ManagedReadWriteLock eventProcessingRWLock, com.espertech.esper.common.internal.settings.ExceptionHandlingService exceptionHandlingService, com.espertech.esper.common.internal.epl.variable.core.VariableManagementService variableManagementService, com.espertech.esper.common.internal.epl.table.core.TableManagementService tableManagementService, com.espertech.esper.common.internal.metrics.stmtmetrics.MetricReportingService metricReportingService)
     
    protected com.espertech.esper.common.internal.epl.namedwindow.consume.NamedWindowFactoryService
     
    protected com.espertech.esper.common.internal.epl.pattern.core.PatternFactoryService
     
    protected com.espertech.esper.common.internal.epl.pattern.pool.PatternSubexpressionPoolRuntimeSvc
    makePatternSubexpressionPoolSvc(long maxSubexpressions, boolean maxSubexpressionPreventStart, com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
     
    protected com.espertech.esper.common.internal.epl.resultset.core.ResultSetProcessorHelperFactory
    makeResultSetProcessorHelperFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices ext)
     
    protected com.espertech.esper.common.internal.epl.rowrecog.state.RowRecogStateRepoFactory
     
    protected com.espertech.esper.common.internal.settings.RuntimeSettingsService
    makeRuntimeSettingsService(com.espertech.esper.common.client.configuration.Configuration configurationSnapshot)
     
    makeSchedulingService(EPServicesHA epServicesHA, com.espertech.esper.common.internal.schedule.TimeSourceService timeSourceService, com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, com.espertech.esper.common.internal.context.util.StatementContextResolver statementContextResolver, ZoneId zoneId)
     
     
    protected com.espertech.esper.common.internal.statement.resource.StatementResourceHolderBuilder
     
    protected com.espertech.esper.common.internal.epl.table.core.TableManagementService
    makeTableManagementService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.epl.table.core.TableExprEvaluatorContext tableExprEvaluatorContext)
     
    makeThreadingService(com.espertech.esper.common.client.configuration.Configuration configs)
     
    protected com.espertech.esper.common.internal.epl.variable.core.VariableManagementService
    makeVariableManagementService(com.espertech.esper.common.client.configuration.Configuration configs, SchedulingServiceSPI schedulingService, com.espertech.esper.common.internal.event.core.EventBeanTypedEventFactory eventBeanTypedEventFactory, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, EPServicesHA epServicesHA)
     
    protected com.espertech.esper.common.internal.view.core.ViewFactoryService
     
    protected com.espertech.esper.common.internal.view.previous.ViewServicePreviousFactory
    makeViewServicePreviousFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices ext)
     

    Methods inherited from class com.espertech.esper.runtime.internal.kernel.service.EPServicesContextFactoryBase

    createServicesContext, initExceptionHandling

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Constructor Details

    • EPServicesContextFactoryDefault

      public EPServicesContextFactoryDefault()
  • Method Details

    • makeRuntimeSettingsService

      protected com.espertech.esper.common.internal.settings.RuntimeSettingsService makeRuntimeSettingsService(com.espertech.esper.common.client.configuration.Configuration configurationSnapshot)
      Specified by:
      makeRuntimeSettingsService in class EPServicesContextFactoryBase
    • initHA

      protected EPServicesHA initHA(String runtimeURI, com.espertech.esper.common.client.configuration.Configuration configurationSnapshot, RuntimeEnvContext runtimeEnvContext, com.espertech.esper.common.internal.util.ManagedReadWriteLock eventProcessingRWLock, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, EPRuntimeOptions options, com.espertech.esper.common.internal.context.util.ParentClassLoader classLoaderParent)
      Specified by:
      initHA in class EPServicesContextFactoryBase
    • initViewableActivatorFactory

      protected com.espertech.esper.common.internal.context.activator.ViewableActivatorFactory initViewableActivatorFactory()
      Specified by:
      initViewableActivatorFactory in class EPServicesContextFactoryBase
    • makeFilterService

      protected FilterServiceSPI makeFilterService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepository eventTypeRepository, StatementLifecycleServiceImpl statementLifecycleService, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, com.espertech.esper.common.internal.event.core.EventTypeIdResolver eventTypeIdResolver, com.espertech.esper.common.internal.filterspec.FilterSharedLookupableRepository filterSharedLookupableRepository)
      Specified by:
      makeFilterService in class EPServicesContextFactoryBase
    • createEPRuntime

      public EPEventServiceImpl createEPRuntime(EPServicesContext services, AtomicBoolean serviceStatusProvider)
    • makeStatementResourceHolderBuilder

      protected com.espertech.esper.common.internal.statement.resource.StatementResourceHolderBuilder makeStatementResourceHolderBuilder()
      Specified by:
      makeStatementResourceHolderBuilder in class EPServicesContextFactoryBase
    • makeFilterSharedLookupableRepository

      protected com.espertech.esper.common.internal.filterspec.FilterSharedLookupableRepository makeFilterSharedLookupableRepository()
      Specified by:
      makeFilterSharedLookupableRepository in class EPServicesContextFactoryBase
    • makeAggregationServiceFactoryService

      protected com.espertech.esper.common.internal.epl.agg.core.AggregationServiceFactoryService makeAggregationServiceFactoryService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt)
      Specified by:
      makeAggregationServiceFactoryService in class EPServicesContextFactoryBase
    • makeViewFactoryService

      protected com.espertech.esper.common.internal.view.core.ViewFactoryService makeViewFactoryService()
      Specified by:
      makeViewFactoryService in class EPServicesContextFactoryBase
    • makePatternFactoryService

      protected com.espertech.esper.common.internal.epl.pattern.core.PatternFactoryService makePatternFactoryService()
      Specified by:
      makePatternFactoryService in class EPServicesContextFactoryBase
    • makeEventTypeFactory

      protected com.espertech.esper.common.internal.event.eventtypefactory.EventTypeFactory makeEventTypeFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepositoryImpl eventTypeRepositoryPreconfigured, DeploymentLifecycleServiceImpl deploymentLifecycleService, com.espertech.esper.common.internal.event.core.EventBeanTypedEventFactory eventBeanTypedEventFactory)
      Specified by:
      makeEventTypeFactory in class EPServicesContextFactoryBase
    • makeEventTypeResolvingBeanFactory

      protected com.espertech.esper.common.internal.event.core.EventTypeResolvingBeanFactory makeEventTypeResolvingBeanFactory(com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepository eventTypeRepository, com.espertech.esper.common.internal.event.avro.EventTypeAvroHandler eventTypeAvroHandler)
      Specified by:
      makeEventTypeResolvingBeanFactory in class EPServicesContextFactoryBase
    • makeSchedulingService

      protected SchedulingServiceSPI makeSchedulingService(EPServicesHA epServicesHA, com.espertech.esper.common.internal.schedule.TimeSourceService timeSourceService, com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, com.espertech.esper.common.internal.context.util.StatementContextResolver statementContextResolver, ZoneId zoneId)
      Specified by:
      makeSchedulingService in class EPServicesContextFactoryBase
    • makeFilterBooleanExpressionFactory

      protected com.espertech.esper.common.internal.filterspec.FilterBooleanExpressionFactory makeFilterBooleanExpressionFactory(StatementLifecycleServiceImpl statementLifecycleService)
      Specified by:
      makeFilterBooleanExpressionFactory in class EPServicesContextFactoryBase
    • makeMultiMatchHandlerFactory

      protected com.espertech.esper.common.internal.statement.multimatch.MultiMatchHandlerFactory makeMultiMatchHandlerFactory(com.espertech.esper.common.client.configuration.Configuration configurationInformation)
      Specified by:
      makeMultiMatchHandlerFactory in class EPServicesContextFactoryBase
    • makeContextServiceFactory

      protected com.espertech.esper.common.internal.context.mgr.ContextServiceFactory makeContextServiceFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
      Specified by:
      makeContextServiceFactory in class EPServicesContextFactoryBase
    • makeViewServicePreviousFactory

      protected com.espertech.esper.common.internal.view.previous.ViewServicePreviousFactory makeViewServicePreviousFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices ext)
      Specified by:
      makeViewServicePreviousFactory in class EPServicesContextFactoryBase
    • makeEPStatementFactory

      protected EPStatementFactory makeEPStatementFactory()
      Specified by:
      makeEPStatementFactory in class EPServicesContextFactoryBase
    • makeEventBeanTypedEventFactory

      protected com.espertech.esper.common.internal.event.core.EventBeanTypedEventFactory makeEventBeanTypedEventFactory(com.espertech.esper.common.internal.event.avro.EventTypeAvroHandler eventTypeAvroHandler)
      Specified by:
      makeEventBeanTypedEventFactory in class EPServicesContextFactoryBase
    • makeEventTypeSerdeRepository

      protected com.espertech.esper.common.internal.serde.runtime.eventtype.EventTypeSerdeRepository makeEventTypeSerdeRepository(com.espertech.esper.common.internal.event.eventtyperepo.EventTypeRepository preconfigureds, com.espertech.esper.common.internal.collection.PathRegistry<String,com.espertech.esper.common.client.EventType> eventTypePathRegistry)
      Specified by:
      makeEventTypeSerdeRepository in class EPServicesContextFactoryBase
    • makeEventTableIndexService

      protected com.espertech.esper.common.internal.epl.index.base.EventTableIndexService makeEventTableIndexService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
      Specified by:
      makeEventTableIndexService in class EPServicesContextFactoryBase
    • makeResultSetProcessorHelperFactory

      protected com.espertech.esper.common.internal.epl.resultset.core.ResultSetProcessorHelperFactory makeResultSetProcessorHelperFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices ext)
      Specified by:
      makeResultSetProcessorHelperFactory in class EPServicesContextFactoryBase
    • makeNamedWindowDispatchService

      protected com.espertech.esper.common.internal.epl.namedwindow.consume.NamedWindowDispatchService makeNamedWindowDispatchService(SchedulingServiceSPI schedulingService, com.espertech.esper.common.client.configuration.Configuration configurationSnapshot, com.espertech.esper.common.internal.util.ManagedReadWriteLock eventProcessingRWLock, com.espertech.esper.common.internal.settings.ExceptionHandlingService exceptionHandlingService, com.espertech.esper.common.internal.epl.variable.core.VariableManagementService variableManagementService, com.espertech.esper.common.internal.epl.table.core.TableManagementService tableManagementService, com.espertech.esper.common.internal.metrics.stmtmetrics.MetricReportingService metricReportingService)
      Specified by:
      makeNamedWindowDispatchService in class EPServicesContextFactoryBase
    • makeNamedWindowConsumerManagementService

      protected com.espertech.esper.common.internal.epl.namedwindow.consume.NamedWindowConsumerManagementService makeNamedWindowConsumerManagementService(com.espertech.esper.common.internal.epl.namedwindow.core.NamedWindowManagementService namedWindowManagementService)
      Specified by:
      makeNamedWindowConsumerManagementService in class EPServicesContextFactoryBase
    • makeNamedWindowFactoryService

      protected com.espertech.esper.common.internal.epl.namedwindow.consume.NamedWindowFactoryService makeNamedWindowFactoryService()
      Specified by:
      makeNamedWindowFactoryService in class EPServicesContextFactoryBase
    • makeFilterSharedBoolExprRepository

      protected com.espertech.esper.common.internal.filterspec.FilterSharedBoolExprRepository makeFilterSharedBoolExprRepository()
      Specified by:
      makeFilterSharedBoolExprRepository in class EPServicesContextFactoryBase
    • makeVariableManagementService

      protected com.espertech.esper.common.internal.epl.variable.core.VariableManagementService makeVariableManagementService(com.espertech.esper.common.client.configuration.Configuration configs, SchedulingServiceSPI schedulingService, com.espertech.esper.common.internal.event.core.EventBeanTypedEventFactory eventBeanTypedEventFactory, com.espertech.esper.common.internal.settings.RuntimeSettingsService runtimeSettingsService, EPServicesHA epServicesHA)
      Specified by:
      makeVariableManagementService in class EPServicesContextFactoryBase
    • makeTableManagementService

      protected com.espertech.esper.common.internal.epl.table.core.TableManagementService makeTableManagementService(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt, com.espertech.esper.common.internal.epl.table.core.TableExprEvaluatorContext tableExprEvaluatorContext)
      Specified by:
      makeTableManagementService in class EPServicesContextFactoryBase
    • makeRowRecogStateRepoFactory

      protected com.espertech.esper.common.internal.epl.rowrecog.state.RowRecogStateRepoFactory makeRowRecogStateRepoFactory()
      Specified by:
      makeRowRecogStateRepoFactory in class EPServicesContextFactoryBase
    • makeEventTypeAvroHandler

      protected com.espertech.esper.common.internal.event.avro.EventTypeAvroHandler makeEventTypeAvroHandler(com.espertech.esper.common.internal.settings.ClasspathImportServiceRuntime classpathImportServiceRuntime, com.espertech.esper.common.client.configuration.common.ConfigurationCommonEventTypeMeta.AvroSettings avroSettings, com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExt)
      Specified by:
      makeEventTypeAvroHandler in class EPServicesContextFactoryBase
    • makeHistoricalDataCacheFactory

      protected com.espertech.esper.common.internal.epl.historical.datacache.HistoricalDataCacheFactory makeHistoricalDataCacheFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
      Specified by:
      makeHistoricalDataCacheFactory in class EPServicesContextFactoryBase
    • makeDataFlowFilterServiceAdapter

      protected com.espertech.esper.common.internal.epl.dataflow.filtersvcadapter.DataFlowFilterServiceAdapter makeDataFlowFilterServiceAdapter()
      Specified by:
      makeDataFlowFilterServiceAdapter in class EPServicesContextFactoryBase
    • makeThreadingService

      protected ThreadingService makeThreadingService(com.espertech.esper.common.client.configuration.Configuration configs)
      Specified by:
      makeThreadingService in class EPServicesContextFactoryBase
    • makeEventSerdeFactory

      protected com.espertech.esper.common.internal.serde.runtime.event.EventSerdeFactory makeEventSerdeFactory(com.espertech.esper.common.internal.context.module.RuntimeExtensionServices ext)
      Specified by:
      makeEventSerdeFactory in class EPServicesContextFactoryBase
    • makeStageRecoveryService

      protected StageRecoveryService makeStageRecoveryService(EPServicesHA epServicesHA)
      Specified by:
      makeStageRecoveryService in class EPServicesContextFactoryBase
    • makePatternSubexpressionPoolSvc

      protected com.espertech.esper.common.internal.epl.pattern.pool.PatternSubexpressionPoolRuntimeSvc makePatternSubexpressionPoolSvc(long maxSubexpressions, boolean maxSubexpressionPreventStart, com.espertech.esper.common.internal.context.module.RuntimeExtensionServices runtimeExtensionServices)
      Specified by:
      makePatternSubexpressionPoolSvc in class EPServicesContextFactoryBase