Package | Description |
---|---|
com.espertech.esper.client |
This package and its sub-packages defines the central Esper Client APIs.
|
com.espertech.esper.client.hook |
Callback interfaces for use with statement annotations.
|
com.espertech.esper.client.util |
This package contains utilities for events, specifically rendering of events in JSON and XML formats.
|
com.espertech.esper.collection |
Internal collection classes
|
com.espertech.esper.core.context.activator |
Activation of streams for statement start.
|
com.espertech.esper.core.context.factory |
Statement agent instance factories.
|
com.espertech.esper.core.context.mgr |
Context management.
|
com.espertech.esper.core.context.subselect |
Subselect implementation.
|
com.espertech.esper.core.context.util |
Context partition utility or reference classes.
|
com.espertech.esper.core.deploy |
Module and deployment utility and parser.
|
com.espertech.esper.core.service |
Implementation of client package interfaces, glue code
|
com.espertech.esper.core.start |
Classes related to start and stop of statements
|
com.espertech.esper.dataflow.ops |
Data flow built-in operators.
|
com.espertech.esper.dataflow.ops.epl |
Data flow built-in operator's helper classes.
|
com.espertech.esper.dataflow.util |
Data flow utility classes such as internal model, matching and planning.
|
com.espertech.esper.epl.agg.factory |
Aggregator factories
|
com.espertech.esper.epl.agg.service |
Aggregation services.
|
com.espertech.esper.epl.core |
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
|
com.espertech.esper.epl.core.eval |
Select expression evaluators.
|
com.espertech.esper.epl.datetime.eval |
Date-Time methods and related utility classes.
|
com.espertech.esper.epl.datetime.interval |
Interval algebra.
|
com.espertech.esper.epl.datetime.reformatop |
Date-Time re-formatting operations.
|
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.dot.inner |
Expression dot-method inner evaluators.
|
com.espertech.esper.epl.expression.funcs |
Function expressions.
|
com.espertech.esper.epl.expression.methodagg |
Method-aggregation expressions.
|
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.index.quadtree |
Quad-tree indexes
|
com.espertech.esper.epl.index.service |
Advanced index provisioning
|
com.espertech.esper.epl.join.base |
Join process interfaces and glue code
|
com.espertech.esper.epl.join.exec.base |
Inner join execution
|
com.espertech.esper.epl.join.exec.composite |
Composite query execution for hash+btree combined lookup.
|
com.espertech.esper.epl.join.plan |
Inner join and outer join query planning
|
com.espertech.esper.epl.join.pollindex |
Poll result indexing strategies.
|
com.espertech.esper.epl.join.table |
Indexes for views
|
com.espertech.esper.epl.lookup |
Subquery execution strategies and lookup indexes
|
com.espertech.esper.epl.named |
Named window classes are in this package
|
com.espertech.esper.epl.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.subquery |
Subquery helper classes are found here.
|
com.espertech.esper.epl.table.merge |
Table on-merge handlers.
|
com.espertech.esper.epl.table.mgmt |
Table-related services and metadata.
|
com.espertech.esper.epl.table.onaction |
Table on-action handlers.
|
com.espertech.esper.epl.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.epl.virtualdw |
Virtual data window.
|
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.util |
Utilities around event rendering are here.
|
com.espertech.esper.event.vaevent |
Value added events are revision events and variant events.
|
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.rowregex |
Match-recognize expression tree and state objects.
|
com.espertech.esper.util.support |
Internal-use-only unit and regression test support classes.
|
com.espertech.esper.view |
View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering.
|
com.espertech.esper.view.ext |
Extension views that providing services such as sorting, which don't fit much into other categories.
|
com.espertech.esper.view.internal |
Internal management views for buffering view results and providing these to joins.
|
com.espertech.esper.view.stat |
Views computing statistical values.
|
com.espertech.esper.view.std |
Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc.
|
com.espertech.esper.view.window |
Window views are in this package
|
Modifier and Type | Method and Description |
---|---|
EventType |
EventBean.getEventType()
Return the
EventType instance that describes the set of properties available for this event. |
EventType |
EPOnDemandQueryResult.getEventType()
Returns the event type of the result.
|
EventType |
EPOnDemandPreparedQuery.getEventType()
Returns the event type, representing the columns of the select-clause.
|
EventType |
EPIterable.getEventType()
Returns the type of events the iterable returns.
|
EventType |
ConfigurationOperations.getEventType(String eventTypeName)
Returns the event type for a given event type name.
|
EventType |
Configuration.getEventType(String eventTypeName) |
EventType[] |
ConfigurationOperations.getEventTypes()
Returns an array of event types tracked or available within the engine in any order.
|
EventType[] |
Configuration.getEventTypes() |
EventType |
FragmentEventType.getFragmentType()
Returns the type of the fragment.
|
EventType[] |
EventType.getSuperTypes()
Returns an array of event types that are super to this event type, from which this event type inherited event properties.
|
Modifier and Type | Method and Description |
---|---|
Iterator<EventType> |
EventType.getDeepSuperTypes()
Returns iterator over all super types to event type, going up the hierarchy and including all
Java interfaces (and their extended interfaces) and superclasses as EventType instances.
|
Constructor and Description |
---|
FragmentEventType(EventType fragmentType,
boolean indexed,
boolean isNative)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventType |
VirtualDataWindowFactoryContext.getEventType()
Returns the event type of the events held in the virtual data window as per declaration of the named window.
|
EventType |
VirtualDataWindowContext.getEventType()
Returns the event type of the events held in the virtual data window as per declaration of the named window.
|
EventType |
ObjectValueTypeWidenerFactoryContext.getEventType()
Returns the event type
|
EventType |
EventBeanService.getExistsTypeByName(String eventTypeName)
Look up an event type by name,
|
Modifier and Type | Method and Description |
---|---|
EventBean |
EventBeanService.adapterForType(Object theEvent,
EventType eventType)
Construct an event bean for a given object and event type, wherein it is assumed that the object matches the event type
|
EventBean |
EventBeanService.adapterForTypedAvro(Object avroGenericDataDotRecord,
EventType eventType)
Construct an event bean for a given Avro GenericData.Record and given the Avro-event-type
|
EventBean |
EventBeanService.adapterForTypedBean(Object bean,
EventType eventType)
Construct an event bean for a given bean (Object, POJO) and given the Bean-event-type
|
EventBean |
EventBeanService.adapterForTypedDOM(Node node,
EventType eventType)
Construct an event bean for a given Node and given the XML-event-type
|
EventBean |
EventBeanService.adapterForTypedMap(Map<String,Object> properties,
EventType eventType)
Construct an event bean for a given Map and given the Map-event-type
|
EventBean |
EventBeanService.adapterForTypedObjectArray(Object[] props,
EventType eventType)
Construct an event bean for a given Object-Array and given the Object-Array-event-type
|
Constructor and Description |
---|
ObjectValueTypeWidenerFactoryContext(Class clazz,
String propertyName,
EventType eventType,
String statementName,
String engineURI)
Ctor.
|
VirtualDataWindowContext(AgentInstanceContext agentInstanceContext,
EventType eventType,
Object[] parameters,
ExprNode[] parameterExpressions,
EventBeanFactory eventFactory,
VirtualDataWindowOutStream outputStream,
String namedWindowName,
ViewFactoryContext viewFactoryContext,
Serializable customConfiguration)
Ctor.
|
VirtualDataWindowFactoryContext(EventType eventType,
Object[] parameters,
ExprNode[] parameterExpressions,
EventBeanFactory eventFactory,
String namedWindowName,
ViewFactoryContext viewFactoryContext,
Serializable customConfiguration)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventType |
EventPropertyRendererContext.getEventType()
Returns the event type
|
Modifier and Type | Method and Description |
---|---|
JSONEventRenderer |
EventRenderer.getJSONRenderer(EventType eventType)
Returns a render for the JSON format, valid only for the given event type and its subtypes.
|
JSONEventRenderer |
EventRenderer.getJSONRenderer(EventType eventType,
JSONRenderingOptions options)
Returns a render for the JSON format, valid only for the given event type and its subtypes.
|
XMLEventRenderer |
EventRenderer.getXMLRenderer(EventType eventType)
Returns a render for the XML format, valid only for the given event type and its subtypes.
|
XMLEventRenderer |
EventRenderer.getXMLRenderer(EventType eventType,
XMLRenderingOptions options)
Returns a render for the XML format, valid only for the given event type and its subtypes.
|
Constructor and Description |
---|
EventPropertyRendererContext(EventType eventType,
boolean jsonFormatted)
Ctor.
|
Constructor and Description |
---|
EventDistinctIterator(Iterator<EventBean> sourceIterator,
EventType eventType)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventType |
ViewableActivatorPattern.getEventType() |
Modifier and Type | Method and Description |
---|---|
ViewableActivator |
ViewableActivatorFactoryDefault.createPattern(PatternContext patternContext,
EvalRootFactoryNode rootFactoryNode,
EventType eventType,
boolean consumingFilters,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch,
boolean isCanIterateUnbound) |
ViewableActivator |
ViewableActivatorFactory.createPattern(PatternContext patternContext,
EvalRootFactoryNode rootFactoryNode,
EventType eventType,
boolean consumingFilters,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch,
boolean isCanIterateUnbound) |
Constructor and Description |
---|
ViewableActivatorPattern(PatternContext patternContext,
EvalRootFactoryNode rootFactoryNode,
EventType eventType,
boolean hasConsumingFilter,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch,
boolean isCanIterate) |
Modifier and Type | Method and Description |
---|---|
EventType |
ContextPropertyRegistryImpl.getContextEventType() |
EventType |
ContextControllerFactoryServiceContext.getStatementResultEventType() |
Modifier and Type | Method and Description |
---|---|
void |
ContextManagementServiceImpl.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient,
EventType statementResultEventType) |
void |
ContextManagementService.addContextSpec(EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
CreateContextDesc contextDesc,
boolean isRecoveringResilient,
EventType statementResultEventType) |
FilterSpecLookupable |
ContextManagerNested.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextManagerImpl.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextManager.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextControllerPartitionedFactoryBase.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextControllerInitTermFactoryBase.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextControllerHashFactoryBase.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextControllerFactory.getFilterLookupable(EventType eventType) |
FilterSpecLookupable |
ContextControllerCategoryFactoryBase.getFilterLookupable(EventType eventType) |
String |
ContextPropertyRegistryImpl.getPartitionContextPropertyName(EventType fromType,
String propertyName) |
boolean |
ContextPropertyRegistryImpl.isPartitionProperty(EventType fromType,
String propertyName) |
Modifier and Type | Method and Description |
---|---|
protected static void |
ContextControllerPartitionedUtil.validateStatementForContext(String contextName,
ContextControllerStatementBase statement,
StatementSpecCompiledAnalyzerResult streamAnalysis,
Collection<EventType> itemEventTypes,
NamedWindowMgmtService namedWindowMgmtService) |
Constructor and Description |
---|
ContextControllerFactoryServiceContext(String contextName,
EPServicesContext servicesContext,
ContextDetail detail,
AgentInstanceContext agentInstanceContextCreate,
boolean isRecoveringResilient,
EventType statementResultEventType) |
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) |
ContextPropertyRegistryImpl(EventType contextEventType) |
ContextPropertyRegistryImpl(List<ContextDetailPartitionItem> partitionProperties,
EventType contextEventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
SubSelectActivationCollection.getRootViewableType(ExprSubselectNode subqueryNode)
Returns the lookup viewable, child-most view.
|
EventType |
SubSelectActivationHolder.getViewableType() |
Constructor and Description |
---|
SubSelectActivationHolder(int streamNumber,
EventType viewableType,
ViewFactoryChain viewFactoryChain,
ViewableActivator activator,
StreamSpecCompiled streamSpecCompiled) |
SubSelectStrategyFactoryIndexShare(String statementName,
int statementId,
int subqueryNum,
EventType[] outerEventTypesSelect,
NamedWindowProcessor optionalNamedWindowProcessor,
TableMetadata optionalTableMetadata,
boolean fullTableScan,
IndexHint optionalIndexHint,
SubordPropPlan joinedPropPlan,
ExprEvaluator filterExprEval,
AggregationServiceFactoryDesc aggregationServiceFactory,
ExprEvaluator[] groupByKeys,
TableService tableService,
Annotation[] annotations,
StatementStopService statementStopService,
EngineImportService engineImportService) |
Modifier and Type | Method and Description |
---|---|
EventType |
ContextPropertyRegistry.getContextEventType() |
EventType |
ContextMergeView.getEventType() |
Modifier and Type | Method and Description |
---|---|
String |
ContextPropertyRegistry.getPartitionContextPropertyName(EventType fromType,
String propertyName) |
boolean |
ContextPropertyRegistry.isPartitionProperty(EventType fromType,
String propertyName) |
Constructor and Description |
---|
ContextMergeView(EventType eventType) |
ContextMergeViewForwarding(EventType eventType) |
Modifier and Type | Method and Description |
---|---|
static List<EventType> |
EPLModuleUtil.undeployTypes(Set<String> referencedTypes,
StatementEventTypeRef statementEventTypeRef,
EventAdapterService eventAdapterService,
FilterService filterService) |
Modifier and Type | Method and Description |
---|---|
EventType |
UpdateDispatchViewBase.getEventType() |
EventType |
InternalRoutePreprocessView.getEventType() |
EventType |
InternalEventRouterDesc.getEventType() |
EventType |
EPStatementImpl.getEventType() |
EventType |
EPQueryResultImpl.getEventType() |
EventType |
EPPreparedQueryResult.getEventType()
Returs the event type representing the selected columns.
|
EventType |
EPPreparedQueryImpl.getEventType() |
EventType |
ConfigurationOperationsImpl.getEventType(String eventTypeName) |
EventType[] |
ConfigurationOperationsImpl.getEventTypes() |
EventType |
NamedWindowSelectedProps.getFragmentType()
Returns the fragment type or null if not a fragment type.
|
Modifier and Type | Method and Description |
---|---|
InternalEventRouterDesc |
InternalEventRouterImpl.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
Annotation[] annotations) |
InternalEventRouterDesc |
InternalEventRouter.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
Annotation[] annotations) |
void |
StatementSemiAnonymousTypeRegistryImpl.register(EventType anonymouseType) |
void |
StatementSemiAnonymousTypeRegistry.register(EventType semiAnonymouseType) |
void |
InternalEventRouterImpl.removePreprocessing(EventType eventType,
UpdateDesc desc) |
void |
InternalEventRouter.removePreprocessing(EventType eventType,
UpdateDesc desc)
Remove preprocessing.
|
Constructor and Description |
---|
EPPreparedQueryResult(EventType eventType,
EventBean[] result)
Ctor.
|
InternalEventRouterDesc(UpdateDesc updateDesc,
EventBeanCopyMethod copyMethod,
TypeWidener[] wideners,
EventType eventType,
Annotation[] annotations) |
InternalRoutePreprocessView(EventType eventType,
StatementResultService statementResultService)
Ctor.
|
NamedWindowSelectedProps(Class selectExpressionType,
String assignedName,
EventType fragmentType)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventType |
EPPreparedExecuteMethodQuery.getEventType()
Returns the event type of the prepared statement.
|
EventType |
EPPreparedExecuteMethod.getEventType() |
EventType |
EPPreparedExecuteIUDSingleStream.getEventType()
Returns the event type of the prepared statement.
|
EventType |
FireAndForgetProcessorTable.getEventTypePublic() |
EventType |
FireAndForgetProcessorNamedWindow.getEventTypePublic() |
abstract EventType |
FireAndForgetProcessor.getEventTypePublic() |
EventType |
FireAndForgetProcessorTable.getEventTypeResultSetProcessor() |
EventType |
FireAndForgetProcessorNamedWindow.getEventTypeResultSetProcessor() |
abstract EventType |
FireAndForgetProcessor.getEventTypeResultSetProcessor() |
Modifier and Type | Method and Description |
---|---|
protected static SubSelectStrategyCollection |
EPStatementStartMethodHelperSubselect.planSubSelect(EPServicesContext services,
StatementContext statementContext,
boolean queryPlanLogging,
SubSelectActivationCollection subSelectStreamDesc,
String[] outerStreamNames,
EventType[] outerEventTypesSelect,
String[] outerEventTypeNamees,
ExprDeclaredNode[] declaredExpressions,
ContextPropertyRegistry contextPropertyRegistry) |
protected ExprNode |
EPStatementStartMethodOnTrigger.validateJoinNamedWindow(String engineURI,
StatementContext statementContext,
ExprNodeOrigin exprNodeOrigin,
ExprNode deleteJoinExpr,
EventType namedWindowType,
String namedWindowStreamName,
String namedWindowName,
EventType filteredType,
String filterStreamName,
String filteredTypeName,
String optionalTableName) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
EventBusSource.eventType |
Modifier and Type | Method and Description |
---|---|
protected JSONEventRenderer |
LogSink.ConsoleOpRendererXmlJSon.getJsonRenderer(EventType eventType) |
protected XMLEventRenderer |
LogSink.ConsoleOpRendererXmlJSon.getXmlRenderer(EventType eventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
EPLSelectViewable.getEventType() |
EventType |
EPLSelectUpdateDispatchView.getEventType() |
Constructor and Description |
---|
EPLSelectViewable(EventType eventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
GraphTypeDesc.getEventType() |
Constructor and Description |
---|
GraphTypeDesc(boolean wildcard,
boolean underlying,
EventType eventType) |
Modifier and Type | Method and Description |
---|---|
ExprEvaluator |
AggregationMethodFactorySum.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryStddev.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryRate.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryPlugIn.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryNth.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryMinMax.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryMedian.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryLeaving.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryLastEver.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryFirstEver.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryCountEver.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryCount.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryAvg.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryAvedev.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
static ExprEvaluator |
AggregationMethodFactoryCount.getMethodAggregationEvaluatorCountBy(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream) |
AggregationMethodFactory |
AggregationFactoryFactoryDefault.makeLinearUnbounded(StatementExtensionSvcContext statementExtensionSvcContext,
ExprAggMultiFunctionLinearAccessNode parent,
EventType containedType,
Class accessorResultType,
int streamNum,
boolean hasFilter) |
AggregationMethodFactory |
AggregationFactoryFactory.makeLinearUnbounded(StatementExtensionSvcContext statementExtensionSvcContext,
ExprAggMultiFunctionLinearAccessNode exprAggMultiFunctionLinearAccessNode,
EventType containedType,
Class accessorResultType,
int streamNum,
boolean hasFilter) |
Modifier and Type | Method and Description |
---|---|
ExprEvaluator |
AggregationMethodFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
static AggregationServiceFactoryDesc |
AggregationServiceFactoryFactory.getService(List<ExprAggregateNode> selectAggregateExprNodes,
Map<ExprNode,String> selectClauseNamedNodes,
List<ExprDeclaredNode> declaredExpressions,
ExprNode[] groupByNodes,
List<ExprAggregateNode> havingAggregateExprNodes,
List<ExprAggregateNode> orderByAggregateExprNodes,
List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
Annotation[] annotations,
VariableService variableService,
boolean isJoin,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
AggregationServiceFactoryService factoryService,
EventType[] typesPerStream,
AggregationGroupByRollupDesc groupByRollupDesc,
String optionalContextName,
IntoTableSpec intoTableSpec,
TableService tableService,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect,
EngineImportService engineImportService) |
static AggregationServiceMatchRecognizeFactoryDesc |
AggregationServiceFactoryFactory.getServiceMatchRecognize(int numStreams,
Map<Integer,List<ExprAggregateNode>> measureExprNodesPerStream,
EventType[] typesPerStream)
Produces an aggregation service for use with match-recognice.
|
static void |
AggregationValidationUtil.validateEventType(EventType requiredType,
EventType providedType) |
Constructor and Description |
---|
AggregationStateKeyWStream(int streamNum,
EventType eventType,
AggregationStateTypeWStream stateType,
ExprNode[] criteraExprNodes,
ExprNode filterExprNode) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceBase.eventType |
protected EventType |
MethodPollingExecStrategyBase.eventType |
Modifier and Type | Method and Description |
---|---|
EventType |
MethodPollingViewable.getEventType() |
EventType |
MethodPollingViewableMeta.getEventTypeEventBeanArray() |
EventType[] |
StreamTypeServiceImpl.getEventTypes() |
EventType[] |
StreamTypeService.getEventTypes()
Returns an array of event types for each event stream in the order declared.
|
EventType |
SelectExprWildcardTableProcessor.getResultEventType() |
EventType |
SelectExprWildcardProcessor.getResultEventType() |
EventType |
SelectExprResultProcessor.getResultEventType() |
EventType |
SelectExprProcessorWDeliveryCallback.getResultEventType() |
EventType |
SelectExprProcessor.getResultEventType()
Returns the event type that represents the select-clause items.
|
EventType |
SelectExprJoinWildcardProcessorTableRows.getResultEventType() |
EventType |
SelectExprJoinWildcardProcessorObjectArray.getResultEventType() |
EventType |
SelectExprJoinWildcardProcessorMap.getResultEventType() |
EventType |
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceBase.getResultEventType() |
EventType |
SelectExprInsertEventBeanFactory.SelectExprInsertNativeBase.getResultEventType() |
EventType |
SelectExprInsertEventBeanFactory.SelectExprInsertNativeNoEval.getResultEventType() |
EventType |
ResultSetProcessorSimpleFactory.getResultEventType() |
EventType |
ResultSetProcessorSimple.getResultEventType() |
EventType |
ResultSetProcessorRowPerGroupRollupFactory.getResultEventType() |
EventType |
ResultSetProcessorRowPerGroupRollup.getResultEventType() |
EventType |
ResultSetProcessorRowPerGroupFactory.getResultEventType() |
EventType |
ResultSetProcessorRowPerGroup.getResultEventType() |
EventType |
ResultSetProcessorRowForAllFactory.getResultEventType() |
EventType |
ResultSetProcessorRowForAll.getResultEventType() |
EventType |
ResultSetProcessorHandThroughFactory.getResultEventType() |
EventType |
ResultSetProcessorHandThrough.getResultEventType() |
EventType |
ResultSetProcessorFactory.getResultEventType()
Returns the event type of processed results.
|
EventType |
ResultSetProcessorAggregateGroupedFactory.getResultEventType() |
EventType |
ResultSetProcessorAggregateGrouped.getResultEventType() |
EventType |
ResultSetProcessorAggregateAllFactory.getResultEventType() |
EventType |
ResultSetProcessorAggregateAll.getResultEventType() |
EventType |
ResultSetProcessor.getResultEventType()
Returns the event type of processed results.
|
EventType |
PropertyResolutionDescriptor.getStreamEventType()
Returns event type of the stream that the property was found in.
|
Modifier and Type | Method and Description |
---|---|
void |
SelectExprEventTypeRegistry.add(EventType eventType)
Adds an event type.
|
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) |
protected static Pair<Integer,String> |
StreamTypeServiceUtil.findLevMatch(EventType[] eventTypes,
String propertyName) |
protected static Pair<Integer,String> |
StreamTypeServiceUtil.findLevMatch(String propertyName,
EventType eventType) |
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingJoinWildcard(EventAdapterService eventAdapterService,
EventType eventType,
String[] streamNames,
EventType[] streamTypes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
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,
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) |
SelectExprProcessor |
SelectExprProcessorRepresentationFactory.makeRecast(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
AvroSchemaEventType insertIntoTargetType,
ExprNode[] exprNodes,
String statementName,
String engineURI) |
SelectExprProcessor |
SelectExprProcessorRepresentationFactory.makeSelectNoWildcard(SelectExprContext selectExprContext,
EventType resultEventType,
TableService tableService,
String statementName,
String engineURI) |
Constructor and Description |
---|
BindProcessor(SelectClauseElementCompiled[] selectionList,
EventType[] typesPerStream,
String[] streamNames,
TableService tableService)
Ctor.
|
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) |
MethodPollingExecStrategyScript(ExprNodeScript scriptExpression,
EventType eventTypeEventBeanArray) |
MethodPollingViewable(MethodStreamSpec methodStreamSpec,
DataCache dataCache,
EventType eventType,
ExprEvaluatorContext exprEvaluatorContext,
MethodPollingViewableMeta metadata) |
MethodPollingViewableMeta(Class methodProviderClass,
boolean isStaticMethod,
Map<String,Object> optionalMapType,
LinkedHashMap<String,Object> optionalOaType,
Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
boolean isCollection,
boolean isIterator,
VariableReader variableReader,
String variableName,
EventType eventTypeEventBeanArray,
ExprNodeScript scriptExpression) |
PropertyResolutionDescriptor(String streamName,
EventType streamEventType,
String propertyName,
int streamNum,
Class propertyType,
FragmentEventType fragmentEventType)
Ctor.
|
SelectExprInsertNativeBase(EventType eventType,
EventBeanManufacturer eventManufacturer,
ExprEvaluator[] exprEvaluators) |
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) |
SelectExprInsertNativeNoEval(EventType eventType,
EventBeanManufacturer eventManufacturer) |
SelectExprInsertNativeNoWiden(EventType eventType,
EventBeanManufacturer eventManufacturer,
ExprEvaluator[] exprEvaluators) |
SelectExprInsertNativeWidening(EventType eventType,
EventBeanManufacturer eventManufacturer,
ExprEvaluator[] exprEvaluators,
TypeWidener[] wideners) |
SelectExprJoinWildcardProcessorMap(String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService) |
SelectExprJoinWildcardProcessorObjectArray(String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService) |
SelectExprJoinWildcardProcessorTableRows(EventType[] types,
SelectExprProcessor inner,
TableService tableService) |
SelectExprProcessorEvalStreamInsertNamedWindow(int streamNum,
EventType namedWindowAsType,
Class returnType,
EventAdapterService eventAdapterService) |
SelectExprProcessorEvalTypableMap(EventType mapType,
ExprEvaluator innerEvaluator,
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) |
SelectExprProcessorWDeliveryCallback(EventType eventType,
BindProcessor bindProcessor,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback) |
SelectExprWildcardProcessor(EventType eventType)
Ctor.
|
StreamTypeServiceImpl(EventType[] eventTypes,
String[] streamNames,
boolean[] isIStreamOnly,
String engineURI,
boolean isOnDemandStreams)
Ctor.
|
StreamTypeServiceImpl(EventType eventType,
String streamName,
boolean isIStreamOnly,
String engineURI)
Ctor.
|
Constructor and Description |
---|
StreamTypeServiceImpl(LinkedHashMap<String,Pair<EventType,String>> namesAndTypes,
String engineURI,
boolean isStreamZeroUnambigous,
boolean requireStreamNames)
Ctor.
|
Modifier and Type | Field and Description |
---|---|
protected EventType |
EvalSelectStreamBase.resultEventType |
protected EventType |
EvalInsertNoWildcardObjectArrayRemap.resultEventType |
protected EventType |
EvalBase.resultEventType |
Modifier and Type | Method and Description |
---|---|
EventType |
EvalSelectStreamBase.getResultEventType() |
EventType |
EvalSelectNoWildcardObjectArray.getResultEventType() |
EventType |
EvalSelectNoWildcardMap.getResultEventType() |
EventType |
EvalSelectNoWildcardEmptyProps.getResultEventType() |
EventType |
EvalInsertNoWildcardObjectArrayRemap.getResultEventType() |
EventType |
EvalInsertCoercionObjectArray.getResultEventType() |
EventType |
EvalInsertCoercionMap.getResultEventType() |
EventType |
EvalInsertCoercionAvro.getResultEventType() |
EventType |
EvalInsertBeanWrapRecast.getResultEventType() |
EventType |
EvalInsertBeanRecast.getResultEventType() |
EventType |
EvalBaseFirstProp.getResultEventType() |
EventType |
EvalBase.getResultEventType() |
Modifier and Type | Method and Description |
---|---|
static SelectExprProcessor |
EvalSelectStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static SelectExprProcessor |
EvalSelectStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static SelectExprProcessor |
EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static SelectExprProcessor |
EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService,
String statementName,
String engineURI) |
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(Class sourceType,
EventType targetType) |
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(EventType sourceType,
EventType targetType) |
Constructor and Description |
---|
EvalInsertNoWildcardSingleColCoercionRevisionFunc(SelectExprContext selectExprContext,
EventType resultEventType,
ValueAddEventProcessor vaeProcessor,
EventType vaeInnerEventType,
TriFunction<EventAdapterService,Object,EventType,EventBean> func) |
Modifier and Type | Method and Description |
---|---|
com.espertech.esper.epl.datetime.eval.ExprDotEvalDT.DTLocalEvaluator |
ExprDotEvalDT.getEvaluator(List<CalendarOp> calendarOps,
TimeZone timeZone,
TimeAbacus timeAbacus,
Class inputType,
EventType inputEventType,
ReformatOp reformatOp,
IntervalOp intervalOp) |
Constructor and Description |
---|
ExprDotEvalDT(List<CalendarOp> calendarOps,
TimeZone timeZone,
TimeAbacus timeAbacus,
ReformatOp reformatOp,
IntervalOp intervalOp,
Class inputType,
EventType inputEventType) |
FilterExprAnalyzerDTBetweenAffector(EventType[] typesPerStream,
int targetStreamNum,
String targetPropertyName,
ExprNode start,
ExprNode end,
boolean includeLow,
boolean includeHigh) |
FilterExprAnalyzerDTIntervalAffector(DatetimeMethodEnum currentMethod,
EventType[] typesPerStream,
int targetStreamNum,
String targetStartProp,
String targetEndProp,
Integer parameterStreamNum,
String parameterStartProp,
String parameterEndProp) |
Modifier and Type | Method and Description |
---|---|
FilterExprAnalyzerDTIntervalAffector |
IntervalOpImpl.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodEnum currentMethod,
List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc)
Obtain information used by filter analyzer to handle this dot-method invocation as part of query planning/indexing.
|
FilterExprAnalyzerDTIntervalAffector |
IntervalOp.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodEnum currentMethod,
List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc) |
Modifier and Type | Method and Description |
---|---|
EventType |
DatabasePollingViewable.getEventType() |
Constructor and Description |
---|
DatabasePollingViewable(int myStreamNumber,
List<String> inputParameters,
PollExecStrategy pollExecStrategy,
DataCache dataCache,
EventType eventType)
Ctor.
|
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 |
ExprDeclaredEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprDeclaredEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Modifier and Type | Method and Description |
---|---|
abstract EventType[] |
ExprDotEvalEnumMethodBase.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType |
PropertyExprEvaluatorScalarIterable.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorScalarCollection.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorScalarArray.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorEventSingle.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorEventCollection.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorScalarIterable.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorScalarCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorScalarArray.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorEventSingle.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
PropertyExprEvaluatorEventCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType[] |
ExprDotEvalParamLambda.getGoesToTypes() |
Modifier and Type | Method and Description |
---|---|
abstract EventType[] |
ExprDotEvalEnumMethodBase.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
abstract EnumEval |
ExprDotEvalEnumMethodBase.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
Constructor and Description |
---|
ExprDotEvalParamLambda(int parameterNum,
ExprNode body,
ExprEvaluator bodyEvaluator,
int streamCountIncoming,
List<String> goesToNames,
EventType[] goesToTypes) |
ExprDotEvalUnpackBean(EventType lambdaType) |
ExprDotEvalUnpackBeanTable(EventType lambdaType,
TableMetadata tableMetadata) |
ExprDotEvalUnpackCollEventBean(EventType type) |
ExprDotEvalUnpackCollEventBeanTable(EventType type,
TableMetadata tableMetadata) |
ExprDotStaticMethodWrapEventBeanArr(EventType type) |
ExprDotStaticMethodWrapEventBeanColl(EventType type) |
PropertyExprEvaluatorEventCollection(String propertyNameCache,
int streamId,
EventType fragmentType,
EventPropertyGetter getter,
boolean disablePropertyExpressionEventCollCache) |
PropertyExprEvaluatorEventSingle(int streamId,
EventType fragmentType,
EventPropertyGetter getter) |
Modifier and Type | Method and Description |
---|---|
EventType[] |
ExprDotEvalWhere.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalToMap.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalTakeWhileAndLast.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalTakeAndTakeLast.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSumOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSetExceptUnionIntersect.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSequenceEqual.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSelectFrom.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalReverse.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalOrderByAscDesc.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalNoOp.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalMostLeastFrequent.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalMinMax.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalMinByMaxBy.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalGroupBy.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalFirstLastOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalDistinct.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalCountOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalAverage.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalAllOfAnyOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalAggregate.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventType[] |
ExprDotEvalWhere.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalToMap.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalTakeWhileAndLast.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalTakeAndTakeLast.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSumOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSetExceptUnionIntersect.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSequenceEqual.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalSelectFrom.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalReverse.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalOrderByAscDesc.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalNoOp.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalMostLeastFrequent.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalMinMax.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalMinByMaxBy.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalGroupBy.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalFirstLastOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalDistinct.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalCountOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalAverage.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalAllOfAnyOf.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EventType[] |
ExprDotEvalAggregate.getAddStreamTypes(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService) |
EnumEval |
ExprDotEvalWhere.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalToMap.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalTakeWhileAndLast.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalTakeAndTakeLast.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalSumOf.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalSetExceptUnionIntersect.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalSequenceEqual.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalSelectFrom.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalReverse.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalOrderByAscDesc.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalNoOp.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalMostLeastFrequent.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalMinMax.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalMinByMaxBy.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalGroupBy.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalFirstLastOf.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalDistinct.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalCountOf.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalAverage.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalAllOfAnyOf.getEnumEval(EngineImportService engineImportService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
int statementId,
String enumMethodUsedName,
List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache) |
EnumEval |
ExprDotEvalAggregate.getEnumEval(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 |
ExprAggMultiFunctionSortedMinMaxByNodeFactory.getContainedEventType() |
EventType |
ExprAggMultiFunctionLinearAccessNodeFactoryAccess.getContainedEventType() |
EventType |
LinearAggregationFactoryDesc.getEnumerationEventType() |
EventType |
ExprPlugInAggMultiFunctionNodeFactory.getEventTypeCollection() |
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 |
ExprPlugInAggMultiFunctionNodeFactory.getEventTypeSingle() |
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 |
---|---|
ExprEvaluator |
ExprPlugInAggMultiFunctionNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
ExprAggMultiFunctionSortedMinMaxByNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
ExprAggMultiFunctionLinearAccessNodeFactoryAccess.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
ExprAggCountMinSketchNodeFactoryUse.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
ExprAggCountMinSketchNodeFactoryState.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
ExprEvaluator |
AggregationMethodFactoryFirstLastUnbound.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprStreamUnderlyingNodeImpl.getEventType() |
EventType |
ExprStreamUnderlyingNode.getEventType() |
EventType |
ExprEvaluatorEnumeration.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprEvaluatorEnumeration.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprNodeUtilMethodDesc.getOptionalEventType() |
Modifier and Type | Method and Description |
---|---|
static void |
ExprNodeUtility.addNonAggregatedProps(ExprNode exprNode,
ExprNodePropOrStreamSet set,
EventType[] types,
ContextPropertyRegistry contextPropertyRegistry) |
static ExprIdentNode |
ExprNodeUtility.getExprIdentNode(EventType[] typesPerStream,
int streamId,
String property) |
static ExprNodePropOrStreamSet |
ExprNodeUtility.getNonAggregatedProps(EventType[] types,
List<ExprNode> exprNodes,
ContextPropertyRegistry contextPropertyRegistry) |
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) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType,
boolean allowBindingConsumption) |
Constructor and Description |
---|
ExprIdentNodeImpl(EventType eventType,
String propertyName,
int streamNumber) |
ExprNodeUtilMethodDesc(boolean allConstants,
Class[] paramTypes,
ExprEvaluator[] childEvals,
Method reflectionMethod,
net.sf.cglib.reflect.FastMethod fastMethod,
EventType optionalEventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprDotEvalRootChildInnerEval.getEventTypeCollection() |
EventType |
ExprDotEvalRootChild.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprDotEvalRootChildInnerEval.getEventTypeSingle() |
EventType |
ExprDotEvalRootChild.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
static EventType[] |
ExprDotNodeUtility.getSingleLambdaParamEventType(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
static Object |
ExprDotNodeUtility.evaluateChainWithWrap(ExprDotStaticMethodWrap resultWrapLambda,
Object result,
EventType optionalResultSingleEventType,
Class resultType,
ExprDotEval[] chainEval,
EventBean[] eventsPerStream,
boolean newData,
ExprEvaluatorContext exprEvaluatorContext) |
static ExprDotEnumerationSourceForProps |
ExprDotNodeUtility.getPropertyEnumerationSource(String propertyName,
int streamId,
EventType streamType,
boolean allowEnumType,
boolean disablePropertyExpressionEventCollCache) |
static EventType[] |
ExprDotNodeUtility.getSingleLambdaParamEventType(String enumMethodUsedName,
List<String> goesToNames,
EventType inputEventType,
Class collectionComponentType,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventType |
InnerEvaluatorScalarUnpackEvent.getEventTypeCollection() |
EventType |
InnerEvaluatorScalar.getEventTypeCollection() |
EventType |
InnerEvaluatorEnumerableScalarCollection.getEventTypeCollection() |
EventType |
InnerEvaluatorEnumerableEventCollection.getEventTypeCollection() |
EventType |
InnerEvaluatorEnumerableEventBean.getEventTypeCollection() |
EventType |
InnerEvaluatorColl.getEventTypeCollection() |
EventType |
InnerEvaluatorArrPrimitiveToColl.getEventTypeCollection() |
EventType |
InnerEvaluatorArrObjectToColl.getEventTypeCollection() |
EventType |
InnerEvaluatorScalarUnpackEvent.getEventTypeSingle() |
EventType |
InnerEvaluatorScalar.getEventTypeSingle() |
EventType |
InnerEvaluatorEnumerableScalarCollection.getEventTypeSingle() |
EventType |
InnerEvaluatorEnumerableEventCollection.getEventTypeSingle() |
EventType |
InnerEvaluatorEnumerableEventBean.getEventTypeSingle() |
EventType |
InnerEvaluatorColl.getEventTypeSingle() |
EventType |
InnerEvaluatorArrPrimitiveToColl.getEventTypeSingle() |
EventType |
InnerEvaluatorArrObjectToColl.getEventTypeSingle() |
Constructor and Description |
---|
InnerEvaluatorEnumerableEventBean(ExprEvaluatorEnumeration rootLambdaEvaluator,
EventType eventType) |
InnerEvaluatorEnumerableEventCollection(ExprEvaluatorEnumeration rootLambdaEvaluator,
EventType eventType) |
Constructor and Description |
---|
FragmentTypeEval(int streamId,
EventType eventType,
String resolvedPropertyName) |
Modifier and Type | Method and Description |
---|---|
static ExprEvaluator |
ExprMethodAggUtil.getDefaultEvaluator(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream) |
static ExprEvaluator |
ExprMethodAggUtil.getMultiNodeEvaluator(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprArrayNode.getEventTypeCollection(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 | Field and Description |
---|---|
protected EventType |
ExprSubselectNode.rawEventType
The event type generated for wildcard selects.
|
Modifier and Type | Method and Description |
---|---|
EventType |
ExprSubselectRowNode.SubselectMultirowType.getEventType() |
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) |
EventType |
ExprSubselectNode.getRawEventType()
Returns the event type.
|
Modifier and Type | Method and Description |
---|---|
void |
ExprSubselectNode.setRawEventType(EventType rawEventType)
Sets the event type generated for wildcard selects.
|
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 |
---|---|
AdvancedIndexConfigContextPartition |
EventAdvancedIndexFactoryQuadTree.configureContextPartition(EventType eventType,
AdvancedIndexDesc indexDesc,
ExprEvaluator[] parameters,
ExprEvaluatorContext exprEvaluatorContext,
EventTableOrganization organization,
EventAdvancedIndexConfigStatement advancedIndexConfigStatement) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
EventTableFactoryCustomIndex.eventType |
Constructor and Description |
---|
EventTableFactoryCustomIndex(String indexName,
int indexedStreamNum,
EventType eventType,
boolean unique,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc) |
Modifier and Type | Method and Description |
---|---|
static Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> |
JoinSetComposerPrototypeFactory.determineIndexing(QueryGraph queryGraph,
EventType polledViewType,
EventType streamViewType,
int polledViewStreamNum,
int streamViewStreamNum)
Constructs indexing and lookup strategy for a given relationship that a historical stream may have with another
stream (historical or not) that looks up into results of a poll of a historical stream.
|
static JoinSetComposerPrototype |
JoinSetComposerPrototypeFactory.makeComposerPrototype(String statementName,
int statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean queryPlanLogging,
StatementContext statementContext,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
boolean selectsRemoveStream,
boolean hasAggregations,
TableService tableService,
boolean isOnDemandQuery,
boolean allowIndexInit) |
Constructor and Description |
---|
HistoricalIndexLookupStrategyIndex(EventType eventType,
int lookupStream,
List<QueryGraphValueEntryHashKeyed> hashKeys) |
JoinSetComposerPrototypeHistorical2StreamImpl(ExprNode optionalFilterNode,
EventType[] streamTypes,
ExprEvaluatorContext exprEvaluatorContext,
int polledViewNum,
int streamViewNum,
boolean outerJoin,
ExprNode outerJoinEqualsNode,
Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> indexStrategies,
boolean allHistoricalNoSubordinate,
OuterJoinDesc[] outerJoinDescList,
boolean allowIndexInit) |
JoinSetComposerPrototypeImpl(String statementName,
int statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
Annotation[] annotations,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
QueryPlanIndex[] indexSpecs,
QueryPlan queryPlan,
HistoricalStreamIndexList[] historicalStreamIndexLists,
boolean joinRemoveStream,
boolean isOuterJoins,
TableService tableService,
EventTableIndexService eventTableIndexService) |
Modifier and Type | Method and Description |
---|---|
EventType |
IndexedTableLookupStrategySingle.getEventType()
Returns event type of the lookup event.
|
EventType |
IndexedTableLookupStrategy.getEventType()
Returns event type of the lookup event.
|
EventType |
CompositeTableLookupStrategy.getEventType()
Returns event type of the lookup event.
|
Constructor and Description |
---|
CompositeTableLookupStrategy(EventType eventType,
int lookupStream,
List<QueryGraphValueEntryHashKeyed> hashKeys,
List<QueryGraphValueEntryRange> rangeKeyPairs,
PropertyCompositeEventTable index) |
IndexedTableLookupStrategy(EventType eventType,
String[] properties,
PropertyIndexedEventTable index)
Ctor.
|
IndexedTableLookupStrategySingle(EventType eventType,
String property,
PropertyIndexedEventTableSingle index)
Ctor.
|
Constructor and Description |
---|
CompositeIndexEnterRemoveKeyed(EventType eventType,
String[] keysProps,
Class[] keyCoercionTypes) |
CompositeIndexEnterRemoveRange(EventType eventType,
String rangeProp,
Class coercionType) |
Modifier and Type | Method and Description |
---|---|
static QueryPlan |
TwoStreamQueryPlanBuilder.build(EventType[] typesPerStream,
QueryGraph queryGraph,
OuterJoinType optionalOuterJoinType,
String[][][] uniqueIndexProps,
TableMetadata[] tablesPerStream)
Build query plan.
|
protected static QueryPlan |
NStreamQueryPlanBuilder.build(QueryGraph queryGraph,
EventType[] typesPerStream,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
boolean hasForceNestedIter,
String[][][] indexedStreamsUniqueProps,
TableMetadata[] tablesPerStream) |
protected static QueryPlan |
NStreamOuterQueryPlanBuilder.build(QueryGraph queryGraph,
OuterJoinDesc[] outerJoinDescList,
String[] streamNames,
EventType[] typesPerStream,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
ExprEvaluatorContext exprEvaluatorContext,
String[][][] indexedStreamsUniqueProps,
TableMetadata[] tablesPerStream)
Build a query plan based on the stream property relationships indicated in queryGraph.
|
static QueryPlanIndex[] |
QueryPlanIndexBuilder.buildIndexSpec(QueryGraph queryGraph,
EventType[] typePerStream,
String[][][] indexedStreamsUniqueProps)
Build index specification from navigability info.
|
static TableLookupPlan |
NStreamQueryPlanBuilder.createLookupPlan(QueryGraph queryGraph,
int currentLookupStream,
int indexedStream,
QueryPlanIndex indexSpecs,
EventType[] typesPerStream,
TableMetadata indexedStreamTableMeta)
Create the table lookup plan for a from-stream to look up in an indexed stream
using the columns supplied in the query graph and looking at the actual indexes available
and their index number.
|
protected static QueryPlanNode |
NStreamQueryPlanBuilder.createStreamPlan(int lookupStream,
int[] bestChain,
QueryGraph queryGraph,
QueryPlanIndex[] indexSpecsPerStream,
EventType[] typesPerStream,
boolean[] isHistorical,
HistoricalStreamIndexList[] historicalStreamIndexLists,
TableMetadata[] tablesPerStream)
Walks the chain of lookups and constructs lookup strategy and plan specification based
on the index specifications.
|
static void |
QueryGraph.fillEquivalentNav(EventType[] typesPerStream,
QueryGraph queryGraph)
Fill in equivalent key properties (navigation entries) on all streams.
|
static Class |
CoercionUtil.getCoercionTypeRange(EventType indexedType,
String indexedProp,
SubordPropRangeKey rangeKey) |
static CoercionDesc |
CoercionUtil.getCoercionTypesHash(EventType[] typesPerStream,
int lookupStream,
int indexedStream,
List<QueryGraphValueEntryHashKeyed> keyProps,
String[] indexProps)
Returns null if no coercion is required, or an array of classes for use in coercing the
lookup keys and index keys into a common type.
|
static CoercionDesc |
CoercionUtil.getCoercionTypesHash(EventType viewableEventType,
String[] indexProps,
List<SubordPropHashKey> hashKeys) |
static CoercionDesc |
CoercionUtil.getCoercionTypesRange(EventType[] typesPerStream,
int indexedStream,
String[] indexedProp,
List<QueryGraphValueEntryRange> rangeEntries) |
static CoercionDesc |
CoercionUtil.getCoercionTypesRange(EventType viewableEventType,
Map<String,SubordPropRangeKey> rangeProps,
EventType[] typesPerStream) |
static CoercionDesc |
CoercionUtil.getCoercionTypesRange(EventType viewableEventType,
Map<String,SubordPropRangeKey> rangeProps,
EventType[] typesPerStream) |
static SubordPropPlan |
QueryPlanIndexBuilder.getJoinProps(ExprNode filterExpr,
int outsideStreamCount,
EventType[] allStreamTypesZeroIndexed,
ExcludePlanHint excludePlanHint) |
static QueryPlan |
QueryPlanBuilder.getPlan(EventType[] typesPerStream,
OuterJoinDesc[] outerJoinDescList,
QueryGraph queryGraph,
String[] streamNames,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean isQueryPlanLogging,
Annotation[] annotations,
ExprEvaluatorContext exprEvaluatorContext)
Build query plan using the filter.
|
LookupInstructionExec |
LookupInstructionPlan.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal)
Constructs the executable from the plan.
|
ExecNode |
TableOuterLookupNode.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
TableLookupNode.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
QueryPlanNodeNoOp.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
QueryPlanNodeAllUnidirectionalOuter.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
abstract ExecNode |
QueryPlanNode.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks)
Make execution node from this specification.
|
ExecNode |
NestedIterationNode.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexList,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
LookupInstructionQueryPlanNode.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
ExecNode |
HistoricalDataPlanNode.makeExec(String statementName,
int statementId,
Annotation[] annotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
Lock[] tableSecondaryIndexLocks) |
JoinExecTableLookupStrategy |
TableLookupPlan.makeStrategy(String statementName,
int statementId,
Annotation[] accessedByStmtAnnotations,
Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] eventTypes,
VirtualDWView[] viewExternals) |
abstract JoinExecTableLookupStrategy |
TableLookupPlan.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
SortedTableLookupPlan.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
InKeywordTableLookupPlanSingleIdx.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
InKeywordTableLookupPlanMultiIdx.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
IndexedTableLookupPlanSingle.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
IndexedTableLookupPlanMulti.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
FullTableScanUniquePerKeyLookupPlan.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
FullTableScanLookupPlan.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
JoinExecTableLookupStrategy |
CompositeTableLookupPlan.makeStrategyInternal(EventTable[] eventTable,
EventType[] eventTypes) |
Constructor and Description |
---|
PollResultIndexingStrategyComposite(int streamNum,
EventType eventType,
String[] indexPropertiesJoin,
Class[] keyCoercionTypes,
String[] rangePropertiesJoin,
Class[] rangeCoercionTypes) |
PollResultIndexingStrategyIndex(int streamNum,
EventType eventType,
String[] propertyNames)
Ctor.
|
PollResultIndexingStrategyIndexCoerce(int streamNum,
EventType eventType,
String[] propertyNames,
Class[] coercionTypes)
Ctor.
|
PollResultIndexingStrategyIndexCoerceSingle(int streamNum,
EventType eventType,
String propertyName,
Class coercionType) |
PollResultIndexingStrategyIndexSingle(int streamNum,
EventType eventType,
String propertyName)
Ctor.
|
PollResultIndexingStrategyIndexSingleArray(int streamNum,
EventType eventType,
String[] propertyNames)
Ctor.
|
PollResultIndexingStrategySorted(int streamNum,
EventType eventType,
String propertyName,
Class coercionType) |
Modifier and Type | Method and Description |
---|---|
static EventTable |
EventTableUtil.buildIndex(AgentInstanceContext agentInstanceContext,
int indexedStreamNum,
QueryPlanIndexItem item,
EventType eventType,
boolean coerceOnAddOnly,
boolean unique,
String optionalIndexName,
Object optionalSerde,
boolean isFireAndForget)
Build an index/table instance using the event properties for the event type.
|
Constructor and Description |
---|
HistoricalStreamIndexList(int historicalStreamNum,
EventType[] typesPerStream,
QueryGraph queryGraph)
Ctor.
|
PropertyCompositeEventTableFactory(int streamNum,
EventType eventType,
String[] optionalKeyedProps,
Class[] optKeyCoercedTypes,
String[] rangeProps,
Class[] optRangeCoercedTypes) |
PropertyIndexedEventTableCoerceAddFactory(int streamNum,
EventType eventType,
String[] propertyNames,
Class[] coercionType)
Ctor.
|
PropertyIndexedEventTableCoerceAllFactory(int streamNum,
EventType eventType,
String[] propertyNames,
Class[] coercionType)
Ctor.
|
PropertyIndexedEventTableFactory(int streamNum,
EventType eventType,
String[] propertyNames,
boolean unique,
String optionalIndexName)
Ctor.
|
PropertyIndexedEventTableSingleArrayFactory(int streamNum,
EventType eventType,
String[] propertyNames,
boolean unique,
String optionalIndexName) |
PropertyIndexedEventTableSingleCoerceAddFactory(int streamNum,
EventType eventType,
String propertyName,
Class coercionType)
Ctor.
|
PropertyIndexedEventTableSingleCoerceAllFactory(int streamNum,
EventType eventType,
String propertyName,
Class coercionType)
Ctor.
|
PropertyIndexedEventTableSingleFactory(int streamNum,
EventType eventType,
String propertyName,
boolean unique,
String optionalIndexName) |
PropertySortedEventTableCoercedFactory(int streamNum,
EventType eventType,
String propertyName,
Class coercionType)
Ctor.
|
PropertySortedEventTableFactory(int streamNum,
EventType eventType,
String propertyName)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
void |
EventTableIndexRepository.addExplicitIndex(String explicitIndexName,
QueryPlanIndexItem desc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.addExplicitIndexOrReuse(boolean unique,
List<IndexedPropDesc> hashProps,
List<IndexedPropDesc> btreeProps,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc,
Iterable<EventBean> prefilledEvents,
EventType indexedType,
String indexName,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
AdvancedIndexConfigContextPartition |
EventAdvancedIndexFactory.configureContextPartition(EventType eventType,
AdvancedIndexDesc indexDesc,
ExprEvaluator[] parameters,
ExprEvaluatorContext exprEvaluatorContext,
EventTableOrganization organization,
EventAdvancedIndexConfigStatement advancedIndexConfigStatement) |
EventTableFactory |
EventTableIndexServiceImpl.createComposite(int indexedStreamNum,
EventType eventType,
String[] indexedKeyProps,
Class[] coercionKeyTypes,
String[] indexedRangeProps,
Class[] coercionRangeTypes,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createComposite(int indexedStreamNum,
EventType eventType,
String[] indexedKeyProps,
Class[] coercionKeyTypes,
String[] indexedRangeProps,
Class[] coercionRangeTypes,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createCustom(String indexName,
int indexedStreamNum,
EventType eventType,
boolean unique,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc) |
EventTableFactory |
EventTableIndexService.createCustom(String indexName,
int indexedStreamNum,
EventType eventType,
boolean unique,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc) |
EventTableFactory |
EventTableIndexServiceImpl.createInArray(int indexedStreamNum,
EventType eventType,
String[] indexedProp,
boolean unique) |
EventTableFactory |
EventTableIndexService.createInArray(int indexedStreamNum,
EventType eventType,
String[] indexedProp,
boolean unique) |
EventTableFactory |
EventTableIndexServiceImpl.createMultiKey(int indexedStreamNum,
EventType eventType,
String[] indexProps,
boolean unique,
String optionalIndexName,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createMultiKey(int indexedStreamNum,
EventType eventType,
String[] indexProps,
boolean unique,
String optionalIndexName,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createMultiKeyCoerceAdd(int indexedStreamNum,
EventType eventType,
String[] indexProps,
Class[] indexCoercionTypes,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createMultiKeyCoerceAdd(int indexedStreamNum,
EventType eventType,
String[] indexProps,
Class[] indexCoercionTypes,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createMultiKeyCoerceAll(int indexedStreamNum,
EventType eventType,
String[] indexProps,
Class[] indexCoercionTypes,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createMultiKeyCoerceAll(int indexedStreamNum,
EventType eventType,
String[] indexProps,
Class[] indexCoercionTypes,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createSingle(int indexedStreamNum,
EventType eventType,
String propertyName,
boolean unique,
String optionalIndexName,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createSingle(int indexedStreamNum,
EventType eventType,
String indexProp,
boolean unique,
String optionalIndexName,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createSingleCoerceAdd(int indexedStreamNum,
EventType eventType,
String indexProp,
Class indexCoercionType,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createSingleCoerceAdd(int indexedStreamNum,
EventType eventType,
String indexProp,
Class indexCoercionType,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createSingleCoerceAll(int indexedStreamNum,
EventType eventType,
String indexProp,
Class indexCoercionType,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createSingleCoerceAll(int indexedStreamNum,
EventType eventType,
String indexProp,
Class indexCoercionType,
Object optionalSerde,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createSorted(int indexedStreamNum,
EventType eventType,
String indexedProp,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createSorted(int indexedStreamNum,
EventType eventType,
String indexedProp,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexServiceImpl.createSortedCoerce(int indexedStreamNum,
EventType eventType,
String indexedProp,
Class indexCoercionType,
boolean isFireAndForget) |
EventTableFactory |
EventTableIndexService.createSortedCoerce(int indexedStreamNum,
EventType eventType,
String indexedProp,
Class indexCoercionType,
boolean isFireAndForget) |
static SubordTableLookupStrategyFactory |
SubordinateTableLookupStrategyUtil.getLookupStrategy(EventType[] outerStreamTypesZeroIndexed,
List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
ExprNode[] inKeywordSingleIdxKeys,
ExprNode inKeywordMultiIdxKey,
boolean isNWOnTrigger) |
static SubordinateWMatchExprQueryPlanResult |
SubordinateQueryPlanner.planOnExpression(ExprNode joinExpr,
EventType filterEventType,
IndexHint optionalIndexHint,
boolean isIndexShare,
int subqueryNumber,
ExcludePlanHint excludePlanHint,
boolean isVirtualDataWindow,
EventTableIndexMetadata indexMetadata,
EventType eventTypeIndexed,
Set<String> optionalUniqueKeyProps,
boolean onlyUseExistingIndexes,
String statementName,
int statementId,
Annotation[] annotations) |
static SubordinateQueryPlanDesc |
SubordinateQueryPlanner.planSubquery(EventType[] outerStreams,
SubordPropPlan joinDesc,
boolean isNWOnTrigger,
boolean forceTableScan,
IndexHint optionalIndexHint,
boolean indexShare,
int subqueryNumber,
boolean isVirtualDataWindow,
EventTableIndexMetadata indexMetadata,
Set<String> optionalUniqueKeyProps,
boolean onlyUseExistingIndexes,
String statementName,
int statementId,
Annotation[] annotations) |
static EventTable[] |
SubordinateQueryPlannerUtil.realizeTables(SubordinateQueryIndexDesc[] indexDescriptors,
EventType eventType,
EventTableIndexRepository indexRepository,
Iterable<EventBean> contents,
AgentInstanceContext agentInstanceContext,
boolean isRecoveringResilient) |
void |
EventTableIndexRepository.validateAddExplicitIndex(String explicitIndexName,
QueryPlanIndexItem explicitIndexDesc,
EventType eventType,
Iterable<EventBean> dataWindowContents,
AgentInstanceContext agentInstanceContext,
boolean allowIndexExists,
Object optionalSerde) |
static QueryPlanIndexItem |
EventTableIndexUtil.validateCompileExplicitIndex(String indexName,
boolean unique,
List<CreateIndexItem> columns,
EventType eventType,
StatementContext statementContext) |
Constructor and Description |
---|
SubordIndexedTableLookupStrategyPropFactory(boolean isNWOnTrigger,
EventType[] eventTypes,
int[] keyStreamNumbers,
String[] properties)
Ctor.
|
SubordIndexedTableLookupStrategySinglePropFactory(boolean isNWOnTrigger,
EventType[] eventTypes,
int keyStreamNum,
String property)
Ctor.
|
SubordTableLookupStrategyFactoryVDW(String statementName,
int statementId,
Annotation[] annotations,
EventType[] outerStreams,
List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
boolean nwOnTrigger,
SubordPropPlan joinDesc,
boolean forceTableScan,
SubordinateQueryPlannerIndexPropListPair hashAndRanges) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
NamedWindowTailView.eventType |
protected EventType |
NamedWindowOnExprBaseViewFactory.namedWindowEventType |
Modifier and Type | Method and Description |
---|---|
EventType |
NamedWindowTailViewInstance.getEventType() |
EventType |
NamedWindowTailView.getEventType() |
EventType |
NamedWindowRootViewInstance.getEventType() |
EventType |
NamedWindowRootView.getEventType() |
EventType |
NamedWindowOnUpdateView.getEventType() |
EventType |
NamedWindowOnSelectView.getEventType() |
EventType |
NamedWindowOnMergeView.getEventType() |
EventType |
NamedWindowOnDeleteView.getEventType() |
EventType |
NamedWindowConsumerView.getEventType() |
EventType |
NamedWindowProcessor.getNamedWindowType()
Returns the event type of the named window.
|
Modifier and Type | Method and Description |
---|---|
NamedWindowProcessor |
NamedWindowMgmtServiceImpl.addProcessor(String name,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow,
NamedWindowDispatchService namedWindowDispatchService) |
NamedWindowProcessor |
NamedWindowMgmtService.addProcessor(String name,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow,
NamedWindowDispatchService namedWindowDispatchService) |
NamedWindowProcessor |
NamedWindowDispatchServiceImpl.createProcessor(String name,
NamedWindowMgmtServiceImpl namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow) |
NamedWindowProcessor |
NamedWindowDispatchService.createProcessor(String name,
NamedWindowMgmtServiceImpl namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow) |
NamedWindowTailView |
NamedWindowDispatchServiceImpl.createTailView(EventType eventType,
NamedWindowMgmtService namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
boolean prioritized,
boolean parentBatchWindow,
String contextName,
TimeSourceService timeSourceService,
ConfigurationEngineDefaults.Threading threadingConfig) |
NamedWindowTailView |
NamedWindowDispatchService.createTailView(EventType eventType,
NamedWindowMgmtService namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
boolean prioritized,
boolean parentBatchWindow,
String contextName,
TimeSourceService timeSourceService,
ConfigurationEngineDefaults.Threading threadingConfig) |
static NamedWindowOnExprFactory |
NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType,
String namedWindowName,
String namedWindowAlias,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
String filterStreamName,
boolean addToFront,
InternalEventRouter internalEventRouter,
EventType outputEventType,
StatementContext statementContext,
StatementMetricHandle createNamedWindowMetricsHandle,
boolean isDistinct,
StreamSelector optionalStreamSelector,
String optionalInsertIntoTableName) |
Constructor and Description |
---|
NamedWindowConsumerView(ExprEvaluator[] filterList,
PropertyEvaluator optPropertyEvaluator,
EventType eventType,
NamedWindowConsumerCallback consumerCallback,
ExprEvaluatorContext exprEvaluatorContext,
boolean audit) |
NamedWindowOnDeleteViewFactory(EventType namedWindowEventType,
StatementResultService statementResultService) |
NamedWindowOnExprBaseViewFactory(EventType namedWindowEventType) |
NamedWindowOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
String triggeringStreamName,
InternalEventRouter internalEventRouter,
String namedWindowName,
EventTypeSPI namedWindowType) |
NamedWindowOnMergeViewFactory(EventType namedWindowEventType,
NamedWindowOnMergeHelper namedWindowOnMergeHelper,
StatementResultService statementResultService,
StatementMetricHandle createNamedWindowMetricHandle,
MetricReportingService metricReportingService) |
NamedWindowOnSelectViewFactory(EventType namedWindowEventType,
InternalEventRouter internalEventRouter,
boolean addToFront,
EPStatementHandle statementHandle,
EventBeanReader eventBeanReader,
boolean distinct,
StatementResultService statementResultService,
InternalEventRouteDest internalEventRouteDest,
boolean deleteAndSelect,
StreamSelector optionalStreamSelector,
String optionalInsertIntoTableName) |
NamedWindowOnUpdateViewFactory(EventType namedWindowEventType,
StatementResultService statementResultService,
EventBeanUpdateHelper updateHelper) |
NamedWindowProcessor(String namedWindowName,
NamedWindowMgmtService namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
String contextName,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
String eplExpression,
String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
Set<String> optionalUniqueKeyProps,
String eventTypeAsName,
StatementContext statementContextCreateWindow) |
NamedWindowRootView(ValueAddEventProcessor revisionProcessor,
boolean queryPlanLogging,
MetricReportingService metricReportingService,
EventType eventType,
boolean childBatching,
boolean isEnableIndexShare,
Set<String> optionalUniqueKeyProps) |
NamedWindowTailView(EventType eventType,
NamedWindowMgmtService namedWindowMgmtService,
NamedWindowDispatchService namedWindowDispatchService,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
boolean prioritized,
boolean parentBatchWindow,
TimeSourceService timeSourceService,
ConfigurationEngineDefaults.Threading threadingConfig) |
Modifier and Type | Method and Description |
---|---|
EventType |
PropertyEvaluatorSimple.getFragmentEventType() |
EventType |
PropertyEvaluatorSelect.getFragmentEventType() |
EventType |
PropertyEvaluatorNested.getFragmentEventType() |
EventType |
PropertyEvaluator.getFragmentEventType()
Returns the result type of the events generated by evaluating a property expression.
|
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 |
---|---|
EventType |
EventMultiValuedEPType.getComponent() |
static EventType |
EPTypeHelper.getEventType(EPType epType) |
static EventType |
EPTypeHelper.getEventTypeMultiValued(EPType type) |
static EventType |
EPTypeHelper.getEventTypeSingleValued(EPType type) |
EventType |
EventEPType.getType() |
static EventType |
EPTypeHelper.optionalIsEventTypeColl(EPType type) |
static EventType |
EPTypeHelper.optionalIsEventTypeSingle(EPType type) |
Modifier and Type | Method and Description |
---|---|
static EPType |
EPTypeHelper.collectionOfEvents(EventType eventTypeOfCollectionEvents)
Indicate that the expression return type is a collection of a given type of events.
|
static EPType |
EPTypeHelper.singleEvent(EventType eventTypeOfSingleEvent)
Indicate that the expression return type is single event of a given event type.
|
Constructor and Description |
---|
EventEPType(EventType type) |
EventMultiValuedEPType(Class container,
EventType component) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
ExprNodeScriptEvalBase.eventTypeCollection |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprNodeScriptEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprNodeScriptEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Constructor and Description |
---|
ExprNodeScriptEvalBase(String scriptName,
String statementName,
String[] names,
ExprEvaluator[] parameters,
Class returnType,
EventType eventTypeCollection) |
ExprNodeScriptEvalJSR223(String scriptName,
String statementName,
String[] names,
ExprEvaluator[] parameters,
Class returnType,
EventType eventTypeCollection,
CompiledScript executable) |
ExprNodeScriptEvalMVEL(String scriptName,
String statementName,
String[] names,
ExprEvaluator[] parameters,
Class returnType,
EventType eventTypeCollection,
Object executable) |
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.
|
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
PatternStreamSpecCompiled.getArrayEventTypes()
Returns event types tagged in the pattern expression under a repeat-operator.
|
LinkedHashMap<String,Pair<EventType,String>> |
MatchEventSpec.getArrayEventTypes() |
LinkedHashMap<String,Pair<EventType,String>> |
PatternStreamSpecCompiled.getTaggedEventTypes()
Returns event types tagged in the pattern expression.
|
LinkedHashMap<String,Pair<EventType,String>> |
MatchEventSpec.getTaggedEventTypes() |
Constructor and Description |
---|
MatchEventSpec(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes) |
MatchEventSpec(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes) |
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
ViewSpec[] viewSpecs,
String optionalStreamName,
StreamSpecOptions streamSpecOptions,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch) |
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
ViewSpec[] viewSpecs,
String optionalStreamName,
StreamSpecOptions streamSpecOptions,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch) |
Modifier and Type | Method and Description |
---|---|
EventType |
SubselectAggregatorViewBase.getEventType() |
Constructor and Description |
---|
TableOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
String triggeringStreamName,
InternalEventRouter internalEventRouter,
TableMetadata tableMetadata) |
Modifier and Type | Method and Description |
---|---|
EventType |
TableStateViewablePublic.getEventType() |
EventType |
TableStateViewableInternal.getEventType() |
EventType |
TableColumnDescAgg.getOptionalAssociatedType() |
EventType |
TableMetadataColumnAggregation.getOptionalEventType() |
EventType |
TableMetadata.getPublicEventType() |
Modifier and Type | Method and Description |
---|---|
TableMetadata |
TableServiceImpl.getTableMetadataFromEventType(EventType type) |
TableMetadata |
TableService.getTableMetadataFromEventType(EventType type) |
static String |
TableServiceUtil.getTableNameFromEventType(EventType type) |
Constructor and Description |
---|
TableColumnDescAgg(int positionInDeclaration,
String columnName,
ExprAggregateNode aggregation,
EventType optionalAssociatedType) |
TableMetadataColumnAggregation(String columnName,
AggregationMethodFactory factory,
int methodOffset,
AggregationAccessorSlotPair accessAccessorSlotPair,
EPType optionalEnumerationType,
EventType optionalEventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
TableOnViewBase.getEventType() |
EventType |
TableOnSelectView.getEventType() |
EventType |
TableOnDeleteView.getEventType() |
Modifier and Type | Method and Description |
---|---|
static TableOnViewFactory |
TableOnViewFactoryFactory.make(TableMetadata tableMetadata,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
String filterStreamName,
StatementContext statementContext,
StatementMetricHandle metricsHandle,
boolean isDistinct,
InternalEventRouter internalEventRouter) |
Modifier and Type | Method and Description |
---|---|
EventType |
ExprTableExprEvaluatorAccess.getEventTypeCollection(EventAdapterService eventAdapterService,
int statementId) |
EventType |
ExprTableExprEvaluatorAccess.getEventTypeSingle(EventAdapterService eventAdapterService,
int statementId) |
Constructor and Description |
---|
ExprTableExprEvaluatorAccess(ExprNode exprNode,
String tableName,
String subpropName,
int streamNum,
Class returnType,
AggregationAccessorSlotPair accessAccessorSlotPair,
EventType eventTypeColl) |
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) |
Modifier and Type | Method and Description |
---|---|
EventType |
VariableMetaData.getEventType()
Returns the event type if the variable hold event(s).
|
EventType |
OnSetVariableViewFactory.getEventType() |
EventType |
OnSetVariableView.getEventType() |
EventType |
CreateVariableView.getEventType() |
static EventType |
CreateVariableView.getEventType(int statementId,
EventAdapterService eventAdapterService,
VariableMetaData variableMetaData) |
Modifier and Type | Method and Description |
---|---|
Pair<Boolean,Object> |
VariableStateHandler.getHasState(String variableName,
int variableNumber,
int agentInstanceId,
Class type,
EventType eventType,
StatementExtensionSvcContext statementExtContext,
boolean isConstant)
Returns the current variable state plus Boolean.TRUE if there is a current state since the variable
may have the value of null; returns Boolean.FALSE and null if there is no current state
|
Constructor and Description |
---|
VariableMetaData(String variableName,
String contextPartitionName,
int variableNumber,
Class type,
EventType eventType,
boolean constant,
VariableStateFactory variableStateFactory) |
Modifier and Type | Method and Description |
---|---|
static EventType |
OutputConditionExpressionFactory.getBuiltInEventType(EventAdapterService eventAdapterService)
Build the event type for built-in properties.
|
EventType |
OutputConditionExpressionFactory.getBuiltinPropertiesEventType() |
EventType |
OutputProcessViewBase.getEventType() |
EventType |
FilterExprView.getEventType() |
Modifier and Type | Method and Description |
---|---|
static OutputProcessViewFactory |
OutputProcessViewFactoryFactory.make(StatementSpecCompiled statementSpec,
InternalEventRouter internalEventRouter,
StatementContext statementContext,
EventType resultEventType,
OutputProcessViewCallback optionalOutputProcessViewCallback,
TableService tableService,
ResultSetProcessorType resultSetProcessorType,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
StatementVariableRef statementVariableRef) |
Constructor and Description |
---|
OutputProcessViewConditionFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
Integer afterConditionNumberOfEvents,
EventType resultEventType,
OutputConditionFactory outputConditionFactory,
int streamCount,
OutputProcessViewConditionFactory.ConditionType conditionType,
OutputLimitLimitType outputLimitLimitType,
boolean terminable,
boolean hasAfter,
boolean isUnaggregatedUngrouped,
SelectClauseStreamSelectorEnum selectClauseStreamSelectorEnum,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory) |
OutputProcessViewDirectDistinctOrAfterFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
Integer afterConditionNumberOfEvents,
EventType resultEventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
VirtualDWViewImpl.getEventType() |
EventType |
VirtualDWViewFactoryImpl.getEventType() |
EventType[] |
VirtualDataWindowLookupContextSPI.getOuterTypePerStream() |
Modifier and Type | Method and Description |
---|---|
void |
VirtualDWViewFactoryImpl.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
SubordTableLookupStrategy |
VirtualDWViewImpl.getSubordinateLookupStrategy(String accessedByStatementName,
int accessedByStatementId,
Annotation[] accessedByStmtAnnotations,
EventType[] outerStreamTypes,
List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
boolean nwOnTrigger,
EventTable eventTable,
SubordPropPlan joinDesc,
boolean forceTableScan) |
SubordTableLookupStrategy |
VirtualDWView.getSubordinateLookupStrategy(String accessedByStatementName,
int accessedByStatementId,
Annotation[] accessedByStmtAnnotations,
EventType[] outerStreamTypes,
List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
boolean nwOnTrigger,
EventTable eventTable,
SubordPropPlan joinDesc,
boolean forceTableScan) |
Constructor and Description |
---|
VirtualDataWindowLookupContextSPI(String statementName,
int statementId,
Annotation[] statementAnnotations,
boolean fireAndForget,
String namedWindowName,
List<VirtualDataWindowLookupFieldDesc> hashFields,
List<VirtualDataWindowLookupFieldDesc> btreeFields,
SubordPropPlan joinDesc,
boolean forceTableScan,
EventType[] outerTypePerStream,
String accessedByStatementName,
int accessedByStatementSequenceNum) |
VirtualDWViewImpl(VirtualDataWindow dataExternal,
EventType eventType,
String namedWindowName) |
Modifier and Type | Interface and Description |
---|---|
interface |
EventTypeSPI
Service provider interface for internal use for event types.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseConfigurableEventType
EventType than can be supplied with a preconfigured list of properties getters (aka.
|
class |
BaseNestableEventType
Implementation of the
EventType interface for handling name value pairs. |
class |
WrapperEventType
An event type that adds zero or more fields to an existing event type.
|
Modifier and Type | Field and Description |
---|---|
protected EventType[] |
BaseNestableEventType.optionalSuperTypes |
protected EventType |
WrapperEventType.underlyingEventType
The underlying wrapped event type.
|
Modifier and Type | Field and Description |
---|---|
protected Set<EventType> |
BaseNestableEventType.optionalDeepSupertypes |
Modifier and Type | Method and Description |
---|---|
EventType |
EventAdapterServiceImpl.addAvroType(String eventTypeName,
ConfigurationEventTypeAvro avro,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean isNamedWindow,
boolean isInsertInto) |
EventType |
EventAdapterService.addAvroType(String eventTypeName,
ConfigurationEventTypeAvro avro,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean isNamedWindow,
boolean isInsertInto) |
EventType |
EventAdapterServiceImpl.addAvroType(String eventTypeName,
Map<String,Object> types,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean isNamedWindow,
boolean isInsertInto,
Annotation[] annotations,
ConfigurationEventTypeAvro config,
String statementName,
String engineURI) |
EventType |
EventAdapterService.addAvroType(String eventTypeName,
Map<String,Object> types,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean isNamedWindow,
boolean isInsertInto,
Annotation[] annotations,
ConfigurationEventTypeAvro config,
String statementName,
String engineURI) |
EventType |
EventAdapterServiceImpl.addBeanType(String eventTypeName,
Class clazz,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured) |
EventType |
EventAdapterService.addBeanType(String eventTypeName,
Class clazz,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured)
Add an event type with the given name and Java class.
|
EventType |
EventAdapterServiceImpl.addBeanType(String eventTypeName,
String fullyQualClassName,
boolean considerAutoName,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured)
Add an event type for the given Java class name.
|
EventType |
EventAdapterService.addBeanType(String eventTypeName,
String fullyQualClassName,
boolean considerAutoName,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured)
Add an event type with the given name and Java fully-qualified class name.
|
EventType |
EventAdapterServiceImpl.addBeanTypeByName(String eventTypeName,
Class clazz,
boolean isNamedWindow) |
EventType |
EventAdapterService.addBeanTypeByName(String eventTypeName,
Class clazz,
boolean isNamedWindow) |
EventType |
EventAdapterServiceImpl.addNestableMapType(String eventTypeName,
Map<String,Object> propertyTypes,
ConfigurationEventTypeMap optionalConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto) |
EventType |
EventAdapterService.addNestableMapType(String eventTypeName,
Map<String,Object> propertyTypes,
ConfigurationEventTypeMap optionalConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto)
Add an event type with the given name and a given set of properties,
wherein properties may itself be Maps, nested and strongly-typed.
|
EventType |
EventAdapterServiceImpl.addNestableObjectArrayType(String eventTypeName,
Map<String,Object> propertyTypes,
ConfigurationEventTypeObjectArray optionalConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto,
boolean table,
String tableName) |
EventType |
EventAdapterService.addNestableObjectArrayType(String eventTypeName,
Map<String,Object> propertyTypes,
ConfigurationEventTypeObjectArray typeConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto,
boolean table,
String tableName) |
EventType |
EventAdapterServiceImpl.addPlugInEventType(String eventTypeName,
URI[] resolutionURIs,
Serializable initializer) |
EventType |
EventAdapterService.addPlugInEventType(String name,
URI[] resolutionURIs,
Serializable initializer)
Adds a plug-in event type.
|
EventType |
EventAdapterServiceAnonymousTypeCache.addReturnExistingAnonymousType(EventType requiredType) |
EventType |
EventAdapterServiceImpl.addWrapperType(String eventTypeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes,
boolean isNamedWindow,
boolean isInsertInto) |
EventType |
EventAdapterService.addWrapperType(String eventTypeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes,
boolean isNamedWindow,
boolean isInsertInto)
Add an event type with the given name and the given underlying event type,
as well as the additional given properties.
|
EventType |
EventAdapterServiceImpl.addXMLDOMType(String eventTypeName,
ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM,
SchemaModel optionalSchemaModel,
boolean isPreconfiguredStatic)
Add a configured XML DOM event type.
|
EventType |
EventAdapterService.addXMLDOMType(String eventTypeName,
ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM,
SchemaModel optionalSchemaModel,
boolean isPreconfiguredStatic)
Adds an XML DOM event type.
|
EventType |
EventAdapterServiceImpl.createAnonymousAvroType(String typeName,
Map<String,Object> properties,
Annotation[] annotations,
String statementName,
String engineURI) |
EventType |
EventAdapterService.createAnonymousAvroType(String typeName,
Map<String,Object> properties,
Annotation[] annotations,
String statementName,
String engineURI) |
EventType |
EventAdapterServiceImpl.createAnonymousBeanType(String eventTypeName,
Class clazz) |
EventType |
EventAdapterService.createAnonymousBeanType(String schemaName,
Class clazz) |
EventType |
EventAdapterServiceImpl.createAnonymousMapType(String typeName,
Map<String,Object> propertyTypes,
boolean isTransient) |
EventType |
EventAdapterService.createAnonymousMapType(String typeName,
Map<String,Object> propertyTypes,
boolean isTransient)
Creates a new anonymous EventType instance for an event type that contains a map of name value pairs.
|
EventType |
EventAdapterServiceImpl.createAnonymousObjectArrayType(String typeName,
Map<String,Object> propertyTypes) |
EventType |
EventAdapterService.createAnonymousObjectArrayType(String typeName,
Map<String,Object> propertyTypes) |
EventType |
EventAdapterServiceImpl.createAnonymousWrapperType(String typeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes) |
EventType |
EventAdapterService.createAnonymousWrapperType(String typeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes)
Create a new anonymous event type with the given underlying event type,
as well as the additional given properties.
|
static EventType |
EventTypeUtility.createNonVariantType(boolean isAnonymous,
CreateSchemaDesc spec,
Annotation[] annotations,
ConfigurationInformation configSnapshot,
EventAdapterService eventAdapterService,
EngineImportService engineImportService) |
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews) |
EventType |
EventAdapterService.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews)
Creates an anonymous map that has no name, however in a fail-over scenario
events of this type may be recoverable and therefore the type is only semi-anonymous,
identified by the tags and event type names used.
|
EventType[] |
EventAdapterServiceImpl.getAllTypes() |
EventType[] |
EventAdapterService.getAllTypes()
Return all known event types.
|
EventType |
WrapperEventBean.getEventType() |
EventType |
NaturalEventBean.getEventType() |
EventType |
EventAdapterServiceImpl.getExistsTypeByName(String eventTypeName) |
EventType |
EventAdapterService.getExistsTypeByName(String eventTypeName)
Return the event type for a given event name, or null if none is registered for that name.
|
EventType[] |
WrapperEventType.getSuperTypes() |
EventType[] |
BaseNestableEventType.getSuperTypes() |
EventType |
WrapperEventType.getUnderlyingEventType()
Returns the wrapped event type.
|
EventType |
EventAdapterServiceImpl.replaceXMLEventType(String xmlEventTypeName,
ConfigurationEventTypeXMLDOM config,
SchemaModel schemaModel) |
EventType |
EventAdapterService.replaceXMLEventType(String xmlEventTypeName,
ConfigurationEventTypeXMLDOM config,
SchemaModel schemaModel) |
static EventType |
EventTypeUtility.requireEventType(String aspectCamel,
String aspectName,
EventAdapterService eventAdapterService,
String optionalEventTypeName) |
Modifier and Type | Method and Description |
---|---|
Map<String,EventType> |
EventAdapterServiceImpl.getDeclaredEventTypes() |
Map<String,EventType> |
EventAdapterService.getDeclaredEventTypes() |
Iterator<EventType> |
WrapperEventType.getDeepSuperTypes() |
Iterator<EventType> |
BaseNestableEventType.getDeepSuperTypes() |
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(ConfigurationEventTypeWithSupertype optionalConfig,
EventUnderlyingType representation,
Map<String,? extends EventType> nameToTypeMap) |
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(Set<String> superTypesSet,
EventUnderlyingType representation,
Map<String,? extends EventType> nameToTypeMap) |
Map<String,Pair<EventType,String>> |
TaggedCompositeEventType.getTaggedEventTypes()
Returns the event types for each composing event.
|
Modifier and Type | Method and Description |
---|---|
EventBean |
EventAdapterServiceImpl.adapterForType(Object theEvent,
EventType eventType) |
EventBean |
EventAdapterService.adapterForType(Object theEvent,
EventType eventType)
Returns an adapter for an event underlying object when the event type is known.
|
static EventBean |
EventAdapterServiceHelper.adapterForType(Object theEvent,
EventType eventType,
EventAdapterService eventAdapterService)
Return an adapter for the given type of event using the pre-validated object.
|
EventBean |
EventAdapterServiceImpl.adapterForTypedAvro(Object avroGenericDataDotRecord,
EventType eventType) |
EventBean |
EventAdapterService.adapterForTypedAvro(Object avroGenericDataDotRecord,
EventType eventType) |
EventBean |
EventAdapterServiceImpl.adapterForTypedBean(Object bean,
EventType eventType) |
EventBean |
EventAdapterService.adapterForTypedBean(Object bean,
EventType eventType)
Creates a thin adaper for an event object given an event type.
|
EventBean |
EventAdapterServiceImpl.adapterForTypedDOM(Node node,
EventType eventType) |
EventBean |
EventAdapterService.adapterForTypedDOM(Node node,
EventType eventType)
Returns an adapter for the XML DOM document that exposes it's data as event properties for use in statements.
|
EventBean |
EventAdapterServiceImpl.adapterForTypedMap(Map<String,Object> properties,
EventType eventType) |
EventBean |
EventAdapterService.adapterForTypedMap(Map<String,Object> properties,
EventType eventType)
Create an event map bean from a set of event properties (name and value objectes) stored in a Map.
|
EventBean |
EventAdapterServiceImpl.adapterForTypedObjectArray(Object[] properties,
EventType eventType) |
EventBean |
EventAdapterService.adapterForTypedObjectArray(Object[] props,
EventType resultEventType) |
EventBean |
EventAdapterServiceImpl.adapterForTypedWrapper(EventBean theEvent,
Map<String,Object> properties,
EventType eventType) |
EventBean |
EventAdapterService.adapterForTypedWrapper(EventBean theEvent,
Map<String,Object> properties,
EventType eventType)
Creata a wrapper around an event and some additional properties
|
EventType |
EventAdapterServiceAnonymousTypeCache.addReturnExistingAnonymousType(EventType requiredType) |
void |
EventAdapterServiceImpl.addTypeByName(String name,
EventType eventType) |
void |
EventAdapterService.addTypeByName(String name,
EventType eventType)
Adds an event type to the registery available for use, and originating outside as a non-adapter.
|
EventType |
EventAdapterServiceImpl.addWrapperType(String eventTypeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes,
boolean isNamedWindow,
boolean isInsertInto) |
EventType |
EventAdapterService.addWrapperType(String eventTypeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes,
boolean isNamedWindow,
boolean isInsertInto)
Add an event type with the given name and the given underlying event type,
as well as the additional given properties.
|
EventType |
EventAdapterServiceImpl.createAnonymousWrapperType(String typeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes) |
EventType |
EventAdapterService.createAnonymousWrapperType(String typeName,
EventType underlyingEventType,
Map<String,Object> propertyTypes)
Create a new anonymous event type with the given underlying event type,
as well as the additional given properties.
|
boolean |
WrapperEventType.equalsCompareType(EventType otherEventType) |
boolean |
EventTypeSPI.equalsCompareType(EventType eventType) |
boolean |
BaseNestableEventType.equalsCompareType(EventType otherEventType) |
EventBeanAdapterFactory |
EventAdapterServiceImpl.getAdapterFactoryForType(EventType eventType) |
static EventBeanAdapterFactory |
EventAdapterServiceHelper.getAdapterFactoryForType(EventType eventType) |
EventBeanAdapterFactory |
EventAdapterService.getAdapterFactoryForType(EventType eventType) |
static EventPropertyGetter |
EventBeanUtility.getAssertPropertyGetter(EventType[] eventTypes,
int keyStreamNum,
String property) |
static EventPropertyGetter |
EventBeanUtility.getAssertPropertyGetter(EventType type,
String propertyName) |
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
|
String |
BaseNestableEventType.getEqualsMessage(EventType otherType)
Returns a message if the type, compared to this type, is not compatible in regards to the property numbers
and types.
|
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.getGetterEventBeanArray(String name,
EventType eventType) |
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) |
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.
|
EventBeanManufacturer |
EventAdapterServiceImpl.getManufacturer(EventType eventType,
WriteablePropertyDescriptor[] properties,
EngineImportService engineImportService,
boolean allowAnyType) |
EventBeanManufacturer |
EventAdapterService.getManufacturer(EventType eventType,
WriteablePropertyDescriptor[] properties,
EngineImportService engineImportService,
boolean allowAnyType)
Returns a factory for creating and populating event object instances for the given type.
|
static String |
EventAdapterServiceHelper.getMessageExpecting(String eventTypeName,
EventType existingType,
String typeOfEventType) |
static PropertySetDescriptor |
EventTypeUtility.getNestableProperties(Map<String,Object> propertiesToAdd,
EventAdapterService eventAdapterService,
EventTypeNestableGetterFactory factory,
EventType[] optionalSuperTypes) |
static EventPropertyDescriptor |
EventTypeUtility.getNestablePropertyDescriptor(EventType target,
Deque<Property> stack) |
static EventPropertyDescriptor |
EventTypeUtility.getNestablePropertyDescriptor(EventType target,
String propertyName) |
EventBeanSPI |
EventAdapterServiceImpl.getShellForType(EventType eventType) |
static EventBeanSPI |
EventAdapterServiceHelper.getShellForType(EventType eventType) |
EventBeanSPI |
EventAdapterService.getShellForType(EventType eventType) |
TypeWidenerCustomizer |
EventAdapterServiceImpl.getTypeWidenerCustomizer(EventType resultEventType) |
TypeWidenerCustomizer |
EventAdapterService.getTypeWidenerCustomizer(EventType resultEventType) |
Set<WriteablePropertyDescriptor> |
EventAdapterServiceImpl.getWriteableProperties(EventType eventType,
boolean allowAnyType) |
static Set<WriteablePropertyDescriptor> |
EventAdapterServiceHelper.getWriteableProperties(EventType eventType,
boolean allowAnyType)
Returns descriptors for all writable properties.
|
Set<WriteablePropertyDescriptor> |
EventAdapterService.getWriteableProperties(EventType eventType,
boolean allowAnyType)
Returns descriptors for all writable properties.
|
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 String |
EventAdapterServiceImpl.isCompatibleWrapper(EventType existingType,
EventType underlyingType,
Map<String,Object> propertyTypes)
Returns true if the wrapper type is compatible with an existing wrapper type, for the reason that
the underlying event is a subtype of the existing underlying wrapper's type.
|
static boolean |
EventTypeUtility.isTypeOrSubTypeOf(EventType candidate,
EventType superType) |
static boolean |
EventTypeUtility.isTypeOrSubTypeOf(String typeName,
EventType sameTypeOrSubtype) |
EventBean[] |
EventAdapterServiceImpl.typeCast(List<EventBean> events,
EventType targetType) |
EventBean[] |
EventAdapterService.typeCast(List<EventBean> events,
EventType targetType)
Casts event type of a list of events to either Wrapper or Map type.
|
static EventBean[] |
EventAdapterServiceHelper.typeCast(List<EventBean> events,
EventType targetType,
EventAdapterService eventAdapterService) |
static EventTypeUtility.TimestampPropertyDesc |
EventTypeUtility.validatedDetermineTimestampProps(EventType type,
String startProposed,
String endProposed,
EventType[] superTypes) |
static EventTypeUtility.TimestampPropertyDesc |
EventTypeUtility.validatedDetermineTimestampProps(EventType type,
String startProposed,
String endProposed,
EventType[] superTypes) |
static void |
EventTypeUtility.validateTimestampProperties(EventType eventType,
String startTimestampProperty,
String endTimestampProperty) |
Modifier and Type | Method and Description |
---|---|
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews) |
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews) |
EventType |
EventAdapterService.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews)
Creates an anonymous map that has no name, however in a fail-over scenario
events of this type may be recoverable and therefore the type is only semi-anonymous,
identified by the tags and event type names used.
|
EventType |
EventAdapterService.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews)
Creates an anonymous map that has no name, however in a fail-over scenario
events of this type may be recoverable and therefore the type is only semi-anonymous,
identified by the tags and event type names used.
|
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(ConfigurationEventTypeWithSupertype optionalConfig,
EventUnderlyingType representation,
Map<String,? extends EventType> nameToTypeMap) |
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(Set<String> superTypesSet,
EventUnderlyingType representation,
Map<String,? extends EventType> nameToTypeMap) |
Constructor and Description |
---|
BaseNestableEventType(EventTypeMetadata metadata,
String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
Map<String,Object> propertyTypes,
EventType[] optionalSuperTypes,
Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeWithSupertype typeConfig,
EventTypeNestableGetterFactory getterFactory)
Constructor takes a type name, map of property names and types, for
use with nestable Map events.
|
Modifier and Type | Class and Description |
---|---|
class |
ObjectArrayEventType |
Modifier and Type | Field and Description |
---|---|
protected EventType |
ObjectArrayPropertyGetterDefaultBase.fragmentEventType |
protected EventType |
ObjectArrayNestedEntryPropertyGetterBase.fragmentType |
Modifier and Type | Method and Description |
---|---|
EventType |
ObjectArrayEventBean.getEventType() |
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.getGetterEventBeanArray(String name,
EventType eventType) |
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) |
void |
ObjectArrayEventBean.setEventType(EventType eventType) |
Constructor and Description |
---|
ObjectArrayEventType(EventTypeMetadata metadata,
String eventTypeName,
int eventTypeId,
EventAdapterService eventAdapterService,
Map<String,Object> properyTypes,
ConfigurationEventTypeObjectArray typeDef,
EventType[] optionalSuperTypes,
Set<EventType> optionalDeepSupertypes) |
Modifier and Type | Interface and Description |
---|---|
interface |
AvroSchemaEventType |
Modifier and Type | Method and Description |
---|---|
EventBean |
EventAdapterAvroHandlerUnsupported.adapterForTypeAvro(Object avroGenericDataDotRecord,
EventType existingType) |
EventBean |
EventAdapterAvroHandler.adapterForTypeAvro(Object avroGenericDataDotRecord,
EventType existingType) |
void |
EventAdapterAvroHandlerUnsupported.avroCompat(EventType existingType,
Map<String,Object> selPropertyTypes) |
void |
EventAdapterAvroHandler.avroCompat(EventType existingType,
Map<String,Object> selPropertyTypes) |
EventBeanFactory |
EventAdapterAvroHandlerUnsupported.getEventBeanFactory(EventType type,
EventAdapterService eventAdapterService) |
EventBeanFactory |
EventAdapterAvroHandler.getEventBeanFactory(EventType type,
EventAdapterService eventAdapterService) |
TypeWidenerCustomizer |
EventAdapterAvroHandlerUnsupported.getTypeWidenerCustomizer(EventType eventType) |
TypeWidenerCustomizer |
EventAdapterAvroHandler.getTypeWidenerCustomizer(EventType eventType) |
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) |
void |
EventAdapterAvroHandlerUnsupported.validateExistingType(EventType existingType,
AvroSchemaEventType proposedType) |
void |
EventAdapterAvroHandler.validateExistingType(EventType existingType,
AvroSchemaEventType proposedType) |
Modifier and Type | Method and Description |
---|---|
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 | Class and Description |
---|---|
class |
BeanEventType
Implementation of the EventType interface for handling JavaBean-type classes.
|
Modifier and Type | Method and Description |
---|---|
EventType |
BeanEventBean.getEventType() |
EventType[] |
BeanEventType.getSuperTypes() |
Modifier and Type | Method and Description |
---|---|
Iterator<EventType> |
BeanEventType.getDeepSuperTypes() |
Modifier and Type | Method and Description |
---|---|
boolean |
BeanEventType.equalsCompareType(EventType eventType) |
Constructor and Description |
---|
BeanEventBean(Object theEvent,
EventType eventType)
Constructor.
|
Modifier and Type | Class and Description |
---|---|
class |
MapEventType
Implementation of the
EventType interface for handling plain Maps containing name value pairs. |
Modifier and Type | Field and Description |
---|---|
protected EventType |
MapPropertyGetterDefaultBase.fragmentEventType |
protected EventType |
MapNestedEntryPropertyGetterBase.fragmentType |
Modifier and Type | Method and Description |
---|---|
EventType |
MapEventBean.getEventType() |
Modifier and Type | Method and Description |
---|---|
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterBeanNested(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterBeanNestedArray(String name,
EventType eventType,
EventAdapterService eventAdapterService) |
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterEventBeanArray(String name,
EventType eventType) |
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) |
Constructor and Description |
---|
MapArrayPropertyGetter(String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType fragmentType)
Ctor.
|
MapEventBean(EventType eventType)
Constructor for the mutable functions, e.g.
|
MapEventBean(Map<String,Object> properties,
EventType eventType)
Constructor for initialization with existing values.
|
MapEventType(EventTypeMetadata metadata,
String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
Map<String,Object> propertyTypes,
EventType[] optionalSuperTypes,
Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeMap configMapType) |
MapFragmentArrayPropertyGetter(String propertyNameAtomic,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
Ctor.
|
MapNestedEntryPropertyGetterArrayMap(String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
int index,
MapEventPropertyGetter getter) |
MapNestedEntryPropertyGetterArrayObjectArray(String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
int index,
ObjectArrayEventPropertyGetter getter) |
MapNestedEntryPropertyGetterBase(String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService)
Ctor.
|
MapNestedEntryPropertyGetterMap(String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
MapEventPropertyGetter mapGetter) |
MapNestedEntryPropertyGetterObjectArray(String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
ObjectArrayEventPropertyGetter arrayGetter) |
MapNestedEntryPropertyGetterPropertyProvidedDynamic(String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
EventPropertyGetter nestedGetter) |
MapPropertyGetterDefaultBase(String propertyNameAtomic,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
Ctor.
|
MapPropertyGetterDefaultMap(String propertyName,
EventType fragmentEventType,
EventAdapterService eventAdapterService) |
MapPropertyGetterDefaultObjectArray(String propertyName,
EventType fragmentEventType,
EventAdapterService eventAdapterService) |
Constructor and Description |
---|
MapEventType(EventTypeMetadata metadata,
String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
Map<String,Object> propertyTypes,
EventType[] optionalSuperTypes,
Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeMap configMapType) |
Modifier and Type | Method and Description |
---|---|
JSONEventRenderer |
EventRendererImpl.getJSONRenderer(EventType eventType)
Returns a render for the JSON format, valid only for the given event type and its subtypes.
|
JSONEventRenderer |
EventRendererImpl.getJSONRenderer(EventType eventType,
JSONRenderingOptions options)
Returns a render for the JSON format, valid only for the given event type and its subtypes.
|
XMLEventRenderer |
EventRendererImpl.getXMLRenderer(EventType eventType)
Returns a render for the XML format, valid only for the given event type and its subtypes.
|
XMLEventRenderer |
EventRendererImpl.getXMLRenderer(EventType eventType,
XMLRenderingOptions options)
Returns a render for the XML format, valid only for the given event type and its subtypes.
|
Constructor and Description |
---|
EventTypePropertyPair(EventType eventType,
String propertyName)
Ctor.
|
JSONRendererImpl(EventType eventType,
JSONRenderingOptions options)
Ctor.
|
RendererMeta(EventType eventType,
Stack<EventTypePropertyPair> stack,
RendererMetaOptions options)
Ctor.
|
XMLRendererImpl(EventType eventType,
XMLRenderingOptions options)
Ctor.
|
Modifier and Type | Class and Description |
---|---|
class |
RevisionEventType
Event type of revision events.
|
class |
VariantEventType
Event type for variant event streams.
|
Modifier and Type | Field and Description |
---|---|
protected Map<EventType,RevisionTypeDesc> |
VAERevisionProcessorBase.typeDescriptors
Map of participating type to descriptor.
|
Modifier and Type | Method and Description |
---|---|
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.
|
EventType |
RevisionSpec.getBaseEventType()
Returns the base event type.
|
EventType[] |
RevisionSpec.getDeltaTypes()
Returns the delta event types.
|
EventType |
VariantEventBean.getEventType() |
EventType |
RevisionEventBeanMerge.getEventType() |
EventType |
RevisionEventBeanDeclared.getEventType() |
EventType[] |
VariantSpec.getEventTypes()
Returns types allowed for variant streams.
|
EventType[] |
VariantEventType.getSuperTypes() |
EventType[] |
RevisionEventType.getSuperTypes() |
EventType[] |
ValueAddEventServiceImpl.getValueAddedTypes() |
EventType[] |
ValueAddEventService.getValueAddedTypes()
Returns all event types representing value-add event types.
|
EventType |
ValueAddEventProcessor.getValueAddEventType()
Returns the event type that this revision processor generates.
|
EventType |
VAEVariantProcessor.getValueAddEventType() |
EventType |
ValueAddEventServiceImpl.getValueAddUnderlyingType(String name) |
EventType |
ValueAddEventService.getValueAddUnderlyingType(String name)
Upon named window creation, and during resolution of type specified as part of a named window create statement,
returns looks up the revision event type name provided and return the revision event type if found, or null if not found.
|
Modifier and Type | Method and Description |
---|---|
Iterator<EventType> |
VariantEventType.getDeepSuperTypes() |
Iterator<EventType> |
RevisionEventType.getDeepSuperTypes() |
static Map<EventType,RevisionTypeDesc> |
PropertyUtility.getPerType(PropertyGroupDesc[] groups,
String[] changesetProperties,
String[] keyProperties)
From a list of property groups that include contributing event types, build a map
of contributing event types and their type descriptor.
|
Map<EventType,String> |
PropertyGroupDesc.getTypes()
Returns the types.
|
Modifier and Type | Method and Description |
---|---|
static PropertyGroupDesc[] |
PropertyUtility.analyzeGroups(String[] allProperties,
EventType[] deltaEventTypes,
String[] names)
Analyze multiple event types and determine common property sets that form property groups.
|
boolean |
VariantEventType.equalsCompareType(EventType eventType) |
boolean |
RevisionEventType.equalsCompareType(EventType eventType) |
EventPropertyGetter |
VariantPropertyGetterCache.getGetter(int assignedPropertyNumber,
EventType eventType)
Fast lookup of a getter for a property and type.
|
static EventPropertyGetter[] |
PropertyUtility.getGetters(EventType eventType,
String[] propertyNames)
Return getters for property names.
|
VariantPropertyDesc |
VariantPropResolutionStrategyDefault.resolveProperty(String propertyName,
EventType[] variants) |
VariantPropertyDesc |
VariantPropResolutionStrategyAny.resolveProperty(String propertyName,
EventType[] variants) |
VariantPropertyDesc |
VariantPropResolutionStrategy.resolveProperty(String propertyName,
EventType[] variants)
Resolve the property for each of the types.
|
void |
ValueAddEventProcessor.validateEventType(EventType eventType)
For use in checking insert-into statements, validates that the given type is eligible for revision event.
|
void |
VAEVariantProcessor.validateEventType(EventType eventType) |
void |
VAERevisionProcessorBase.validateEventType(EventType eventType) |
Constructor and Description |
---|
RevisionSpec(ConfigurationRevisionEventType.PropertyRevision propertyRevision,
EventType baseEventType,
EventType[] deltaTypes,
String[] deltaNames,
String[] keyPropertyNames,
String[] changesetPropertyNames,
String[] baseEventOnlyPropertyNames,
boolean deltaTypesAddProperties,
boolean[] changesetPropertyDeltaContributed)
Ctor.
|
RevisionSpec(ConfigurationRevisionEventType.PropertyRevision propertyRevision,
EventType baseEventType,
EventType[] deltaTypes,
String[] deltaNames,
String[] keyPropertyNames,
String[] changesetPropertyNames,
String[] baseEventOnlyPropertyNames,
boolean deltaTypesAddProperties,
boolean[] changesetPropertyDeltaContributed)
Ctor.
|
VariantPropertyGetterCache(EventType[] knownTypes)
Ctor.
|
VariantSpec(String variantStreamName,
EventType[] eventTypes,
ConfigurationVariantStream.TypeVariance typeVariance)
Ctor.
|
Constructor and Description |
---|
PropertyGroupDesc(int groupNum,
Map<EventType,String> nameTypeSet,
String[] properties)
Ctor.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseXMLEventType
Base class for XML event types.
|
class |
SchemaXMLEventType
EventType for xml events that have a Schema.
|
class |
SimpleXMLEventType
Optimistic try to resolve the property string into an appropiate xPath,
and use it as getter.
|
Modifier and Type | Method and Description |
---|---|
EventType |
XMLEventBean.getEventType() |
EventType[] |
BaseXMLEventType.getSuperTypes() |
Modifier and Type | Method and Description |
---|---|
Iterator<EventType> |
BaseXMLEventType.getDeepSuperTypes() |
Modifier and Type | Method and Description |
---|---|
boolean |
BaseXMLEventType.equalsCompareType(EventType eventType) |
Constructor and Description |
---|
XMLEventBean(Node theEvent,
EventType type)
Ctor.
|
Modifier and Type | Field and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecCompilerArgs.arrayEventTypes |
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecCompilerArgs.taggedEventTypes |
Modifier and Type | Method and Description |
---|---|
EventType |
FilterValueSetImpl.getEventType()
Returns event type to filter for.
|
EventType |
FilterValueSet.getEventType()
Returns type of event to filter for.
|
EventType |
FilterSpecCompiled.getFilterForEventType()
Returns type of event to filter for.
|
EventType |
FilterSpecCompiled.getResultEventType()
Returns the result event type of the filter specification.
|
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecParamExprNode.getArrayEventTypes() |
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecParamExprNode.getTaggedEventTypes()
Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)
|
Modifier and Type | Method and Description |
---|---|
void |
EventTypeIndex.add(EventType eventType,
FilterHandleSetNode rootNode)
Add a new event type to the index and use the specified node for the root node of its subtree.
|
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext stmtContext,
Collection<Integer> assignedTypeNumberStack) |
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) |
FilterHandleSetNode |
EventTypeIndex.get(EventType eventType)
Returns the root node for the given event type, or null if this event type has not been seen before.
|
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext statementContext,
Collection<Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
void |
FilterNonPropertyRegisteryServiceImpl.registerNonPropertyExpression(String statementName,
EventType eventType,
FilterSpecLookupable lookupable) |
void |
FilterNonPropertyRegisteryService.registerNonPropertyExpression(String statementName,
EventType eventType,
FilterSpecLookupable lookupable)
Register expression.
|
static void |
IndexTreeBuilder.remove(EventType eventType,
FilterHandle filterCallback,
EventTypeIndexBuilderIndexLookupablePair[] treePathInfo,
FilterHandleSetNode topNode)
Remove an filterCallback from the given top node.
|
void |
FilterServiceLockFine.removeType(EventType type) |
void |
FilterServiceLockCoarse.removeType(EventType type) |
void |
FilterService.removeType(EventType type) |
void |
EventTypeIndex.removeType(EventType type) |
protected void |
FilterServiceBase.removeTypeInternal(EventType type) |
Modifier and Type | Method and Description |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext stmtContext,
Collection<Integer> assignedTypeNumberStack) |
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext stmtContext,
Collection<Integer> assignedTypeNumberStack) |
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) |
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) |
protected static FilterSpecParam |
FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
String statementName)
For a given expression determine if this is optimizable and create the filter parameter
representing the expression, or null if not optimizable.
|
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext statementContext,
Collection<Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext statementContext,
Collection<Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
Constructor and Description |
---|
FilterSpecCompiled(EventType eventType,
String eventTypeName,
List<FilterSpecParam>[] filterParameters,
PropertyEvaluator optionalPropertyEvaluator)
Constructor - validates parameter list against event type, throws exception if invalid
property names or mismatcing filter operators are found.
|
FilterValueSetImpl(EventType eventType,
FilterValueSetParam[][] parameters)
Ctor.
|
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) |
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) |
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) |
Constructor and Description |
---|
MatchedEventConvertorImpl(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
EventAdapterService eventAdapterService) |
MatchedEventConvertorImpl(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
EventAdapterService eventAdapterService) |
Modifier and Type | Method and Description |
---|---|
EventType[] |
PlugInAggregationMultiFunctionValidationContext.getEventTypes()
Returns the event types of all events in the select clause
|
EventType |
PlugInEventTypeHandler.getType()
Returns the event type.
|
Constructor and Description |
---|
PlugInAggregationMultiFunctionValidationContext(String functionName,
EventType[] eventTypes,
ExprNode[] parameterExpressions,
String engineURI,
String statementName,
ExprValidationContext validationContext,
ConfigurationPlugInAggregationMultiFunction config,
TableMetadataColumnAggregation optionalTableColumnAccessed,
ExprNode[] allParameterExpressions) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
EventRowRegexNFAViewFactory.rowEventType |
Modifier and Type | Method and Description |
---|---|
EventType |
EventRowRegexNFAViewFactory.getEventType() |
EventType |
EventRowRegexNFAView.getEventType() |
Modifier and Type | Method and Description |
---|---|
void |
EventRowRegexNFAViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
Map<String,Set<String>> visibilityByIdentifier,
EventType parentViewType) |
static ObjectArrayBackedEventBean |
EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
EventType parentViewType) |
Constructor and Description |
---|
EventRowRegexNFAView(EventRowRegexNFAViewFactory factory,
ObjectArrayEventType compositeEventType,
EventType rowEventType,
MatchRecognizeSpec matchRecognizeSpec,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
Map<Integer,String> streamsVariables,
Set<String> variablesSingle,
AgentInstanceContext agentInstanceContext,
TreeMap<Integer,List<ExprPreviousMatchRecognizeNode>> callbacksPerIndex,
AggregationServiceMatchRecognize aggregationService,
boolean isDefineAsksMultimatches,
ObjectArrayBackedEventBean defineMultimatchEventBean,
boolean[] isExprRequiresMultimatchState,
boolean isUnbound,
boolean isIterateOnly,
boolean isCollectMultimatches,
RowRegexExprNode expandedPatternNode,
ConfigurationEngineDefaults.MatchRecognize matchRecognizeConfig,
EventRowRegexNFAViewScheduler scheduler) |
Modifier and Type | Method and Description |
---|---|
static void |
SupportEventTypeAssertionUtil.assertConsistency(EventType eventType) |
static void |
SupportEventTypeAssertionUtil.assertEventTypeProperties(Object[][] expectedArr,
EventType eventType,
SupportEventTypeAssertionEnum... assertions) |
Object |
SupportEventTypeAssertionEnum.Extractor.extract(EventPropertyDescriptor desc,
EventType eventType) |
Modifier and Type | Method and Description |
---|---|
EventType |
ZeroDepthStreamNoIterate.getEventType() |
EventType |
ZeroDepthStreamIterable.getEventType() |
EventType |
ViewFactoryChain.getEventType()
Returns the final event type which is the event type of the last view factory in the chain,
or if the chain is empty then the stream's event type.
|
EventType |
ViewFactory.getEventType()
Returns the event type that the view that is created by the view factory would create for events posted
by the view.
|
EventType |
ViewableDefaultImpl.getEventType() |
EventType |
EventCollection.getEventType()
Provides metadata information about the type of object the event collection contains.
|
Modifier and Type | Method and Description |
---|---|
void |
ViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories)
Attaches the factory to a parent event type such that the factory can validate
attach requirements and determine an event type for resulting views.
|
static String |
PropertyCheckHelper.checkLong(EventType type,
String longFieldName)
Check if the field identified by the field name is of type long according to the schema.
|
static String |
PropertyCheckHelper.checkNumeric(EventType type,
String numericFieldName)
Check if the field identified by the field name is a valid numeric field according to the schema.
|
static String |
PropertyCheckHelper.checkNumeric(EventType type,
String numericFieldNameX,
String numericFieldNameY)
Check if the fields identified by their field names are valid numeric field according to the schema.
|
ViewFactoryChain |
ViewServiceImpl.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecDefinitions,
StreamSpecOptions options,
StatementContext context,
boolean isSubquery,
int subqueryNumber) |
ViewFactoryChain |
ViewService.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecList,
StreamSpecOptions options,
StatementContext context,
boolean isSubquery,
int subqueryNumber)
Returns a chain of view factories that can be used to obtain the final event type,
and that can later be used to actually create the chain of views or reuse existing views.
|
static String |
PropertyCheckHelper.exists(EventType type,
String fieldName)
Check if the field identified by the field name exists according to the schema.
|
static String |
PropertyCheckHelper.exists(EventType type,
String fieldNameOne,
String fieldNameTwo)
Check if the fields identified by the field names both exists according to the schema.
|
static ViewFactoryChain |
ViewFactoryChain.fromTypeNoViews(EventType eventType) |
static ExprNode[] |
ViewFactorySupport.validate(String viewName,
EventType eventType,
StatementContext statementContext,
List<ExprNode> expressions,
boolean allowConstantResult)
Validate the view parameter expressions and return the validated expression for later execution.
|
Constructor and Description |
---|
ViewableDefaultImpl(EventType eventType) |
ViewFactoryChain(EventType streamEventType,
List<ViewFactory> viewFactoryChain)
Ctor.
|
ZeroDepthStreamIterable(EventType eventType)
Ctor.
|
ZeroDepthStreamNoIterate(EventType eventType)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
EventType |
TimeToLiveViewFactory.getEventType() |
EventType |
TimeOrderViewFactory.getEventType() |
EventType |
TimeOrderView.getEventType() |
EventType |
SortWindowViewFactory.getEventType() |
EventType |
SortWindowView.getEventType() |
EventType |
RankWindowViewFactory.getEventType() |
EventType |
RankWindowView.getEventType() |
Modifier and Type | Method and Description |
---|---|
void |
TimeToLiveViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeOrderViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
SortWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
RankWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
UnionViewFactory.parentEventType
The event type.
|
protected EventType |
IntersectViewFactory.parentEventType |
Modifier and Type | Method and Description |
---|---|
EventType |
UnionViewFactory.getEventType() |
EventType |
UnionView.getEventType() |
EventType |
UnionAsymetricView.getEventType() |
EventType |
SingleStreamDispatchView.getEventType() |
EventType |
RouteResultView.getEventType() |
EventType |
PriorEventViewFactory.getEventType() |
EventType |
PriorEventView.getEventType() |
EventType |
PatternRemoveDispatchView.getEventType() |
EventType |
NoopViewFactory.getEventType() |
EventType |
NoopView.getEventType() |
EventType |
LastPostObserverView.getEventType() |
EventType |
IntersectViewFactory.getEventType() |
EventType |
IntersectDefaultView.getEventType() |
EventType |
IntersectBatchView.getEventType() |
EventType |
IntersectAsymetricView.getEventType() |
EventType |
BufferView.getEventType() |
EventType |
IntersectViewFactory.getParentEventType() |
Modifier and Type | Method and Description |
---|---|
void |
UnionViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
PriorEventViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
NoopViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
IntersectViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
UnionViewFactory.setParentEventType(EventType parentEventType)
Sets the parent event type.
|
void |
IntersectViewFactory.setParentEventType(EventType parentEventType)
Sets the parent event type.
|
Constructor and Description |
---|
RouteResultView(boolean isFirst,
EventType eventType,
EPStatementHandle epStatementHandle,
InternalEventRouter internalEventRouter,
TableStateInstance[] tableStateInstances,
EPStatementStartMethodOnTriggerItem[] items,
ResultSetProcessor[] processors,
ExprEvaluator[] whereClauses,
AgentInstanceContext agentInstanceContext) |
UnionAsymetricView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
UnionViewFactory factory,
EventType eventType,
List<View> viewList) |
UnionView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
UnionViewFactory factory,
EventType eventType,
List<View> viewList) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
WeightedAverageViewFactory.eventType |
protected EventType |
UnivariateStatisticsViewFactory.eventType |
protected EventType |
RegressionLinestViewFactory.eventType |
protected EventType |
CorrelationViewFactory.eventType
Event type.
|
protected EventType |
BaseBivariateStatisticsView.eventType
Event type.
|
Modifier and Type | Method and Description |
---|---|
static EventType |
WeightedAverageView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
static EventType |
UnivariateStatisticsView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
protected static EventType |
RegressionLinestView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
protected static EventType |
CorrelationView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
EventType |
WeightedAverageViewFactory.getEventType() |
EventType |
WeightedAverageView.getEventType() |
EventType |
UnivariateStatisticsViewFactory.getEventType() |
EventType |
UnivariateStatisticsView.getEventType() |
EventType |
RegressionLinestViewFactory.getEventType() |
EventType |
RegressionLinestView.getEventType() |
EventType |
CorrelationViewFactory.getEventType() |
EventType |
CorrelationView.getEventType() |
Modifier and Type | Method and Description |
---|---|
void |
WeightedAverageViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
UnivariateStatisticsViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
RegressionLinestViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
CorrelationViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
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 StatViewAdditionalProps |
StatViewAdditionalProps.make(ExprNode[] validated,
int startIndex,
EventType parentEventType) |
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.
|
void |
WeightedAverageViewFactory.setEventType(EventType eventType) |
void |
UnivariateStatisticsViewFactory.setEventType(EventType eventType) |
Constructor and Description |
---|
BaseBivariateStatisticsView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode expressionX,
ExprNode expressionY,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor requires the name of the two fields to use in the parent view to compute the statistics.
|
CorrelationView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode xExpression,
ExprNode yExpression,
EventType eventType,
StatViewAdditionalProps additionalProps) |
RegressionLinestView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode xFieldName,
ExprNode yFieldName,
EventType eventType,
StatViewAdditionalProps additionalProps) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
SizeViewFactory.eventType |
Modifier and Type | Method and Description |
---|---|
static EventType |
SizeView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum) |
EventType |
UniqueByPropertyViewFactory.getEventType() |
EventType |
UniqueByPropertyView.getEventType() |
EventType |
SizeViewFactory.getEventType() |
EventType |
SizeView.getEventType() |
EventType |
MergeViewFactory.getEventType() |
EventType |
MergeView.getEventType() |
EventType |
LastElementViewFactory.getEventType() |
EventType |
LastElementView.getEventType() |
EventType |
GroupByViewReclaimAged.getEventType() |
EventType |
GroupByViewImpl.getEventType() |
EventType |
GroupByViewFactory.getEventType() |
EventType |
FirstUniqueByPropertyViewFactory.getEventType() |
EventType |
FirstUniqueByPropertyView.getEventType() |
EventType |
FirstElementViewFactory.getEventType() |
EventType |
FirstElementView.getEventType() |
EventType |
AddPropertyValueOptionalView.getEventType() |
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.
|
void |
UniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
SizeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
MergeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
LastElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
GroupByViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstUniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
Constructor and Description |
---|
AddPropertyValueOptionalView(AgentInstanceViewFactoryChainContext agentInstanceContext,
String[] propertyNames,
Object mergeValues,
EventType mergedResultEventType)
Constructor.
|
MergeView(AgentInstanceViewFactoryChainContext agentInstanceContext,
ExprNode[] groupCriteria,
EventType resultEventType,
boolean removable) |
SizeView(AgentInstanceContext agentInstanceContext,
EventType eventType,
StatViewAdditionalProps additionalProps) |
Modifier and Type | Field and Description |
---|---|
protected EventType |
ExpressionViewFactoryBase.builtinMapType |
protected EventType |
TimeBatchViewFactoryParams.eventType
Event type
|
Modifier and Type | Method and Description |
---|---|
EventType |
ExpressionViewFactoryBase.getBuiltinMapType() |
EventType |
TimeWindowViewFactory.getEventType() |
EventType |
TimeWindowView.getEventType() |
EventType |
TimeLengthBatchViewFactory.getEventType() |
EventType |
TimeLengthBatchView.getEventType() |
EventType |
TimeBatchViewRStream.getEventType() |
EventType |
TimeBatchViewFactory.getEventType() |
EventType |
TimeBatchView.getEventType() |
EventType |
TimeAccumViewRStream.getEventType() |
EventType |
TimeAccumViewFactory.getEventType() |
EventType |
TimeAccumView.getEventType() |
EventType |
LengthWindowViewRStream.getEventType() |
EventType |
LengthWindowViewFactory.getEventType() |
EventType |
LengthWindowView.getEventType() |
EventType |
LengthBatchViewRStream.getEventType() |
EventType |
LengthBatchViewFactory.getEventType() |
EventType |
LengthBatchView.getEventType() |
EventType |
KeepAllViewFactory.getEventType() |
EventType |
KeepAllView.getEventType() |
EventType |
FirstTimeViewFactory.getEventType() |
EventType |
FirstTimeView.getEventType() |
EventType |
FirstLengthWindowViewFactory.getEventType() |
EventType |
FirstLengthWindowView.getEventType() |
EventType |
ExternallyTimedWindowViewFactory.getEventType() |
EventType |
ExternallyTimedWindowView.getEventType() |
EventType |
ExternallyTimedBatchViewFactory.getEventType() |
EventType |
ExternallyTimedBatchView.getEventType() |
EventType |
ExpressionViewFactoryBase.getEventType() |
EventType |
ExpressionViewBase.getEventType() |
Modifier and Type | Method and Description |
---|---|
static LinkedHashMap<String,Object> |
ExpressionViewOAFieldEnum.asMapOfTypes(EventType eventType) |
void |
TimeWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeLengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
TimeAccumViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
LengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
LengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
KeepAllViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstTimeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
FirstLengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
ExternallyTimedWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
ExternallyTimedBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |
void |
ExpressionViewFactoryBase.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
List<ViewFactory> parentViewFactories) |