Uses of Interface
net.esper.event.EventType

Packages that use EventType
net.esper.client This package defines the central Esper Client APIs. 
net.esper.core Implementation of client package interfaces, glue code 
net.esper.eql.core Contains EQL statement specification classes define the constructs that make up an EQL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
net.esper.eql.db Database SQL polling views and caches 
net.esper.eql.expression This package contains the EQL expression nodes that represent all expressions such as used in select clauses, group-by and having clauses, or order-by clauses 
net.esper.eql.join Join process interfaces and glue code 
net.esper.eql.join.exec Inner join execution 
net.esper.eql.join.plan Inner join and outer join query planning 
net.esper.eql.join.table Indexes for views 
net.esper.eql.lookup Subquery execution strategies and lookup indexes 
net.esper.eql.named Named window classes are in this package 
net.esper.eql.spec Contains EQL statement specification classes define the constructs that make up an EQL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
net.esper.eql.variable Variable service and variable collections 
net.esper.eql.view Internal processing views for output rate limiting, filtering and internal event routing 
net.esper.event This package defines the Esper Client event API. 
net.esper.event.xml XML event wrappers 
net.esper.filter Main switchboard filtering and routing of incoming events to interested statements is performed in this package. 
net.esper.indicator.jmx Classes for indicating events through a JMX console 
net.esper.view View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering. 
net.esper.view.ext Extension views that providing services such as sorting, which don't fit much into other categories. 
net.esper.view.internal Internal management views for buffering view results and providing these to joins. 
net.esper.view.stat Views computing statistical values. 
net.esper.view.std Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc. 
net.esper.view.window Window views are in this package 
 

Uses of EventType in net.esper.client
 

Methods in net.esper.client that return EventType
 EventType EPIterable.getEventType()
          Returns the type of events the iterable returns.
 

Uses of EventType in net.esper.core
 

Methods in net.esper.core that return EventType
 EventType UpdateDispatchViewBase.getEventType()
           
 EventType EPStatementImpl.getEventType()
           
 

Uses of EventType in net.esper.eql.core
 

Methods in net.esper.eql.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 SelectExprProcessor.getResultEventType()
          Returns the event type that represents the select-clause items.
 EventType SelectExprJoinWildcardProcessor.getResultEventType()
           
 EventType SelectExprEvalProcessorStreams.getResultEventType()
           
 EventType SelectExprEvalProcessor.getResultEventType()
           
 EventType ResultSetProcessorSimple.getResultEventType()
           
 EventType ResultSetProcessorRowPerGroup.getResultEventType()
           
 EventType ResultSetProcessorRowForAll.getResultEventType()
           
 EventType ResultSetProcessorAggregateGrouped.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.
 

Constructors in net.esper.eql.core with parameters of type EventType
MethodPollingViewable(MethodStreamSpec methodStreamSpec, int myStreamNumber, List<ExprNode> inputParameters, PollExecStrategy pollExecStrategy, DataCache dataCache, EventType eventType)
          Ctor.
PropertyResolutionDescriptor(String streamName, EventType streamEventType, String propertyName, int streamNum, Class propertyType)
          Ctor.
SelectExprJoinWildcardProcessor(String[] streamNames, EventType[] streamTypes, EventAdapterService eventAdapterService, InsertIntoDesc insertIntoDesc)
          Ctor.
StreamTypeServiceImpl(EventType[] eventTypes, String[] streamNames)
          Ctor.
 

Constructor parameters in net.esper.eql.core with type arguments of type EventType
StreamTypeServiceImpl(LinkedHashMap<String,EventType> namesAndTypes, boolean isStreamZeroUnambigous, boolean requireStreamNames)
          Ctor.
 

Uses of EventType in net.esper.eql.db
 

Methods in net.esper.eql.db that return EventType
 EventType DatabasePollingViewable.getEventType()
           
 

Constructors in net.esper.eql.db with parameters of type EventType
DatabasePollingViewable(int myStreamNumber, List<String> inputParameters, PollExecStrategy pollExecStrategy, DataCache dataCache, EventType eventType)
          Ctor.
PollExecStrategyDBQuery(EventAdapterService eventAdapterService, EventType eventType, ConnectionCache connectionCache, String preparedStatementText, Map<String,DBOutputTypeDesc> outputTypes)
          Ctor.
 

Uses of EventType in net.esper.eql.expression
 

Fields in net.esper.eql.expression declared as EventType
protected  EventType ExprSubselectNode.rawEventType
          The event type generated for wildcard selects.
 

Methods in net.esper.eql.expression with parameters of type EventType
 void ExprSubselectNode.setRawEventType(EventType rawEventType)
          Sets the event type generated for wildcard selects.
 

Uses of EventType in net.esper.eql.join
 

Methods in net.esper.eql.join with parameters of type EventType
protected static EventTable JoinSetComposerFactoryImpl.buildIndex(int indexedStreamNum, String[] indexProps, Class[] optCoercionTypes, EventType eventType)
          Build an index/table instance using the event properties for the event type.
 JoinSetComposer JoinSetComposerFactoryImpl.makeComposer(List<OuterJoinDesc> outerJoinDescList, ExprNode optionalFilterNode, EventType[] streamTypes, String[] streamNames, Viewable[] streamViews, SelectClauseStreamSelectorEnum selectStreamSelectorEnum)
          Builds join tuple composer.
 JoinSetComposer JoinSetComposerFactory.makeComposer(List<OuterJoinDesc> outerJoinDescList, ExprNode optionalFilterNode, EventType[] streamTypes, String[] streamNames, Viewable[] streamViews, SelectClauseStreamSelectorEnum selectStreamSelectorEnum)
          Builds join tuple composer.
 

Constructors in net.esper.eql.join with parameters of type EventType
HistoricalIndexLookupStrategyIndex(EventType eventType, String[] properties)
          Ctor.
PollResultIndexingStrategyIndex(int streamNum, EventType eventType, String[] propertyNames)
          Ctor.
PollResultIndexingStrategyIndexCoerce(int streamNum, EventType eventType, String[] propertyNames, Class[] coercionTypes)
          Ctor.
 

Uses of EventType in net.esper.eql.join.exec
 

Methods in net.esper.eql.join.exec that return EventType
 EventType IndexedTableLookupStrategy.getEventType()
          Returns event type of the lookup event.
 

Constructors in net.esper.eql.join.exec with parameters of type EventType
IndexedTableLookupStrategy(EventType eventType, String[] properties, PropertyIndexedEventTable index)
          Ctor.
 

Uses of EventType in net.esper.eql.join.plan
 

Methods in net.esper.eql.join.plan with parameters of type EventType
static QueryPlan TwoStreamQueryPlanBuilder.build(EventType[] typesPerStream, QueryGraph queryGraph, OuterJoinType optionalOuterJoinType)
          Build query plan.
protected static QueryPlan NStreamQueryPlanBuilder.build(QueryGraph queryGraph, EventType[] typesPerStream)
          Build a query plan based on the stream property relationships indicated in queryGraph.
protected static QueryPlan NStreamOuterQueryPlanBuilder.build(QueryGraph queryGraph, List<OuterJoinDesc> outerJoinDescList, String[] streamNames, EventType[] typesPerStream)
          Build a query plan based on the stream property relationships indicated in queryGraph.
protected static QueryPlan NStreamQueryPlanBuilder.buildNStreamDefaultQuerySpec(EventType[] eventTypes)
          Returns query plan based on all unindexed full table lookups and lookups based on a simple nesting order.
protected static TableLookupPlan NStreamQueryPlanBuilder.createLookupPlan(QueryGraph queryGraph, int currentLookupStream, int indexedStream, QueryPlanIndex indexSpecs, EventType[] typesPerStream)
          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)
          Walks the chain of lookups and constructs lookup strategy and plan specification based on the index specifications.
protected static Class[] TwoStreamQueryPlanBuilder.getCoercionTypes(EventType[] typesPerStream, int lookupStream, int indexedStream, String[] keyProps, String[] indexProps)
          Returns null if no coercion is required, or an array of classes for use in coercing the lookup keys and index keys into a common type.
static QueryPlan QueryPlanBuilder.getPlan(EventType[] typesPerStream, List<OuterJoinDesc> outerJoinDescList, ExprNode optionalFilterNode, String[] streamNames)
          Build query plan using the filter.
 ExecNode TableOuterLookupNode.makeExec(EventTable[][] indexesPerStream, EventType[] streamTypes)
           
 ExecNode TableLookupNode.makeExec(EventTable[][] indexesPerStream, EventType[] streamTypes)
           
abstract  ExecNode QueryPlanNode.makeExec(EventTable[][] indexesPerStream, EventType[] streamTypes)
          Make execution node from this specification.
 ExecNode NestedIterationNode.makeExec(EventTable[][] indexPerStream, EventType[] streamTypes)
           
 ExecNode LookupInstructionQueryPlanNode.makeExec(EventTable[][] indexesPerStream, EventType[] streamTypes)
           
 LookupInstructionExec LookupInstructionPlan.makeExec(EventTable[][] indexesPerStream, EventType[] streamTypes)
          Constructs the executable from the plan.
abstract  TableLookupStrategy TableLookupPlan.makeStrategy(EventTable[][] indexesPerStream, EventType[] eventTypes)
          Instantiates the lookup plan into a execution strategy for the lookup.
 TableLookupStrategy IndexedTableLookupPlan.makeStrategy(EventTable[][] indexesPerStream, EventType[] eventTypes)
           
 TableLookupStrategy FullTableScanLookupPlan.makeStrategy(EventTable[][] indexesPerStream, EventType[] eventTypes)
           
 

Uses of EventType in net.esper.eql.join.table
 

Constructors in net.esper.eql.join.table with parameters of type EventType
PropertyIndexedEventTable(int streamNum, EventType eventType, String[] propertyNames)
          Ctor.
PropertyIndTableCoerceAdd(int streamNum, EventType eventType, String[] propertyNames, Class[] coercionType)
          Ctor.
PropertyIndTableCoerceAll(int streamNum, EventType eventType, String[] propertyNames, Class[] coercionType)
          Ctor.
 

Uses of EventType in net.esper.eql.lookup
 

Constructors in net.esper.eql.lookup with parameters of type EventType
IndexedTableLookupStrategy(EventType[] eventTypes, int[] streamNumbers, String[] properties, PropertyIndexedEventTable index)
          Ctor.
IndexedTableLookupStrategyCoercing(EventType[] eventTypes, int[] streamNumbers, String[] properties, PropertyIndexedEventTable index, Class[] coercionTypes)
          Ctor.
 

Uses of EventType in net.esper.eql.named
 

Fields in net.esper.eql.named declared as EventType
protected  EventType NamedWindowOnExprBaseView.namedWindowEventType
          The event type of the events hosted in the named window.
 

Methods in net.esper.eql.named that return EventType
 EventType NamedWindowTailView.getEventType()
           
 EventType NamedWindowRootView.getEventType()
           
 EventType NamedWindowOnSelectView.getEventType()
           
 EventType NamedWindowOnDeleteView.getEventType()
           
 EventType NamedWindowConsumerView.getEventType()
           
 EventType NamedWindowProcessor.getNamedWindowType()
          Returns the event type of the named window.
 

Methods in net.esper.eql.named with parameters of type EventType
 NamedWindowOnExprBaseView NamedWindowRootView.addOnExpr(OnTriggerDesc onTriggerDesc, ExprNode joinExpr, EventType filterEventType, StatementStopService statementStopService, InternalEventRouter internalEventRouter, ResultSetProcessor optionalResultSetProcessor, EPStatementHandle statementHandle)
          Add an on-trigger view that, using a lookup strategy, looks up from the named window and may select or delete rows.
 NamedWindowOnExprBaseView NamedWindowProcessor.addOnExpr(OnTriggerDesc onTriggerDesc, ExprNode joinExpr, EventType filterEventType, StatementStopService statementStopService, InternalEventRouter internalEventRouter, ResultSetProcessor optionalResultSetProcessor, EPStatementHandle statementHandle)
          Returns a new view for a new on-delete or on-select statement.
 NamedWindowProcessor NamedWindowServiceImpl.addProcessor(String name, EventType eventType)
           
 NamedWindowProcessor NamedWindowService.addProcessor(String name, EventType eventType)
          Create a new named window.
 PropertyIndexedEventTable NamedWindowIndexRepository.addTable(JoinedPropDesc[] joinedPropDesc, Iterable<EventBean> prefilledEvents, EventType indexedType, boolean mustCoerce)
          Create a new index table or use an existing index table, by matching the join descriptor properties to an existing table.
 

Constructors in net.esper.eql.named with parameters of type EventType
NamedWindowConsumerView(List<ExprNode> filterList, EventType eventType, StatementStopService statementStopService, NamedWindowTailView tailView)
          Ctor.
NamedWindowProcessor(NamedWindowService namedWindowService, String windowName, EventType eventType)
          Ctor.
NamedWindowTailView(EventType eventType, NamedWindowService namedWindowService, NamedWindowRootView namedWindowRootView)
          Ctor.
 

Uses of EventType in net.esper.eql.spec
 

Methods in net.esper.eql.spec that return EventType
protected static EventType FilterStreamSpecRaw.resolveType(String eventName, EventAdapterService eventAdapterService)
          Resolves a given event alias to an event type.
 

Methods in net.esper.eql.spec that return types with arguments of type EventType
 Map<String,EventType> PatternStreamSpecCompiled.getTaggedEventTypes()
          Returns event types tagged in the pattern expression.
 

Constructor parameters in net.esper.eql.spec with type arguments of type EventType
PatternStreamSpecCompiled(EvalNode evalNode, Map<String,EventType> taggedEventTypes, List<ViewSpec> viewSpecs, String optionalStreamName)
          Ctor.
 

Uses of EventType in net.esper.eql.variable
 

Methods in net.esper.eql.variable that return EventType
 EventType OnSetVariableView.getEventType()
           
 EventType CreateVariableView.getEventType()
           
 

Uses of EventType in net.esper.eql.view
 

Methods in net.esper.eql.view that return EventType
 EventType OutputProcessView.getEventType()
           
 EventType IStreamRStreamSelectorView.getEventType()
           
 EventType InternalRouteView.getEventType()
           
 EventType FilterExprView.getEventType()
           
 

Uses of EventType in net.esper.event
 

Classes in net.esper.event that implement EventType
 class BaseConfigurableEventType
          EventType than can be supplied with a preconfigured list of properties getters (aka.
 class BeanEventType
          Implementation of the EventType interface for handling JavaBean-type classes.
 class CompositeEventType
          Event type for events that itself have event properties that are event wrappers.
 class MapEventType
          Implementation of the EventType interface for handling plain Maps containing name value pairs.
 class WrapperEventType
          An event type that adds zero or more fields to an existing event type.
 

Fields in net.esper.event declared as EventType
protected  EventType WrapperEventType.underlyingEventType
          The underlying wrapped event type.
 

Fields in net.esper.event with type parameters of type EventType
protected  Map<String,EventType> CompositeEventType.taggedEventTypes
          Map of tag name and event type.
 

Methods in net.esper.event that return EventType
 EventType EventAdapterServiceImpl.addBeanType(String eventTypeAlias, Class clazz)
          Add an alias and class as an event type.
 EventType EventAdapterService.addBeanType(String eventTypeAlias, Class clazz)
          Add an event type with the given alias and Java class.
 EventType EventAdapterServiceImpl.addBeanType(String eventTypeAlias, String fullyQualClassName, boolean considerAutoAlias)
          Add an event type for the given Java class name.
 EventType EventAdapterService.addBeanType(String eventTypeAlias, String fullyQualClassName, boolean considerAutoAlias)
          Add an event type with the given alias and Java fully-qualified class name.
 EventType EventAdapterServiceImpl.addMapType(String eventTypeAlias, Map<String,Class> propertyTypes)
           
 EventType EventAdapterService.addMapType(String eventTypeAlias, Map<String,Class> propertyTypes)
          Add an event type with the given alias and a given set of properties.
 EventType EventAdapterServiceImpl.addWrapperType(String eventTypeAlias, EventType underlyingEventType, Map<String,Class> propertyTypes)
           
 EventType EventAdapterService.addWrapperType(String eventTypeAlias, EventType underlyingEventType, Map<String,Class> propertyTypes)
          Add an event type with the given alias and the given underlying event type, as well as the additional given properties.
 EventType EventAdapterServiceImpl.addXMLDOMType(String eventTypeAlias, ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM)
          Add a configured XML DOM event type.
 EventType EventAdapterService.addXMLDOMType(String eventTypeAlias, ConfigurationEventTypeXMLDOM configurationEventTypeXMLDOM)
          Adds an XML DOM event type.
 EventType EventAdapterServiceImpl.createAddToEventType(EventType originalType, String[] fieldNames, Class[] fieldTypes)
           
 EventType EventAdapterService.createAddToEventType(EventType originalType, String[] fieldNames, Class[] fieldTypes)
          Create an event type based on the original type passed in adding one or more properties.
 EventType EventAdapterServiceImpl.createAnonymousCompositeType(Map<String,EventType> taggedEventTypes)
           
 EventType EventAdapterService.createAnonymousCompositeType(Map<String,EventType> taggedEventTypes)
          Creates an unnamed composite event type with event properties that are name-value pairs with values being other event types.
 EventType EventAdapterServiceImpl.createAnonymousMapType(Map<String,Class> propertyTypes)
           
 EventType EventAdapterService.createAnonymousMapType(Map<String,Class> propertyTypes)
          Creates a new anonymous EventType instance for an event type that contains a map of name value pairs.
 EventType EventAdapterServiceImpl.createAnonymousWrapperType(EventType underlyingEventType, Map<String,Class> propertyTypes)
           
 EventType EventAdapterService.createAnonymousWrapperType(EventType underlyingEventType, Map<String,Class> propertyTypes)
          Create a new anonymous event type with the given underlying event type, as well as the additional given properties.
 EventType WrapperEventBean.getEventType()
           
 EventType MapEventBean.getEventType()
           
 EventType EventBean.getEventType()
          Return the EventType instance that describes the set of properties available for this event.
 EventType CompositeEventBean.getEventType()
           
 EventType BeanEventBean.getEventType()
           
 EventType EventAdapterServiceImpl.getExistsTypeByAlias(String eventTypeAlias)
           
 EventType EventAdapterService.getExistsTypeByAlias(String eventTypeAlias)
          Return the event type for a given event name, or null if none is registered for that name.
 EventType[] WrapperEventType.getSuperTypes()
           
 EventType[] MapEventType.getSuperTypes()
           
 EventType[] EventType.getSuperTypes()
          Returns an array of event types that are super to this event type, from which this event type inherited event properties.
 EventType[] CompositeEventType.getSuperTypes()
           
 EventType[] BeanEventType.getSuperTypes()
           
 EventType WrapperEventType.getUnderlyingEventType()
          Returns the wrapped event type.
 

Methods in net.esper.event that return types with arguments of type EventType
 Iterator<EventType> WrapperEventType.getDeepSuperTypes()
           
 Iterator<EventType> MapEventType.getDeepSuperTypes()
           
 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.
 Iterator<EventType> CompositeEventType.getDeepSuperTypes()
           
 Iterator<EventType> BeanEventType.getDeepSuperTypes()
           
 Map<String,EventType> TaggedCompositeEventType.getTaggedEventTypes()
          Returns the event types for each composing event.
 Map<String,EventType> CompositeEventType.getTaggedEventTypes()
           
 

Methods in net.esper.event with parameters of type EventType
 EventBean EventAdapterServiceImpl.adapterForCompositeEvent(EventType eventType, Map<String,EventBean> taggedEvents)
           
 EventBean EventAdapterService.adapterForCompositeEvent(EventType eventType, Map<String,EventBean> taggedEvents)
          Creates a wrapper for a composite event type.
 EventType EventAdapterServiceImpl.addWrapperType(String eventTypeAlias, EventType underlyingEventType, Map<String,Class> propertyTypes)
           
 EventType EventAdapterService.addWrapperType(String eventTypeAlias, EventType underlyingEventType, Map<String,Class> propertyTypes)
          Add an event type with the given alias and the given underlying event type, as well as the additional given properties.
 EventType EventAdapterServiceImpl.createAddToEventType(EventType originalType, String[] fieldNames, Class[] fieldTypes)
           
 EventType EventAdapterService.createAddToEventType(EventType originalType, String[] fieldNames, Class[] fieldTypes)
          Create an event type based on the original type passed in adding one or more properties.
 EventType EventAdapterServiceImpl.createAnonymousWrapperType(EventType underlyingEventType, Map<String,Class> propertyTypes)
           
 EventType EventAdapterService.createAnonymousWrapperType(EventType underlyingEventType, Map<String,Class> propertyTypes)
          Create a new anonymous event type with the given underlying event type, as well as the additional given properties.
 EventBean EventAdapterServiceImpl.createMapFromValues(Map<String,Object> properties, EventType eventType)
           
 EventBean EventAdapterService.createMapFromValues(Map<String,Object> properties, EventType eventType)
          Create an event wrapper bean from a set of event properties (name and value objectes) stored in a Map.
 EventBean EventAdapterServiceImpl.createWrapper(EventBean event, Map<String,Object> properties, EventType eventType)
           
 EventBean EventAdapterService.createWrapper(EventBean event, Map<String,Object> properties, EventType eventType)
          Creata a wrapper around an event and some additional properties
static boolean EventAdapterServiceImpl.isCompatibleWrapper(EventType existingType, EventType underlyingType, Map<String,Class> 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.
 

Method parameters in net.esper.event with type arguments of type EventType
 EventType EventAdapterServiceImpl.createAnonymousCompositeType(Map<String,EventType> taggedEventTypes)
           
 EventType EventAdapterService.createAnonymousCompositeType(Map<String,EventType> taggedEventTypes)
          Creates an unnamed composite event type with event properties that are name-value pairs with values being other event types.
 

Constructors in net.esper.event with parameters of type EventType
BeanEventBean(Object event, EventType eventType)
          Constructor.
CompositeEventBean(Map<String,EventBean> wrappedEvents, EventType eventType)
          Ctor.
MapEventBean(EventType eventType)
          Constructor for the mutable functions, e.g.
MapEventBean(EventType eventType, Map<String,EventBean> events)
          Constructor for initialization with existing values.
MapEventBean(Map<String,Object> properties, EventType eventType)
          Constructor for initialization with existing values.
WrapperEventBean(EventBean event, Map<String,Object> properties, EventType eventType)
          Ctor.
WrapperEventType(String typeName, EventType eventType, Map<String,Class> properties, EventAdapterService eventAdapterService)
          Ctor.
 

Constructor parameters in net.esper.event with type arguments of type EventType
CompositeEventType(String alias, Map<String,EventType> taggedEventTypes)
          Ctor.
 

Uses of EventType in net.esper.event.xml
 

Classes in net.esper.event.xml that implement EventType
 class BaseXMLEventType
          Base class for XMLEventTypes.
 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 net.esper.event.xml that return EventType
 EventType XMLEventBean.getEventType()
           
 EventType[] BaseXMLEventType.getSuperTypes()
           
 

Methods in net.esper.event.xml that return types with arguments of type EventType
 Iterator<EventType> BaseXMLEventType.getDeepSuperTypes()
           
 

Constructors in net.esper.event.xml with parameters of type EventType
XMLEventBean(Node event, EventType type)
          Ctor.
 

Uses of EventType in net.esper.filter
 

Methods in net.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.getEventType()
          Returns type of event to filter for.
 

Methods in net.esper.filter that return types with arguments of type EventType
 LinkedHashMap<String,EventType> FilterSpecParamExprNode.getTaggedEventTypes()
          Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)
 

Methods in net.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 FilterParamIndexBase IndexFactory.createIndex(EventType eventType, String propertyName, FilterOperator filterOperator)
          Factory for indexes that store filter parameter constants for a given event property and filter operator.
 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, List<ExprNode> filterExpessions, LinkedHashMap<String,EventType> taggedEventTypes, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService)
          Factory method for compiling filter expressions into a filter specification for use with filter service.
 

Method parameters in net.esper.filter with type arguments of type EventType
static FilterSpecCompiled FilterSpecCompiler.makeFilterSpec(EventType eventType, List<ExprNode> filterExpessions, LinkedHashMap<String,EventType> taggedEventTypes, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService)
          Factory method for compiling filter expressions into a filter specification for use with filter service.
 

Constructors in net.esper.filter with parameters of type EventType
FilterParamIndexBooleanExpr(EventType eventType)
          Constructs the index for multiple-exact matches.
FilterParamIndexCompare(String propertyName, FilterOperator filterOperator, EventType eventType)
          Constructs the index for matching comparison operators (<, >, <=, >=).
FilterParamIndexEquals(String propertyName, EventType eventType)
          Constructs the index for exact matches.
FilterParamIndexIn(String propertyName, EventType eventType)
          Constructs the index for multiple-exact matches.
FilterParamIndexNotEquals(String propertyName, EventType eventType)
          Constructs the index for exact matches.
FilterParamIndexNotIn(String propertyName, EventType eventType)
          Constructs the index for multiple-exact matches.
FilterParamIndexNotRange(String attributeName, FilterOperator filterOperator, EventType eventType)
          Constructs the index for matching ranges.
FilterParamIndexPropBase(String propertyName, FilterOperator filterOperator, EventType eventType)
          Constructor.
FilterParamIndexRange(String attributeName, FilterOperator filterOperator, EventType eventType)
          Constructs the index for matching ranges.
FilterSpecCompiled(EventType eventType, List<FilterSpecParam> parameters)
          Constructor - validates parameter list against event type, throws exception if invalid property names or mismatcing filter operators are found.
FilterValueSetImpl(EventType eventType, List<FilterValueSetParam> parameters)
          Ctor.
 

Constructor parameters in net.esper.filter with type arguments of type EventType
FilterSpecParamExprNode(String propertyName, FilterOperator filterOperator, ExprNode exprNode, LinkedHashMap<String,EventType> taggedEventTypes, VariableService variableService)
          Ctor.
 

Uses of EventType in net.esper.indicator.jmx
 

Constructors in net.esper.indicator.jmx with parameters of type EventType
JMXLastElementDynamicMBean(EventType eventType)
          Constructor.
JMXLastEventIndicator(EventType eventType, String domainName, String keyProperties)
          Constructor.
 

Uses of EventType in net.esper.view
 

Methods in net.esper.view that return EventType
 EventType ZeroDepthStream.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 EventCollection.getEventType()
          Provides metadata information about the type of object the event collection contains.
 

Methods in net.esper.view with parameters of type EventType
 void ViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
          Attaches the factory to a parent event type such that the factory can validate attach requirements and determine an event type for resulting views.
static String PropertyCheckHelper.checkLong(EventType type, String longFieldName)
          Check if the field identified by the field name is of type long according to the schema.
static String PropertyCheckHelper.checkNumeric(EventType type, String numericFieldName)
          Check if the field identified by the field name is a valid numeric field according to the schema.
static String PropertyCheckHelper.checkNumeric(EventType type, String numericFieldNameX, String numericFieldNameY)
          Check if the fields identified by their field names are valid numeric field according to the schema.
 ViewFactoryChain ViewServiceImpl.createFactories(int streamNum, EventType parentEventType, List<ViewSpec> viewSpecDefinitions, StatementContext context)
           
 ViewFactoryChain ViewService.createFactories(int streamNum, EventType parentEventType, List<ViewSpec> viewSpecList, 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 String PropertyCheckHelper.exists(EventType type, String fieldName)
          Check if the field identified by the field name exists according to the schema.
static String PropertyCheckHelper.exists(EventType type, String fieldNameOne, String fieldNameTwo)
          Check if the fields identified by the field names both exists according to the schema.
 

Constructors in net.esper.view with parameters of type EventType
ViewFactoryChain(EventType streamEventType, List<ViewFactory> viewFactoryChain)
          Ctor.
ZeroDepthStream(EventType eventType)
          Ctor.
 

Uses of EventType in net.esper.view.ext
 

Methods in net.esper.view.ext that return EventType
 EventType TimeOrderViewFactory.getEventType()
           
 EventType TimeOrderView.getEventType()
           
 EventType SortWindowViewFactory.getEventType()
           
 EventType SortWindowView.getEventType()
           
 

Methods in net.esper.view.ext with parameters of type EventType
 void TimeOrderViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void SortWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 

Uses of EventType in net.esper.view.internal
 

Methods in net.esper.view.internal that return EventType
 EventType PriorEventViewFactory.getEventType()
           
 EventType PriorEventView.getEventType()
           
 EventType BufferView.getEventType()
           
 

Methods in net.esper.view.internal with parameters of type EventType
 void PriorEventViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 

Uses of EventType in net.esper.view.stat
 

Methods in net.esper.view.stat that return EventType
protected static EventType WeightedAverageView.createEventType(StatementContext statementContext)
          Creates the event type for this view.
protected static EventType UnivariateStatisticsView.createEventType(StatementContext statementContext)
          Creates the event type for this view.
protected static EventType RegressionLinestView.createEventType(StatementContext statementContext)
          Creates the event type for this view.
protected static EventType MultiDimStatsView.createEventType(StatementContext statementContext)
          Creates the event type for this view.
protected static EventType CorrelationView.createEventType(StatementContext statementContext)
          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 MultiDimStatsViewFactory.getEventType()
           
 EventType MultiDimStatsView.getEventType()
           
 EventType CorrelationViewFactory.getEventType()
           
 EventType CorrelationView.getEventType()
           
 

Methods in net.esper.view.stat with parameters of type EventType
 void WeightedAverageViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void UnivariateStatisticsViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void RegressionLinestViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void MultiDimStatsViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void CorrelationViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 

Uses of EventType in net.esper.view.std
 

Methods in net.esper.view.std that return EventType
protected static EventType SizeView.createEventType(StatementContext statementContext)
          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 GroupByViewFactory.getEventType()
           
 EventType GroupByView.getEventType()
           
 EventType AddPropertyValueView.getEventType()
           
 

Methods in net.esper.view.std with parameters of type EventType
protected static EventBean AddPropertyValueView.addProperty(EventBean originalEvent, String[] propertyNames, Object[] propertyValues, EventType targetEventType, EventAdapterService eventAdapterService)
          Add a property to the event passed in.
 void UniqueByPropertyViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void SizeViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void MergeViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void LastElementViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void GroupByViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 

Constructors in net.esper.view.std with parameters of type EventType
AddPropertyValueView(StatementContext statementContext, String[] fieldNames, Object[] mergeValues, EventType mergedResultEventType)
          Constructor.
MergeView(StatementContext statementContext, String[] groupFieldNames, EventType resultEventType)
          Constructor.
 

Uses of EventType in net.esper.view.window
 

Methods in net.esper.view.window that return EventType
 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 ExternallyTimedWindowViewFactory.getEventType()
           
 EventType ExternallyTimedWindowView.getEventType()
           
 

Methods in net.esper.view.window with parameters of type EventType
 void TimeWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void TimeLengthBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void TimeBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void TimeAccumViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void LengthWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void LengthBatchViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void KeepAllViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 void ExternallyTimedWindowViewFactory.attach(EventType parentEventType, StatementContext statementContext, ViewFactory optionalParentFactory, List<ViewFactory> parentViewFactories)
           
 


© 2007 EsperTech Inc.
All rights reserved.
Visit us at espertech.com