|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use EventType | |
---|---|
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.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.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.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.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 |
Uses of EventType in com.espertech.esper.client |
---|
Methods in com.espertech.esper.client that return EventType | |
---|---|
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(java.lang.String eventTypeName)
Returns the event type for a given event type name. |
EventType |
Configuration.getEventType(java.lang.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. |
Methods in com.espertech.esper.client that return types with arguments of type EventType | |
---|---|
java.util.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. |
Constructors in com.espertech.esper.client with parameters of type EventType | |
---|---|
FragmentEventType(EventType fragmentType,
boolean indexed,
boolean isNative)
Ctor. |
Uses of EventType in com.espertech.esper.client.hook |
---|
Methods in com.espertech.esper.client.hook that return EventType | |
---|---|
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. |
Constructors in com.espertech.esper.client.hook with parameters of type EventType | |
---|---|
VirtualDataWindowContext(AgentInstanceContext agentInstanceContext,
EventType eventType,
java.lang.Object[] parameters,
ExprNode[] parameterExpressions,
EventBeanFactory eventFactory,
VirtualDataWindowOutStream outputStream,
java.lang.String namedWindowName,
ViewFactoryContext viewFactoryContext,
java.io.Serializable customConfiguration)
Ctor. |
|
VirtualDataWindowFactoryContext(EventType eventType,
java.lang.Object[] parameters,
ExprNode[] parameterExpressions,
EventBeanFactory eventFactory,
java.lang.String namedWindowName,
ViewFactoryContext viewFactoryContext,
java.io.Serializable customConfiguration)
Ctor. |
Uses of EventType in com.espertech.esper.client.util |
---|
Methods in com.espertech.esper.client.util that return EventType | |
---|---|
EventType |
EventPropertyRendererContext.getEventType()
Returns the event type |
Methods in com.espertech.esper.client.util with parameters of type EventType | |
---|---|
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. |
Constructors in com.espertech.esper.client.util with parameters of type EventType | |
---|---|
EventPropertyRendererContext(EventType eventType,
boolean jsonFormatted)
Ctor. |
Uses of EventType in com.espertech.esper.collection |
---|
Constructors in com.espertech.esper.collection with parameters of type EventType | |
---|---|
EventDistinctIterator(java.util.Iterator<EventBean> sourceIterator,
EventType eventType)
Ctor. |
Uses of EventType in com.espertech.esper.core.context.activator |
---|
Constructors in com.espertech.esper.core.context.activator with parameters of type EventType | |
---|---|
ViewableActivatorPattern(PatternContext patternContext,
EvalRootFactoryNode rootFactoryNode,
EventType eventType,
boolean hasConsumingFilter,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch,
boolean isCanIterate)
|
Uses of EventType in com.espertech.esper.core.context.factory |
---|
Uses of EventType in com.espertech.esper.core.context.mgr |
---|
Methods in com.espertech.esper.core.context.mgr that return EventType | |
---|---|
EventType |
ContextPropertyRegistryImpl.getContextEventType()
|
Methods in com.espertech.esper.core.context.mgr with parameters of type EventType | |
---|---|
FilterSpecLookupable |
ContextManagerNested.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextManagerImpl.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextManager.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextControllerPartitionedFactory.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextControllerInitTermFactory.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextControllerHashFactory.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextControllerFactory.getFilterLookupable(EventType eventType)
|
FilterSpecLookupable |
ContextControllerCategoryFactory.getFilterLookupable(EventType eventType)
|
java.lang.String |
ContextPropertyRegistryImpl.getPartitionContextPropertyName(EventType fromType,
java.lang.String propertyName)
|
boolean |
ContextPropertyRegistryImpl.isPartitionProperty(EventType fromType,
java.lang.String propertyName)
|
Method parameters in com.espertech.esper.core.context.mgr with type arguments of type EventType | |
---|---|
protected static void |
ContextControllerPartitionedUtil.validateStatementForContext(java.lang.String contextName,
ContextControllerStatementBase statement,
StatementSpecCompiledAnalyzerResult streamAnalysis,
java.util.Collection<EventType> itemEventTypes,
NamedWindowService namedWindowService)
|
Constructors in com.espertech.esper.core.context.mgr with parameters of type EventType | |
---|---|
ContextControllerHashedGetterSingleRow(java.lang.String statementName,
java.lang.String functionName,
Pair<java.lang.Class,EngineImportSingleRowDesc> func,
java.util.List<ExprNode> parameters,
int granularity,
MethodResolutionService methodResolutionService,
EventType eventType,
EventAdapterService eventAdapterService,
java.lang.String statementId,
TableService tableService)
|
|
ContextPropertyRegistryImpl(EventType contextEventType)
|
|
ContextPropertyRegistryImpl(java.util.List<ContextDetailPartitionItem> partitionProperties,
EventType contextEventType)
|
Uses of EventType in com.espertech.esper.core.context.subselect |
---|
Methods in com.espertech.esper.core.context.subselect that return EventType | |
---|---|
EventType |
SubSelectActivationCollection.getRootViewableType(ExprSubselectNode subqueryNode)
Returns the lookup viewable, child-most view. |
EventType |
SubSelectActivationHolder.getViewableType()
|
Constructors in com.espertech.esper.core.context.subselect with parameters of type EventType | |
---|---|
SubSelectActivationHolder(int streamNumber,
EventType viewableType,
ViewFactoryChain viewFactoryChain,
ViewableActivator activator,
StreamSpecCompiled streamSpecCompiled)
|
|
SubSelectStrategyFactoryIndexShare(java.lang.String statementName,
java.lang.String statementId,
int subqueryNum,
EventType[] outerEventTypesSelect,
NamedWindowProcessor optionalNamedWindowProcessor,
TableMetadata optionalTableMetadata,
boolean fullTableScan,
IndexHint optionalIndexHint,
SubordPropPlan joinedPropPlan,
ExprEvaluator filterExprEval,
AggregationServiceFactoryDesc aggregationServiceFactory,
ExprEvaluator[] groupByKeys,
TableService tableService,
java.lang.annotation.Annotation[] annotations,
StatementStopService statementStopService)
|
Uses of EventType in com.espertech.esper.core.context.util |
---|
Methods in com.espertech.esper.core.context.util that return EventType | |
---|---|
EventType |
ContextPropertyRegistry.getContextEventType()
|
EventType |
ContextMergeView.getEventType()
|
Methods in com.espertech.esper.core.context.util with parameters of type EventType | |
---|---|
java.lang.String |
ContextPropertyRegistry.getPartitionContextPropertyName(EventType fromType,
java.lang.String propertyName)
|
boolean |
ContextPropertyRegistry.isPartitionProperty(EventType fromType,
java.lang.String propertyName)
|
Constructors in com.espertech.esper.core.context.util with parameters of type EventType | |
---|---|
ContextMergeView(EventType eventType)
|
|
ContextMergeViewForwarding(EventType eventType)
|
Uses of EventType in com.espertech.esper.core.deploy |
---|
Methods in com.espertech.esper.core.deploy that return types with arguments of type EventType | |
---|---|
static java.util.List<EventType> |
EPLModuleUtil.undeployTypes(java.util.Set<java.lang.String> referencedTypes,
StatementEventTypeRef statementEventTypeRef,
EventAdapterService eventAdapterService,
FilterService filterService)
|
Uses of EventType in com.espertech.esper.core.service |
---|
Methods in com.espertech.esper.core.service that return EventType | |
---|---|
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(java.lang.String eventTypeName)
|
EventType[] |
ConfigurationOperationsImpl.getEventTypes()
|
EventType |
NamedWindowSelectedProps.getFragmentType()
Returns the fragment type or null if not a fragment type. |
Methods in com.espertech.esper.core.service with parameters of type EventType | |
---|---|
InternalEventRouterDesc |
InternalEventRouterImpl.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
java.lang.annotation.Annotation[] annotations)
|
InternalEventRouterDesc |
InternalEventRouter.getValidatePreprocessing(EventType eventType,
UpdateDesc desc,
java.lang.annotation.Annotation[] annotations)
|
void |
InternalEventRouterImpl.removePreprocessing(EventType eventType,
UpdateDesc desc)
|
void |
InternalEventRouter.removePreprocessing(EventType eventType,
UpdateDesc desc)
Remove preprocessing. |
Constructors in com.espertech.esper.core.service with parameters of type EventType | |
---|---|
EPPreparedQueryResult(EventType eventType,
EventBean[] result)
Ctor. |
|
InternalEventRouterDesc(UpdateDesc updateDesc,
EventBeanCopyMethod copyMethod,
TypeWidener[] wideners,
EventType eventType,
java.lang.annotation.Annotation[] annotations)
|
|
InternalRoutePreprocessView(EventType eventType,
StatementResultService statementResultService)
Ctor. |
|
NamedWindowSelectedProps(java.lang.Class selectExpressionType,
java.lang.String assignedName,
EventType fragmentType)
Ctor. |
Uses of EventType in com.espertech.esper.core.start |
---|
Methods in com.espertech.esper.core.start that return EventType | |
---|---|
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()
|
Methods in com.espertech.esper.core.start with parameters of type EventType | |
---|---|
protected static SubSelectStrategyCollection |
EPStatementStartMethodHelperSubselect.planSubSelect(EPServicesContext services,
StatementContext statementContext,
boolean queryPlanLogging,
SubSelectActivationCollection subSelectStreamDesc,
java.lang.String[] outerStreamNames,
EventType[] outerEventTypesSelect,
java.lang.String[] outerEventTypeNamees,
ExprDeclaredNode[] declaredExpressions,
ContextPropertyRegistry contextPropertyRegistry)
|
protected ExprNode |
EPStatementStartMethodOnTrigger.validateJoinNamedWindow(java.lang.String engineURI,
StatementContext statementContext,
ExprNodeOrigin exprNodeOrigin,
ExprNode deleteJoinExpr,
EventType namedWindowType,
java.lang.String namedWindowStreamName,
java.lang.String namedWindowName,
EventType filteredType,
java.lang.String filterStreamName,
java.lang.String filteredTypeName,
java.lang.String optionalTableName)
|
Uses of EventType in com.espertech.esper.dataflow.ops |
---|
Methods in com.espertech.esper.dataflow.ops with parameters of type EventType | |
---|---|
protected JSONEventRenderer |
LogSink.ConsoleOpRendererXmlJSon.getJsonRenderer(EventType eventType)
|
protected XMLEventRenderer |
LogSink.ConsoleOpRendererXmlJSon.getXmlRenderer(EventType eventType)
|
Uses of EventType in com.espertech.esper.dataflow.ops.epl |
---|
Methods in com.espertech.esper.dataflow.ops.epl that return EventType | |
---|---|
EventType |
EPLSelectViewable.getEventType()
|
EventType |
EPLSelectUpdateDispatchView.getEventType()
|
Constructors in com.espertech.esper.dataflow.ops.epl with parameters of type EventType | |
---|---|
EPLSelectViewable(EventType eventType)
|
Uses of EventType in com.espertech.esper.dataflow.util |
---|
Methods in com.espertech.esper.dataflow.util that return EventType | |
---|---|
EventType |
GraphTypeDesc.getEventType()
|
Constructors in com.espertech.esper.dataflow.util with parameters of type EventType | |
---|---|
GraphTypeDesc(boolean wildcard,
boolean underlying,
EventType eventType)
|
Uses of EventType in com.espertech.esper.epl.agg.service |
---|
Methods in com.espertech.esper.epl.agg.service with parameters of type EventType | |
---|---|
ExprEvaluator |
AggregationMethodFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
static AggregationServiceFactoryDesc |
AggregationServiceFactoryFactory.getService(java.util.List<ExprAggregateNode> selectAggregateExprNodes,
java.util.Map<ExprNode,java.lang.String> selectClauseNamedNodes,
java.util.List<ExprDeclaredNode> declaredExpressions,
ExprNode[] groupByNodes,
java.util.List<ExprAggregateNode> havingAggregateExprNodes,
java.util.List<ExprAggregateNode> orderByAggregateExprNodes,
java.util.List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
java.lang.annotation.Annotation[] annotations,
VariableService variableService,
boolean isJoin,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
AggregationServiceFactoryService factoryService,
EventType[] typesPerStream,
MethodResolutionService methodResolutionService,
AggregationGroupByRollupDesc groupByRollupDesc,
java.lang.String optionalContextName,
IntoTableSpec intoTableSpec,
TableService tableService)
Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on whether there are any group-by nodes. |
static AggregationServiceMatchRecognizeFactoryDesc |
AggregationServiceFactoryFactory.getServiceMatchRecognize(int numStreams,
java.util.Map<java.lang.Integer,java.util.List<ExprAggregateNode>> measureExprNodesPerStream,
EventType[] typesPerStream)
Produces an aggregation service for use with match-recognice. |
static void |
AggregationMethodFactoryUtil.validateEventType(EventType requiredType,
EventType providedType)
|
Constructors in com.espertech.esper.epl.agg.service with parameters of type EventType | |
---|---|
AggregationStateKeyWStream(int streamNum,
EventType eventType,
AggregationStateTypeWStream stateType,
ExprNode[] exprNodes)
|
Uses of EventType in com.espertech.esper.epl.core |
---|
Fields in com.espertech.esper.epl.core declared as EventType | |
---|---|
protected EventType |
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceBase.eventType
|
protected EventType |
MethodPollingExecStrategyBase.eventType
|
Methods in com.espertech.esper.epl.core that return EventType | |
---|---|
EventType |
MethodPollingViewable.getEventType()
|
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 |
ResultSetProcessorSimpleFactory.getResultEventType()
|
EventType |
ResultSetProcessorSimple.getResultEventType()
|
EventType |
ResultSetProcessorRowPerGroupRollupFactory.getResultEventType()
|
EventType |
ResultSetProcessorRowPerGroupRollup.getResultEventType()
|
EventType |
ResultSetProcessorRowPerGroupFactory.getResultEventType()
|
EventType |
ResultSetProcessorRowPerGroup.getResultEventType()
|
EventType |
ResultSetProcessorRowForAllFactory.getResultEventType()
|
EventType |
ResultSetProcessorRowForAll.getResultEventType()
|
EventType |
ResultSetProcessorHandThrough.getResultEventType()
|
EventType |
ResultSetProcessorHandThrougFactory.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. |
Methods in com.espertech.esper.epl.core with parameters of type EventType | |
---|---|
void |
SelectExprEventTypeRegistry.add(EventType eventType)
Adds an event type. |
static SelectExprProcessor |
SelectExprJoinWildcardProcessorFactory.create(java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
java.lang.String statementId,
java.lang.String[] streamNames,
EventType[] streamTypes,
EventAdapterService eventAdapterService,
InsertIntoDesc insertIntoDesc,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
MethodResolutionService methodResolutionService,
java.lang.annotation.Annotation[] annotations,
ConfigurationInformation configuration,
TableService tableService)
Ctor. |
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingJoinWildcard(EventAdapterService eventAdapterService,
EventType eventType,
java.lang.String[] streamNames,
EventType[] streamTypes,
EngineImportService engineImportService)
|
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingJoinWildcard(EventAdapterService eventAdapterService,
EventType eventType,
java.lang.String[] streamNames,
EventType[] streamTypes,
EngineImportService engineImportService)
|
static SelectExprProcessor |
SelectExprInsertEventBeanFactory.getInsertUnderlyingNonJoin(EventAdapterService eventAdapterService,
EventType eventType,
boolean isUsingWildcard,
StreamTypeService typeService,
ExprEvaluator[] expressionNodes,
java.lang.String[] columnNames,
java.lang.Object[] expressionReturnTypes,
EngineImportService engineImportService,
InsertIntoDesc insertIntoDesc,
java.lang.String[] columnNamesAsProvided,
boolean allowNestableTargetFragmentTypes)
|
static SelectExprProcessor |
SelectExprProcessorFactory.getProcessor(java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
SelectClauseElementCompiled[] selectionList,
boolean isUsingWildcard,
InsertIntoDesc insertIntoDesc,
EventType optionalInsertIntoEventType,
ForClauseSpec forClauseSpec,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
StatementResultService statementResultService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
MethodResolutionService methodResolutionService,
ExprEvaluatorContext exprEvaluatorContext,
VariableService variableService,
TableService tableService,
TimeProvider timeProvider,
java.lang.String engineURI,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configuration,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback,
NamedWindowService namedWindowService,
IntoTableSpec intoTableClause)
Returns the processor to use for a given select-clause. |
Constructors in com.espertech.esper.epl.core with parameters of type EventType | |
---|---|
BindProcessor(SelectClauseElementCompiled[] selectionList,
EventType[] typesPerStream,
java.lang.String[] streamNames,
TableService tableService)
Ctor. |
|
MethodPollingExecStrategyBase(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyBaseArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyBaseCollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyBaseIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyMapArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyMapCollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyMapIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyMapPlain(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyOAArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyOACollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyOAIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyOAPlain(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyPOJOArray(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyPOJOCollection(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyPOJOIterator(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingExecStrategyPOJOPlain(EventAdapterService eventAdapterService,
net.sf.cglib.reflect.FastMethod method,
EventType eventType,
java.lang.Object invocationTarget,
MethodPollingExecStrategyEnum strategy,
VariableReader variableReader,
java.lang.String variableName,
VariableService variableService)
|
|
MethodPollingViewable(boolean isStaticMethod,
java.lang.Class methodProviderClass,
MethodStreamSpec methodStreamSpec,
int myStreamNumber,
java.util.List<ExprNode> inputParameters,
PollExecStrategy pollExecStrategy,
DataCache dataCache,
EventType eventType,
ExprEvaluatorContext exprEvaluatorContext)
Ctor. |
|
PropertyResolutionDescriptor(java.lang.String streamName,
EventType streamEventType,
java.lang.String propertyName,
int streamNum,
java.lang.Class propertyType,
FragmentEventType fragmentEventType)
Ctor. |
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeBase(EventType eventType,
EventBeanManufacturer eventManufacturer,
ExprEvaluator[] exprEvaluators)
|
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceBase(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService)
|
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceMap(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService)
|
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceNative(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService)
|
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeExpressionCoerceObjectArray(EventType eventType,
ExprEvaluator exprEvaluator,
EventAdapterService eventAdapterService)
|
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeNoWiden(EventType eventType,
EventBeanManufacturer eventManufacturer,
ExprEvaluator[] exprEvaluators)
|
|
SelectExprInsertEventBeanFactory.SelectExprInsertNativeWidening(EventType eventType,
EventBeanManufacturer eventManufacturer,
ExprEvaluator[] exprEvaluators,
TypeWidener[] wideners)
|
|
SelectExprJoinWildcardProcessorMap(java.lang.String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService)
|
|
SelectExprJoinWildcardProcessorObjectArray(java.lang.String[] streamNames,
EventType resultEventType,
EventAdapterService eventAdapterService)
|
|
SelectExprJoinWildcardProcessorTableRows(EventType[] types,
SelectExprProcessor inner,
TableService tableService)
|
|
SelectExprProcessorHelper(java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
java.util.List<SelectClauseExprCompiledSpec> selectionList,
java.util.List<SelectExprStreamDesc> selectedStreams,
InsertIntoDesc insertIntoDesc,
EventType optionalInsertIntoOverrideType,
boolean isUsingWildcard,
StreamTypeService typeService,
EventAdapterService eventAdapterService,
ValueAddEventService valueAddEventService,
SelectExprEventTypeRegistry selectExprEventTypeRegistry,
MethodResolutionService methodResolutionService,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
ConfigurationInformation configuration,
NamedWindowService namedWindowService,
TableService tableService)
Ctor. |
|
SelectExprProcessorWDeliveryCallback(EventType eventType,
BindProcessor bindProcessor,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback)
|
|
SelectExprWildcardProcessor(EventType eventType)
Ctor. |
|
StreamTypeServiceImpl(EventType[] eventTypes,
java.lang.String[] streamNames,
boolean[] isIStreamOnly,
java.lang.String engineURI,
boolean isOnDemandStreams)
Ctor. |
|
StreamTypeServiceImpl(EventType eventType,
java.lang.String streamName,
boolean isIStreamOnly,
java.lang.String engineURI)
Ctor. |
Constructor parameters in com.espertech.esper.epl.core with type arguments of type EventType | |
---|---|
StreamTypeServiceImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> namesAndTypes,
java.lang.String engineURI,
boolean isStreamZeroUnambigous,
boolean requireStreamNames)
Ctor. |
Uses of EventType in com.espertech.esper.epl.core.eval |
---|
Fields in com.espertech.esper.epl.core.eval declared as EventType | |
---|---|
protected EventType |
EvalSelectStreamBase.resultEventType
|
protected EventType |
EvalInsertNoWildcardObjectArrayRemap.resultEventType
|
protected EventType |
EvalBase.resultEventType
|
Methods in com.espertech.esper.epl.core.eval that return EventType | |
---|---|
EventType |
EvalSelectStreamBase.getResultEventType()
|
EventType |
EvalSelectNoWildcardObjectArray.getResultEventType()
|
EventType |
EvalSelectNoWildcardMap.getResultEventType()
|
EventType |
EvalSelectNoWildcardEmptyProps.getResultEventType()
|
EventType |
EvalInsertNoWildcardObjectArrayRemap.getResultEventType()
|
EventType |
EvalInsertCoercionObjectArray.getResultEventType()
|
EventType |
EvalInsertCoercionMap.getResultEventType()
|
EventType |
EvalInsertBeanWrapRecast.getResultEventType()
|
EventType |
EvalInsertBeanRecast.getResultEventType()
|
EventType |
EvalBaseFirstProp.getResultEventType()
|
EventType |
EvalBase.getResultEventType()
|
Methods in com.espertech.esper.epl.core.eval with parameters of type EventType | |
---|---|
static SelectExprProcessor |
EvalSelectStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService)
|
static SelectExprProcessor |
EvalSelectStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService)
|
static SelectExprProcessor |
EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService)
|
static SelectExprProcessor |
EvalSelectStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprContext selectExprContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
EngineImportService engineImportService)
|
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(java.lang.Class sourceType,
EventType targetType)
|
static ExprValidationException |
EvalInsertUtil.makeEventTypeCastException(EventType sourceType,
EventType targetType)
|
Uses of EventType in com.espertech.esper.epl.datetime.eval |
---|
Methods in com.espertech.esper.epl.datetime.eval with parameters of type EventType | |
---|---|
com.espertech.esper.epl.datetime.eval.ExprDotEvalDT.DTLocalEvaluator |
ExprDotEvalDT.getEvaluator(java.util.List<CalendarOp> calendarOps,
java.lang.Class inputType,
EventType inputEventType,
ReformatOp reformatOp,
IntervalOp intervalOp)
|
Constructors in com.espertech.esper.epl.datetime.eval with parameters of type EventType | |
---|---|
ExprDotEvalDT(java.util.List<CalendarOp> calendarOps,
ReformatOp reformatOp,
IntervalOp intervalOp,
java.lang.Class inputType,
EventType inputEventType)
|
|
ExprDotNodeFilterAnalyzerDTBetweenDesc(EventType[] typesPerStream,
int targetStreamNum,
java.lang.String targetPropertyName,
ExprNode start,
ExprNode end,
boolean includeLow,
boolean includeHigh)
|
|
ExprDotNodeFilterAnalyzerDTIntervalDesc(DatetimeMethodEnum currentMethod,
EventType[] typesPerStream,
int targetStreamNum,
java.lang.String targetStartProp,
java.lang.String targetEndProp,
java.lang.Integer parameterStreamNum,
java.lang.String parameterStartProp,
java.lang.String parameterEndProp)
|
Uses of EventType in com.espertech.esper.epl.datetime.interval |
---|
Methods in com.espertech.esper.epl.datetime.interval with parameters of type EventType | |
---|---|
ExprDotNodeFilterAnalyzerDTIntervalDesc |
IntervalOpImpl.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodEnum currentMethod,
java.util.List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc)
Obtain information used by filter analyzer to handle this dot-method invocation as part of query planning/indexing. |
ExprDotNodeFilterAnalyzerDTIntervalDesc |
IntervalOp.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodEnum currentMethod,
java.util.List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc)
|
Uses of EventType in com.espertech.esper.epl.datetime.reformatop |
---|
Uses of EventType in com.espertech.esper.epl.db |
---|
Methods in com.espertech.esper.epl.db that return EventType | |
---|---|
EventType |
DatabasePollingViewable.getEventType()
|
Constructors in com.espertech.esper.epl.db with parameters of type EventType | |
---|---|
DatabasePollingViewable(int myStreamNumber,
java.util.List<java.lang.String> inputParameters,
PollExecStrategy pollExecStrategy,
DataCache dataCache,
EventType eventType)
Ctor. |
|
PollExecStrategyDBQuery(EventAdapterService eventAdapterService,
EventType eventType,
ConnectionCache connectionCache,
java.lang.String preparedStatementText,
java.util.Map<java.lang.String,DBOutputTypeDesc> outputTypes,
SQLColumnTypeConversion columnTypeConversionHook,
SQLOutputRowConversion outputRowConversionHook,
boolean enableJDBCLogging)
Ctor. |
Uses of EventType in com.espertech.esper.epl.declexpr |
---|
Methods in com.espertech.esper.epl.declexpr that return EventType | |
---|---|
EventType |
ExprDeclaredEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprDeclaredEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Uses of EventType in com.espertech.esper.epl.enummethod.dot |
---|
Methods in com.espertech.esper.epl.enummethod.dot that return EventType | |
---|---|
abstract EventType[] |
ExprDotEvalEnumMethodBase.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType |
PropertyExprEvaluatorScalarIterable.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorScalarCollection.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorScalarArray.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorEventSingle.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorEventCollection.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorScalarIterable.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorScalarCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorScalarArray.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorEventSingle.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
PropertyExprEvaluatorEventCollection.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType[] |
ExprDotEvalParamLambda.getGoesToTypes()
|
Methods in com.espertech.esper.epl.enummethod.dot with parameters of type EventType | |
---|---|
abstract EventType[] |
ExprDotEvalEnumMethodBase.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
abstract EnumEval |
ExprDotEvalEnumMethodBase.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
Constructors in com.espertech.esper.epl.enummethod.dot with parameters of type EventType | |
---|---|
ExprDotEvalParamLambda(int parameterNum,
ExprNode body,
ExprEvaluator bodyEvaluator,
int streamCountIncoming,
java.util.List<java.lang.String> goesToNames,
EventType[] goesToTypes)
|
|
ExprDotEvalUnpackBean(EventType lambdaType)
|
|
ExprDotEvalUnpackBeanTable(EventType lambdaType,
TableMetadata tableMetadata)
|
|
ExprDotEvalUnpackCollEventBean(EventType type)
|
|
ExprDotEvalUnpackCollEventBeanTable(EventType type,
TableMetadata tableMetadata)
|
|
PropertyExprEvaluatorEventCollection(java.lang.String propertyNameCache,
int streamId,
EventType fragmentType,
EventPropertyGetter getter,
boolean disablePropertyExpressionEventCollCache)
|
|
PropertyExprEvaluatorEventSingle(int streamId,
EventType fragmentType,
EventPropertyGetter getter)
|
Uses of EventType in com.espertech.esper.epl.enummethod.eval |
---|
Methods in com.espertech.esper.epl.enummethod.eval that return EventType | |
---|---|
EventType[] |
ExprDotEvalWhere.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalToMap.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalTakeWhileAndLast.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalTakeAndTakeLast.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSumOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSetExceptUnionIntersect.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSequenceEqual.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSelectFrom.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalReverse.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalOrderByAscDesc.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalNoOp.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalMostLeastFrequent.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalMinMax.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalMinByMaxBy.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalGroupBy.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalFirstLastOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalDistinct.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalCountOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalAverage.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalAllOfAnyOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalAggregate.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
Methods in com.espertech.esper.epl.enummethod.eval with parameters of type EventType | |
---|---|
EventType[] |
ExprDotEvalWhere.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalToMap.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalTakeWhileAndLast.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalTakeAndTakeLast.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSumOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSetExceptUnionIntersect.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSequenceEqual.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalSelectFrom.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalReverse.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalOrderByAscDesc.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalNoOp.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalMostLeastFrequent.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalMinMax.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalMinByMaxBy.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalGroupBy.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalFirstLastOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalDistinct.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalCountOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalAverage.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalAllOfAnyOf.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EventType[] |
ExprDotEvalAggregate.getAddStreamTypes(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventAdapterService eventAdapterService)
|
EnumEval |
ExprDotEvalWhere.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalToMap.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalTakeWhileAndLast.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalTakeAndTakeLast.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalSumOf.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalSetExceptUnionIntersect.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalSequenceEqual.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalSelectFrom.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalReverse.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalOrderByAscDesc.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalNoOp.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalMostLeastFrequent.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalMinMax.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalMinByMaxBy.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalGroupBy.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalFirstLastOf.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalDistinct.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalCountOf.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalAverage.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalAllOfAnyOf.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
EnumEval |
ExprDotEvalAggregate.getEnumEval(MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
StreamTypeService streamTypeService,
java.lang.String statementId,
java.lang.String enumMethodUsedName,
java.util.List<ExprDotEvalParam> bodiesAndParameters,
EventType inputEventType,
java.lang.Class collectionComponentType,
int numStreamsIncoming,
boolean disablePropertyExpressionEventCollCache)
|
Uses of EventType in com.espertech.esper.epl.expression.accessagg |
---|
Methods in com.espertech.esper.epl.expression.accessagg that return EventType | |
---|---|
EventType |
ExprAggMultiFunctionSortedMinMaxByNodeFactory.getContainedEventType()
|
EventType |
ExprAggMultiFunctionLinearAccessNodeFactoryAccess.getContainedEventType()
|
EventType |
LinearAggregationFactoryDesc.getEnumerationEventType()
|
EventType |
ExprPlugInAggMultiFunctionNodeFactory.getEventTypeCollection()
|
EventType |
ExprPlugInAggMultiFunctionNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprAggMultiFunctionLinearAccessNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprAggCountMinSketchNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprPlugInAggMultiFunctionNodeFactory.getEventTypeSingle()
|
EventType |
ExprPlugInAggMultiFunctionNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprAggMultiFunctionSortedMinMaxByNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprAggMultiFunctionLinearAccessNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprAggCountMinSketchNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Methods in com.espertech.esper.epl.expression.accessagg with parameters of type EventType | |
---|---|
ExprEvaluator |
ExprPlugInAggMultiFunctionNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprAggMultiFunctionSortedMinMaxByNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprAggMultiFunctionLinearAccessNodeFactoryMethod.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)
|
Uses of EventType in com.espertech.esper.epl.expression.core |
---|
Methods in com.espertech.esper.epl.expression.core that return EventType | |
---|---|
EventType |
ExprStreamUnderlyingNodeImpl.getEventType()
|
EventType |
ExprStreamUnderlyingNode.getEventType()
|
EventType |
ExprEvaluatorEnumeration.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprEvaluatorEnumeration.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Methods in com.espertech.esper.epl.expression.core with parameters of type EventType | |
---|---|
static void |
ExprNodeUtility.addNonAggregatedProps(ExprNode exprNode,
ExprNodePropOrStreamSet set,
EventType[] types,
ContextPropertyRegistry contextPropertyRegistry)
|
static ExprIdentNode |
ExprNodeUtility.getExprIdentNode(EventType[] typesPerStream,
int streamId,
java.lang.String property)
|
static ExprNodePropOrStreamSet |
ExprNodeUtility.getNonAggregatedProps(EventType[] types,
java.util.List<ExprNode> exprNodes,
ContextPropertyRegistry contextPropertyRegistry)
|
static ExprNodeUtilMethodDesc |
ExprNodeUtility.resolveMethodAllowWildcardAndStream(java.lang.String className,
java.lang.Class optionalClass,
java.lang.String methodName,
java.util.List<ExprNode> parameters,
MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
java.lang.String statementId,
boolean allowWildcard,
EventType wildcardType,
ExprNodeUtilResolveExceptionHandler exceptionHandler,
java.lang.String functionName,
TableService tableService)
|
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType,
boolean allowBindingConsumption)
|
Constructors in com.espertech.esper.epl.expression.core with parameters of type EventType | |
---|---|
ExprIdentNodeImpl(EventType eventType,
java.lang.String propertyName,
int streamNumber)
|
Uses of EventType in com.espertech.esper.epl.expression.dot |
---|
Methods in com.espertech.esper.epl.expression.dot that return EventType | |
---|---|
EventType |
ExprDotEvalRootChildInnerEval.getEventTypeCollection()
|
EventType |
ExprDotEvalRootChild.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprDotEvalRootChildInnerEval.getEventTypeSingle()
|
EventType |
ExprDotEvalRootChild.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
static EventType[] |
ExprDotNodeUtility.getSingleLambdaParamEventType(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
EventAdapterService eventAdapterService)
|
Methods in com.espertech.esper.epl.expression.dot with parameters of type EventType | |
---|---|
static java.lang.Object |
ExprDotNodeUtility.evaluateChainWithWrap(ExprDotStaticMethodWrap resultWrapLambda,
java.lang.Object result,
EventType optionalResultSingleEventType,
java.lang.Class resultType,
ExprDotEval[] chainEval,
EventBean[] eventsPerStream,
boolean newData,
ExprEvaluatorContext exprEvaluatorContext)
|
static ExprDotEnumerationSourceForProps |
ExprDotNodeUtility.getPropertyEnumerationSource(java.lang.String propertyName,
int streamId,
EventType streamType,
boolean allowEnumType,
boolean disablePropertyExpressionEventCollCache)
|
static EventType[] |
ExprDotNodeUtility.getSingleLambdaParamEventType(java.lang.String enumMethodUsedName,
java.util.List<java.lang.String> goesToNames,
EventType inputEventType,
java.lang.Class collectionComponentType,
EventAdapterService eventAdapterService)
|
Uses of EventType in com.espertech.esper.epl.expression.dot.inner |
---|
Methods in com.espertech.esper.epl.expression.dot.inner that return EventType | |
---|---|
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()
|
Constructors in com.espertech.esper.epl.expression.dot.inner with parameters of type EventType | |
---|---|
InnerEvaluatorEnumerableEventBean(ExprEvaluatorEnumeration rootLambdaEvaluator,
EventType eventType)
|
|
InnerEvaluatorEnumerableEventCollection(ExprEvaluatorEnumeration rootLambdaEvaluator,
EventType eventType)
|
Uses of EventType in com.espertech.esper.epl.expression.funcs |
---|
Constructors in com.espertech.esper.epl.expression.funcs with parameters of type EventType | |
---|---|
ExprTypeofNode.FragmentTypeEval(int streamId,
EventType eventType,
java.lang.String resolvedPropertyName)
|
Uses of EventType in com.espertech.esper.epl.expression.methodagg |
---|
Methods in com.espertech.esper.epl.expression.methodagg with parameters of type EventType | |
---|---|
static ExprEvaluator |
ExprMethodAggUtil.getDefaultEvaluator(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprSumNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprStddevNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprRateAggNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprPlugInAggFunctionFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprNthAggNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprMinMaxAggrNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprMedianNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprLeavingAggNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprLastEverNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprFirstEverNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprCountNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprCountEverNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprAvgNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
ExprEvaluator |
ExprAvedevNodeFactory.getMethodAggregationEvaluator(boolean join,
EventType[] typesPerStream)
|
static ExprEvaluator |
ExprCountNodeFactory.getMethodAggregationEvaluatorCountBy(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream)
|
static ExprEvaluator |
ExprMethodAggUtil.getMultiNodeEvaluator(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream)
|
Uses of EventType in com.espertech.esper.epl.expression.ops |
---|
Methods in com.espertech.esper.epl.expression.ops that return EventType | |
---|---|
EventType |
ExprArrayNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprArrayNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Uses of EventType in com.espertech.esper.epl.expression.prev |
---|
Methods in com.espertech.esper.epl.expression.prev that return EventType | |
---|---|
EventType |
ExprPreviousNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprPreviousNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Uses of EventType in com.espertech.esper.epl.expression.subquery |
---|
Fields in com.espertech.esper.epl.expression.subquery declared as EventType | |
---|---|
protected EventType |
ExprSubselectNode.rawEventType
The event type generated for wildcard selects. |
Methods in com.espertech.esper.epl.expression.subquery that return EventType | |
---|---|
EventType |
ExprSubselectRowNode.SubselectMultirowType.getEventType()
|
EventType |
ExprSubselectRowNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectInNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectExistsNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectAllSomeAnyNode.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectRowNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectInNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectExistsNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectAllSomeAnyNode.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprSubselectNode.getRawEventType()
Returns the event type. |
Methods in com.espertech.esper.epl.expression.subquery with parameters of type EventType | |
---|---|
void |
ExprSubselectNode.setRawEventType(EventType rawEventType)
Sets the event type generated for wildcard selects. |
Uses of EventType in com.espertech.esper.epl.expression.table |
---|
Methods in com.espertech.esper.epl.expression.table that return EventType | |
---|---|
EventType |
ExprTableIdentNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprTableAccessNodeSubpropAccessor.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprTableAccessNodeSubprop.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprTableIdentNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprTableAccessNodeSubpropAccessor.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprTableAccessNodeSubprop.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Uses of EventType in com.espertech.esper.epl.join.base |
---|
Methods in com.espertech.esper.epl.join.base with parameters of type EventType | |
---|---|
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(java.lang.String statementName,
java.lang.String statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
java.lang.String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean queryPlanLogging,
StatementContext statementContext,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
boolean selectsRemoveStream,
boolean hasAggregations,
TableService tableService,
boolean isOnDemandQuery)
Builds join tuple composer. |
Constructors in com.espertech.esper.epl.join.base with parameters of type EventType | |
---|---|
HistoricalIndexLookupStrategyIndex(EventType eventType,
int lookupStream,
java.util.List<QueryGraphValueEntryHashKeyed> hashKeys)
Ctor. |
|
JoinSetComposerPrototypeHistorical2StreamImpl(ExprNode optionalFilterNode,
EventType[] streamTypes,
ExprEvaluatorContext exprEvaluatorContext,
int polledViewNum,
int streamViewNum,
boolean outerJoin,
ExprNode outerJoinEqualsNode,
Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> indexStrategies,
boolean allHistoricalNoSubordinate,
OuterJoinDesc[] outerJoinDescList)
|
|
JoinSetComposerPrototypeImpl(java.lang.String statementName,
java.lang.String statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
java.lang.String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
java.lang.annotation.Annotation[] annotations,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
QueryPlanIndex[] indexSpecs,
QueryPlan queryPlan,
HistoricalStreamIndexList[] historicalStreamIndexLists,
boolean joinRemoveStream,
boolean isOuterJoins,
TableService tableService)
|
Uses of EventType in com.espertech.esper.epl.join.exec.base |
---|
Methods in com.espertech.esper.epl.join.exec.base that return EventType | |
---|---|
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. |
Constructors in com.espertech.esper.epl.join.exec.base with parameters of type EventType | |
---|---|
CompositeTableLookupStrategy(EventType eventType,
int lookupStream,
java.util.List<QueryGraphValueEntryHashKeyed> hashKeys,
java.util.List<QueryGraphValueEntryRange> rangeKeyPairs,
PropertyCompositeEventTable index)
Ctor. |
|
IndexedTableLookupStrategy(EventType eventType,
java.lang.String[] properties,
PropertyIndexedEventTable index)
Ctor. |
|
IndexedTableLookupStrategySingle(EventType eventType,
java.lang.String property,
PropertyIndexedEventTableSingle index)
Ctor. |
Uses of EventType in com.espertech.esper.epl.join.exec.composite |
---|
Constructors in com.espertech.esper.epl.join.exec.composite with parameters of type EventType | |
---|---|
CompositeIndexEnterRemoveKeyed(EventType eventType,
java.lang.String[] keysProps,
java.lang.Class[] keyCoercionTypes)
|
|
CompositeIndexEnterRemoveRange(EventType eventType,
java.lang.String rangeProp,
java.lang.Class coercionType)
|
Uses of EventType in com.espertech.esper.epl.join.plan |
---|
Methods in com.espertech.esper.epl.join.plan with parameters of type EventType | |
---|---|
static QueryPlan |
TwoStreamQueryPlanBuilder.build(EventType[] typesPerStream,
QueryGraph queryGraph,
OuterJoinType optionalOuterJoinType,
java.lang.String[][][] uniqueIndexProps,
TableMetadata[] tablesPerStream)
Build query plan. |
protected static QueryPlan |
NStreamQueryPlanBuilder.build(QueryGraph queryGraph,
EventType[] typesPerStream,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
boolean hasForceNestedIter,
java.lang.String[][][] indexedStreamsUniqueProps,
TableMetadata[] tablesPerStream)
Build a query plan based on the stream property relationships indicated in queryGraph. |
protected static QueryPlan |
NStreamOuterQueryPlanBuilder.build(QueryGraph queryGraph,
OuterJoinDesc[] outerJoinDescList,
java.lang.String[] streamNames,
EventType[] typesPerStream,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.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,
java.lang.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 java.lang.Class |
CoercionUtil.getCoercionTypeRange(EventType indexedType,
java.lang.String indexedProp,
SubordPropRangeKey rangeKey)
|
static CoercionDesc |
CoercionUtil.getCoercionTypesHash(EventType[] typesPerStream,
int lookupStream,
int indexedStream,
java.util.List<QueryGraphValueEntryHashKeyed> keyProps,
java.lang.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,
java.lang.String[] indexProps,
java.util.List<SubordPropHashKey> hashKeys)
|
static CoercionDesc |
CoercionUtil.getCoercionTypesRange(EventType[] typesPerStream,
int indexedStream,
java.lang.String[] indexedProp,
java.util.List<QueryGraphValueEntryRange> rangeEntries)
|
static CoercionDesc |
CoercionUtil.getCoercionTypesRange(EventType viewableEventType,
java.util.Map<java.lang.String,SubordPropRangeKey> rangeProps,
EventType[] typesPerStream)
|
static CoercionDesc |
CoercionUtil.getCoercionTypesRange(EventType viewableEventType,
java.util.Map<java.lang.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,
java.lang.String[] streamNames,
HistoricalViewableDesc historicalViewableDesc,
DependencyGraph dependencyGraph,
HistoricalStreamIndexList[] historicalStreamIndexLists,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean isQueryPlanLogging,
java.lang.annotation.Annotation[] annotations,
ExprEvaluatorContext exprEvaluatorContext)
Build query plan using the filter. |
LookupInstructionExec |
LookupInstructionPlan.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal)
Constructs the executable from the plan. |
ExecNode |
TableOuterLookupNode.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
|
ExecNode |
TableLookupNode.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
|
ExecNode |
QueryPlanNodeNoOp.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
|
abstract ExecNode |
QueryPlanNode.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
Make execution node from this specification. |
ExecNode |
NestedIterationNode.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexList,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
|
ExecNode |
LookupInstructionQueryPlanNode.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
|
ExecNode |
HistoricalDataPlanNode.makeExec(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] streamTypes,
Viewable[] streamViews,
HistoricalStreamIndexList[] historicalStreamIndexLists,
VirtualDWView[] viewExternal,
java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
|
JoinExecTableLookupStrategy |
TableLookupPlan.makeStrategy(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] accessedByStmtAnnotations,
java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream,
EventType[] eventTypes,
VirtualDWView[] viewExternals)
Instantiates the lookup plan into a execution strategy for the lookup. |
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)
|
Uses of EventType in com.espertech.esper.epl.join.pollindex |
---|
Constructors in com.espertech.esper.epl.join.pollindex with parameters of type EventType | |
---|---|
PollResultIndexingStrategyComposite(int streamNum,
EventType eventType,
java.lang.String[] indexPropertiesJoin,
java.lang.Class[] keyCoercionTypes,
java.lang.String[] rangePropertiesJoin,
java.lang.Class[] rangeCoercionTypes)
Ctor. |
|
PollResultIndexingStrategyIndex(int streamNum,
EventType eventType,
java.lang.String[] propertyNames)
Ctor. |
|
PollResultIndexingStrategyIndexCoerce(int streamNum,
EventType eventType,
java.lang.String[] propertyNames,
java.lang.Class[] coercionTypes)
Ctor. |
|
PollResultIndexingStrategyIndexCoerceSingle(int streamNum,
EventType eventType,
java.lang.String propertyName,
java.lang.Class coercionType)
Ctor. |
|
PollResultIndexingStrategyIndexSingle(int streamNum,
EventType eventType,
java.lang.String propertyName)
Ctor. |
|
PollResultIndexingStrategyIndexSingleArray(int streamNum,
EventType eventType,
java.lang.String[] propertyNames)
Ctor. |
|
PollResultIndexingStrategySorted(int streamNum,
EventType eventType,
java.lang.String propertyName,
java.lang.Class coercionType)
Ctor. |
Uses of EventType in com.espertech.esper.epl.join.table |
---|
Methods in com.espertech.esper.epl.join.table with parameters of type EventType | |
---|---|
static EventTable |
EventTableUtil.buildIndex(int indexedStreamNum,
QueryPlanIndexItem item,
EventType eventType,
boolean coerceOnAddOnly,
boolean unique,
java.lang.String optionalIndexName)
Build an index/table instance using the event properties for the event type. |
Constructors in com.espertech.esper.epl.join.table with parameters of type EventType | |
---|---|
HistoricalStreamIndexList(int historicalStreamNum,
EventType[] typesPerStream,
QueryGraph queryGraph)
Ctor. |
|
PropertyCompositeEventTableFactory(int streamNum,
EventType eventType,
java.lang.String[] optionalKeyedProps,
java.lang.Class[] optKeyCoercedTypes,
java.lang.String[] rangeProps,
java.lang.Class[] optRangeCoercedTypes)
Ctor. |
|
PropertyIndexedEventTableCoerceAddFactory(int streamNum,
EventType eventType,
java.lang.String[] propertyNames,
java.lang.Class[] coercionType)
Ctor. |
|
PropertyIndexedEventTableCoerceAllFactory(int streamNum,
EventType eventType,
java.lang.String[] propertyNames,
java.lang.Class[] coercionType)
Ctor. |
|
PropertyIndexedEventTableFactory(int streamNum,
EventType eventType,
java.lang.String[] propertyNames,
boolean unique,
java.lang.String optionalIndexName)
Ctor. |
|
PropertyIndexedEventTableSingleArrayFactory(int streamNum,
EventType eventType,
java.lang.String[] propertyNames,
boolean unique,
java.lang.String optionalIndexName)
Ctor. |
|
PropertyIndexedEventTableSingleCoerceAddFactory(int streamNum,
EventType eventType,
java.lang.String propertyName,
java.lang.Class coercionType)
Ctor. |
|
PropertyIndexedEventTableSingleCoerceAllFactory(int streamNum,
EventType eventType,
java.lang.String propertyName,
java.lang.Class coercionType)
Ctor. |
|
PropertyIndexedEventTableSingleFactory(int streamNum,
EventType eventType,
java.lang.String propertyName,
boolean unique,
java.lang.String optionalIndexName)
Ctor. |
|
PropertySortedEventTableCoercedFactory(int streamNum,
EventType eventType,
java.lang.String propertyName,
java.lang.Class coercionType)
Ctor. |
|
PropertySortedEventTableFactory(int streamNum,
EventType eventType,
java.lang.String propertyName)
Ctor. |
Uses of EventType in com.espertech.esper.epl.lookup |
---|
Methods in com.espertech.esper.epl.lookup with parameters of type EventType | |
---|---|
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.addExplicitIndexOrReuse(boolean unique,
java.util.List<IndexedPropDesc> hashProps,
java.util.List<IndexedPropDesc> btreeProps,
java.lang.Iterable<EventBean> prefilledEvents,
EventType indexedType,
java.lang.String indexName)
|
static SubordTableLookupStrategyFactory |
SubordinateTableLookupStrategyUtil.getLookupStrategy(EventType[] outerStreamTypesZeroIndexed,
java.util.List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
java.util.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,
java.util.Set<java.lang.String> optionalUniqueKeyProps,
boolean onlyUseExistingIndexes,
java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations)
|
static SubordinateQueryPlanDesc |
SubordinateQueryPlanner.planSubquery(EventType[] outerStreams,
SubordPropPlan joinDesc,
boolean isNWOnTrigger,
boolean forceTableScan,
IndexHint optionalIndexHint,
boolean indexShare,
int subqueryNumber,
boolean isVirtualDataWindow,
EventTableIndexMetadata indexMetadata,
java.util.Set<java.lang.String> optionalUniqueKeyProps,
boolean onlyUseExistingIndexes,
java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations)
|
static EventTable[] |
SubordinateQueryPlannerUtil.realizeTables(SubordinateQueryIndexDesc[] indexDescriptors,
EventType eventType,
EventTableIndexRepository indexRepository,
java.lang.Iterable<EventBean> contents)
|
void |
EventTableIndexRepository.validateAddExplicitIndex(boolean unique,
java.lang.String indexName,
java.util.List<CreateIndexItem> columns,
EventType eventType,
java.lang.Iterable<EventBean> dataWindowContents)
|
static EventTableCreateIndexDesc |
EventTableIndexUtil.validateCompileExplicitIndex(boolean unique,
java.util.List<CreateIndexItem> columns,
EventType eventType)
|
Constructors in com.espertech.esper.epl.lookup with parameters of type EventType | |
---|---|
SubordIndexedTableLookupStrategyPropFactory(boolean isNWOnTrigger,
EventType[] eventTypes,
int[] keyStreamNumbers,
java.lang.String[] properties)
Ctor. |
|
SubordIndexedTableLookupStrategySinglePropFactory(boolean isNWOnTrigger,
EventType[] eventTypes,
int keyStreamNum,
java.lang.String property)
Ctor. |
|
SubordTableLookupStrategyFactoryVDW(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] annotations,
EventType[] outerStreams,
java.util.List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
java.util.List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
boolean nwOnTrigger,
SubordPropPlan joinDesc,
boolean forceTableScan,
SubordinateQueryPlannerIndexPropListPair hashAndRanges)
|
Uses of EventType in com.espertech.esper.epl.named |
---|
Fields in com.espertech.esper.epl.named declared as EventType | |
---|---|
protected EventType |
NamedWindowOnExprBaseViewFactory.namedWindowEventType
|
Methods in com.espertech.esper.epl.named that return EventType | |
---|---|
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. |
Methods in com.espertech.esper.epl.named with parameters of type EventType | |
---|---|
NamedWindowProcessor |
NamedWindowServiceImpl.addProcessor(java.lang.String name,
java.lang.String contextName,
boolean singleInstanceContext,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
java.lang.String eplExpression,
java.lang.String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
StatementMetricHandle statementMetricHandle,
java.util.Set<java.lang.String> optionalUniqueKeyProps,
java.lang.String eventTypeAsName)
|
NamedWindowProcessor |
NamedWindowService.addProcessor(java.lang.String name,
java.lang.String contextName,
boolean singleInstanceContext,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
java.lang.String eplExpression,
java.lang.String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
StatementMetricHandle statementMetricHandle,
java.util.Set<java.lang.String> optionalUniqueKeyProps,
java.lang.String eventTypeAsName)
Create a new named window. |
static NamedWindowOnExprFactory |
NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType,
java.lang.String namedWindowName,
java.lang.String namedWindowAlias,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
java.lang.String filterStreamName,
boolean addToFront,
InternalEventRouter internalEventRouter,
EventType outputEventType,
StatementContext statementContext,
StatementMetricHandle createNamedWindowMetricsHandle,
boolean isDistinct,
StreamSelector optionalStreamSelector,
java.lang.String optionalInsertIntoTableName)
|
Constructors in com.espertech.esper.epl.named with parameters of type EventType | |
---|---|
NamedWindowConsumerView(ExprEvaluator[] filterList,
PropertyEvaluator optPropertyEvaluator,
EventType eventType,
NamedWindowConsumerCallback consumerCallback,
ExprEvaluatorContext exprEvaluatorContext,
boolean audit)
Ctor. |
|
NamedWindowOnDeleteViewFactory(EventType namedWindowEventType,
StatementResultService statementResultService)
|
|
NamedWindowOnExprBaseViewFactory(EventType namedWindowEventType)
|
|
NamedWindowOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
java.lang.String triggeringStreamName,
InternalEventRouter internalEventRouter,
java.lang.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,
java.lang.String optionalInsertIntoTableName)
|
|
NamedWindowOnUpdateViewFactory(EventType namedWindowEventType,
StatementResultService statementResultService,
EventBeanUpdateHelper updateHelper)
|
|
NamedWindowProcessor(java.lang.String namedWindowName,
NamedWindowService namedWindowService,
java.lang.String contextName,
boolean singleInstanceContext,
EventType eventType,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
java.lang.String eplExpression,
java.lang.String statementName,
boolean isPrioritized,
boolean isEnableSubqueryIndexShare,
boolean enableQueryPlanLog,
MetricReportingService metricReportingService,
boolean isBatchingDataWindow,
boolean isVirtualDataWindow,
StatementMetricHandle statementMetricHandle,
java.util.Set<java.lang.String> optionalUniqueKeyProps,
java.lang.String eventTypeAsName)
Ctor. |
|
NamedWindowRootView(ValueAddEventProcessor revisionProcessor,
boolean queryPlanLogging,
MetricReportingService metricReportingService,
EventType eventType,
boolean childBatching,
boolean isEnableIndexShare,
java.util.Set<java.lang.String> optionalUniqueKeyProps)
|
|
NamedWindowTailView(EventType eventType,
NamedWindowService namedWindowService,
StatementResultService statementResultService,
ValueAddEventProcessor revisionProcessor,
boolean prioritized,
boolean parentBatchWindow)
|
Uses of EventType in com.espertech.esper.epl.property |
---|
Methods in com.espertech.esper.epl.property that return EventType | |
---|---|
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. |
Methods in com.espertech.esper.epl.property with parameters of type EventType | |
---|---|
static PropertyEvaluator |
PropertyEvaluatorFactory.makeEvaluator(PropertyEvalSpec spec,
EventType sourceEventType,
java.lang.String optionalSourceStreamName,
EventAdapterService eventAdapterService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
java.lang.String engineURI,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
ConfigurationInformation configuration,
NamedWindowService namedWindowService)
Makes the property evaluator. |
Uses of EventType in com.espertech.esper.epl.rettype |
---|
Methods in com.espertech.esper.epl.rettype that return EventType | |
---|---|
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)
|
Methods in com.espertech.esper.epl.rettype with parameters of type EventType | |
---|---|
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. |
Constructors in com.espertech.esper.epl.rettype with parameters of type EventType | |
---|---|
EventEPType(EventType type)
|
|
EventMultiValuedEPType(java.lang.Class container,
EventType component)
|
Uses of EventType in com.espertech.esper.epl.script |
---|
Methods in com.espertech.esper.epl.script that return EventType | |
---|---|
EventType |
ExprNodeScriptEvalBase.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprNodeScriptEvalBase.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Uses of EventType in com.espertech.esper.epl.spec |
---|
Methods in com.espertech.esper.epl.spec that return EventType | |
---|---|
static EventType |
FilterStreamSpecRaw.resolveType(java.lang.String engineURI,
java.lang.String eventName,
EventAdapterService eventAdapterService,
java.net.URI[] optionalResolutionURIs)
Resolves a given event name to an event type. |
Methods in com.espertech.esper.epl.spec that return types with arguments of type EventType | |
---|---|
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
PatternStreamSpecCompiled.getArrayEventTypes()
Returns event types tagged in the pattern expression under a repeat-operator. |
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
MatchEventSpec.getArrayEventTypes()
|
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
PatternStreamSpecCompiled.getTaggedEventTypes()
Returns event types tagged in the pattern expression. |
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
MatchEventSpec.getTaggedEventTypes()
|
Constructor parameters in com.espertech.esper.epl.spec with type arguments of type EventType | |
---|---|
MatchEventSpec(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
|
|
MatchEventSpec(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
|
|
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
java.util.LinkedHashSet<java.lang.String> allTags,
ViewSpec[] viewSpecs,
java.lang.String optionalStreamName,
StreamSpecOptions streamSpecOptions,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch)
Ctor. |
|
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
java.util.LinkedHashSet<java.lang.String> allTags,
ViewSpec[] viewSpecs,
java.lang.String optionalStreamName,
StreamSpecOptions streamSpecOptions,
boolean suppressSameEventMatches,
boolean discardPartialsOnMatch)
Ctor. |
Uses of EventType in com.espertech.esper.epl.subquery |
---|
Methods in com.espertech.esper.epl.subquery that return EventType | |
---|---|
EventType |
SubselectAggregatorViewBase.getEventType()
|
Uses of EventType in com.espertech.esper.epl.table.merge |
---|
Constructors in com.espertech.esper.epl.table.merge with parameters of type EventType | |
---|---|
TableOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
java.lang.String triggeringStreamName,
InternalEventRouter internalEventRouter,
TableMetadata tableMetadata)
|
Uses of EventType in com.espertech.esper.epl.table.mgmt |
---|
Methods in com.espertech.esper.epl.table.mgmt that return EventType | |
---|---|
EventType |
TableStateViewablePublic.getEventType()
|
EventType |
TableStateViewableInternal.getEventType()
|
EventType |
TableColumnDescAgg.getOptionalAssociatedType()
|
EventType |
TableMetadataColumnAggregation.getOptionalEventType()
|
EventType |
TableMetadata.getPublicEventType()
|
Methods in com.espertech.esper.epl.table.mgmt with parameters of type EventType | |
---|---|
TableMetadata |
TableServiceImpl.getTableMetadataFromEventType(EventType type)
|
TableMetadata |
TableService.getTableMetadataFromEventType(EventType type)
|
static java.lang.String |
TableServiceUtil.getTableNameFromEventType(EventType type)
|
Constructors in com.espertech.esper.epl.table.mgmt with parameters of type EventType | |
---|---|
TableColumnDescAgg(int positionInDeclaration,
java.lang.String columnName,
ExprAggregateNode aggregation,
EventType optionalAssociatedType)
|
|
TableMetadataColumnAggregation(java.lang.String columnName,
AggregationMethodFactory factory,
int methodOffset,
AggregationAccessorSlotPair accessAccessorSlotPair,
EPType optionalEnumerationType,
EventType optionalEventType)
|
Uses of EventType in com.espertech.esper.epl.table.onaction |
---|
Methods in com.espertech.esper.epl.table.onaction that return EventType | |
---|---|
EventType |
TableOnViewBase.getEventType()
|
EventType |
TableOnSelectView.getEventType()
|
EventType |
TableOnDeleteView.getEventType()
|
Methods in com.espertech.esper.epl.table.onaction with parameters of type EventType | |
---|---|
static TableOnViewFactory |
TableOnViewFactoryFactory.make(TableMetadata tableMetadata,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
java.lang.String filterStreamName,
StatementContext statementContext,
StatementMetricHandle metricsHandle,
boolean isDistinct,
InternalEventRouter internalEventRouter)
|
Uses of EventType in com.espertech.esper.epl.table.strategy |
---|
Methods in com.espertech.esper.epl.table.strategy that return EventType | |
---|---|
EventType |
ExprTableExprEvaluatorAccess.getEventTypeCollection(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
EventType |
ExprTableExprEvaluatorAccess.getEventTypeSingle(EventAdapterService eventAdapterService,
java.lang.String statementId)
|
Constructors in com.espertech.esper.epl.table.strategy with parameters of type EventType | |
---|---|
ExprTableExprEvaluatorAccess(ExprNode exprNode,
java.lang.String tableName,
java.lang.String subpropName,
int streamNum,
java.lang.Class returnType,
AggregationAccessorSlotPair accessAccessorSlotPair,
EventType eventTypeColl)
|
Uses of EventType in com.espertech.esper.epl.updatehelper |
---|
Methods in com.espertech.esper.epl.updatehelper with parameters of type EventType | |
---|---|
static EventBeanUpdateHelper |
EventBeanUpdateHelperFactory.make(java.lang.String updatedWindowOrTableName,
EventTypeSPI eventTypeSPI,
java.util.List<OnTriggerSetAssignment> assignments,
java.lang.String updatedAlias,
EventType optionalTriggeringEventType,
boolean isCopyOnWrite)
|
Uses of EventType in com.espertech.esper.epl.variable |
---|
Methods in com.espertech.esper.epl.variable that return EventType | |
---|---|
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(java.lang.String statementId,
EventAdapterService eventAdapterService,
VariableMetaData variableMetaData)
|
Methods in com.espertech.esper.epl.variable with parameters of type EventType | |
---|---|
Pair<java.lang.Boolean,java.lang.Object> |
VariableStateHandler.getHasState(java.lang.String variableName,
int variableNumber,
int agentInstanceId,
java.lang.Class type,
EventType eventType,
StatementExtensionSvcContext statementExtContext)
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 |
Constructors in com.espertech.esper.epl.variable with parameters of type EventType | |
---|---|
VariableMetaData(java.lang.String variableName,
java.lang.String contextPartitionName,
int variableNumber,
java.lang.Class type,
EventType eventType,
boolean constant,
VariableStateFactory variableStateFactory)
|
Uses of EventType in com.espertech.esper.epl.view |
---|
Methods in com.espertech.esper.epl.view that return EventType | |
---|---|
static EventType |
OutputConditionExpressionFactory.getBuiltInEventType(EventAdapterService eventAdapterService)
Build the event type for built-in properties. |
EventType |
OutputConditionExpressionFactory.getBuiltinPropertiesEventType()
|
EventType |
OutputProcessViewBase.getEventType()
|
EventType |
FilterExprView.getEventType()
|
Methods in com.espertech.esper.epl.view with parameters of type EventType | |
---|---|
static OutputProcessViewFactory |
OutputProcessViewFactoryFactory.make(StatementSpecCompiled statementSpec,
InternalEventRouter internalEventRouter,
StatementContext statementContext,
EventType resultEventType,
OutputProcessViewCallback optionalOutputProcessViewCallback,
TableService tableService)
|
Constructors in com.espertech.esper.epl.view with parameters of type EventType | |
---|---|
OutputProcessViewConditionFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
java.lang.Integer afterConditionNumberOfEvents,
EventType resultEventType,
OutputConditionFactory outputConditionFactory,
int streamCount,
OutputProcessViewConditionFactory.ConditionType conditionType,
OutputLimitLimitType outputLimitLimitType,
boolean terminable)
|
|
OutputProcessViewDirectDistinctOrAfterFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
java.lang.Integer afterConditionNumberOfEvents,
EventType resultEventType)
|
Uses of EventType in com.espertech.esper.epl.virtualdw |
---|
Methods in com.espertech.esper.epl.virtualdw that return EventType | |
---|---|
EventType |
VirtualDWViewImpl.getEventType()
|
EventType |
VirtualDWViewFactoryImpl.getEventType()
|
EventType[] |
VirtualDataWindowLookupContextSPI.getOuterTypePerStream()
|
Methods in com.espertech.esper.epl.virtualdw with parameters of type EventType | |
---|---|
void |
VirtualDWViewFactoryImpl.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
SubordTableLookupStrategy |
VirtualDWViewImpl.getSubordinateLookupStrategy(java.lang.String accessedByStatementName,
java.lang.String accessedByStatementId,
java.lang.annotation.Annotation[] accessedByStmtAnnotations,
EventType[] outerStreamTypes,
java.util.List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
java.util.List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
boolean nwOnTrigger,
EventTable eventTable,
SubordPropPlan joinDesc,
boolean forceTableScan)
|
SubordTableLookupStrategy |
VirtualDWView.getSubordinateLookupStrategy(java.lang.String accessedByStatementName,
java.lang.String accessedByStatementId,
java.lang.annotation.Annotation[] accessedByStmtAnnotations,
EventType[] outerStreamTypes,
java.util.List<SubordPropHashKey> hashKeys,
CoercionDesc hashKeyCoercionTypes,
java.util.List<SubordPropRangeKey> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
boolean nwOnTrigger,
EventTable eventTable,
SubordPropPlan joinDesc,
boolean forceTableScan)
|
Constructors in com.espertech.esper.epl.virtualdw with parameters of type EventType | |
---|---|
VirtualDataWindowLookupContextSPI(java.lang.String statementName,
java.lang.String statementId,
java.lang.annotation.Annotation[] statementAnnotations,
boolean fireAndForget,
java.lang.String namedWindowName,
java.util.List<VirtualDataWindowLookupFieldDesc> hashFields,
java.util.List<VirtualDataWindowLookupFieldDesc> btreeFields,
SubordPropPlan joinDesc,
boolean forceTableScan,
EventType[] outerTypePerStream,
java.lang.String accessedByStatementName,
int accessedByStatementSequenceNum)
|
|
VirtualDWViewImpl(VirtualDataWindow dataExternal,
EventType eventType,
java.lang.String namedWindowName)
|
Uses of EventType in com.espertech.esper.event |
---|
Subinterfaces of EventType in com.espertech.esper.event | |
---|---|
interface |
EventTypeSPI
Service provider interface for internal use for event types. |
Classes in com.espertech.esper.event that implement EventType | |
---|---|
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. |
Fields in com.espertech.esper.event declared as EventType | |
---|---|
protected EventType[] |
BaseNestableEventType.optionalSuperTypes
|
protected EventType |
WrapperEventType.underlyingEventType
The underlying wrapped event type. |
Fields in com.espertech.esper.event with type parameters of type EventType | |
---|---|
protected java.util.Set<EventType> |
BaseNestableEventType.optionalDeepSupertypes
|
Methods in com.espertech.esper.event that return EventType | |
---|---|
EventType |
EventAdapterServiceImpl.addBeanType(java.lang.String eventTypeName,
java.lang.Class clazz,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured)
|
EventType |
EventAdapterService.addBeanType(java.lang.String eventTypeName,
java.lang.Class clazz,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured)
Add an event type with the given name and Java class. |
EventType |
EventAdapterServiceImpl.addBeanType(java.lang.String eventTypeName,
java.lang.String fullyQualClassName,
boolean considerAutoName,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured)
Add an event type for the given Java class name. |
EventType |
EventAdapterService.addBeanType(java.lang.String eventTypeName,
java.lang.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(java.lang.String eventTypeName,
java.lang.Class clazz,
boolean isNamedWindow)
|
EventType |
EventAdapterService.addBeanTypeByName(java.lang.String eventTypeName,
java.lang.Class clazz,
boolean isNamedWindow)
|
EventType |
EventAdapterServiceImpl.addNestableMapType(java.lang.String eventTypeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
ConfigurationEventTypeMap optionalConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto)
|
EventType |
EventAdapterService.addNestableMapType(java.lang.String eventTypeName,
java.util.Map<java.lang.String,java.lang.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(java.lang.String eventTypeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
ConfigurationEventTypeObjectArray optionalConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto,
boolean table,
java.lang.String tableName)
|
EventType |
EventAdapterService.addNestableObjectArrayType(java.lang.String eventTypeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
ConfigurationEventTypeObjectArray typeConfig,
boolean isPreconfiguredStatic,
boolean isPreconfigured,
boolean isConfigured,
boolean namedWindow,
boolean insertInto,
boolean table,
java.lang.String tableName)
|
EventType |
EventAdapterServiceImpl.addPlugInEventType(java.lang.String eventTypeName,
java.net.URI[] resolutionURIs,
java.io.Serializable initializer)
|
EventType |
EventAdapterService.addPlugInEventType(java.lang.String name,
java.net.URI[] resolutionURIs,
java.io.Serializable initializer)
Adds a plug-in event type. |
EventType |
EventAdapterServiceAnonymousTypeCache.addReturnExistingAnonymousType(EventType requiredType)
|
EventType |
EventAdapterServiceImpl.addWrapperType(java.lang.String eventTypeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
boolean isNamedWindow,
boolean isInsertInto)
|
EventType |
EventAdapterService.addWrapperType(java.lang.String eventTypeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.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(java.lang.String eventTypeName,
ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM,
SchemaModel optionalSchemaModel,
boolean isPreconfiguredStatic)
Add a configured XML DOM event type. |
EventType |
EventAdapterService.addXMLDOMType(java.lang.String eventTypeName,
ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM,
SchemaModel optionalSchemaModel,
boolean isPreconfiguredStatic)
Adds an XML DOM event type. |
EventType |
EventAdapterServiceImpl.createAnonymousBeanType(java.lang.String eventTypeName,
java.lang.Class clazz)
|
EventType |
EventAdapterService.createAnonymousBeanType(java.lang.String schemaName,
java.lang.Class clazz)
|
EventType |
EventAdapterServiceImpl.createAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes)
|
EventType |
EventAdapterService.createAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes)
Creates a new anonymous EventType instance for an event type that contains a map of name value pairs. |
EventType |
EventAdapterServiceImpl.createAnonymousObjectArrayType(java.lang.String typeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes)
|
EventType |
EventAdapterService.createAnonymousObjectArrayType(java.lang.String typeName,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes)
|
EventType |
EventAdapterServiceImpl.createAnonymousWrapperType(java.lang.String typeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes)
|
EventType |
EventAdapterService.createAnonymousWrapperType(java.lang.String typeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.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,
java.lang.annotation.Annotation[] annotations,
ConfigurationInformation configSnapshot,
EventAdapterService eventAdapterService,
EngineImportService engineImportService)
|
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
boolean isUsedByChildViews)
|
EventType |
EventAdapterService.createSemiAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.Map<java.lang.String,Pair<EventType,java.lang.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(java.lang.String eventTypeName)
|
EventType |
EventAdapterService.getExistsTypeByName(java.lang.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(java.lang.String xmlEventTypeName,
ConfigurationEventTypeXMLDOM config,
SchemaModel schemaModel)
|
EventType |
EventAdapterService.replaceXMLEventType(java.lang.String xmlEventTypeName,
ConfigurationEventTypeXMLDOM config,
SchemaModel schemaModel)
|
Methods in com.espertech.esper.event that return types with arguments of type EventType | |
---|---|
java.util.Map<java.lang.String,EventType> |
EventAdapterServiceImpl.getDeclaredEventTypes()
|
java.util.Map<java.lang.String,EventType> |
EventAdapterService.getDeclaredEventTypes()
|
java.util.Iterator<EventType> |
WrapperEventType.getDeepSuperTypes()
|
java.util.Iterator<EventType> |
BaseNestableEventType.getDeepSuperTypes()
|
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> |
TaggedCompositeEventType.getTaggedEventTypes()
Returns the event types for each composing event. |
Methods in com.espertech.esper.event with parameters of type EventType | |
---|---|
EventBean |
EventAdapterServiceImpl.adapterForType(java.lang.Object theEvent,
EventType eventType)
|
EventBean |
EventAdapterService.adapterForType(java.lang.Object theEvent,
EventType eventType)
Returns an adapter for an event underlying object when the event type is known. |
static EventBean |
EventAdapterServiceHelper.adapterForType(java.lang.Object theEvent,
EventType eventType,
EventAdapterService eventAdapterService)
Return an adapter for the given type of event using the pre-validated object. |
EventBean |
EventAdapterServiceImpl.adapterForTypedBean(java.lang.Object bean,
EventType eventType)
|
EventBean |
EventAdapterService.adapterForTypedBean(java.lang.Object bean,
EventType eventType)
Creates a thin adaper for an event object given an event type. |
EventBean |
EventAdapterServiceImpl.adapterForTypedDOM(org.w3c.dom.Node node,
EventType eventType)
|
EventBean |
EventAdapterService.adapterForTypedDOM(org.w3c.dom.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(java.util.Map<java.lang.String,java.lang.Object> properties,
EventType eventType)
|
EventBean |
EventAdapterService.adapterForTypedMap(java.util.Map<java.lang.String,java.lang.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(java.lang.Object[] properties,
EventType eventType)
|
EventBean |
EventAdapterService.adapterForTypedObjectArray(java.lang.Object[] props,
EventType resultEventType)
|
EventBean |
EventAdapterServiceImpl.adapterForTypedWrapper(EventBean theEvent,
java.util.Map<java.lang.String,java.lang.Object> properties,
EventType eventType)
|
EventBean |
EventAdapterService.adapterForTypedWrapper(EventBean theEvent,
java.util.Map<java.lang.String,java.lang.Object> properties,
EventType eventType)
Creata a wrapper around an event and some additional properties |
EventType |
EventAdapterServiceAnonymousTypeCache.addReturnExistingAnonymousType(EventType requiredType)
|
void |
EventAdapterServiceImpl.addTypeByName(java.lang.String name,
EventType eventType)
|
void |
EventAdapterService.addTypeByName(java.lang.String name,
EventType eventType)
Adds an event type to the registery available for use, and originating outside as a non-adapter. |
EventType |
EventAdapterServiceImpl.addWrapperType(java.lang.String eventTypeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
boolean isNamedWindow,
boolean isInsertInto)
|
EventType |
EventAdapterService.addWrapperType(java.lang.String eventTypeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.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(java.lang.String typeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes)
|
EventType |
EventAdapterService.createAnonymousWrapperType(java.lang.String typeName,
EventType underlyingEventType,
java.util.Map<java.lang.String,java.lang.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,
java.lang.String property)
|
static EventPropertyGetter |
EventBeanUtility.getAssertPropertyGetter(EventType type,
java.lang.String propertyName)
|
java.lang.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)
|
static java.lang.Object |
BaseNestableEventUtil.getFragmentArray(EventAdapterService eventAdapterService,
java.lang.Object value,
EventType fragmentEventType)
|
static EventBean |
BaseNestableEventUtil.getFragmentNonPojo(EventAdapterService eventAdapterService,
java.lang.Object fragmentUnderlying,
EventType fragmentEventType)
|
EventPropertyGetter |
EventTypeNestableGetterFactory.getGetterBeanNested(java.lang.String name,
EventType eventType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactory.getGetterBeanNestedArray(java.lang.String name,
EventType eventType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactory.getGetterEventBeanArray(java.lang.String name,
EventType eventType)
|
EventPropertyGetter |
EventTypeNestableGetterFactory.getGetterIndexedUnderlyingArray(java.lang.String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType innerType)
|
EventPropertyGetter |
EventTypeNestableGetterFactory.getGetterNestedEntryBean(java.lang.String propertyName,
EventPropertyGetter innerGetter,
EventType innerType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactory.getGetterNestedEntryBeanArray(java.lang.String propertyNameAtomic,
int index,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService)
|
static EventBeanManufacturer |
EventAdapterServiceHelper.getManufacturer(EventAdapterService eventAdapterService,
EventType eventType,
WriteablePropertyDescriptor[] properties,
EngineImportService engineImportService,
boolean allowAnyType)
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 PropertySetDescriptor |
EventTypeUtility.getNestableProperties(java.util.Map<java.lang.String,java.lang.Object> propertiesToAdd,
EventAdapterService eventAdapterService,
EventTypeNestableGetterFactory factory,
EventType[] optionalSuperTypes)
|
static EventPropertyDescriptor |
EventTypeUtility.getNestablePropertyDescriptor(EventType target,
java.util.Deque<Property> stack)
|
static EventPropertyDescriptor |
EventTypeUtility.getNestablePropertyDescriptor(EventType target,
java.lang.String propertyName)
|
EventBeanSPI |
EventAdapterServiceImpl.getShellForType(EventType eventType)
|
static EventBeanSPI |
EventAdapterServiceHelper.getShellForType(EventType eventType)
|
EventBeanSPI |
EventAdapterService.getShellForType(EventType eventType)
|
java.util.Set<WriteablePropertyDescriptor> |
EventAdapterServiceImpl.getWriteableProperties(EventType eventType,
boolean allowAnyType)
|
static java.util.Set<WriteablePropertyDescriptor> |
EventAdapterServiceHelper.getWriteableProperties(EventType eventType,
boolean allowAnyType)
Returns descriptors for all writable properties. |
java.util.Set<WriteablePropertyDescriptor> |
EventAdapterService.getWriteableProperties(EventType eventType,
boolean allowAnyType)
Returns descriptors for all writable properties. |
static java.lang.Object |
BaseNestableEventUtil.handleCreateFragmentMap(java.lang.Object value,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
|
static java.lang.Object |
BaseNestableEventUtil.handleCreateFragmentObjectArray(java.lang.Object value,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
|
static java.lang.Object |
BaseNestableEventUtil.handleNestedValueArrayWithMapFragment(java.lang.Object value,
int index,
MapEventPropertyGetter getter,
EventAdapterService eventAdapterService,
EventType fragmentType)
|
static java.lang.Object |
BaseNestableEventUtil.handleNestedValueArrayWithObjectArrayFragment(java.lang.Object value,
int index,
ObjectArrayEventPropertyGetter getter,
EventType fragmentType,
EventAdapterService eventAdapterService)
|
static java.lang.String |
EventAdapterServiceImpl.isCompatibleWrapper(EventType existingType,
EventType underlyingType,
java.util.Map<java.lang.String,java.lang.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(java.lang.String typeName,
EventType sameTypeOrSubtype)
|
EventBean[] |
EventAdapterServiceImpl.typeCast(java.util.List<EventBean> events,
EventType targetType)
|
EventBean[] |
EventAdapterService.typeCast(java.util.List<EventBean> events,
EventType targetType)
Casts event type of a list of events to either Wrapper or Map type. |
static EventBean[] |
EventAdapterServiceHelper.typeCast(java.util.List<EventBean> events,
EventType targetType,
EventAdapterService eventAdapterService)
|
static EventTypeUtility.TimestampPropertyDesc |
EventTypeUtility.validatedDetermineTimestampProps(EventType type,
java.lang.String startProposed,
java.lang.String endProposed,
EventType[] superTypes)
|
static EventTypeUtility.TimestampPropertyDesc |
EventTypeUtility.validatedDetermineTimestampProps(EventType type,
java.lang.String startProposed,
java.lang.String endProposed,
EventType[] superTypes)
|
static void |
EventTypeUtility.validateTimestampProperties(EventType eventType,
java.lang.String startTimestampProperty,
java.lang.String endTimestampProperty)
|
Method parameters in com.espertech.esper.event with type arguments of type EventType | |
---|---|
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
boolean isUsedByChildViews)
|
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
boolean isUsedByChildViews)
|
EventType |
EventAdapterService.createSemiAnonymousMapType(java.lang.String typeName,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.Map<java.lang.String,Pair<EventType,java.lang.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(java.lang.String typeName,
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.Map<java.lang.String,Pair<EventType,java.lang.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. |
Constructors in com.espertech.esper.event with parameters of type EventType | |
---|---|
BaseNestableEventType(EventTypeMetadata metadata,
java.lang.String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
EventType[] optionalSuperTypes,
java.util.Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeWithSupertype typeConfig,
EventTypeNestableGetterFactory getterFactory)
Constructor takes a type name, map of property names and types, for use with nestable Map events. |
|
EventAdapterServiceHelper.EventBeanAdapterFactoryBean(EventType eventType)
|
|
EventAdapterServiceHelper.EventBeanAdapterFactoryMap(EventType eventType)
|
|
EventAdapterServiceHelper.EventBeanAdapterFactoryObjectArray(EventType eventType)
|
|
EventAdapterServiceHelper.EventBeanAdapterFactoryXml(EventType eventType)
|
|
EventBeanFactoryBean(EventType type,
EventAdapterService eventAdapterService)
|
|
EventBeanFactoryBeanWrapped(EventType beanEventType,
EventType wrapperEventType,
EventAdapterService eventAdapterService)
|
|
EventBeanFactoryMap(EventType type,
EventAdapterService eventAdapterService)
|
|
EventBeanFactoryObjectArray(EventType type,
EventAdapterService eventAdapterService)
|
|
EventBeanFactoryXML(EventType type,
EventAdapterService eventAdapterService)
|
|
EventBeanReaderDefaultImpl(EventType eventType)
Ctor. |
|
NaturalEventBean(EventType eventBeanType,
java.lang.Object[] natural,
EventBean optionalSynthetic)
Ctor. |
|
WrapperEventBean(EventBean theEvent,
java.util.Map<java.lang.String,java.lang.Object> properties,
EventType eventType)
Ctor. |
|
WrapperEventType(EventTypeMetadata metadata,
java.lang.String typeName,
int eventTypeId,
EventType eventType,
java.util.Map<java.lang.String,java.lang.Object> properties,
EventAdapterService eventAdapterService)
Ctor. |
Constructor parameters in com.espertech.esper.event with type arguments of type EventType | |
---|---|
BaseNestableEventType(EventTypeMetadata metadata,
java.lang.String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
EventType[] optionalSuperTypes,
java.util.Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeWithSupertype typeConfig,
EventTypeNestableGetterFactory getterFactory)
Constructor takes a type name, map of property names and types, for use with nestable Map events. |
Uses of EventType in com.espertech.esper.event.arr |
---|
Classes in com.espertech.esper.event.arr that implement EventType | |
---|---|
class |
ObjectArrayEventType
|
Fields in com.espertech.esper.event.arr declared as EventType | |
---|---|
protected EventType |
ObjectArrayPropertyGetterDefaultBase.fragmentEventType
|
protected EventType |
ObjectArrayNestedEntryPropertyGetterBase.fragmentType
|
Methods in com.espertech.esper.event.arr that return EventType | |
---|---|
EventType |
ObjectArrayEventBean.getEventType()
|
Methods in com.espertech.esper.event.arr with parameters of type EventType | |
---|---|
EventPropertyGetter |
EventTypeNestableGetterFactoryObjectArray.getGetterBeanNested(java.lang.String name,
EventType eventType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryObjectArray.getGetterBeanNestedArray(java.lang.String name,
EventType eventType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryObjectArray.getGetterEventBeanArray(java.lang.String name,
EventType eventType)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryObjectArray.getGetterIndexedUnderlyingArray(java.lang.String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType innerType)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryObjectArray.getGetterNestedEntryBean(java.lang.String propertyName,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryObjectArray.getGetterNestedEntryBeanArray(java.lang.String propertyNameAtomic,
int index,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService)
|
void |
ObjectArrayEventBean.setEventType(EventType eventType)
|
Constructors in com.espertech.esper.event.arr with parameters of type EventType | |
---|---|
ObjectArrayArrayPropertyGetter(int propertyIndex,
int index,
EventAdapterService eventAdapterService,
EventType fragmentType)
Ctor. |
|
ObjectArrayEventBean(java.lang.Object[] propertyValues,
EventType eventType)
|
|
ObjectArrayEventType(EventTypeMetadata metadata,
java.lang.String eventTypeName,
int eventTypeId,
EventAdapterService eventAdapterService,
java.util.Map<java.lang.String,java.lang.Object> properyTypes,
ConfigurationEventTypeObjectArray typeDef,
EventType[] optionalSuperTypes,
java.util.Set<EventType> optionalDeepSupertypes)
|
|
ObjectArrayFragmentArrayPropertyGetter(int propertyIndex,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
Ctor. |
|
ObjectArrayNestedEntryPropertyGetterArrayMap(int propertyIndex,
EventType fragmentType,
EventAdapterService eventAdapterService,
int index,
MapEventPropertyGetter getter)
|
|
ObjectArrayNestedEntryPropertyGetterArrayObjectArray(int propertyIndex,
EventType fragmentType,
EventAdapterService eventAdapterService,
int index,
ObjectArrayEventPropertyGetter getter)
|
|
ObjectArrayNestedEntryPropertyGetterBase(int propertyIndex,
EventType fragmentType,
EventAdapterService eventAdapterService)
Ctor. |
|
ObjectArrayNestedEntryPropertyGetterMap(int propertyIndex,
EventType fragmentType,
EventAdapterService eventAdapterService,
MapEventPropertyGetter mapGetter)
|
|
ObjectArrayNestedEntryPropertyGetterObjectArray(int propertyIndex,
EventType fragmentType,
EventAdapterService eventAdapterService,
ObjectArrayEventPropertyGetter arrayGetter)
|
|
ObjectArrayPropertyGetterDefaultBase(int propertyIndex,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
Ctor. |
|
ObjectArrayPropertyGetterDefaultMap(int propertyIndex,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
|
|
ObjectArrayPropertyGetterDefaultObjectArray(int propertyIndex,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
|
Constructor parameters in com.espertech.esper.event.arr with type arguments of type EventType | |
---|---|
ObjectArrayEventType(EventTypeMetadata metadata,
java.lang.String eventTypeName,
int eventTypeId,
EventAdapterService eventAdapterService,
java.util.Map<java.lang.String,java.lang.Object> properyTypes,
ConfigurationEventTypeObjectArray typeDef,
EventType[] optionalSuperTypes,
java.util.Set<EventType> optionalDeepSupertypes)
|
Uses of EventType in com.espertech.esper.event.bean |
---|
Classes in com.espertech.esper.event.bean that implement EventType | |
---|---|
class |
BeanEventType
Implementation of the EventType interface for handling JavaBean-type classes. |
Methods in com.espertech.esper.event.bean that return EventType | |
---|---|
EventType |
BeanEventBean.getEventType()
|
EventType[] |
BeanEventType.getSuperTypes()
|
Methods in com.espertech.esper.event.bean that return types with arguments of type EventType | |
---|---|
java.util.Iterator<EventType> |
BeanEventType.getDeepSuperTypes()
|
Methods in com.espertech.esper.event.bean with parameters of type EventType | |
---|---|
boolean |
BeanEventType.equalsCompareType(EventType eventType)
|
Constructors in com.espertech.esper.event.bean with parameters of type EventType | |
---|---|
BeanEventBean(java.lang.Object theEvent,
EventType eventType)
Constructor. |
Uses of EventType in com.espertech.esper.event.map |
---|
Classes in com.espertech.esper.event.map that implement EventType | |
---|---|
class |
MapEventType
Implementation of the EventType interface for handling plain Maps containing name value pairs. |
Fields in com.espertech.esper.event.map declared as EventType | |
---|---|
protected EventType |
MapPropertyGetterDefaultBase.fragmentEventType
|
protected EventType |
MapNestedEntryPropertyGetterBase.fragmentType
|
Methods in com.espertech.esper.event.map that return EventType | |
---|---|
EventType |
MapEventBean.getEventType()
|
Methods in com.espertech.esper.event.map with parameters of type EventType | |
---|---|
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterBeanNested(java.lang.String name,
EventType eventType,
EventAdapterService eventAdapterService)
|
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterBeanNestedArray(java.lang.String name,
EventType eventType,
EventAdapterService eventAdapterService)
|
MapEventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterEventBeanArray(java.lang.String name,
EventType eventType)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterIndexedUnderlyingArray(java.lang.String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType innerType)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterNestedEntryBean(java.lang.String propertyName,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService)
|
EventPropertyGetter |
EventTypeNestableGetterFactoryMap.getGetterNestedEntryBeanArray(java.lang.String propertyNameAtomic,
int index,
EventPropertyGetter getter,
EventType innerType,
EventAdapterService eventAdapterService)
|
Constructors in com.espertech.esper.event.map with parameters of type EventType | |
---|---|
MapArrayPropertyGetter(java.lang.String propertyNameAtomic,
int index,
EventAdapterService eventAdapterService,
EventType fragmentType)
Ctor. |
|
MapEventBean(EventType eventType)
Constructor for the mutable functions, e.g. |
|
MapEventBean(java.util.Map<java.lang.String,java.lang.Object> properties,
EventType eventType)
Constructor for initialization with existing values. |
|
MapEventType(EventTypeMetadata metadata,
java.lang.String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
EventType[] optionalSuperTypes,
java.util.Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeMap configMapType)
|
|
MapFragmentArrayPropertyGetter(java.lang.String propertyNameAtomic,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
Ctor. |
|
MapNestedEntryPropertyGetterArrayMap(java.lang.String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
int index,
MapEventPropertyGetter getter)
|
|
MapNestedEntryPropertyGetterArrayObjectArray(java.lang.String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
int index,
ObjectArrayEventPropertyGetter getter)
|
|
MapNestedEntryPropertyGetterBase(java.lang.String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService)
Ctor. |
|
MapNestedEntryPropertyGetterMap(java.lang.String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
MapEventPropertyGetter mapGetter)
|
|
MapNestedEntryPropertyGetterObjectArray(java.lang.String propertyMap,
EventType fragmentType,
EventAdapterService eventAdapterService,
ObjectArrayEventPropertyGetter arrayGetter)
|
|
MapPropertyGetterDefaultBase(java.lang.String propertyNameAtomic,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
Ctor. |
|
MapPropertyGetterDefaultMap(java.lang.String propertyName,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
|
|
MapPropertyGetterDefaultObjectArray(java.lang.String propertyName,
EventType fragmentEventType,
EventAdapterService eventAdapterService)
|
Constructor parameters in com.espertech.esper.event.map with type arguments of type EventType | |
---|---|
MapEventType(EventTypeMetadata metadata,
java.lang.String typeName,
int eventTypeId,
EventAdapterService eventAdapterService,
java.util.Map<java.lang.String,java.lang.Object> propertyTypes,
EventType[] optionalSuperTypes,
java.util.Set<EventType> optionalDeepSupertypes,
ConfigurationEventTypeMap configMapType)
|
Uses of EventType in com.espertech.esper.event.util |
---|
Methods in com.espertech.esper.event.util with parameters of type EventType | |
---|---|
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. |
Constructors in com.espertech.esper.event.util with parameters of type EventType | |
---|---|
EventTypePropertyPair(EventType eventType,
java.lang.String propertyName)
Ctor. |
|
JSONRendererImpl(EventType eventType,
JSONRenderingOptions options)
Ctor. |
|
RendererMeta(EventType eventType,
java.util.Stack<EventTypePropertyPair> stack,
RendererMetaOptions options)
Ctor. |
|
XMLRendererImpl(EventType eventType,
XMLRenderingOptions options)
Ctor. |
Uses of EventType in com.espertech.esper.event.vaevent |
---|
Classes in com.espertech.esper.event.vaevent that implement EventType | |
---|---|
class |
RevisionEventType
Event type of revision events. |
class |
VariantEventType
Event type for variant event streams. |
Fields in com.espertech.esper.event.vaevent with type parameters of type EventType | |
---|---|
protected java.util.Map<EventType,RevisionTypeDesc> |
VAERevisionProcessorBase.typeDescriptors
Map of participating type to descriptor. |
Methods in com.espertech.esper.event.vaevent that return EventType | |
---|---|
EventType |
ValueAddEventServiceImpl.createRevisionType(java.lang.String namedWindowName,
java.lang.String name,
StatementStopService statementStopService,
EventAdapterService eventAdapterService,
EventTypeIdGenerator eventTypeIdGenerator)
|
EventType |
ValueAddEventService.createRevisionType(java.lang.String namedWindowName,
java.lang.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(java.lang.String name)
|
EventType |
ValueAddEventService.getValueAddUnderlyingType(java.lang.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. |
Methods in com.espertech.esper.event.vaevent that return types with arguments of type EventType | |
---|---|
java.util.Iterator<EventType> |
VariantEventType.getDeepSuperTypes()
|
java.util.Iterator<EventType> |
RevisionEventType.getDeepSuperTypes()
|
static java.util.Map<EventType,RevisionTypeDesc> |
PropertyUtility.getPerType(PropertyGroupDesc[] groups,
java.lang.String[] changesetProperties,
java.lang.String[] keyProperties)
From a list of property groups that include contributing event types, build a map of contributing event types and their type descriptor. |
java.util.Map<EventType,java.lang.String> |
PropertyGroupDesc.getTypes()
Returns the types. |
Methods in com.espertech.esper.event.vaevent with parameters of type EventType | |
---|---|
static PropertyGroupDesc[] |
PropertyUtility.analyzeGroups(java.lang.String[] allProperties,
EventType[] deltaEventTypes,
java.lang.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,
java.lang.String[] propertyNames)
Return getters for property names. |
VariantPropertyDesc |
VariantPropResolutionStrategyDefault.resolveProperty(java.lang.String propertyName,
EventType[] variants)
|
VariantPropertyDesc |
VariantPropResolutionStrategyAny.resolveProperty(java.lang.String propertyName,
EventType[] variants)
|
VariantPropertyDesc |
VariantPropResolutionStrategy.resolveProperty(java.lang.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)
|
Constructors in com.espertech.esper.event.vaevent with parameters of type EventType | |
---|---|
RevisionSpec(ConfigurationRevisionEventType.PropertyRevision propertyRevision,
EventType baseEventType,
EventType[] deltaTypes,
java.lang.String[] deltaNames,
java.lang.String[] keyPropertyNames,
java.lang.String[] changesetPropertyNames,
java.lang.String[] baseEventOnlyPropertyNames,
boolean deltaTypesAddProperties,
boolean[] changesetPropertyDeltaContributed)
Ctor. |
|
RevisionSpec(ConfigurationRevisionEventType.PropertyRevision propertyRevision,
EventType baseEventType,
EventType[] deltaTypes,
java.lang.String[] deltaNames,
java.lang.String[] keyPropertyNames,
java.lang.String[] changesetPropertyNames,
java.lang.String[] baseEventOnlyPropertyNames,
boolean deltaTypesAddProperties,
boolean[] changesetPropertyDeltaContributed)
Ctor. |
|
VariantPropertyGetterCache(EventType[] knownTypes)
Ctor. |
|
VariantSpec(java.lang.String variantStreamName,
EventType[] eventTypes,
ConfigurationVariantStream.TypeVariance typeVariance)
Ctor. |
Constructor parameters in com.espertech.esper.event.vaevent with type arguments of type EventType | |
---|---|
PropertyGroupDesc(int groupNum,
java.util.Map<EventType,java.lang.String> nameTypeSet,
java.lang.String[] properties)
Ctor. |
Uses of EventType in com.espertech.esper.event.xml |
---|
Classes in com.espertech.esper.event.xml that implement EventType | |
---|---|
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. |
Methods in com.espertech.esper.event.xml that return EventType | |
---|---|
EventType |
XMLEventBean.getEventType()
|
EventType[] |
BaseXMLEventType.getSuperTypes()
|
Methods in com.espertech.esper.event.xml that return types with arguments of type EventType | |
---|---|
java.util.Iterator<EventType> |
BaseXMLEventType.getDeepSuperTypes()
|
Methods in com.espertech.esper.event.xml with parameters of type EventType | |
---|---|
boolean |
BaseXMLEventType.equalsCompareType(EventType eventType)
|
Constructors in com.espertech.esper.event.xml with parameters of type EventType | |
---|---|
XMLEventBean(org.w3c.dom.Node theEvent,
EventType type)
Ctor. |
Uses of EventType in com.espertech.esper.filter |
---|
Fields in com.espertech.esper.filter with type parameters of type EventType | |
---|---|
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
FilterSpecCompilerArgs.arrayEventTypes
|
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
FilterSpecCompilerArgs.taggedEventTypes
|
Methods in com.espertech.esper.filter that return EventType | |
---|---|
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. |
Methods in com.espertech.esper.filter that return types with arguments of type EventType | |
---|---|
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
FilterSpecParamExprNode.getTaggedEventTypes()
Returns the map of tag/stream names to event types that the filter expressions map use (for patterns) |
Methods in com.espertech.esper.filter with parameters of type EventType | |
---|---|
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(java.util.List<ExprNode> validatedNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext stmtContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
|
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowService namedWindowService)
|
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,
java.lang.String eventTypeName,
java.util.List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext statementContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification for use with filter service. |
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)
|
Method parameters in com.espertech.esper.filter with type arguments of type EventType | |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext stmtContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
|
static FilterSpecCompiled |
FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext stmtContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
|
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowService namedWindowService)
|
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.String statementId,
java.lang.String statementName,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
MethodResolutionService methodResolutionService,
EventAdapterService eventAdapterService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowService namedWindowService)
|
protected static FilterSpecParam |
FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.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,
java.lang.String eventTypeName,
java.util.List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext statementContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification for use with filter service. |
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
java.lang.String eventTypeName,
java.util.List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext statementContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification for use with filter service. |
static java.util.List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
java.util.List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes. |
static java.util.List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
java.util.List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes. |
Constructors in com.espertech.esper.filter with parameters of type EventType | |
---|---|
FilterSpecCompiled(EventType eventType,
java.lang.String eventTypeName,
java.util.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 parameters in com.espertech.esper.filter with type arguments of type EventType | |
---|---|
FilterSpecCompilerArgs(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.String statementName,
java.lang.String statementId,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation)
|
|
FilterSpecCompilerArgs(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
java.lang.String statementName,
java.lang.String statementId,
StreamTypeService streamTypeService,
MethodResolutionService methodResolutionService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation)
|
|
FilterSpecParamExprNode(FilterSpecLookupable lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
ConfigurationInformation configurationInformation,
java.lang.String statementName,
boolean hasSubquery,
boolean hasTableAccess)
Ctor. |
|
FilterSpecParamExprNode(FilterSpecLookupable lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
ConfigurationInformation configurationInformation,
java.lang.String statementName,
boolean hasSubquery,
boolean hasTableAccess)
Ctor. |
Uses of EventType in com.espertech.esper.pattern |
---|
Constructor parameters in com.espertech.esper.pattern with type arguments of type EventType | |
---|---|
MatchedEventConvertorImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> filterTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
java.util.LinkedHashSet<java.lang.String> allTags,
EventAdapterService eventAdapterService)
Ctor. |
|
MatchedEventConvertorImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> filterTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
java.util.LinkedHashSet<java.lang.String> allTags,
EventAdapterService eventAdapterService)
Ctor. |
Uses of EventType in com.espertech.esper.plugin |
---|
Methods in com.espertech.esper.plugin that return EventType | |
---|---|
EventType[] |
PlugInAggregationMultiFunctionValidationContext.getEventTypes()
Returns the event types of all events in the select clause |
EventType |
PlugInEventTypeHandler.getType()
Returns the event type. |
Constructors in com.espertech.esper.plugin with parameters of type EventType | |
---|---|
PlugInAggregationMultiFunctionValidationContext(java.lang.String functionName,
EventType[] eventTypes,
ExprNode[] parameterExpressions,
java.lang.String engineURI,
java.lang.String statementName,
ExprValidationContext validationContext,
ConfigurationPlugInAggregationMultiFunction config,
TableMetadataColumnAggregation optionalTableColumnAccessed,
ExprNode[] allParameterExpressions)
Ctor. |
Uses of EventType in com.espertech.esper.rowregex |
---|
Methods in com.espertech.esper.rowregex that return EventType | |
---|---|
EventType |
EventRowRegexNFAViewFactory.getEventType()
|
EventType |
EventRowRegexNFAView.getEventType()
|
Methods in com.espertech.esper.rowregex with parameters of type EventType | |
---|---|
void |
EventRowRegexNFAViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
java.util.Map<java.lang.String,java.util.Set<java.lang.String>> visibilityByIdentifier,
EventType parentViewType)
|
static ObjectArrayBackedEventBean |
EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
EventType parentViewType)
|
Constructors in com.espertech.esper.rowregex with parameters of type EventType | |
---|---|
EventRowRegexNFAView(EventRowRegexNFAViewFactory factory,
ObjectArrayEventType compositeEventType,
EventType rowEventType,
MatchRecognizeSpec matchRecognizeSpec,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
java.util.Map<java.lang.Integer,java.lang.String> streamsVariables,
java.util.Set<java.lang.String> variablesSingle,
AgentInstanceContext agentInstanceContext,
java.util.TreeMap<java.lang.Integer,java.util.List<ExprPreviousMatchRecognizeNode>> callbacksPerIndex,
AggregationServiceMatchRecognize aggregationService,
boolean isDefineAsksMultimatches,
ObjectArrayBackedEventBean defineMultimatchEventBean,
boolean[] isExprRequiresMultimatchState,
boolean isUnbound,
boolean isIterateOnly,
boolean isCollectMultimatches,
RowRegexExprNode expandedPatternNode)
Ctor. |
Uses of EventType in com.espertech.esper.view |
---|
Methods in com.espertech.esper.view that return EventType | |
---|---|
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. |
Methods in com.espertech.esper.view with parameters of type EventType | |
---|---|
void |
ViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.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 java.lang.String |
PropertyCheckHelper.checkLong(EventType type,
java.lang.String longFieldName)
Check if the field identified by the field name is of type long according to the schema. |
static java.lang.String |
PropertyCheckHelper.checkNumeric(EventType type,
java.lang.String numericFieldName)
Check if the field identified by the field name is a valid numeric field according to the schema. |
static java.lang.String |
PropertyCheckHelper.checkNumeric(EventType type,
java.lang.String numericFieldNameX,
java.lang.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)
|
ViewFactoryChain |
ViewService.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecList,
StreamSpecOptions options,
StatementContext context)
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 java.lang.String |
PropertyCheckHelper.exists(EventType type,
java.lang.String fieldName)
Check if the field identified by the field name exists according to the schema. |
static java.lang.String |
PropertyCheckHelper.exists(EventType type,
java.lang.String fieldNameOne,
java.lang.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(java.lang.String viewName,
EventType eventType,
StatementContext statementContext,
java.util.List<ExprNode> expressions,
boolean allowConstantResult)
Validate the view parameter expressions and return the validated expression for later execution. |
Constructors in com.espertech.esper.view with parameters of type EventType | |
---|---|
ViewableDefaultImpl(EventType eventType)
|
|
ViewFactoryChain(EventType streamEventType,
java.util.List<ViewFactory> viewFactoryChain)
Ctor. |
|
ZeroDepthStreamIterable(EventType eventType)
Ctor. |
|
ZeroDepthStreamNoIterate(EventType eventType)
Ctor. |
Uses of EventType in com.espertech.esper.view.ext |
---|
Methods in com.espertech.esper.view.ext that return EventType | |
---|---|
EventType |
TimeOrderViewFactory.getEventType()
|
EventType |
TimeOrderView.getEventType()
|
EventType |
SortWindowViewFactory.getEventType()
|
EventType |
SortWindowView.getEventType()
|
EventType |
RankWindowViewFactory.getEventType()
|
EventType |
RankWindowView.getEventType()
|
Methods in com.espertech.esper.view.ext with parameters of type EventType | |
---|---|
void |
TimeOrderViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
SortWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
RankWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
Uses of EventType in com.espertech.esper.view.internal |
---|
Fields in com.espertech.esper.view.internal declared as EventType | |
---|---|
protected EventType |
IntersectBatchView.eventType
|
protected EventType |
UnionViewFactory.parentEventType
The event type. |
protected EventType |
IntersectViewFactory.parentEventType
The event type. |
Methods in com.espertech.esper.view.internal that return EventType | |
---|---|
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 |
LastPostObserverView.getEventType()
|
EventType |
IntersectViewFactory.getEventType()
|
EventType |
IntersectView.getEventType()
|
EventType |
IntersectBatchView.getEventType()
|
EventType |
IntersectAsymetricView.getEventType()
|
EventType |
BufferView.getEventType()
|
Methods in com.espertech.esper.view.internal with parameters of type EventType | |
---|---|
void |
UnionViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
PriorEventViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
IntersectViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
UnionViewFactory.setParentEventType(EventType parentEventType)
Sets the parent event type. |
void |
IntersectViewFactory.setParentEventType(EventType parentEventType)
Sets the parent event type. |
Constructors in com.espertech.esper.view.internal with parameters of type EventType | |
---|---|
IntersectAsymetricView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
IntersectViewFactory factory,
EventType eventType,
java.util.List<View> viewList)
Ctor. |
|
IntersectBatchView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
IntersectViewFactory factory,
EventType eventType,
java.util.List<View> viewList,
java.util.List<ViewFactory> viewFactories,
boolean hasAsymetric)
Ctor. |
|
IntersectView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
IntersectViewFactory factory,
EventType eventType,
java.util.List<View> viewList)
Ctor. |
|
RouteResultView(boolean isFirst,
EventType eventType,
EPStatementHandle epStatementHandle,
InternalEventRouter internalEventRouter,
TableStateInstance[] tableStateInstances,
boolean[] isNamedWindowInsert,
ResultSetProcessor[] processors,
ExprNode[] whereClauses,
AgentInstanceContext agentInstanceContext)
Ctor. |
|
UnionAsymetricView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
UnionViewFactory factory,
EventType eventType,
java.util.List<View> viewList)
Ctor. |
|
UnionView(AgentInstanceViewFactoryChainContext agentInstanceViewFactoryContext,
UnionViewFactory factory,
EventType eventType,
java.util.List<View> viewList)
Ctor. |
Uses of EventType in com.espertech.esper.view.stat |
---|
Fields in com.espertech.esper.view.stat declared as EventType | |
---|---|
protected EventType |
WeightedAverageViewFactory.eventType
|
protected EventType |
UnivariateStatisticsViewFactory.eventType
|
protected EventType |
RegressionLinestViewFactory.eventType
|
protected EventType |
CorrelationViewFactory.eventType
Event type. |
protected EventType |
BaseBivariateStatisticsView.eventType
Event type. |
Methods in com.espertech.esper.view.stat that return EventType | |
---|---|
static EventType |
WeightedAverageView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view. |
static EventType |
UnivariateStatisticsView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view. |
protected static EventType |
RegressionLinestView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view. |
protected static EventType |
CorrelationView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view. |
EventType |
WeightedAverageViewFactory.getEventType()
|
EventType |
WeightedAverageView.getEventType()
|
EventType |
UnivariateStatisticsViewFactory.getEventType()
|
EventType |
UnivariateStatisticsView.getEventType()
|
EventType |
RegressionLinestViewFactory.getEventType()
|
EventType |
RegressionLinestView.getEventType()
|
EventType |
CorrelationViewFactory.getEventType()
|
EventType |
CorrelationView.getEventType()
|
Methods in com.espertech.esper.view.stat with parameters of type EventType | |
---|---|
void |
WeightedAverageViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
UnivariateStatisticsViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
RegressionLinestViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
CorrelationViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
static EventBean |
RegressionLinestView.doPopulateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
java.lang.Object[] decoration)
|
static EventBean |
CorrelationView.doPopulateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
java.lang.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,
java.lang.Object[] lastNewValues)
|
EventBean |
RegressionLinestView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
java.lang.Object[] decoration)
|
EventBean |
CorrelationView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
java.lang.Object[] decoration)
|
protected abstract EventBean |
BaseBivariateStatisticsView.populateMap(BaseStatisticsBean baseStatisticsBean,
EventAdapterService eventAdapterService,
EventType eventType,
StatViewAdditionalProps additionalProps,
java.lang.Object[] decoration)
Populate bean. |
void |
WeightedAverageViewFactory.setEventType(EventType eventType)
|
void |
UnivariateStatisticsViewFactory.setEventType(EventType eventType)
|
Constructors in com.espertech.esper.view.stat with parameters of type EventType | |
---|---|
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)
Constructor. |
|
RegressionLinestView(ViewFactory viewFactory,
AgentInstanceContext agentInstanceContext,
ExprNode xFieldName,
ExprNode yFieldName,
EventType eventType,
StatViewAdditionalProps additionalProps)
Constructor. |
Uses of EventType in com.espertech.esper.view.std |
---|
Fields in com.espertech.esper.view.std declared as EventType | |
---|---|
protected EventType |
SizeViewFactory.eventType
|
Methods in com.espertech.esper.view.std that return EventType | |
---|---|
static EventType |
SizeView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view |
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 |
AddPropertyValueView.getEventType()
|
Methods in com.espertech.esper.view.std with parameters of type EventType | |
---|---|
protected static EventBean |
AddPropertyValueView.addProperty(EventBean originalEvent,
java.lang.String[] propertyNames,
java.lang.Object propertyValues,
EventType targetEventType,
EventAdapterService eventAdapterService)
Add a property to the event passed in. |
void |
UniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
SizeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
MergeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
LastElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
GroupByViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
FirstUniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
FirstElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
Constructors in com.espertech.esper.view.std with parameters of type EventType | |
---|---|
AddPropertyValueView(AgentInstanceViewFactoryChainContext agentInstanceContext,
java.lang.String[] propertyNames,
java.lang.Object mergeValues,
EventType mergedResultEventType)
Constructor. |
|
MergeView(AgentInstanceViewFactoryChainContext agentInstanceContext,
ExprNode[] groupCriteria,
EventType resultEventType,
boolean removable)
Constructor. |
|
SizeView(AgentInstanceContext agentInstanceContext,
EventType eventType,
StatViewAdditionalProps additionalProps)
Ctor. |
Uses of EventType in com.espertech.esper.view.window |
---|
Fields in com.espertech.esper.view.window declared as EventType | |
---|---|
protected EventType |
ExpressionViewFactoryBase.builtinMapType
|
protected EventType |
TimeBatchViewFactoryParams.eventType
Event type |
Methods in com.espertech.esper.view.window that return EventType | |
---|---|
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()
|
Methods in com.espertech.esper.view.window with parameters of type EventType | |
---|---|
static java.util.LinkedHashMap<java.lang.String,java.lang.Object> |
ExpressionViewOAFieldEnum.asMapOfTypes(EventType eventType)
|
void |
TimeWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
TimeLengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
TimeBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
TimeAccumViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
LengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
LengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
KeepAllViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
FirstTimeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
FirstLengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
ExternallyTimedWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
ExternallyTimedBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
void |
ExpressionViewFactoryBase.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
|
|
© 2006-2015 EsperTech Inc. All rights reserved. Visit us at espertech.com |
|||||||||
PREV NEXT | FRAMES NO FRAMES |