Package | Description |
---|---|
com.espertech.esper.core.context.mgr |
Context management.
|
com.espertech.esper.core.deploy |
Module and deployment utility and parser.
|
com.espertech.esper.core.service |
Implementation of client package interfaces, glue code
|
com.espertech.esper.core.support |
Internal-use-only services for unit and regression testing
|
com.espertech.esper.epl.core |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.core.eval |
Select expression evaluators.
|
com.espertech.esper.epl.db |
Database SQL polling views and caches
|
com.espertech.esper.epl.declexpr |
Declared expression handling.
|
com.espertech.esper.epl.enummethod.dot |
Enumeration method utility classes and input data sources.
|
com.espertech.esper.epl.enummethod.eval |
Enumeration method implementations.
|
com.espertech.esper.epl.expression.accessagg |
Access-aggregation expressions.
|
com.espertech.esper.epl.expression.core |
Core expression classes.
|
com.espertech.esper.epl.expression.dot |
Chained expression functionality.
|
com.espertech.esper.epl.expression.ops |
Operator expressions.
|
com.espertech.esper.epl.expression.prev |
'Previous'-group expressions.
|
com.espertech.esper.epl.expression.subquery |
Subselect expressions.
|
com.espertech.esper.epl.expression.table |
Table access and identifiers expressions.
|
com.espertech.esper.epl.property |
Classes for handling events-within-events.
|
com.espertech.esper.epl.rettype |
EPL-internal expression return type.
|
com.espertech.esper.epl.script |
Script expression evaluation.
|
com.espertech.esper.epl.spec |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.table.mgmt |
Table-related services and metadata.
|
com.espertech.esper.epl.table.strategy |
Table access evaluators.
|
com.espertech.esper.epl.updatehelper |
Helpers for EPL update functionality.
|
com.espertech.esper.epl.variable |
Variable service and variable collections
|
com.espertech.esper.epl.view |
Internal processing views for output rate limiting, filtering and internal event routing
|
com.espertech.esper.event |
This package defines the internal event APIs.
|
com.espertech.esper.event.arr |
Object-array event type.
|
com.espertech.esper.event.avro |
Avro event type core interfaces.
|
com.espertech.esper.event.bean |
JavaBean and legacy Java underlying event classes are here.
|
com.espertech.esper.event.map |
Map-underlying event classes are here.
|
com.espertech.esper.event.property |
Parsers and business objects to handle nested, indexed, mapped or generally complex properties for use in JavaBean
access
|
com.espertech.esper.event.vaevent |
Value added events are revision events and variant events.
|
com.espertech.esper.event.wrap |
Event wrap refers to adding properties to an existing event
|
com.espertech.esper.event.xml |
XML event wrappers
|
com.espertech.esper.filter |
Main switchboard filtering and routing of incoming events to interested statements is performed in this package.
|
com.espertech.esper.pattern |
Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active
pattern instance
|
com.espertech.esper.plugin |
APIs for plug-in adapter (for input-output) and plug-in event representation (event types and event objects) are in
this package.
|
com.espertech.esper.view |
View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering.
|
com.espertech.esper.view.stat |
Views computing statistical values.
|
com.espertech.esper.view.std |
Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc.
|
Modifier and Type | Method and Description |
---|---|
Object |
ContextStatePathValueBinding.byteArrayToObject(byte[] bytes,
EventAdapterService eventAdapterService) |
Object |
ContextStateCacheNoSave.MyContextStatePathValueBindingSerializable.byteArrayToObject(byte[] bytes,
EventAdapterService eventAdapterService) |
Object |
ContextStateCacheNoSave.ContextStateCacheNoSaveInitTermBinding.byteArrayToObject(byte[] bytes,
EventAdapterService eventAdapterService) |
Constructor and Description |
---|
ContextControllerHashedGetterSingleRow(String statementName,
String functionName,
Pair<Class,EngineImportSingleRowDesc> func,
List<ExprNode> parameters,
int granularity,
EngineImportService engineImportService,
EventType eventType,
EventAdapterService eventAdapterService,
int statementId,
TableService tableService,
String engineURI) |
Modifier and Type | Method and Description |
---|---|
static List<EventType> |
EPLModuleUtil.undeployTypes(Set<String> referencedTypes,
StatementEventTypeRef statementEventTypeRef,
EventAdapterService eventAdapterService,
FilterService filterService) |
Constructor and Description |
---|
EPDeploymentAdminImpl(EPAdministratorSPI epService,
ManagedReadWriteLock eventProcessingRWLock,
DeploymentStateService deploymentStateService,
StatementEventTypeRef statementEventTypeRef,
EventAdapterService eventAdapterService,
StatementIsolationService statementIsolationService,
FilterService filterService,
TimeZone timeZone,
ConfigurationEngineDefaults.ExceptionHandling.UndeployRethrowPolicy undeployRethrowPolicy) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
StatementContextEngineServices.getEventAdapterService() |
EventAdapterService |
StatementContext.getEventAdapterService()
Returns service for generating events and handling event types.
|
EventAdapterService |
EPServicesContext.getEventAdapterService()
Returns event type resolution service.
|
EventAdapterService |
EPServiceProviderSPI.getEventAdapterService()
Get the EventAdapterService for this engine.
|
EventAdapterService |
EPServiceProviderImpl.getEventAdapterService() |
Modifier and Type | Method and Description |
---|---|
protected static void |
EPServicesContextFactoryDefault.init(EventAdapterService eventAdapterService,
ConfigurationInformation configSnapshot,
EngineImportService engineImportService)
Initialize event adapter service for config snapshot.
|
Constructor and Description |
---|
ConfigurationOperationsImpl(EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator,
EngineImportService engineImportService,
VariableService variableService,
EngineSettingsService engineSettingsService,
ValueAddEventService valueAddEventService,
MetricReportingService metricReportingService,
StatementEventTypeRef statementEventTypeRef,
StatementVariableRef statementVariableRef,
PluggableObjectCollection plugInViews,
FilterService filterService,
PatternSubexpressionPoolEngineSvc patternSubexpressionPoolSvc,
MatchRecognizeStatePoolEngineSvc matchRecognizeStatePoolEngineSvc,
TableService tableService,
Map<String,Object> transientConfiguration) |
EPServicesContext(String engineURI,
SchedulingServiceSPI schedulingService,
EventAdapterService eventAdapterService,
EngineImportService engineImportService,
EngineSettingsService engineSettingsService,
DatabaseConfigService databaseConfigService,
PluggableObjectCollection plugInViews,
StatementLockFactory statementLockFactory,
ManagedReadWriteLock eventProcessingRWLock,
EngineLevelExtensionServicesContext engineLevelExtensionServicesContext,
EngineEnvContext engineEnvContext,
StatementContextFactory statementContextFactory,
PluggableObjectCollection plugInPatternObjects,
TimerService timerService,
FilterServiceSPI filterService,
StreamFactoryService streamFactoryService,
NamedWindowMgmtService namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
VariableService variableService,
TableService tableService,
TimeSourceService timeSourceService,
ValueAddEventService valueAddEventService,
MetricReportingServiceSPI metricsReportingService,
StatementEventTypeRef statementEventTypeRef,
StatementVariableRef statementVariableRef,
ConfigurationInformation configSnapshot,
ThreadingService threadingServiceImpl,
InternalEventRouterImpl internalEventRouter,
StatementIsolationService statementIsolationService,
SchedulingMgmtService schedulingMgmtService,
DeploymentStateService deploymentStateService,
ExceptionHandlingService exceptionHandlingService,
PatternNodeFactory patternNodeFactory,
EventTypeIdGenerator eventTypeIdGenerator,
StatementMetadataFactory statementMetadataFactory,
ContextManagementService contextManagementService,
PatternSubexpressionPoolEngineSvc patternSubexpressionPoolSvc,
MatchRecognizeStatePoolEngineSvc matchRecognizeStatePoolEngineSvc,
DataFlowService dataFlowService,
ExprDeclaredService exprDeclaredService,
ContextControllerFactoryFactorySvc contextControllerFactoryFactorySvc,
ContextManagerFactoryService contextManagerFactoryService,
EPStatementFactory epStatementFactory,
RegexHandlerFactory regexHandlerFactory,
ViewableActivatorFactory viewableActivatorFactory,
FilterNonPropertyRegisteryService filterNonPropertyRegisteryService,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
ViewServicePreviousFactory viewServicePreviousFactory,
EventTableIndexService eventTableIndexService,
EPRuntimeIsolatedFactory epRuntimeIsolatedFactory,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
DataCacheFactory dataCacheFactory,
MultiMatchHandlerFactory multiMatchHandlerFactory,
NamedWindowConsumerMgmtService namedWindowConsumerMgmtService,
AggregationFactoryFactory aggregationFactoryFactory) |
StatementContextEngineServices(String engineURI,
EventAdapterService eventAdapterService,
NamedWindowMgmtService namedWindowMgmtService,
VariableService variableService,
TableService tableService,
EngineSettingsService engineSettingsService,
ValueAddEventService valueAddEventService,
ConfigurationInformation configSnapshot,
MetricReportingServiceSPI metricReportingService,
ViewService viewService,
ExceptionHandlingService exceptionHandlingService,
ExpressionResultCacheService expressionResultCacheService,
StatementEventTypeRef statementEventTypeRef,
TableExprEvaluatorContext tableExprEvaluatorContext,
EngineLevelExtensionServicesContext engineLevelExtensionServicesContext,
RegexHandlerFactory regexHandlerFactory,
StatementLockFactory statementLockFactory,
ContextManagementService contextManagementService,
ViewServicePreviousFactory viewServicePreviousFactory,
EventTableIndexService eventTableIndexService,
PatternNodeFactory patternNodeFactory,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
TimeSourceService timeSourceService,
EngineImportService engineImportService,
AggregationFactoryFactory aggregationFactoryFactory,
SchedulingService schedulingService,
ExprDeclaredService exprDeclaredService) |
Modifier and Type | Method and Description |
---|---|
static EventAdapterService |
SupportEventAdapterService.getService() |
Modifier and Type | Field and Description |
---|---|
protected EventAdapterService |
SelectExprProcessorTypableMapForge.eventAdapterService |
protected EventAdapterService |
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceBase.eventAdapterService |
protected EventAdapterService |
MethodPollingExecStrategyBase.eventAdapterService |
Modifier and Type | Method and Description |
---|---|
static SelectExprProcessor |
SelectExprJoinWildcardProcessorFactory.create(Collection<Integer> assignedTypeNumberStack,
int statementId,
String statementName,
String[] streamNames,
EventType[] streamTypes,
EventAdapterService eventAdapterService,
InsertIntoDesc insertIntoDesc,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
EngineImportService engineImportService,
Annotation[] annotations,
ConfigurationInformation configuration,
TableService tableService,
String engineURI) |
static HistoricalEventViewable |
MethodPollingViewableFactory.createPollMethodView(int streamNumber,
MethodStreamSpec methodStreamSpec,
EventAdapterService eventAdapterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
EngineImportService engineImportService,
SchedulingService schedulingService,
ScheduleBucket scheduleBucket,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
String contextName,
DataCacheFactory dataCacheFactory,
StatementContext statementContext)
Creates a method-invocation polling view for use as a stream that calls a method, or pulls results from cache.
|
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingJoinWildcard(EventAdapterService eventAdapterService,
EventType eventType,
String[] streamNames,
EventType[] streamTypes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingNonJoin(EventAdapterService eventAdapterService,
EventType eventType,
boolean isUsingWildcard,
StreamTypeService typeService,
ExprEvaluator[] expressionNodes,
ExprForge[] forges,
String[] columnNames,
Object[] expressionReturnTypes,
EngineImportService engineImportService,
InsertIntoDesc insertIntoDesc,
String[] columnNamesAsProvided,
boolean allowNestableTargetFragmentTypes,
String statementName) |
static SelectExprProcessor |
SelectExprProcessorFactory.getProcessor(Collection<Integer> assignedTypeNumberStack,
SelectClauseElementCompiled[] selectionList,
boolean isUsingWildcard,
InsertIntoDesc insertIntoDesc,
EventType optionalInsertIntoEventType,
ForClauseSpec forClauseSpec,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
StatementResultService statementResultService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
EngineImportService engineImportService,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
TableService tableService,
TimeProvider timeProvider,
String engineURI,
int statementId,
String statementName,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configuration,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback,
NamedWindowMgmtService namedWindowMgmtService,
IntoTableSpec intoTableClause,
com.espertech.esper.epl.core.GroupByRollupInfo groupByRollupInfo,
StatementExtensionSvcContext statementExtensionSvcContext) |
SelectExprProcessor |
SelectExprProcessorRepresentationFactory.makeJoinWildcard(String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService) |
void |
MethodPollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
String engineURI,
Map<Integer,List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
StatementContext statementContext) |
Constructor and Description |
---|
MethodPollingExecStrategyBase(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyBaseArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyBaseCollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyBaseIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyEventBeans(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyMapArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyMapCollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyMapIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyMapPlain(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyOAArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyOACollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyOAIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyOAPlain(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyPOJOArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyPOJOCollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyPOJOIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
MethodPollingExecStrategyPOJOPlain(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
String variableName,
VariableService variableService) |
SelectExprInsertNativeExpressionCoerceAvro(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService) |
SelectExprInsertNativeExpressionCoerceBase(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService) |
SelectExprInsertNativeExpressionCoerceMap(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService) |
SelectExprInsertNativeExpressionCoerceNative(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService) |
SelectExprInsertNativeExpressionCoerceObjectArray(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService) |
SelectExprJoinWildcardProcessorMap(String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService) |
SelectExprJoinWildcardProcessorObjectArray(String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService) |
SelectExprProcessorEvalStreamInsertNamedWindow(int streamNum,
EventType namedWindowAsType,
Class returnType,
EventAdapterService eventAdapterService) |
SelectExprProcessorHelper(Collection<Integer> assignedTypeNumberStack,
List<SelectClauseExprCompiledSpec> selectionList,
List<SelectExprStreamDesc> selectedStreams,
InsertIntoDesc insertIntoDesc,
EventType optionalInsertIntoOverrideType,
boolean isUsingWildcard,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
EngineImportService engineImportService,
int statementId,
String statementName,
Annotation[] annotations,
ConfigurationInformation configuration,
NamedWindowMgmtService namedWindowMgmtService,
TableService tableService,
com.espertech.esper.epl.core.GroupByRollupInfo groupByRollupInfo) |
SelectExprProcessorTypableMapForge(EventType mapType,
ExprForge innerForge,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
SelectExprContext.getEventAdapterService() |
EventAdapterService |
EvalBaseFirstProp.getEventAdapterService() |
EventAdapterService |
EvalBase.getEventAdapterService() |
Constructor and Description |
---|
EvalInsertBeanRecast(EventType targetType,
EventAdapterService eventAdapterService,
int streamNumber,
EventType[] typesPerStream) |
EvalInsertBeanWrapRecast(WrapperEventType targetType,
EventAdapterService eventAdapterService,
int streamNumber,
EventType[] typesPerStream) |
EvalInsertCoercionAvro(EventType resultEventType,
EventAdapterService eventAdapterService) |
EvalInsertCoercionMap(EventType resultEventType,
EventAdapterService eventAdapterService) |
EvalInsertCoercionObjectArray(EventType resultEventType,
EventAdapterService eventAdapterService) |
SelectExprContext(ExprEvaluator[] expressionNodes,
String[] columnNames,
EventAdapterService eventAdapterService) |
Constructor and Description |
---|
EvalInsertNoWildcardSingleColCoercionRevisionFunc(SelectExprContext selectExprContext,
EventType resultEventType,
ValueAddEventProcessor vaeProcessor,
EventType vaeInnerEventType,
TriFunction<EventAdapterService,Object,EventType,EventBean> func) |
Modifier and Type | Method and Description |
---|---|
static HistoricalEventViewable |
DatabasePollingViewableFactory.createDBStatementView(int statementId,
int streamNumber,
DBStatementStreamSpec databaseStreamSpec,
DatabaseConfigService databaseConfigService,
EventAdapterService eventAdapterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
SQLColumnTypeConversion columnTypeConversionHook,
SQLOutputRowConversion outputRowConversionHook,
boolean enableJDBCLogging,
DataCacheFactory dataCacheFactory,
StatementContext statementContext)
Creates the viewable for polling via database SQL query.
|
void |
DatabasePollingViewable.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
String engineURI,
Map<Integer,List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
StatementContext statementContext) |
Constructor and Description |
---|
PollExecStrategyDBQuery(EventAdapterService eventAdapterService,
EventType eventType,
ConnectionCache connectionCache,
String preparedStatementText,
Map<String,DBOutputTypeDesc> outputTypes,
SQLColumnTypeConversion columnTypeConversionHook,
SQLOutputRowConversion outputRowConversionHook,
boolean enableJDBCLogging)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventType |
ExprDeclaredForgeBase.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprDeclaredForgeBase.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
abstract EventType[] |
ExprDotForgeEnumMethodBase.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
abstract EnumForge |
ExprDotForgeEnumMethodBase.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EventType |
PropertyDotScalarIterable.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarCollection.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarArrayForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotEventSingleForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotEventCollectionForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarIterable.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotScalarArrayForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotEventSingleForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyDotEventCollectionForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
static ExprDotStaticMethodWrap |
ExprDotStaticMethodWrapFactory.make(Method method,
EventAdapterService eventAdapterService,
List<ExprChainedSpec> modifiedChain,
String optionalEventTypeName) |
Constructor and Description |
---|
ExprDotStaticMethodWrapArrayEvents(EventAdapterService eventAdapterService,
BeanEventType type) |
ExprDotStaticMethodWrapIterableEvents(EventAdapterService eventAdapterService,
BeanEventType type) |
WrappingCollection(EventAdapterService eventAdapterService,
BeanEventType type,
Iterator inner) |
WrappingCollection(EventAdapterService eventAdapterService,
BeanEventType type,
Object array) |
WrappingIterator(EventAdapterService eventAdapterService,
BeanEventType type,
Object array) |
Modifier and Type | Method and Description |
---|---|
EventType[] |
ExprDotForgeWhere.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeToMap.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeTakeWhileAndLast.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeTakeAndTakeLast.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeSumOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeSetExceptUnionIntersect.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeSequenceEqual.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeSelectFrom.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeReverse.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeOrderByAscDesc.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeNoOp.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeMostLeastFrequent.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeMinMax.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeMinByMaxBy.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeGroupBy.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeFirstLastOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeDistinct.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeCountOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeAverage.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeAllOfAnyOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotForgeAggregate.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EnumForge |
ExprDotForgeWhere.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeToMap.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeTakeWhileAndLast.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeTakeAndTakeLast.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeSumOf.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeSetExceptUnionIntersect.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeSequenceEqual.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeSelectFrom.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeReverse.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeOrderByAscDesc.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeNoOp.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeMostLeastFrequent.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeMinMax.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeMinByMaxBy.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeGroupBy.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeFirstLastOf.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeDistinct.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeCountOf.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeAverage.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeAllOfAnyOf.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumForge |
ExprDotForgeAggregate.getEnumForge(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprPlugInAggMultiFunctionNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggMultiFunctionLinearAccessNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggCountMinSketchNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprPlugInAggMultiFunctionNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggMultiFunctionLinearAccessNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprAggCountMinSketchNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
ExprValidationContext.getEventAdapterService() |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprEnumerationForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprEnumerationForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
static ExprNodeUtilMethodDesc |
ExprNodeUtility.resolveMethodAllowWildcardAndStream(String className,
Class optionalClass,
String methodName,
List<ExprNode> parameters,
EngineImportService engineImportService,
EventAdapterService eventAdapterService,
int statementId,
boolean allowWildcard,
EventType wildcardType,
ExprNodeUtilResolveExceptionHandler exceptionHandler,
String functionName,
TableService tableService,
String engineURI) |
Constructor and Description |
---|
ExprValidationContext(StreamTypeService streamTypeService,
EngineImportService engineImportService,
StatementExtensionSvcContext statementExtensionSvcContext,
ViewResourceDelegateUnverified viewResourceDelegate,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
EventAdapterService eventAdapterService,
String statementName,
int statementId,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
boolean disablePropertyExpressionEventCollCache,
boolean allowRollupFunctions,
boolean allowBindingConsumption,
boolean isUnidirectionalJoin,
String intoTableName,
boolean isFilterExpression) |
Modifier and Type | Method and Description |
---|---|
static ExprDotEnumerationSourceForge |
ExprDotNodeUtility.getEnumerationSource(ExprNode inputExpression,
StreamTypeService streamTypeService,
EventAdapterService eventAdapterService,
int statementId,
boolean hasEnumerationMethod,
boolean disablePropertyExpressionEventCollCache) |
EventType |
ExprDotNodeForgeRootChild.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprDotNodeForgeRootChild.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
static EventType[] |
ExprDotNodeUtility.getSingleLambdaParamEventType(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
EventAdapterService eventAdapterService) |
static ObjectArrayEventType |
ExprDotNodeUtility.makeTransientOAType(String enumMethod,
String propertyName,
Class type,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprArrayNodeForge.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprArrayNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprArrayNodeForge.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprArrayNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprPreviousNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprPreviousNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
ExprSubselectRowNode.SubselectMultirowType.getEventAdapterService() |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprSubselectRowNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectInNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectExistsNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectAllSomeAnyNode.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectRowNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectInNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectExistsNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprSubselectAllSomeAnyNode.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprTableIdentNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubprop.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableIdentNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableAccessNodeSubprop.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
static PropertyEvaluator |
PropertyEvaluatorFactory.makeEvaluator(PropertyEvalSpec spec,
EventType sourceEventType,
String optionalSourceStreamName,
EventAdapterService eventAdapterService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
String engineURI,
int statementId,
String statementName,
Annotation[] annotations,
Collection<Integer> assignedTypeNumberStack,
ConfigurationInformation configuration,
NamedWindowMgmtService namedWindowMgmtService,
StatementExtensionSvcContext statementExtensionSvcContext) |
Modifier and Type | Method and Description |
---|---|
static EPType |
EPTypeHelper.optionalFromEnumerationExpr(int statementId,
EventAdapterService eventAdapterService,
ExprNode exprNode) |
Modifier and Type | Method and Description |
---|---|
static AgentInstanceScriptContext |
AgentInstanceScriptContext.from(EventAdapterService eventAdapterService) |
EventType |
ExprNodeScriptEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprNodeScriptEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
static EventType |
FilterStreamSpecRaw.resolveType(String engineURI,
String eventName,
EventAdapterService eventAdapterService,
URI[] optionalResolutionURIs)
Resolves a given event name to an event type.
|
Constructor and Description |
---|
TableMetadataInternalEventToPublic(ObjectArrayEventType publicEventType,
TableMetadataColumnPairPlainCol[] plains,
TableMetadataColumnPairAggMethod[] methods,
TableMetadataColumnPairAggAccess[] accessors,
EventAdapterService eventAdapterService) |
TableStateRowFactory(ObjectArrayEventType objectArrayEventType,
EngineImportService engineImportService,
AggregationMethodFactory[] methodFactories,
AggregationStateFactory[] stateFactories,
int[] groupKeyIndexes,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprTableExprEvaluatorAccess.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableExprEvaluatorAccess.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
static EventBeanUpdateHelper |
EventBeanUpdateHelperFactory.make(String updatedWindowOrTableName,
EventTypeSPI eventTypeSPI,
List<OnTriggerSetAssignment> assignments,
String updatedAlias,
EventType optionalTriggeringEventType,
boolean isCopyOnWrite,
String statementName,
String engineURI,
EventAdapterService eventAdapterService,
boolean isFireAndForget) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
OnSetVariableViewFactory.getEventAdapterService() |
Modifier and Type | Method and Description |
---|---|
static EventType |
CreateVariableView.getEventType(int statementId,
EventAdapterService eventAdapterService,
VariableMetaData variableMetaData) |
Constructor and Description |
---|
CreateVariableView(int statementId,
EventAdapterService eventAdapterService,
VariableService variableService,
String variableName,
StatementResultService statementResultService,
int agentInstanceId)
Ctor.
|
OnSetVariableViewFactory(int statementId,
OnTriggerSetDesc desc,
EventAdapterService eventAdapterService,
VariableService variableService,
StatementResultService statementResultService,
ExprEvaluatorContext exprEvaluatorContext)
Ctor.
|
VariableReadWritePackage(List<OnTriggerSetAssignment> assignments,
VariableService variableService,
EventAdapterService eventAdapterService,
String statementName)
Ctor.
|
VariableServiceImpl(int startVersion,
long millisecondLifetimeOldVersions,
TimeProvider timeProvider,
EventAdapterService eventAdapterService,
VariableStateHandler optionalStateHandler)
Ctor.
|
VariableServiceImpl(long millisecondLifetimeOldVersions,
TimeProvider timeProvider,
EventAdapterService eventAdapterService,
VariableStateHandler optionalStateHandler)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static EventType |
OutputConditionExpressionFactory.getBuiltInEventType(EventAdapterService eventAdapterService)
Build the event type for built-in properties.
|
Modifier and Type | Class and Description |
---|---|
class |
EventAdapterServiceImpl
Implementation for resolving event name to event type.
|
Modifier and Type | Field and Description |
---|---|
protected EventAdapterService |
BaseNestableEventType.eventAdapterService |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
BaseConfigurableEventType.getEventAdapterService()
Returns the event adapter service.
|
Modifier and Type | Method and Description |
---|---|
static EventBean |
EventAdapterServiceHelper.adapterForType(Object theEvent,
EventType eventType,
EventAdapterService eventAdapterService)
Return an adapter for the given type of event using the pre-validated object.
|
void |
BaseNestableEventType.addAdditionalProperties(Map<String,Object> typeMap,
EventAdapterService eventAdapterService)
Adds additional properties that do not yet exist on the given type.
|
static LinkedHashMap<String,Object> |
EventTypeUtility.buildType(List<ColumnDesc> columns,
EventAdapterService eventAdapterService,
Set<String> copyFrom,
EngineImportService engineImportService) |
static Map<String,Object> |
EventTypeUtility.compileMapTypeProperties(Map<String,Object> typing,
EventAdapterService eventAdapterService)
Determine among the Map-type properties which properties are Bean-type event type names,
rewrites these as Class-type instead so that they are configured as native property and do not require wrapping,
but may require unwrapping.
|
static FragmentEventType |
EventBeanUtility.createNativeFragmentType(Class propertyType,
Class genericType,
EventAdapterService eventAdapterService)
Create a fragment event type.
|
static EventType |
EventTypeUtility.createNonVariantType(boolean isAnonymous,
CreateSchemaDesc spec,
Annotation[] annotations,
ConfigurationInformation configSnapshot,
EventAdapterService eventAdapterService,
EngineImportService engineImportService) |
static Object |
BaseNestableEventUtil.getBNFragmentArray(Object value,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static EventBean |
BaseNestableEventUtil.getBNFragmentNonPojo(Object fragmentUnderlying,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static Object |
BaseNestableEventUtil.getBNFragmentPojo(Object result,
BeanEventType eventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static EventBeanFactory |
EventAdapterServiceHelper.getFactoryForType(EventType type,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterBeanNested(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterBeanNestedArray(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterIndexedEntryPOJO(String propertyNameAtomic,
int index,
BeanEventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService,
Class propertyTypeGetter) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterIndexedPOJO(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
Class componentType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterIndexedUnderlyingArray(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType innerType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterNestedEntryBean(String propertyName,
EventPropertyGetter innerGetter,
EventType innerType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterNestedEntryBeanArray(String propertyNameAtomic,
int index,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterNestedPOJOProp(String propertyName,
BeanEventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService,
Class nestedReturnType,
Class nestedComponentType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterNestedPropertyProvidedGetterDynamic(Map<String,Object> nestableTypes,
String propertyName,
EventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getGetterProperty(String name,
BeanEventType nativeFragmentType,
EventAdapterService eventAdapterService) |
static EventBeanManufacturer |
EventAdapterServiceHelper.getManufacturer(EventAdapterService eventAdapterService,
EventType eventType,
WriteablePropertyDescriptor[] properties,
EngineImportService engineImportService,
boolean allowAnyType,
EventAdapterAvroHandler avroHandler)
Returns a factory for creating and populating event object instances for the given type.
|
static EventPropertyGetterSPI |
EventTypeUtility.getNestableGetter(String propertyName,
Map<String,PropertySetDescriptorItem> propertyGetters,
Map<String,EventPropertyGetterSPI> propertyGetterCache,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService,
EventTypeNestableGetterFactory factory,
boolean isObjectArray) |
static PropertySetDescriptor |
EventTypeUtility.getNestableProperties(Map<String,Object> propertiesToAdd,
EventAdapterService eventAdapterService,
EventTypeNestableGetterFactory factory,
EventType[] optionalSuperTypes) |
static Class |
EventTypeUtility.getNestablePropertyType(String propertyName,
Map<String,PropertySetDescriptorItem> simplePropertyTypes,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactory.getPropertyProvidedGetter(Map<String,Object> nestableTypes,
String propertyName,
Property prop,
EventAdapterService eventAdapterService) |
EventPropertyGetterIndexedSPI |
EventTypeNestableGetterFactory.getPropertyProvidedGetterIndexed(Map<String,Object> nestableTypes,
String indexedPropertyName,
IndexedProperty indexedProperty,
EventAdapterService eventAdapterService) |
EventPropertyGetterMappedSPI |
EventTypeNestableGetterFactory.getPropertyProvidedGetterMap(Map<String,Object> nestableTypes,
String mappedPropertyName,
MappedProperty mappedProperty,
EventAdapterService eventAdapterService) |
static Object |
BaseNestableEventUtil.handleBNCreateFragmentMap(Object value,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static Object |
BaseNestableEventUtil.handleBNCreateFragmentObjectArray(Object value,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static Object |
BaseNestableEventUtil.handleBNNestedValueArrayWithMapFragment(Object value,
int index,
MapEventPropertyGetter getter,
EventAdapterService eventAdapterService,
EventType fragmentType) |
static CodegenExpression |
BaseNestableEventUtil.handleBNNestedValueArrayWithMapFragmentCode(int index,
MapEventPropertyGetter getter,
CodegenExpression ref,
CodegenContext context,
EventAdapterService eventAdapterService,
EventType fragmentType,
Class generator) |
static CodegenExpression |
BaseNestableEventUtil.handleNestedValueArrayWithMapExistsCode(int index,
MapEventPropertyGetter getter,
CodegenExpression ref,
CodegenContext context,
EventAdapterService eventAdapterService,
EventType fragmentType,
Class generator) |
static Object |
BaseNestableEventUtil.handleNestedValueArrayWithObjectArrayFragment(Object value,
int index,
ObjectArrayEventPropertyGetter getter,
EventType fragmentType,
EventAdapterService eventAdapterService) |
static EventType |
EventTypeUtility.requireEventType(String aspectCamel,
String aspectName,
EventAdapterService eventAdapterService,
String optionalEventTypeName) |
static EventBean[] |
EventAdapterServiceHelper.typeCast(List<EventBean> events,
EventType targetType,
EventAdapterService eventAdapterService) |
Modifier and Type | Field and Description |
---|---|
protected EventAdapterService |
ObjectArrayPropertyGetterDefaultBase.eventAdapterService |
protected EventAdapterService |
ObjectArrayNestedEntryPropertyGetterBase.eventAdapterService |
Modifier and Type | Method and Description |
---|---|
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterBeanNested(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterBeanNestedArray(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterIndexedEntryPOJO(String propertyNameAtomic,
int index,
BeanEventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService,
Class propertyTypeGetter) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterIndexedPOJO(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
Class componentType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterIndexedUnderlyingArray(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType innerType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterNestedEntryBean(String propertyName,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterNestedEntryBeanArray(String propertyNameAtomic,
int index,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterNestedPOJOProp(String propertyName,
BeanEventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService,
Class nestedReturnType,
Class nestedComponentType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterNestedPropertyProvidedGetterDynamic(Map<String,Object> nestableTypes,
String propertyName,
EventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getGetterProperty(String name,
BeanEventType nativeFragmentType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryObjectArray.getPropertyProvidedGetter(Map<String,Object> nestableTypes,
String propertyName,
Property prop,
EventAdapterService eventAdapterService) |
EventPropertyGetterIndexedSPI |
EventTypeNestableGetterFactoryObjectArray.getPropertyProvidedGetterIndexed(Map<String,Object> nestableTypes,
String indexedPropertyName,
IndexedProperty indexedProperty,
EventAdapterService eventAdapterService) |
EventPropertyGetterMappedSPI |
EventTypeNestableGetterFactoryObjectArray.getPropertyProvidedGetterMap(Map<String,Object> nestableTypes,
String mappedPropertyName,
MappedProperty mappedProperty,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventBeanFactory |
EventAdapterAvroHandlerUnsupported.getEventBeanFactory(EventType type,
EventAdapterService eventAdapterService) |
EventBeanFactory |
EventAdapterAvroHandler.getEventBeanFactory(EventType type,
EventAdapterService eventAdapterService) |
EventBeanManufacturer |
EventAdapterAvroHandlerUnsupported.getEventBeanManufacturer(AvroSchemaEventType avroSchemaEventType,
EventAdapterService eventAdapterService,
WriteablePropertyDescriptor[] properties) |
EventBeanManufacturer |
EventAdapterAvroHandler.getEventBeanManufacturer(AvroSchemaEventType avroSchemaEventType,
EventAdapterService eventAdapterService,
WriteablePropertyDescriptor[] properties) |
AvroSchemaEventType |
EventAdapterAvroHandlerUnsupported.newEventTypeFromNormalized(EventTypeMetadata metadata,
String eventTypeName,
int typeId,
EventAdapterService eventAdapterService,
Map<String,Object> properties,
Annotation[] annotations,
ConfigurationEventTypeAvro optionalConfig,
EventType[] superTypes,
Set<EventType> deepSuperTypes,
String statementName,
String engineURI) |
AvroSchemaEventType |
EventAdapterAvroHandler.newEventTypeFromNormalized(EventTypeMetadata metadata,
String eventTypeName,
int typeId,
EventAdapterService eventAdapterService,
Map<String,Object> properties,
Annotation[] annotations,
ConfigurationEventTypeAvro optionalConfig,
EventType[] superTypes,
Set<EventType> deepSuperTypes,
String statementName,
String engineURI) |
AvroSchemaEventType |
EventAdapterAvroHandlerUnsupported.newEventTypeFromSchema(EventTypeMetadata metadata,
String eventTypeName,
int typeId,
EventAdapterService eventAdapterService,
ConfigurationEventTypeAvro requiredConfig,
EventType[] supertypes,
Set<EventType> deepSupertypes) |
AvroSchemaEventType |
EventAdapterAvroHandler.newEventTypeFromSchema(EventTypeMetadata metadata,
String eventTypeName,
int typeId,
EventAdapterService eventAdapterService,
ConfigurationEventTypeAvro requiredConfig,
EventType[] superTypes,
Set<EventType> deepSuperTypes) |
Modifier and Type | Method and Description |
---|---|
static Object |
DynamicPropertyGetterBase.cacheAndCall(CopyOnWriteArrayList<DynamicPropertyDescriptor> cache,
DynamicPropertyGetterBase getter,
Object object,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static boolean |
DynamicPropertyGetterBase.cacheAndExists(CopyOnWriteArrayList<DynamicPropertyDescriptor> cache,
DynamicPropertyGetterBase getter,
Object object,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static Object |
BaseNativePropertyGetter.getFragmentDynamic(Object object,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
Returns the fragment for dynamic properties.
|
static EventPropertyGetterSPI |
PropertyHelper.getGetter(Method method,
net.sf.cglib.reflect.FastClass fastClass,
EventAdapterService eventAdapterService)
Return getter for the given method and CGLIB FastClass.
|
static Object |
BaseNativePropertyGetter.toFragmentArray(Object[] object,
BeanEventType fragmentEventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
static Object |
BaseNativePropertyGetter.toFragmentIterable(Object object,
BeanEventType fragmentEventType,
EventAdapterService eventAdapterService)
NOTE: Code-generation-invoked method, method name and parameter order matters
Returns the fragment for dynamic properties.
|
Constructor and Description |
---|
ArrayFastPropertyGetter(net.sf.cglib.reflect.FastMethod fastMethod,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
ArrayFieldPropertyGetter(Field field,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
ArrayMethodPropertyGetter(Method method,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
BaseNativePropertyGetter(EventAdapterService eventAdapterService,
Class returnType,
Class genericType)
Constructor.
|
BeanEventAdapter(ConcurrentHashMap<Class,BeanEventType> typesPerJavaBean,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator)
Ctor.
|
BeanEventBeanConfiguredCopyMethod(BeanEventType beanEventType,
EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod copyMethod)
Ctor.
|
BeanEventBeanSerializableCopyMethod(BeanEventType beanEventType,
EventAdapterService eventAdapterService)
Ctor.
|
BeanEventType(EventTypeMetadata metadata,
int eventTypeId,
Class clazz,
EventAdapterService eventAdapterService,
ConfigurationEventTypeLegacy optionalLegacyDef)
Constructor takes a java bean class as an argument.
|
CGLibPropertyGetter(Method method,
net.sf.cglib.reflect.FastMethod fastMethod,
EventAdapterService eventAdapterService)
Constructor.
|
DynamicIndexedPropertyGetter(String fieldName,
int index,
EventAdapterService eventAdapterService)
Ctor.
|
DynamicMappedPropertyGetter(String fieldName,
String key,
EventAdapterService eventAdapterService)
Ctor.
|
DynamicPropertyGetterBase(EventAdapterService eventAdapterService) |
DynamicSimplePropertyGetter(String fieldName,
EventAdapterService eventAdapterService)
Ctor.
|
EventBeanManufacturerBean(BeanEventType beanEventType,
EventAdapterService service,
WriteablePropertyDescriptor[] properties,
EngineImportService engineImportService)
Ctor.
|
EventBeanManufacturerCtor(net.sf.cglib.reflect.FastConstructor fastConstructor,
BeanEventType beanEventType,
EventAdapterService eventAdapterService) |
IterableFastPropertyGetter(Method method,
net.sf.cglib.reflect.FastMethod fastMethod,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
IterableFieldPropertyGetter(Field field,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
IterableMethodPropertyGetter(Method method,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
KeyedFastPropertyGetter(net.sf.cglib.reflect.FastMethod fastMethod,
Object key,
EventAdapterService eventAdapterService)
Constructor.
|
KeyedMapFastPropertyGetter(Method method,
net.sf.cglib.reflect.FastMethod fastMethod,
Object key,
EventAdapterService eventAdapterService)
Constructor.
|
KeyedMapFieldPropertyGetter(Field field,
Object key,
EventAdapterService eventAdapterService)
Constructor.
|
KeyedMapMethodPropertyGetter(Method method,
Object key,
EventAdapterService eventAdapterService)
Constructor.
|
KeyedMethodPropertyGetter(Method method,
Object key,
EventAdapterService eventAdapterService)
Constructor.
|
ListFastPropertyGetter(Method method,
net.sf.cglib.reflect.FastMethod fastMethod,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
ListFieldPropertyGetter(Field field,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
ListMethodPropertyGetter(Method method,
int index,
EventAdapterService eventAdapterService)
Constructor.
|
NestedPropertyGetter(List<EventPropertyGetter> getterChain,
EventAdapterService eventAdapterService,
Class finalPropertyType,
Class finalGenericType)
Ctor.
|
ReflectionPropFieldGetter(Field field,
EventAdapterService eventAdapterService)
Constructor.
|
ReflectionPropMethodGetter(Method method,
EventAdapterService eventAdapterService)
Constructor.
|
Modifier and Type | Field and Description |
---|---|
protected EventAdapterService |
MapPropertyGetterDefaultBase.eventAdapterService |
protected EventAdapterService |
MapNestedEntryPropertyGetterBase.eventAdapterService |
Modifier and Type | Method and Description |
---|---|
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterBeanNested(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterBeanNestedArray(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterIndexedEntryPOJO(String propertyNameAtomic,
int index,
BeanEventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService,
Class propertyTypeGetter) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterIndexedPOJO(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
Class componentType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterIndexedUnderlyingArray(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType innerType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterNestedEntryBean(String propertyName,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterNestedEntryBeanArray(String propertyNameAtomic,
int index,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterNestedPOJOProp(String propertyName,
BeanEventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService,
Class nestedReturnType,
Class nestedComponentType) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterNestedPropertyProvidedGetterDynamic(Map<String,Object> nestableTypes,
String propertyName,
EventPropertyGetter nestedGetter,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getGetterProperty(String name,
BeanEventType nativeFragmentType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
EventTypeNestableGetterFactoryMap.getPropertyProvidedGetter(Map<String,Object> nestableTypes,
String propertyName,
Property prop,
EventAdapterService eventAdapterService) |
EventPropertyGetterIndexedSPI |
EventTypeNestableGetterFactoryMap.getPropertyProvidedGetterIndexed(Map<String,Object> nestableTypes,
String indexedPropertyName,
IndexedProperty indexedProperty,
EventAdapterService eventAdapterService) |
EventPropertyGetterMappedSPI |
EventTypeNestableGetterFactoryMap.getPropertyProvidedGetterMap(Map<String,Object> nestableTypes,
String mappedPropertyName,
MappedProperty mappedProperty,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventPropertyGetterSPI |
SimpleProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
Property.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService)
Returns value getter for the property of an event of the given event type.
|
EventPropertyGetterSPI |
NestedProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterAndMapped |
MappedProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterAndIndexed |
IndexedProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
DynamicSimpleProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
DynamicMappedProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
DynamicIndexedProperty.getGetter(BeanEventType eventType,
EventAdapterService eventAdapterService) |
EventPropertyGetterSPI |
SimpleProperty.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType xmlEventType,
String propertyExpression) |
EventPropertyGetterSPI |
Property.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType xmlEventType,
String propertyExpression)
Returns the getter-method for use with XML DOM event representations.
|
EventPropertyGetterSPI |
NestedProperty.getGetterDOM(SchemaElementComplex parentComplexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType eventType,
String propertyExpression) |
EventPropertyGetterSPI |
MappedProperty.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType eventType,
String propertyExpression) |
EventPropertyGetterSPI |
IndexedProperty.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType eventType,
String propertyExpression) |
EventPropertyGetterSPI |
DynamicSimpleProperty.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType eventType,
String propertyExpression) |
EventPropertyGetterSPI |
DynamicMappedProperty.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType eventType,
String propertyExpression) |
EventPropertyGetterSPI |
DynamicIndexedProperty.getGetterDOM(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService,
BaseXMLEventType eventType,
String propertyExpression) |
MapEventPropertyGetter |
SimpleProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
Property.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService)
Returns the getter-method for use with Map event representations.
|
MapEventPropertyGetter |
NestedProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
MapEventPropertyGetterAndMapped |
MappedProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
MapEventPropertyGetterAndIndexed |
IndexedProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
DynamicSimpleProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
DynamicMappedProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
DynamicIndexedProperty.getGetterMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetter |
SimpleProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetter |
Property.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetter |
NestedProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetterAndMapped |
MappedProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetterAndIndexed |
IndexedProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetter |
DynamicSimpleProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetter |
DynamicMappedProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
ObjectArrayEventPropertyGetter |
DynamicIndexedProperty.getGetterObjectArray(Map<String,Integer> indexPerProperty,
Map<String,Object> nestableTypes,
EventAdapterService eventAdapterService) |
Class |
SimpleProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
Class |
Property.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService)
Returns the property type.
|
Class |
NestedProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
Class |
MappedProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
Class |
IndexedProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
Class |
DynamicSimpleProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
Class |
DynamicMappedProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
Class |
DynamicIndexedProperty.getPropertyType(BeanEventType eventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
SimpleProperty.getPropertyTypeGeneric(BeanEventType eventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
Property.getPropertyTypeGeneric(BeanEventType eventType,
EventAdapterService eventAdapterService)
Returns the property type plus its generic type parameter, if any.
|
GenericPropertyDesc |
NestedProperty.getPropertyTypeGeneric(BeanEventType eventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
MappedProperty.getPropertyTypeGeneric(BeanEventType eventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
IndexedProperty.getPropertyTypeGeneric(BeanEventType eventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
DynamicSimpleProperty.getPropertyTypeGeneric(BeanEventType beanEventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
DynamicMappedProperty.getPropertyTypeGeneric(BeanEventType beanEventType,
EventAdapterService eventAdapterService) |
GenericPropertyDesc |
DynamicIndexedProperty.getPropertyTypeGeneric(BeanEventType beanEventType,
EventAdapterService eventAdapterService) |
Class |
SimpleProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
Class |
Property.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService)
Returns the property type for use with Map event representations.
|
Class |
NestedProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
Class |
MappedProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
Class |
IndexedProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
Class |
DynamicSimpleProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
Class |
DynamicMappedProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
Class |
DynamicIndexedProperty.getPropertyTypeMap(Map optionalMapPropTypes,
EventAdapterService eventAdapterService) |
SchemaItem |
SimpleProperty.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService) |
SchemaItem |
Property.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService)
Returns the property type for use with DOM event representations.
|
SchemaItem |
NestedProperty.getPropertyTypeSchema(SchemaElementComplex parentComplexProperty,
EventAdapterService eventAdapterService) |
SchemaItem |
MappedProperty.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService) |
SchemaItem |
IndexedProperty.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService) |
SchemaItem |
DynamicSimpleProperty.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService) |
SchemaItem |
DynamicMappedProperty.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService) |
SchemaItem |
DynamicIndexedProperty.getPropertyTypeSchema(SchemaElementComplex complexProperty,
EventAdapterService eventAdapterService) |
Modifier and Type | Field and Description |
---|---|
protected EventAdapterService |
VAERevisionProcessorBase.eventAdapterService
For interogating nested properties.
|
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
VAERevisionProcessorBase.getEventAdapterService() |
Modifier and Type | Method and Description |
---|---|
void |
ValueAddEventServiceImpl.addRevisionEventType(String revisioneventTypeName,
ConfigurationRevisionEventType config,
EventAdapterService eventAdapterService) |
void |
ValueAddEventService.addRevisionEventType(String name,
ConfigurationRevisionEventType config,
EventAdapterService eventAdapterService)
Adds a new revision event types.
|
void |
ValueAddEventServiceImpl.addVariantStream(String variantStreamname,
ConfigurationVariantStream variantStreamConfig,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator) |
void |
ValueAddEventService.addVariantStream(String variantEventTypeName,
ConfigurationVariantStream variantStreamConfig,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator)
Adds a new variant stream.
|
EventType |
ValueAddEventServiceImpl.createRevisionType(String namedWindowName,
String name,
StatementStopService statementStopService,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator) |
EventType |
ValueAddEventService.createRevisionType(String namedWindowName,
String typeName,
StatementStopService statementStopService,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator)
Upon named window creation, create a unique revision event type that this window processes.
|
void |
ValueAddEventServiceImpl.init(Map<String,ConfigurationRevisionEventType> configRevision,
Map<String,ConfigurationVariantStream> configVariant,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator) |
void |
ValueAddEventService.init(Map<String,ConfigurationRevisionEventType> revisionTypes,
Map<String,ConfigurationVariantStream> variantStreams,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator)
Called at initialization time, verifies configurations provided.
|
protected static RevisionSpec |
ValueAddEventServiceImpl.validateRevision(String revisioneventTypeName,
ConfigurationRevisionEventType config,
EventAdapterService eventAdapterService)
Valiate the revision configuration.
|
static VariantSpec |
ValueAddEventServiceImpl.validateVariantStream(String variantStreamname,
ConfigurationVariantStream variantStreamConfig,
EventAdapterService eventAdapterService)
Validate the variant stream definition.
|
Constructor and Description |
---|
WrapperMapPropertyGetter(WrapperEventType wrapperEventType,
EventAdapterService eventAdapterService,
MapEventType underlyingMapType,
EventPropertyGetterSPI mapGetter) |
Modifier and Type | Method and Description |
---|---|
static EventPropertyGetterSPI |
SchemaXMLPropertyParser.getXPathResolution(String propertyName,
XPathFactory xPathFactory,
String rootElementName,
String namespace,
SchemaModel schemaModel,
EventAdapterService eventAdapterService,
BaseXMLEventType xmlEventType,
boolean isAllowFragment,
String defaultNamespace)
Return the xPath corresponding to the given property.
|
Constructor and Description |
---|
BaseXMLEventType(EventTypeMetadata metadata,
int eventTypeId,
ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM,
EventAdapterService eventAdapterService)
Ctor.
|
FragmentFactoryDOMGetter(EventAdapterService eventAdapterService,
BaseXMLEventType xmlEventType,
String propertyExpression)
Ctor.
|
FragmentFactoryXPathPredefinedGetter(EventAdapterService eventAdapterService,
String eventTypeName,
String propertyName)
Ctor.
|
SchemaXMLEventType(EventTypeMetadata eventTypeMetadata,
int eventTypeId,
ConfigurationEventTypeXMLDOM config,
SchemaModel schemaModel,
EventAdapterService eventAdapterService)
Ctor.
|
SimpleXMLEventType(EventTypeMetadata eventTypeMetadata,
int eventTypeId,
ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM,
EventAdapterService eventAdapterService)
Ctor.
|
Modifier and Type | Field and Description |
---|---|
EventAdapterService |
FilterSpecCompilerArgs.eventAdapterService |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
FilterSpecParamExprNode.getEventAdapterService() |
Modifier and Type | Method and Description |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(List<ExprNode> validatedFilterNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
Collection<Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
int statementId,
String statementName,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
EngineImportService engineImportService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowMgmtService namedWindowMgmtService,
StatementExtensionSvcContext statementExtensionSvcContext) |
Constructor and Description |
---|
FilterSpecCompilerArgs(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
String statementName,
int statementId,
StreamTypeService streamTypeService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation,
StatementExtensionSvcContext statementExtensionSvcContext) |
FilterSpecParamExprNode(FilterSpecLookupable lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
ConfigurationInformation configurationInformation,
boolean hasSubquery,
boolean hasTableAccess) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
PatternContext.getEventAdapterService()
Returns teh service providing event adaptering or wrapping.
|
Constructor and Description |
---|
MatchedEventConvertorImpl(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
PlugInEventRepresentationContext.getEventAdapterService()
Returns the service for for creating further event types or wrapping event objects.
|
Constructor and Description |
---|
PlugInEventRepresentationContext(EventAdapterService eventAdapterService,
URI eventRepresentationRootURI,
Serializable representationInitializer)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventAdapterService |
ViewFactoryContext.getEventAdapterService()
Returns service for generating events and handling event types.
|
Modifier and Type | Method and Description |
---|---|
void |
ValidatedView.validate(EngineImportService engineImportService,
StreamTypeService streamTypeService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ExprEvaluatorContext exprEvaluatorContext,
ConfigurationInformation configSnapshot,
SchedulingService schedulingService,
String engineURI,
Map<Integer,List<ExprNode>> sqlParameters,
EventAdapterService eventAdapterService,
StatementContext statementContext)
Validate the view.
|
Modifier and Type | Method and Description |
---|---|
static EventBean |
RegressionLinestView.doPopulateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
Object[] decoration) |
static EventBean |
CorrelationView.doPopulateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
Object[] decoration)
Populate bean.
|
static EventBean |
UnivariateStatisticsView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
Object[] lastNewValues) |
EventBean |
RegressionLinestView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
Object[] decoration) |
EventBean |
CorrelationView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
Object[] decoration) |
protected abstract EventBean |
BaseBivariateStatisticsView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
Object[] decoration)
Populate bean.
|
Modifier and Type | Method and Description |
---|---|
protected static EventBean |
AddPropertyValueOptionalView.addProperty(EventBean originalEvent,
String[] propertyNames,
Object propertyValues,
EventType targetEventType,
EventAdapterService eventAdapterService)
Add a property to the event passed in.
|