A B C D E F G H I J K L M N O P Q R S T U V W X Z _

A

AbstractHashedMap - Class in net.esper.collection.apachecommons
An abstract implementation of a hash-based map which provides numerous points for subclasses to override.
AbstractHashedMap() - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap
Constructor only used in deserialization, do not use otherwise.
AbstractHashedMap(int, float, int) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap
Constructor which performs no validation on the passed in parameters.
AbstractHashedMap(int) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap
Constructs a new, empty map with the specified initial capacity and default load factor.
AbstractHashedMap(int, float) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap
Constructs a new, empty map with the specified initial capacity and load factor.
AbstractHashedMap(Map) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap
Constructor copying elements from another map.
AbstractHashedMap.EntrySet - Class in net.esper.collection.apachecommons
EntrySet implementation.
AbstractHashedMap.EntrySet(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
Ctor.
AbstractHashedMap.EntrySetIterator - Class in net.esper.collection.apachecommons
EntrySet iterator.
AbstractHashedMap.EntrySetIterator(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.EntrySetIterator
Ctor.
AbstractHashedMap.HashEntry - Class in net.esper.collection.apachecommons
HashEntry used to store the data.
AbstractHashedMap.HashEntry(AbstractHashedMap.HashEntry, int, Object, Object) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
Ctor.
AbstractHashedMap.HashIterator - Class in net.esper.collection.apachecommons
Base Iterator
AbstractHashedMap.HashIterator(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
Ctor.
AbstractHashedMap.HashMapIterator - Class in net.esper.collection.apachecommons
MapIterator implementation.
AbstractHashedMap.HashMapIterator(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.HashMapIterator
Ctor.
AbstractHashedMap.KeySet - Class in net.esper.collection.apachecommons
KeySet implementation.
AbstractHashedMap.KeySet(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
Ctor.
AbstractHashedMap.KeySetIterator - Class in net.esper.collection.apachecommons
KeySet iterator.
AbstractHashedMap.KeySetIterator(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.KeySetIterator
Ctor.
AbstractHashedMap.Values - Class in net.esper.collection.apachecommons
Values implementation.
AbstractHashedMap.Values(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.Values
Ctor.
AbstractHashedMap.ValuesIterator - Class in net.esper.collection.apachecommons
Values iterator.
AbstractHashedMap.ValuesIterator(AbstractHashedMap) - Constructor for class net.esper.collection.apachecommons.AbstractHashedMap.ValuesIterator
Ctor.
AbstractKeyValue - Class in net.esper.collection.apachecommons
Abstract pair class to assist with creating KeyValue and Map.Entry implementations.
AbstractKeyValue(Object, Object) - Constructor for class net.esper.collection.apachecommons.AbstractKeyValue
Constructs a new pair with the specified key and given value.
AbstractMapEntry - Class in net.esper.collection.apachecommons
Abstract Pair class to assist with creating correct Map.Entry implementations.
AbstractMapEntry(Object, Object) - Constructor for class net.esper.collection.apachecommons.AbstractMapEntry
Constructs a new entry with the given key and given value.
AbstractReferenceMap - Class in net.esper.collection.apachecommons
An abstract implementation of a hash-based map that allows the entries to be removed by the garbage collector.
AbstractReferenceMap() - Constructor for class net.esper.collection.apachecommons.AbstractReferenceMap
Constructor used during deserialization.
AbstractReferenceMap(int, int, int, float, boolean) - Constructor for class net.esper.collection.apachecommons.AbstractReferenceMap
Constructs a new empty map with the specified reference types, load factor and initial capacity.
AbstractReferenceMap.ReferenceEntry - Class in net.esper.collection.apachecommons
A MapEntry implementation for the map.
AbstractReferenceMap.ReferenceEntry(AbstractReferenceMap, AbstractHashedMap.HashEntry, int, Object, Object) - Constructor for class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Creates a new entry object for the ReferenceMap.
accept(ExprNodeVisitor) - Method in class net.esper.eql.expression.ExprNode
Accept the visitor.
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalAndStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalEveryStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalFilterStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalFollowedByStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalGuardStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalNotStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalObserverStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalOrStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalRootStateNode
 
accept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalStateNode
Accept a visitor.
ACQUIRE_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
Acquire text.
ACQUIRED_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
Acquired text.
acquireLock(StatementLockFactory) - Method in interface net.esper.util.ManagedLock
Acquire a lock.
acquireLock(StatementLockFactory) - Method in class net.esper.util.ManagedLockImpl
Lock.
acquireReadLock() - Method in class net.esper.util.ManagedReadWriteLock
Lock read lock.
acquireWriteLock() - Method in class net.esper.util.ManagedReadWriteLock
Lock write lock.
adapterForBean(Object) - Method in interface net.esper.event.EventAdapterService
Wrap the native event returning an EventBean.
adapterForBean(Object) - Method in class net.esper.event.EventAdapterServiceImpl
Create an event bean given an event of object id.
adapterForCompositeEvent(EventType, Map<String, EventBean>) - Method in interface net.esper.event.EventAdapterService
Creates a wrapper for a composite event type.
adapterForCompositeEvent(EventType, Map<String, EventBean>) - Method in class net.esper.event.EventAdapterServiceImpl
 
adapterForDOM(Node) - Method in interface net.esper.event.EventAdapterService
Returns an adapter for the XML DOM document that exposes it's data as event properties for use in statements.
adapterForDOM(Node) - Method in class net.esper.event.EventAdapterServiceImpl
 
adapterForMap(Map, String) - Method in interface net.esper.event.EventAdapterService
Wrap the Map-type event returning an EventBean using the event type alias name to identify the EventType that the event should carry.
adapterForMap(Map, String) - Method in class net.esper.event.EventAdapterServiceImpl
 
AdapterLoader - Interface in net.esper.adapter
Interface for loaders of input/output adapters.
adapterLoaders - Variable in class net.esper.client.Configuration
List of adapter loaders.
add(Object) - Method in class net.esper.client.soda.ArithmaticExpression
Add a constant to include in the computation.
add(Expression) - Method in class net.esper.client.soda.ArithmaticExpression
Add an expression to include in the computation.
add(String) - Method in class net.esper.client.soda.ArithmaticExpression
Add a property to include in the computation.
add(String) - Method in class net.esper.client.soda.ArrayExpression
Add a property to the expression.
add(Object) - Method in class net.esper.client.soda.ArrayExpression
Add a constant to the expression.
add(Expression) - Method in class net.esper.client.soda.ArrayExpression
Add an expression representing an array element to the expression.
add(String) - Method in class net.esper.client.soda.BitwiseOpExpression
Add a property to the expression.
add(Object) - Method in class net.esper.client.soda.BitwiseOpExpression
Add a constant to the expression.
add(Expression) - Method in class net.esper.client.soda.BitwiseOpExpression
Add an expression to the expression.
add(Expression, Expression) - Method in class net.esper.client.soda.CaseSwitchExpression
Adds a pair of expressions representing a "when" and a "then" in the switch.
add(Expression, Expression) - Method in class net.esper.client.soda.CaseWhenThenExpression
Adds a when-then pair of expressions.
add(Object) - Method in class net.esper.client.soda.CoalesceExpression
Add a constant to include in the computation.
add(Expression) - Method in class net.esper.client.soda.CoalesceExpression
Add an expression to include in the computation.
add(String) - Method in class net.esper.client.soda.CoalesceExpression
Add a property to include in the computation.
add(Object) - Method in class net.esper.client.soda.ConcatExpression
Add a constant to include in the computation.
add(Expression) - Method in class net.esper.client.soda.ConcatExpression
Add an expression to include in the computation.
add(String) - Method in class net.esper.client.soda.ConcatExpression
Add a property to include in the computation.
add(Stream) - Method in class net.esper.client.soda.FromClause
Adds a stream.
add(OuterJoinQualifier) - Method in class net.esper.client.soda.FromClause
Adds an outer join descriptor that defines how the streams are related via outer joins.
add(Object) - Method in class net.esper.client.soda.InExpression
Add a constant to include in the computation.
add(Expression) - Method in class net.esper.client.soda.InExpression
Add an expression to include in the computation.
add(String) - Method in class net.esper.client.soda.InExpression
Add a property to include in the computation.
add(String) - Method in class net.esper.client.soda.InsertIntoClause
Add a column name to the insert-into clause.
add(Expression) - Method in class net.esper.client.soda.Junction
Expression to add to the conjunction (AND) or disjunction (OR).
add(String) - Method in class net.esper.client.soda.Junction
Property to add to the conjunction (AND) or disjunction (OR).
add(Object) - Method in class net.esper.client.soda.MaxRowExpression
Add a constant to include in the computation.
add(Expression) - Method in class net.esper.client.soda.MaxRowExpression
Add an expression to include in the computation.
add(String) - Method in class net.esper.client.soda.MaxRowExpression
Add a property to include in the computation.
add(Object) - Method in class net.esper.client.soda.MinRowExpression
Add a constant to include in the computation.
add(Expression) - Method in class net.esper.client.soda.MinRowExpression
Add an expression to include in the computation.
add(String) - Method in class net.esper.client.soda.MinRowExpression
Add a property to include in the computation.
add(String, boolean) - Method in class net.esper.client.soda.OrderByClause
Adds a property and flag.
add(Expression, boolean) - Method in class net.esper.client.soda.OrderByClause
Adds an expression and flag.
add(String, String) - Method in class net.esper.client.soda.OuterJoinQualifier
Add additional properties to the on-clause, which are logical-and to existing properties
add(PatternExpr) - Method in class net.esper.client.soda.PatternAndExpr
Adds a pattern expression to the AND relationship between patterns.
add(PatternExpr) - Method in class net.esper.client.soda.PatternFollowedByExpr
Adds a pattern expression to the followed-by relationship between patterns.
add(PatternExpr) - Method in class net.esper.client.soda.PatternOrExpr
Adds a pattern expression to the OR relationship between patterns.
add(String...) - Method in class net.esper.client.soda.SelectClause
Adds property names to be selected.
add(Expression) - Method in class net.esper.client.soda.SelectClause
Adds an expression to the select clause.
add(Expression, String) - Method in class net.esper.client.soda.SelectClause
Adds an expression to the select clause and an "as"-asName for the column.
add(T) - Method in class net.esper.collection.ArrayBackedCollection
 
add(EventBean[]) - Method in class net.esper.collection.FlushedEventBuffer
Add an event array to buffer.
add(Object, Object) - Method in class net.esper.collection.IndexedDataCollection
Add a value object to the index.
add(EventBean) - Method in class net.esper.collection.OneEventLinkedList
Add an event to the collection.
add(K) - Method in class net.esper.collection.RefCountedSet
Add a key to the set.
add(K, int) - Method in class net.esper.collection.RefCountedSet
Add a key to the set with the given number of references.
add(EventBean[]) - Method in class net.esper.collection.RollingEventBuffer
Add events to the buffer.
add(EventBean) - Method in class net.esper.collection.RollingEventBuffer
Add an event to the buffer.
add(double) - Method in class net.esper.collection.SortedDoubleVector
Add a value to the collection.
add(K) - Method in class net.esper.collection.SortedRefCountedSet
Add a key to the set.
add(K, int) - Method in class net.esper.collection.SortedRefCountedSet
Add a key to the set with the given number of references.
add(Object) - Static method in class net.esper.collection.ThreadWorkQueue
Adds event to the end of the event queue.
add(long, EventBean) - Method in class net.esper.collection.TimeWindow
Adds event to the time window for the specified timestamp.
add(EventBean) - Method in class net.esper.core.PatternListenerDispatch
Add an event to be dispatched.
add(ExprSubselectNode, int, Viewable, ViewFactoryChain) - Method in class net.esper.core.SubSelectStreamCollection
Add lookup.
add(int, EventBean[]) - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode.ChildStreamResults
Add result from stream.
add(int, int) - Method in class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Add an outer-to-inner join stream relationship.
add(int, String, int, String) - Method in class net.esper.eql.join.plan.QueryGraph
Add properties for 2 streams that are equal.
add(String, String) - Method in class net.esper.eql.join.plan.QueryGraphValue
Add key and index property.
add(EventBean[]) - Method in interface net.esper.eql.join.table.EventTable
Add events to table.
add(EventBean[]) - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
Add an array of events.
add(EventBean[]) - Method in class net.esper.eql.join.table.UnindexedEventTable
 
add(EventBean[]) - Method in class net.esper.eql.join.table.UnindexedEventTableList
 
add(String) - Method in class net.esper.eql.spec.InsertIntoDesc
Add a column name to the insert-into clause.
add(SelectExprElementRawSpec) - Method in class net.esper.eql.spec.SelectClauseSpec
Adds an select expression within the select clause.
add(SelectExprElementStreamRawSpec) - Method in class net.esper.eql.spec.SelectClauseSpec
Adds a stream wildcard selection element.
add(int, SubstitutionParameterExpression) - Method in class net.esper.eql.spec.StatementSpecUnMapContext
Adds a substitution parameters.
add(EventType, FilterHandleSetNode) - Method in class net.esper.filter.EventTypeIndex
Add a new event type to the index and use the specified node for the root node of its subtree.
add(FilterValueSet, FilterHandle) - Method in class net.esper.filter.EventTypeIndexBuilder
Add a filter to the event type index structure, and to the filter subtree.
add(FilterParamIndexBase) - Method in class net.esper.filter.FilterHandleSetNode
Add an index.
add(FilterHandle) - Method in class net.esper.filter.FilterHandleSetNode
Add a filter callback.
add(FilterValueSet, FilterHandle) - Method in interface net.esper.filter.FilterService
Add a filter for events as defined by the filter specification, and register a callback to be invoked upon evaluation of an event that matches the filter spec.
add(FilterValueSet, FilterHandle) - Method in class net.esper.filter.FilterServiceImpl
 
add(FilterValueSet, FilterHandle, FilterHandleSetNode) - Method in class net.esper.filter.IndexTreeBuilder
Add a filter callback according to the filter specification to the top node returning information to be used to remove the filter callback.
add(FilterParamIndexBase, Object) - Method in class net.esper.filter.IndexTreePath
Add an index to end of the list representing a path through indexes.
add(EvalFilterNode) - Method in class net.esper.pattern.EvalNodeAnalysisResult
Adds a filter node.
add(EvalGuardNode) - Method in class net.esper.pattern.EvalNodeAnalysisResult
Adds a guard node.
add(EvalObserverNode) - Method in class net.esper.pattern.EvalNodeAnalysisResult
Adds an observer node.
add(String, EventBean) - Method in interface net.esper.pattern.MatchedEventMap
Add an event to the collection identified by the given tag.
add(String, EventBean) - Method in class net.esper.pattern.MatchedEventMapImpl
Add an event to the collection identified by the given tag.
add(long, ScheduleHandle, ScheduleSlot) - Method in interface net.esper.schedule.SchedulingService
Add a callback for after the given milliseconds from the current time.
add(ScheduleSpec, ScheduleHandle, ScheduleSlot) - Method in interface net.esper.schedule.SchedulingService
Add a callback for a time specified by the schedule specification passed in based on the current time.
add(long, ScheduleHandle, ScheduleSlot) - Method in class net.esper.schedule.SchedulingServiceImpl
 
add(ScheduleSpec, ScheduleHandle, ScheduleSlot) - Method in class net.esper.schedule.SchedulingServiceImpl
 
add(NumberSetParameter) - Method in class net.esper.type.ListParameter
Add to the list a further parameter.
addAdapterLoader(String, String, Properties) - Method in class net.esper.client.Configuration
Add an input/output adapter loader.
addAggregation(String, String) - Method in interface net.esper.eql.core.EngineImportService
Add an aggregation function.
addAggregation(String, String) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
addAll(Collection) - Method in class net.esper.collection.ArrayBackedCollection
 
addAll(Map<Integer, SubstitutionParameterExpression>) - Method in class net.esper.eql.spec.StatementSpecUnMapContext
Adds all substitution parameters.
addAssignment(String, Expression) - Method in class net.esper.client.soda.OnSetClause
Adds a variable to set to the clause.
addAssignment(OnTriggerSetAssignment) - Method in class net.esper.eql.spec.OnTriggerSetDesc
Adds a variable assignment.
addAutoAliasPackage(String) - Method in interface net.esper.event.EventAdapterService
Adds a Java package name of a package that Java event classes reside in.
addAutoAliasPackage(String) - Method in class net.esper.event.EventAdapterServiceImpl
 
addBeanType(String, String, boolean) - Method in interface net.esper.event.EventAdapterService
Add an event type with the given alias and Java fully-qualified class name.
addBeanType(String, Class) - Method in interface net.esper.event.EventAdapterService
Add an event type with the given alias and Java class.
addBeanType(String, Class) - Method in class net.esper.event.EventAdapterServiceImpl
Add an alias and class as an event type.
addBeanType(String, String, boolean) - Method in class net.esper.event.EventAdapterServiceImpl
Add an event type for the given Java class name.
addChild(Expression) - Method in class net.esper.client.soda.ExpressionBase
Adds a new child expression to the current expression.
addChild(PatternExpr) - Method in class net.esper.client.soda.PatternExprBase
Adds a sub-expression to the pattern expression.
addChild(BaseAssemblyNode) - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Add a child node.
addChild(BaseAssemblyNode) - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode
 
addChild(BaseAssemblyNode) - Method in class net.esper.eql.join.assemble.RootCartProdAssemblyNode
 
addChildNode(ExprNode) - Method in class net.esper.eql.expression.ExprNode
Adds a child node.
addChildNode(ExecNode) - Method in class net.esper.eql.join.exec.NestedIterationExecNode
Add a child node.
addChildNode(QueryPlanNode) - Method in class net.esper.eql.join.plan.NestedIterationNode
Adds a child node.
addChildNode(EvalNode) - Method in class net.esper.pattern.EvalNode
Adds a child node.
addConsumer(List<ExprNode>, EPStatementHandle, StatementStopService) - Method in class net.esper.eql.named.NamedWindowProcessor
Adds a consuming (selecting) statement to the named window.
addConsumer(List<ExprNode>, EPStatementHandle, StatementStopService) - Method in class net.esper.eql.named.NamedWindowTailView
Adds a consumer view keeping the consuming statement's handle and lock to coordinate dispatches.
addDatabaseReference(String, ConfigurationDBRef) - Method in class net.esper.client.Configuration
Add a database reference with a given database name.
addDispatch(NamedWindowDeltaData, Map<EPStatementHandle, List<NamedWindowConsumerView>>) - Method in interface net.esper.eql.named.NamedWindowService
For use to add a result of a named window that must be dispatched to consuming views.
addDispatch(NamedWindowDeltaData, Map<EPStatementHandle, List<NamedWindowConsumerView>>) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
addEmittedListener(EmittedListener, String) - Method in interface net.esper.client.EPRuntime
Register an object that listens for events emitted from the event stream processing runtime on the specified channel.
addEmittedListener(EmittedListener, String) - Method in class net.esper.core.EPRuntimeImpl
 
addEntry(AbstractHashedMap.HashEntry, int) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Adds an entry into this map.
addEventTypeAlias(String, String) - Method in class net.esper.client.Configuration
Add an alias for an event type represented by Java-bean plain-old Java object events.
addEventTypeAlias(String, Class) - Method in class net.esper.client.Configuration
Add an alias for an event type represented by Java-bean plain-old Java object events.
addEventTypeAlias(String, Properties) - Method in class net.esper.client.Configuration
Add an alias for an event type that represents java.util.Map events.
addEventTypeAlias(String, Map<String, Class>) - Method in class net.esper.client.Configuration
Add an alias for an event type that represents java.util.Map events, taking a Map of event property and class name as a parameter.
addEventTypeAlias(String, ConfigurationEventTypeXMLDOM) - Method in class net.esper.client.Configuration
Add an alias for an event type that represents org.w3c.dom.Node events.
addEventTypeAlias(String, String, ConfigurationEventTypeLegacy) - Method in class net.esper.client.Configuration
Add an alias for an event type that represents legacy Java type (non-JavaBean style) events.
addEventTypeAlias(String, String) - Method in interface net.esper.client.ConfigurationOperations
Add an alias for an event type represented by JavaBean object events.
addEventTypeAlias(String, Class) - Method in interface net.esper.client.ConfigurationOperations
Add an alias for an event type represented by Java-bean plain-old Java object events.
addEventTypeAlias(String, Properties) - Method in interface net.esper.client.ConfigurationOperations
Add an alias for an event type that represents java.util.Map events.
addEventTypeAlias(String, Map<String, Class>) - Method in interface net.esper.client.ConfigurationOperations
Add an alias for an event type that represents java.util.Map events, taking a Map of event property and class name as a parameter.
addEventTypeAlias(String, ConfigurationEventTypeXMLDOM) - Method in interface net.esper.client.ConfigurationOperations
Add an alias for an event type that represents org.w3c.dom.Node events.
addEventTypeAlias(String, String) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addEventTypeAlias(String, Class) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addEventTypeAlias(String, Properties) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addEventTypeAlias(String, Map<String, Class>) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addEventTypeAlias(String, ConfigurationEventTypeXMLDOM) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addEventTypeAliasSimpleName(Class) - Method in class net.esper.client.Configuration
Add an alias for an event type represented by Java-bean plain-old Java object events, and the alias is the simple class name of the class.
addEventTypeAliasSimpleName(Class) - Method in interface net.esper.client.ConfigurationOperations
Add an alias for an event type represented by Java-bean plain-old Java object events, using the simple name of the Java class as the alias.
addEventTypeAliasSimpleName(Class) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addEventTypeAutoAlias(String) - Method in class net.esper.client.Configuration
 
addEventTypeAutoAlias(String) - Method in interface net.esper.client.ConfigurationOperations
Adds a Java package name of a package that Java event classes reside in.
addEventTypeAutoAlias(String) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addExternal(Dispatchable) - Method in interface net.esper.dispatch.DispatchService
Add a Dispatchable implementation.
addExternal(Dispatchable) - Method in class net.esper.dispatch.DispatchServiceImpl
 
addFieldProperty(String, String) - Method in class net.esper.client.ConfigurationEventTypeLegacy
Adds the named event property backed by the named accessor field.
addFront(Object) - Static method in class net.esper.collection.ThreadWorkQueue
Adds event to the front of the queue.
addImport(String) - Method in class net.esper.client.Configuration
 
addImport(String) - Method in interface net.esper.client.ConfigurationOperations
Adds a package or class to the list of automatically-imported classes and packages.
addImport(String) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addImport(String) - Method in interface net.esper.eql.core.EngineImportService
Add an import, such as "com.mypackage.*" or "com.mypackage.MyClass".
addImport(String) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
addIndex(String[], Class[]) - Method in class net.esper.eql.join.plan.QueryPlanIndex
Add an index specification element.
addIntrospectProperties(Class, List<EventPropertyDescriptor>) - Static method in class net.esper.event.property.PropertyHelper
Adds to the given list of property descriptors the properties of the given class using the Introspector to introspect properties.
additiveExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
addJavaSqlTypesBinding(int, String) - Method in class net.esper.client.ConfigurationDBRef
Adds a mapping of a java.sql.Types type to a Java type.
addJavaSqlTypesBinding(int, Class) - Method in class net.esper.client.ConfigurationDBRef
Adds a mapping of a java.sql.Types type to a Java type.
addListener(UpdateListener) - Method in interface net.esper.client.EPListenable
Add a listener that observes events.
addListener(StatementAwareUpdateListener) - Method in interface net.esper.client.EPListenable
Add a statement-aware listener that observes events.
addListener(UpdateListener) - Method in class net.esper.core.EPStatementImpl
Add a listener to the statement.
addListener(StatementAwareUpdateListener) - Method in class net.esper.core.EPStatementImpl
 
addListener(UpdateListener) - Method in class net.esper.core.EPStatementListenerSet
Add a listener to the statement.
addListener(StatementAwareUpdateListener) - Method in class net.esper.core.EPStatementListenerSet
Add a listener to the statement.
addListener(EmittedListener, String) - Method in interface net.esper.emit.EmitService
Add emitted event listener for the specified channel, or the default channel if the channel value is null.
addListener(EmittedListener, String) - Method in class net.esper.emit.EmitServiceImpl
 
addMappedProperties(Class, List<EventPropertyDescriptor>) - Static method in class net.esper.event.property.PropertyHelper
Adds to the given list of property descriptors the mapped properties, ie.
addMapping(int, int, Object, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Adds a new key-value mapping into this map.
addMapType(String, Map<String, Class>) - Method in interface net.esper.event.EventAdapterService
Add an event type with the given alias and a given set of properties.
addMapType(String, Map<String, Class>) - Method in class net.esper.event.EventAdapterServiceImpl
 
addMergeViews(List<ViewSpec>) - Static method in class net.esper.view.ViewServiceHelper
Add merge views for any views in the chain requiring a merge (group view).
addMethodProperty(String, String) - Method in class net.esper.client.ConfigurationEventTypeLegacy
Adds the named event property backed by the named accessor method.
addMethodRef(String, ConfigurationMethodRef) - Method in class net.esper.client.Configuration
Adds a cache configuration for a class providing methods for use in the from-clause.
addMethodRef(Class, ConfigurationMethodRef) - Method in class net.esper.client.Configuration
Adds a cache configuration for a class providing methods for use in the from-clause.
addMethodRefs(Map<String, ConfigurationMethodRef>) - Method in class net.esper.eql.core.EngineImportServiceImpl
Adds cache configs for method invocations for from-clause.
addNamedWindowLock(String, ManagedLock) - Method in interface net.esper.eql.named.NamedWindowService
Sets the lock to use for a named window.
addNamedWindowLock(String, ManagedLock) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
addNamespacePrefix(String, String) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Add a prefix and namespace name for use in XPath expressions refering to that prefix.
addObject(String, String, Class, PluggableObjectType) - Method in class net.esper.eql.spec.PluggableObjectCollection
Add a single object to the collection.
addObjects(PluggableObjectCollection) - Method in class net.esper.eql.spec.PluggableObjectCollection
Add the plug-in objects for another collection.
addOnExpr(OnTriggerDesc, ExprNode, EventType, StatementStopService, InternalEventRouter, ResultSetProcessor, EPStatementHandle) - Method in class net.esper.eql.named.NamedWindowProcessor
Returns a new view for a new on-delete or on-select statement.
addOnExpr(OnTriggerDesc, ExprNode, EventType, StatementStopService, InternalEventRouter, ResultSetProcessor, EPStatementHandle) - Method in class net.esper.eql.named.NamedWindowRootView
Add an on-trigger view that, using a lookup strategy, looks up from the named window and may select or delete rows.
addParameter(Expression) - Method in class net.esper.client.soda.MethodInvocationStream
Adds a parameters to the method invocation.
addParentView(AddPropertyValueView) - Method in class net.esper.view.std.MergeView
Add a parent data merge view.
addPatternObjects(List<ConfigurationPlugInPatternObject>) - Method in class net.esper.eql.spec.PluggableObjectCollection
Add a plug-in pattern object.
addPlugInAggregationFunction(String, String) - Method in class net.esper.client.Configuration
 
addPlugInAggregationFunction(String, String) - Method in interface net.esper.client.ConfigurationOperations
Adds a plug-in aggregation function given a function name and an aggregation class name.
addPlugInAggregationFunction(String, String) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addPlugInPatternGuard(String, String, String) - Method in class net.esper.client.Configuration
Add a pattern guard for plug-in.
addPlugInPatternObserver(String, String, String) - Method in class net.esper.client.Configuration
Add a pattern event observer for plug-in.
addPlugInView(String, String, String) - Method in class net.esper.client.Configuration
Add a view for plug-in.
addPoint(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Add a data point for the X data set only.
addPoint(double, double) - Method in class net.esper.view.stat.BaseStatisticsBean
Add a data point.
addPrefix(String, String) - Method in class net.esper.event.xml.XPathNamespaceContext
Add a namespace prefix and namespace name to context.
addProcessor(String, EventType) - Method in interface net.esper.eql.named.NamedWindowService
Create a new named window.
addProcessor(String, EventType) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
addProperty(EventBean, String[], Object[], EventType, EventAdapterService) - Static method in class net.esper.view.std.AddPropertyValueView
Add a property to the event passed in.
AddPropertyValueView - Class in net.esper.view.std
This view simply adds a property to the events posted to it.
AddPropertyValueView(StatementContext, String[], Object[], EventType) - Constructor for class net.esper.view.std.AddPropertyValueView
Constructor.
addResult(Cursor, Set<EventBean>, int) - Method in interface net.esper.eql.join.rep.Repository
Add a lookup result.
addResult(Cursor, Set<EventBean>, int) - Method in class net.esper.eql.join.rep.RepositoryImpl
 
addStreamWildcard(String) - Method in class net.esper.client.soda.SelectClause
Adds to the select-clause a stream wildcard selector (e.g.
addStreamWildcard(String, String) - Method in class net.esper.client.soda.SelectClause
Adds to the select-clause a stream wildcard selector with column alias (e.g.
addSubscriber(StatementStopCallback) - Method in interface net.esper.view.StatementStopService
Add a callback to perform for a stop of a statement.
addSubscriber(StatementStopCallback) - Method in class net.esper.view.StatementStopServiceImpl
 
addTable(JoinedPropDesc[], Iterable<EventBean>, EventType, boolean) - Method in class net.esper.eql.named.NamedWindowIndexRepository
Create a new index table or use an existing index table, by matching the join descriptor properties to an existing table.
addToEnvironment(String, Object) - Method in class net.esper.core.EngineEnvContext
 
addValue(int, T, long) - Method in class net.esper.eql.variable.VersionedValueList
Add a value and version to the list, returning the prior value of the variable.
addValue(ScheduleUnit, int) - Method in class net.esper.schedule.ScheduleSpec
For unit testing, add a single value, changing wildcards to value sets.
addVariable(String, Class, Object) - Method in class net.esper.client.Configuration
 
addVariable(String, Class, Object) - Method in interface net.esper.client.ConfigurationOperations
Add a variable.
addVariable(String, Class, Object) - Method in class net.esper.core.ConfigurationOperationsImpl
 
addView(String, String) - Method in class net.esper.client.soda.CreateWindowClause
Adds an un-parameterized view to the named window.
addView(String, String, List<Object>) - Method in class net.esper.client.soda.CreateWindowClause
Adds a parameterized view to the named window.
addView(String, String) - Method in class net.esper.client.soda.ProjectedStream
Adds an un-parameterized view to the stream.
addView(String, String, List<Object>) - Method in class net.esper.client.soda.ProjectedStream
Adds a parameterized view to the stream.
addView(String, String, Object...) - Method in class net.esper.client.soda.ProjectedStream
Adds a parameterized view to the stream.
addView(View) - Method in class net.esper.client.soda.ProjectedStream
Add a view to the stream.
addView(View) - Method in class net.esper.eql.core.MethodPollingViewable
 
addView(View) - Method in class net.esper.eql.db.DatabasePollingViewable
 
addView(View) - Method in interface net.esper.view.Viewable
Add a view to the viewable object.
addView(View) - Method in class net.esper.view.ViewSupport
 
addView(View) - Method in class net.esper.view.ZeroDepthStream
 
addViews(List<ConfigurationPlugInView>) - Method in class net.esper.eql.spec.PluggableObjectCollection
Add a plug-in view.
addWithAlias(String, String) - Method in class net.esper.client.soda.SelectClause
Adds a single property name and an "as"-asName for the column.
addWrapperType(String, EventType, Map<String, Class>) - Method in interface net.esper.event.EventAdapterService
Add an event type with the given alias and the given underlying event type, as well as the additional given properties.
addWrapperType(String, EventType, Map<String, Class>) - Method in class net.esper.event.EventAdapterServiceImpl
 
addXMLDOMType(String, ConfigurationEventTypeXMLDOM) - Method in interface net.esper.event.EventAdapterService
Adds an XML DOM event type.
addXMLDOMType(String, ConfigurationEventTypeXMLDOM) - Method in class net.esper.event.EventAdapterServiceImpl
Add a configured XML DOM event type.
addXPathProperty(String, String, QName) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Adds an event property for which the engine uses the supplied XPath expression against a DOM document node to resolve a property value.
AggregationMethod - Interface in net.esper.eql.agg
Maintains aggregation state applying values as entering and leaving the state.
AggregationResultFuture - Interface in net.esper.eql.agg
Interface for use by aggregate expression nodes representing aggregate functions such as 'sum' or 'avg' to use to obtain the current value for the function at time of expression evaluation.
AggregationService - Interface in net.esper.eql.agg
Service for maintaing aggregation state.
AggregationServiceBase - Class in net.esper.eql.agg
All aggregation services require evaluation nodes which supply the value to be aggregated (summed, averaged, etc.) and aggregation state factories to make new aggregation states.
AggregationServiceBase(ExprEvaluator[], AggregationMethod[]) - Constructor for class net.esper.eql.agg.AggregationServiceBase
Ctor.
AggregationServiceFactory - Class in net.esper.eql.agg
Factory for aggregation service instances.
AggregationServiceFactory() - Constructor for class net.esper.eql.agg.AggregationServiceFactory
 
AggregationServiceGroupAllImpl - Class in net.esper.eql.agg
Implementation for handling aggregation without any grouping (no group-by).
AggregationServiceGroupAllImpl(ExprEvaluator[], AggregationMethod[]) - Constructor for class net.esper.eql.agg.AggregationServiceGroupAllImpl
Ctor.
AggregationServiceGroupByImpl - Class in net.esper.eql.agg
Implementation for handling aggregation with grouping by group-keys.
AggregationServiceGroupByImpl(ExprEvaluator[], AggregationMethod[], MethodResolutionService) - Constructor for class net.esper.eql.agg.AggregationServiceGroupByImpl
Ctor.
AggregationServiceNull - Class in net.esper.eql.agg
A null object implementation of the AggregationService interface.
AggregationServiceNull() - Constructor for class net.esper.eql.agg.AggregationServiceNull
 
AggregationSupport - Class in net.esper.eql.agg
Base class for use with plug-in aggregation functions.
AggregationSupport() - Constructor for class net.esper.eql.agg.AggregationSupport
Ctor.
aggregators - Variable in class net.esper.eql.agg.AggregationServiceBase
Aggregation states and factories.
AliasNodeSwapper - Class in net.esper.eql.core
A utility class for replacing select-clause aliases with their definitions in expression node trees.
AliasNodeSwapper() - Constructor for class net.esper.eql.core.AliasNodeSwapper
 
ALL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ALL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
allocateBucket() - Method in interface net.esper.schedule.SchedulingService
Returns a bucket from which slots can be allocated for ordering concurrent callbacks.
allocateBucket() - Method in class net.esper.schedule.SchedulingServiceImpl
 
allocateSlot() - Method in class net.esper.schedule.ScheduleBucket
Returns a new slot in the bucket.
analyze(ExprNode, QueryGraph) - Static method in class net.esper.eql.join.plan.FilterExprAnalyzer
Analyzes filter expression to build query graph model.
analyze(List<OuterJoinDesc>, QueryGraph) - Static method in class net.esper.eql.join.plan.OuterJoinAnalyzer
Analyzes the outer join descriptor list to build a query graph model.
analyzeAndNode(ExprAndNode, QueryGraph) - Static method in class net.esper.eql.join.plan.FilterExprAnalyzer
Analyze the AND-node.
analyzeEqualsNode(ExprEqualsNode, QueryGraph) - Static method in class net.esper.eql.join.plan.FilterExprAnalyzer
Analye EQUALS (=) node.
and() - Static method in class net.esper.client.soda.Expressions
Logical AND conjunction.
and(Expression, Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
Logical AND conjunction.
and() - Static method in class net.esper.client.soda.Patterns
Pattern-AND expression, allows adding sub-expressions that are connected by a logical AND.
and(PatternExpr, PatternExpr, PatternExpr...) - Static method in class net.esper.client.soda.Patterns
Pattern-AND expression, allows adding sub-expressions that are connected by a logical AND.
AND_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
AND_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
andExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
append(EventBean[], EventBean[]) - Static method in class net.esper.event.EventBeanUtility
Append arrays.
applyEnter(EventBean[], MultiKeyUntyped) - Method in interface net.esper.eql.agg.AggregationService
Apply events as entering a window (new events).
applyEnter(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceGroupAllImpl
 
applyEnter(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceGroupByImpl
 
applyEnter(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceNull
 
applyLeave(EventBean[], MultiKeyUntyped) - Method in interface net.esper.eql.agg.AggregationService
Apply events as leaving a window (old events).
applyLeave(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceGroupAllImpl
 
applyLeave(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceGroupByImpl
 
applyLeave(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceNull
 
applyOutputLimit(EventBean[], boolean) - Static method in class net.esper.eql.core.ResultSetProcessorSimple
Applies the last/all event output limit clause.
applyOutputLimit(Set<MultiKey<EventBean>>, boolean) - Static method in class net.esper.eql.core.ResultSetProcessorSimple
Applies the last/all event output limit clause.
ArithmaticExpression - Class in net.esper.client.soda
Arithmatic expression for addition, subtraction, multiplication, division and modulo.
ArithmaticExpression(String) - Constructor for class net.esper.client.soda.ArithmaticExpression
Ctor.
ArithmaticExpression(Expression, String, Expression) - Constructor for class net.esper.client.soda.ArithmaticExpression
Ctor.
arithmeticExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
array() - Static method in class net.esper.client.soda.Expressions
Array expression, representing the syntax of "{1, 2, 3}" returning an integer array of 3 elements valued 1, 2, 3.
ARRAY_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ARRAY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ARRAY_PARAM_LIST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ARRAY_PARAM_LIST - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ArrayBackedCollection<T> - Class in net.esper.collection
A fast collection backed by an array with severe limitations.
ArrayBackedCollection(int) - Constructor for class net.esper.collection.ArrayBackedCollection
Ctor.
ArrayEventIterator - Class in net.esper.collection
Iterator for an array of events.
ArrayEventIterator(EventBean[]) - Constructor for class net.esper.collection.ArrayEventIterator
Ctor.
arrayExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
ArrayExpression - Class in net.esper.client.soda
Array expression forms array results, similar to the EQL syntax of "{element 1, element 2, ...
ArrayExpression() - Constructor for class net.esper.client.soda.ArrayExpression
 
arrayExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
ArrayFastPropertyGetter - Class in net.esper.event.property
Getter for an array property identified by a given index, using the CGLIB fast method.
ArrayFastPropertyGetter(FastMethod, int) - Constructor for class net.esper.event.property.ArrayFastPropertyGetter
Constructor.
ArrayFieldPropertyGetter - Class in net.esper.event.property
Getter for an array property backed by a field, identified by a given index, using vanilla reflection.
ArrayFieldPropertyGetter(Field, int) - Constructor for class net.esper.event.property.ArrayFieldPropertyGetter
Constructor.
ArrayMethodPropertyGetter - Class in net.esper.event.property
Getter for an array property identified by a given index, using vanilla reflection.
ArrayMethodPropertyGetter(Method, int) - Constructor for class net.esper.event.property.ArrayMethodPropertyGetter
Constructor.
arrayParameterList() - Method in class net.esper.eql.generated.EQLStatementParser
 
AS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
AS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ASC - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ASC - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
AssemblyStrategyTreeBuilder - Class in net.esper.eql.join.assemble
Builds a tree of assembly nodes given a strategy for how to join streams.
AssemblyStrategyTreeBuilder() - Constructor for class net.esper.eql.join.assemble.AssemblyStrategyTreeBuilder
 
assessProperties(Class) - Method in interface net.esper.event.property.PropertyListBuilder
Introspect the clazz and deterime exposed event properties.
assessProperties(Class) - Method in class net.esper.event.property.PropertyListBuilderExplicit
 
assessProperties(Class) - Method in class net.esper.event.property.PropertyListBuilderJavaBean
 
assessProperties(Class) - Method in class net.esper.event.property.PropertyListBuilderPublic
 
ASTConstantHelper - Class in net.esper.eql.parse
Parses constant strings and returns the constant Object.
ASTConstantHelper() - Constructor for class net.esper.eql.parse.ASTConstantHelper
 
ASTFilterSpecHelper - Class in net.esper.eql.parse
Builds a filter specification from filter AST nodes.
ASTFilterSpecHelper() - Constructor for class net.esper.eql.parse.ASTFilterSpecHelper
 
ASTFilterSpecValidationException - Exception in net.esper.eql.parse
This exception is thrown to indicate a problem in a filter specification.
ASTFilterSpecValidationException(String, Throwable) - Constructor for exception net.esper.eql.parse.ASTFilterSpecValidationException
Ctor.
ASTFilterSpecValidationException(String) - Constructor for exception net.esper.eql.parse.ASTFilterSpecValidationException
Ctor.
ASTOutputLimitHelper - Class in net.esper.eql.parse
Builds an output limit spec from an output limit AST node.
ASTOutputLimitHelper() - Constructor for class net.esper.eql.parse.ASTOutputLimitHelper
 
ASTParameterHelper - Class in net.esper.eql.parse
Parse AST parameter nodes including constants, arrays, lists.
ASTParameterHelper() - Constructor for class net.esper.eql.parse.ASTParameterHelper
 
ASTViewSpecHelper - Class in net.esper.eql.parse
Builds a view specification from view AST nodes.
ASTViewSpecHelper() - Constructor for class net.esper.eql.parse.ASTViewSpecHelper
 
ASTWalkException - Exception in net.esper.eql.parse
This exception is thrown to indicate a problem in statement creation.
ASTWalkException(String, Throwable) - Constructor for exception net.esper.eql.parse.ASTWalkException
Ctor.
ASTWalkException(String) - Constructor for exception net.esper.eql.parse.ASTWalkException
Ctor.
atomicExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
atomicExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.ext.SortWindowViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.ext.TimeOrderViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.internal.PriorEventViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.CorrelationViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.GroupByViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.LastElementViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.MergeViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.SizeViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in interface net.esper.view.ViewFactory
Attaches the factory to a parent event type such that the factory can validate attach requirements and determine an event type for resulting views.
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.KeepAllViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.LengthBatchViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.LengthWindowViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.TimeAccumViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.TimeBatchViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
attach(EventType, StatementContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.TimeWindowViewFactory
 
available() - Method in class net.esper.util.SimpleByteArrayInputStream
 
avedev(String) - Static method in class net.esper.client.soda.Expressions
Mean deviation aggregation function.
avedev(Expression) - Static method in class net.esper.client.soda.Expressions
Mean deviation aggregation function.
AVEDEV - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
AVEDEV - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
AvedevAggregator - Class in net.esper.eql.agg
Standard deviation always generates double-types numbers.
AvedevAggregator() - Constructor for class net.esper.eql.agg.AvedevAggregator
Ctor.
avedevDistinct(String) - Static method in class net.esper.client.soda.Expressions
Mean deviation function considering distinct values only.
avedevDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Mean deviation function considering distinct values only.
AvedevProjectionExpression - Class in net.esper.client.soda
Mean deviation of the (distinct) values returned by an expression.
AvedevProjectionExpression(boolean) - Constructor for class net.esper.client.soda.AvedevProjectionExpression
Ctor - for use to create an expression tree, without inner expression.
AvedevProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.AvedevProjectionExpression
Ctor - adds the expression to project.
avg(String) - Static method in class net.esper.client.soda.Expressions
Average aggregation function.
avg(Expression) - Static method in class net.esper.client.soda.Expressions
Average aggregation function.
AVG - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
AVG - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
AvgAggregator - Class in net.esper.eql.agg
Average always generates double-types numbers.
AvgAggregator() - Constructor for class net.esper.eql.agg.AvgAggregator
 
avgDistinct(String) - Static method in class net.esper.client.soda.Expressions
Average aggregation function considering distinct values only.
avgDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Average aggregation function considering distinct values only.
AvgProjectionExpression - Class in net.esper.client.soda
Average of the (distinct) values returned by an expression.
AvgProjectionExpression(boolean) - Constructor for class net.esper.client.soda.AvgProjectionExpression
Ctor - for use to create an expression tree, without inner expression
AvgProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.AvgProjectionExpression
Ctor - adds the expression to project.
await() - Method in class net.esper.core.InsertIntoLatchSpin
Blocking call that returns only when the earlier latch completed.
await() - Method in class net.esper.core.InsertIntoLatchWait
Blcking call that returns only when the earlier latch completed.

B

BAND - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BAND - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BAND_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BAND_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BaseAssemblyNode - Class in net.esper.eql.join.assemble
Represents a node in a tree responsible for assembling outer join query results.
BaseAssemblyNode(int, int) - Constructor for class net.esper.eql.join.assemble.BaseAssemblyNode
Ctor.
BaseBivariateStatisticsView - Class in net.esper.view.stat
View for computing statistics that require 2 input variable arrays containing X and Y datapoints.
BaseBivariateStatisticsView(StatementContext, BaseStatisticsBean, String, String) - Constructor for class net.esper.view.stat.BaseBivariateStatisticsView
Constructor requires the name of the two fields to use in the parent view to compute the statistics.
BaseConfigurableEventType - Class in net.esper.event
EventType than can be supplied with a preconfigured list of properties getters (aka.
BaseConfigurableEventType(Class) - Constructor for class net.esper.event.BaseConfigurableEventType
Ctor.
BaseStatisticsBean - Class in net.esper.view.stat
Bean for performing statistical calculations.
BaseStatisticsBean() - Constructor for class net.esper.view.stat.BaseStatisticsBean
 
BaseXMLEventType - Class in net.esper.event.xml
Base class for XMLEventTypes.
BaseXMLEventType(ConfigurationEventTypeXMLDOM) - Constructor for class net.esper.event.xml.BaseXMLEventType
Ctor.
BeanEventAdapter - Class in net.esper.event
A fcatory for BeanEventType instances based on Java class information and using configured settings for
BeanEventAdapter(ConcurrentHashMap<Class, BeanEventType>) - Constructor for class net.esper.event.BeanEventAdapter
Ctor.
BeanEventBean - Class in net.esper.event
Wrapper for Java bean (POJO or regular) Java objects the represent events.
BeanEventBean(Object, EventType) - Constructor for class net.esper.event.BeanEventBean
Constructor.
BeanEventType - Class in net.esper.event
Implementation of the EventType interface for handling JavaBean-type classes.
BeanEventType(Class, BeanEventTypeFactory, ConfigurationEventTypeLegacy, String) - Constructor for class net.esper.event.BeanEventType
Constructor takes a java bean class as an argument.
BeanEventType.SimplePropertyInfo - Class in net.esper.event
Descriptor caching the getter, class and property info.
BeanEventType.SimplePropertyInfo(Class, EventPropertyGetter, EventPropertyDescriptor) - Constructor for class net.esper.event.BeanEventType.SimplePropertyInfo
Ctor.
BeanEventTypeFactory - Interface in net.esper.event
Interface for a factory for obtaining BeanEventType instances.
between(String, Object, Object) - Static method in class net.esper.client.soda.Expressions
Between.
between(Expression, Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Between.
BETWEEN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BETWEEN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
betweenExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
BetweenExpression - Class in net.esper.client.soda
Between checks that a given value is in a range between a low endpoint and a high endpoint.
BetweenExpression(Expression, Expression, Expression) - Constructor for class net.esper.client.soda.BetweenExpression
Ctor, creates a between range check.
BetweenExpression(boolean, boolean, boolean) - Constructor for class net.esper.client.soda.BetweenExpression
Ctor - for use to create an expression tree, without child expression.
BetweenExpression(Expression, Expression, Expression, boolean, boolean, boolean) - Constructor for class net.esper.client.soda.BetweenExpression
Ctor.
betweenList() - Method in class net.esper.eql.generated.EQLStatementParser
 
betweenProperty(String, String, String) - Static method in class net.esper.client.soda.Expressions
Between.
binaryAnd() - Static method in class net.esper.client.soda.Expressions
Bitwise (binary) AND.
binaryOr() - Static method in class net.esper.client.soda.Expressions
Bitwise (binary) OR.
binaryXor() - Static method in class net.esper.client.soda.Expressions
Bitwise (binary) XOR.
bind(Name, Object) - Method in class net.esper.core.EngineEnvContext
 
bind(String, Object) - Method in class net.esper.core.EngineEnvContext
 
bitWiseExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
BitWiseOpEnum - Enum in net.esper.type
Enum representing relational types of operation.
BitWiseOpEnum.BAndBoolean - Class in net.esper.type
Bit Wise And.
BitWiseOpEnum.BAndBoolean() - Constructor for class net.esper.type.BitWiseOpEnum.BAndBoolean
 
BitWiseOpEnum.BAndByte - Class in net.esper.type
Bit Wise And.
BitWiseOpEnum.BAndByte() - Constructor for class net.esper.type.BitWiseOpEnum.BAndByte
 
BitWiseOpEnum.BAndInt - Class in net.esper.type
Bit Wise And.
BitWiseOpEnum.BAndInt() - Constructor for class net.esper.type.BitWiseOpEnum.BAndInt
 
BitWiseOpEnum.BAndLong - Class in net.esper.type
Bit Wise And.
BitWiseOpEnum.BAndLong() - Constructor for class net.esper.type.BitWiseOpEnum.BAndLong
 
BitWiseOpEnum.BAndShort - Class in net.esper.type
Bit Wise And.
BitWiseOpEnum.BAndShort() - Constructor for class net.esper.type.BitWiseOpEnum.BAndShort
 
BitWiseOpEnum.BOrBoolean - Class in net.esper.type
Bit Wise Or.
BitWiseOpEnum.BOrBoolean() - Constructor for class net.esper.type.BitWiseOpEnum.BOrBoolean
 
BitWiseOpEnum.BOrByte - Class in net.esper.type
Bit Wise Or.
BitWiseOpEnum.BOrByte() - Constructor for class net.esper.type.BitWiseOpEnum.BOrByte
 
BitWiseOpEnum.BOrInt - Class in net.esper.type
Bit Wise Or.
BitWiseOpEnum.BOrInt() - Constructor for class net.esper.type.BitWiseOpEnum.BOrInt
 
BitWiseOpEnum.BOrLong - Class in net.esper.type
Bit Wise Or.
BitWiseOpEnum.BOrLong() - Constructor for class net.esper.type.BitWiseOpEnum.BOrLong
 
BitWiseOpEnum.BOrShort - Class in net.esper.type
Bit Wise Or.
BitWiseOpEnum.BOrShort() - Constructor for class net.esper.type.BitWiseOpEnum.BOrShort
 
BitWiseOpEnum.BXorBoolean - Class in net.esper.type
Bit Wise Xor.
BitWiseOpEnum.BXorBoolean() - Constructor for class net.esper.type.BitWiseOpEnum.BXorBoolean
 
BitWiseOpEnum.BXorByte - Class in net.esper.type
Bit Wise Xor.
BitWiseOpEnum.BXorByte() - Constructor for class net.esper.type.BitWiseOpEnum.BXorByte
 
BitWiseOpEnum.BXorInt - Class in net.esper.type
Bit Wise Xor.
BitWiseOpEnum.BXorInt() - Constructor for class net.esper.type.BitWiseOpEnum.BXorInt
 
BitWiseOpEnum.BXorLong - Class in net.esper.type
Bit Wise Xor.
BitWiseOpEnum.BXorLong() - Constructor for class net.esper.type.BitWiseOpEnum.BXorLong
 
BitWiseOpEnum.BXorShort - Class in net.esper.type
Bit Wise Xor.
BitWiseOpEnum.BXorShort() - Constructor for class net.esper.type.BitWiseOpEnum.BXorShort
 
BitWiseOpEnum.Computer - Interface in net.esper.type
Computer for relational op.
BitwiseOpExpression - Class in net.esper.client.soda
Bitwise (binary) operator for binary AND, binary OR and binary XOR.
BitwiseOpExpression(BitWiseOpEnum) - Constructor for class net.esper.client.soda.BitwiseOpExpression
Ctor - for use to create an expression tree, without child expression.
BNOT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BNOT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BOGUS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BOOL_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BOOL_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BoolValue - Class in net.esper.type
Placeholder for a boolean value in an event expression.
BoolValue(Boolean) - Constructor for class net.esper.type.BoolValue
Constructor.
BoolValue() - Constructor for class net.esper.type.BoolValue
Constructor.
BOR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BOR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BOR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BOR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BranchOptionalAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a branch with a single optional child node below it.
BranchOptionalAssemblyNode(int, int) - Constructor for class net.esper.eql.join.assemble.BranchOptionalAssemblyNode
Ctor.
BranchRequiredAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a branch with a single required child node below it.
BranchRequiredAssemblyNode(int, int) - Constructor for class net.esper.eql.join.assemble.BranchRequiredAssemblyNode
Ctor.
BSR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BSR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BSR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BSR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BufferObserver - Interface in net.esper.view.internal
Observer interface to a stream publishing new and old events.
BufferView - Class in net.esper.view.internal
A view that acts as an adapter between views and update listeners.
BufferView(int) - Constructor for class net.esper.view.internal.BufferView
Ctor.
build(int, Map<Integer, int[]>, boolean[]) - Static method in class net.esper.eql.join.assemble.AssemblyStrategyTreeBuilder
Builds a tree of BaseAssemblyNode from join strategy information.
build(QueryGraph, List<OuterJoinDesc>, String[], EventType[]) - Static method in class net.esper.eql.join.plan.NStreamOuterQueryPlanBuilder
Build a query plan based on the stream property relationships indicated in queryGraph.
build(QueryGraph, EventType[]) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Build a query plan based on the stream property relationships indicated in queryGraph.
build(EventType[], QueryGraph, OuterJoinType) - Static method in class net.esper.eql.join.plan.TwoStreamQueryPlanBuilder
Build query plan.
buildDefaultNestingOrder(int, int) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Returns default nesting order for a given number of streams for a certain stream.
buildIndex(int, String[], Class[], EventType) - Static method in class net.esper.eql.join.JoinSetComposerFactoryImpl
Build an index/table instance using the event properties for the event type.
buildIndexSpec(QueryGraph) - Static method in class net.esper.eql.join.plan.QueryPlanIndexBuilder
Build index specification from navigability info.
buildNStreamDefaultQuerySpec(EventType[]) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Returns query plan based on all unindexed full table lookups and lookups based on a simple nesting order.
buildSpec(AST) - Static method in class net.esper.eql.parse.ASTOutputLimitHelper
Build an output limit spec from the AST node supplied.
buildSpec(AST) - Static method in class net.esper.eql.parse.ASTViewSpecHelper
Build a view specification from the AST node supplied.
buildTokenTypeASTClassMap() - Method in class net.esper.eql.generated.EQLStatementParser
 
builtinFunc(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
builtinFunc() - Method in class net.esper.eql.generated.EQLStatementParser
 
BXOR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BXOR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BXOR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BXOR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
BY - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
BY - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ByteValue - Class in net.esper.type
Placeholder for a byte value in an event expression.
ByteValue() - Constructor for class net.esper.type.ByteValue
 

C

calculateNewCapacity(int) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Calculates the new capacity of the map.
calculateThreshold(int, float) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Calculates the new threshold of the map, where it will be resized.
call(DynamicPropertyDescriptor, Object) - Method in class net.esper.event.property.DynamicIndexedPropertyGetter
 
call(DynamicPropertyDescriptor, Object) - Method in class net.esper.event.property.DynamicMappedPropertyGetter
 
call(DynamicPropertyDescriptor, Object) - Method in class net.esper.event.property.DynamicPropertyGetterBase
Call the getter to obtains the return result object, or null if no such method exists.
call(DynamicPropertyDescriptor, Object) - Method in class net.esper.event.property.DynamicSimplePropertyGetter
 
callbacksPerIndex - Variable in class net.esper.view.internal.PriorEventViewFactory
Map of prior-index and callback to expressions.
canCoerce(Class, Class) - Static method in class net.esper.util.JavaClassHelper
Determines if a number can be coerced upwards to another number class without loss.
canProvideCapability(ViewCapability) - Method in class net.esper.view.ext.SortWindowViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.ext.TimeOrderViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.internal.PriorEventViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.stat.CorrelationViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.std.GroupByViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.std.LastElementViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.std.MergeViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.std.SizeViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
canProvideCapability(ViewCapability) - Method in interface net.esper.view.ViewFactory
Returns true if the view factory can make views that provide a view resource with the given capability.
canProvideCapability(ViewCapability) - Method in class net.esper.view.ViewFactorySupport
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.KeepAllViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.LengthBatchViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.LengthWindowViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.TimeAccumViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.TimeBatchViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.TimeWindowViewFactory
 
canReuse(View) - Method in class net.esper.view.ext.SortWindowViewFactory
 
canReuse(View) - Method in class net.esper.view.ext.TimeOrderViewFactory
 
canReuse(View) - Method in class net.esper.view.internal.PriorEventViewFactory
 
canReuse(View) - Method in class net.esper.view.stat.CorrelationViewFactory
 
canReuse(View) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
canReuse(View) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
canReuse(View) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
canReuse(View) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
canReuse(View) - Method in class net.esper.view.std.GroupByViewFactory
 
canReuse(View) - Method in class net.esper.view.std.LastElementViewFactory
 
canReuse(View) - Method in class net.esper.view.std.MergeViewFactory
 
canReuse(View) - Method in class net.esper.view.std.SizeViewFactory
 
canReuse(View) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
canReuse(View) - Method in interface net.esper.view.ViewFactory
Determines if the given view could be used instead of creating a new view, requires the view factory to compare view type, parameters and other capabilities provided.
canReuse(View) - Method in class net.esper.view.ViewFactorySupport
 
canReuse(View) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
canReuse(View) - Method in class net.esper.view.window.KeepAllViewFactory
 
canReuse(View) - Method in class net.esper.view.window.LengthBatchViewFactory
 
canReuse(View) - Method in class net.esper.view.window.LengthWindowViewFactory
 
canReuse(View) - Method in class net.esper.view.window.TimeAccumViewFactory
 
canReuse(View) - Method in class net.esper.view.window.TimeBatchViewFactory
 
canReuse(View) - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
canReuse(View) - Method in class net.esper.view.window.TimeWindowViewFactory
 
CartesianProdAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a branch with a two or more child nodes (required and optional) below it.
CartesianProdAssemblyNode(int, int, boolean) - Constructor for class net.esper.eql.join.assemble.CartesianProdAssemblyNode
Ctor.
CartesianProdAssemblyNode.ChildStreamResults - Class in net.esper.eql.join.assemble
Structure to represent a list of event result rows per stream.
CartesianProdAssemblyNode.ChildStreamResults(int) - Constructor for class net.esper.eql.join.assemble.CartesianProdAssemblyNode.ChildStreamResults
Ctor.
CartesianUtil - Class in net.esper.eql.join.assemble
Helper class to compute the cartesian product of the events from two streams.
CartesianUtil() - Constructor for class net.esper.eql.join.assemble.CartesianUtil
 
CASE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CASE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CASE2 - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CASE2 - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
caseExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
caseExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
caseSwitch(Expression) - Static method in class net.esper.client.soda.Expressions
Case-switch expresssion.
caseSwitch(String) - Static method in class net.esper.client.soda.Expressions
Case-switch expresssion.
CaseSwitchExpression - Class in net.esper.client.soda
Case-expression that acts as a switch testing a value against other values.
CaseSwitchExpression() - Constructor for class net.esper.client.soda.CaseSwitchExpression
Ctor - for use to create an expression tree, without inner expression
CaseSwitchExpression(Expression) - Constructor for class net.esper.client.soda.CaseSwitchExpression
Ctor.
caseWhenThen() - Static method in class net.esper.client.soda.Expressions
Case-when-then expression.
CaseWhenThenExpression - Class in net.esper.client.soda
Case expression that act as a when-then-else.
CaseWhenThenExpression() - Constructor for class net.esper.client.soda.CaseWhenThenExpression
Ctor - for use to create an expression tree, without child expression.
cast(Expression, String) - Static method in class net.esper.client.soda.Expressions
Cast function, casts the result on an expression to the desired type, or returns null if the type cannot be casted to the type.
cast(String, String) - Static method in class net.esper.client.soda.Expressions
Cast function, casts the result on an expression to the desired type, or returns null if the type cannot be casted to the type.
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.ByteCaster
 
cast(Object) - Method in interface net.esper.eql.expression.ExprCastNode.Caster
Casts an object to another type.
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.DoubleCaster
 
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.FloatCaster
 
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.IntCaster
 
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.LongCaster
 
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.ShortCaster
 
cast(Object) - Method in class net.esper.eql.expression.ExprCastNode.TypeCaster
 
CAST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CAST - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CAST_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CAST_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CastExpression - Class in net.esper.client.soda
Cast expression casts the return value of an expression to a specified type.
CastExpression(String) - Constructor for class net.esper.client.soda.CastExpression
Ctor - for use to create an expression tree, without child expression.
CastExpression(Expression, String) - Constructor for class net.esper.client.soda.CastExpression
Ctor.
Cell - Interface in net.esper.view.stat.olap
Cell is the analytic values or variable tracked by a cube.
CellImpl - Class in net.esper.view.stat.olap
Hold the measure information which consists of a double value.
CellImpl(double) - Constructor for class net.esper.view.stat.olap.CellImpl
Constructor.
CGLibPropertyGetter - Class in net.esper.event
Property getter using CGLib's FastMethod instance.
CGLibPropertyGetter(FastMethod) - Constructor for class net.esper.event.CGLibPropertyGetter
Constructor.
checkCapacity() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Checks the capacity of the map and enlarges it if necessary.
checkLong(EventType, String) - Static method in class net.esper.view.PropertyCheckHelper
Check if the field identified by the field name is of type long according to the schema.
checkNumeric(EventType, String) - Static method in class net.esper.view.PropertyCheckHelper
Check if the field identified by the field name is a valid numeric field according to the schema.
checkNumeric(EventType, String, String) - Static method in class net.esper.view.PropertyCheckHelper
Check if the fields identified by their field names are valid numeric field according to the schema.
childNodes - Variable in class net.esper.eql.join.assemble.BaseAssemblyNode
Child nodes.
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalAndStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalEveryStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalFilterStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalFollowedByStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalGuardStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalNotStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalObserverStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalOrStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalRootStateNode
 
childrenAccept(EvalStateNodeVisitor, Object) - Method in class net.esper.pattern.EvalStateNode
Pass the visitor to all child nodes.
CLASS_IDENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CLASS_IDENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
classIdentifier() - Method in class net.esper.eql.generated.EQLStatementParser
 
classIdentifierNonGreedy() - Method in class net.esper.eql.generated.EQLStatementParser
 
clear() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Clears the map, resetting the size to zero and nullifying references to avoid garbage collection issues.
clear() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
 
clear() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
 
clear() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.Values
 
clear() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Clears this map.
clear() - Method in class net.esper.collection.ArrayBackedCollection
 
clear() - Method in class net.esper.collection.RefCountedMap
Clear out the collection.
clear() - Method in class net.esper.collection.RefCountedSet
Clear out the collection.
clear() - Method in class net.esper.collection.SortedDoubleVector
Clear out the collection.
clear() - Method in class net.esper.collection.SortedRefCountedSet
Clear out the collection.
clear() - Method in class net.esper.core.UpdateDispatchViewBase
Remove event reference to last event.
clear() - Method in interface net.esper.eql.agg.AggregationMethod
Clear out the collection.
clear() - Method in class net.esper.eql.agg.AvedevAggregator
 
clear() - Method in class net.esper.eql.agg.AvgAggregator
 
clear() - Method in class net.esper.eql.agg.CountAggregator
 
clear() - Method in class net.esper.eql.agg.DistinctValueAggregator
 
clear() - Method in class net.esper.eql.agg.DoubleSumAggregator
 
clear() - Method in class net.esper.eql.agg.FloatSumAggregator
 
clear() - Method in class net.esper.eql.agg.IntegerSumAggregator
 
clear() - Method in class net.esper.eql.agg.LongSumAggregator
 
clear() - Method in class net.esper.eql.agg.MedianAggregator
 
clear() - Method in class net.esper.eql.agg.MinMaxAggregator
 
clear() - Method in class net.esper.eql.agg.NonNullCountAggregator
 
clear() - Method in class net.esper.eql.agg.NumIntegerSumAggregator
 
clear() - Method in class net.esper.eql.agg.StddevAggregator
 
clear() - Method in interface net.esper.eql.core.ResultSetProcessor
Clear out current state.
clear() - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
 
clear() - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
 
clear() - Method in class net.esper.eql.core.ResultSetProcessorRowForAll
 
clear() - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
 
clear() - Method in class net.esper.eql.core.ResultSetProcessorSimple
 
clear() - Method in interface net.esper.eql.join.table.EventTable
Clear out index.
clear() - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
 
clear() - Method in class net.esper.eql.join.table.UnindexedEventTable
 
clear() - Method in class net.esper.eql.join.table.UnindexedEventTableList
 
clearEmittedListeners() - Method in interface net.esper.client.EPRuntime
Deregister all emitted event listeners.
clearEmittedListeners() - Method in class net.esper.core.EPRuntimeImpl
 
clearListeners() - Method in interface net.esper.emit.EmitService
Removes all listeners for emitted events.
clearListeners() - Method in class net.esper.emit.EmitServiceImpl
 
clearResults() - Method in interface net.esper.eql.agg.AggregationService
Clear current aggregation state.
clearResults() - Method in class net.esper.eql.agg.AggregationServiceGroupAllImpl
 
clearResults() - Method in class net.esper.eql.agg.AggregationServiceGroupByImpl
 
clearResults() - Method in class net.esper.eql.agg.AggregationServiceNull
 
clone() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Clones the map without cloning the keys or values.
clone() - Method in class net.esper.view.stat.BaseStatisticsBean
 
CloneableView - Interface in net.esper.view
Views that can work under a group-by must be able to duplicate and are required to implement this interface.
cloneView(StatementContext) - Method in interface net.esper.view.CloneableView
Duplicates the view.
cloneView(StatementContext) - Method in class net.esper.view.ext.SortWindowView
 
cloneView(StatementContext) - Method in class net.esper.view.ext.TimeOrderView
 
cloneView(StatementContext) - Method in class net.esper.view.stat.CorrelationView
 
cloneView(StatementContext) - Method in class net.esper.view.stat.MultiDimStatsView
 
cloneView(StatementContext) - Method in class net.esper.view.stat.RegressionLinestView
 
cloneView(StatementContext) - Method in class net.esper.view.stat.UnivariateStatisticsView
 
cloneView(StatementContext) - Method in class net.esper.view.stat.WeightedAverageView
 
cloneView(StatementContext) - Method in class net.esper.view.std.AddPropertyValueView
 
cloneView(StatementContext) - Method in class net.esper.view.std.GroupByView
 
cloneView(StatementContext) - Method in class net.esper.view.std.LastElementView
 
cloneView(StatementContext) - Method in class net.esper.view.std.MergeView
 
cloneView(StatementContext) - Method in class net.esper.view.std.SizeView
 
cloneView(StatementContext) - Method in class net.esper.view.std.UniqueByPropertyView
 
cloneView(StatementContext) - Method in class net.esper.view.window.ExternallyTimedWindowView
 
cloneView(StatementContext) - Method in class net.esper.view.window.KeepAllView
 
cloneView(StatementContext) - Method in class net.esper.view.window.LengthBatchView
 
cloneView(StatementContext) - Method in class net.esper.view.window.LengthBatchViewRStream
 
cloneView(StatementContext) - Method in class net.esper.view.window.LengthWindowView
 
cloneView(StatementContext) - Method in class net.esper.view.window.LengthWindowViewRStream
 
cloneView(StatementContext) - Method in class net.esper.view.window.TimeAccumView
 
cloneView(StatementContext) - Method in class net.esper.view.window.TimeAccumViewRStream
 
cloneView(StatementContext) - Method in class net.esper.view.window.TimeBatchView
 
cloneView(StatementContext) - Method in class net.esper.view.window.TimeBatchViewRStream
 
cloneView(StatementContext) - Method in class net.esper.view.window.TimeLengthBatchView
 
cloneView(StatementContext) - Method in class net.esper.view.window.TimeWindowView
 
close() - Method in interface net.esper.client.SafeIterator
Close the safe itertor, releasing locks.
close() - Method in class net.esper.collection.SafeIteratorImpl
 
close() - Method in class net.esper.core.EngineEnvContext
 
close(Pair<Connection, PreparedStatement>) - Static method in class net.esper.eql.db.ConnectionCache
Close resources.
coalesce(String, String, String...) - Static method in class net.esper.client.soda.Expressions
Coalesce.
coalesce(Expression, Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
Coalesce.
COALESCE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COALESCE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CoalesceExpression - Class in net.esper.client.soda
Coalesce-function which returns the first non-null value in a list of values.
CoalesceExpression() - Constructor for class net.esper.client.soda.CoalesceExpression
Ctor - for use to create an expression tree, without child expression.
CoalesceExpression(String, String, String...) - Constructor for class net.esper.client.soda.CoalesceExpression
Ctor.
CoalesceExpression(Expression, Expression, Expression...) - Constructor for class net.esper.client.soda.CoalesceExpression
Ctor.
coerceBoxed(Number, Class) - Static method in class net.esper.util.JavaClassHelper
Coerce the given number to the given type, assuming the type is a Boxed type.
CoercionException - Exception in net.esper.util
Exception to represent a mismatch in Java types in an expression.
CoercionException(String) - Constructor for exception net.esper.util.CoercionException
Ctor.
COLON - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COLON - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
columnField - Variable in class net.esper.view.stat.MultiDimStatsViewFactory
Property name supplying columns.
ColumnSettings - Class in net.esper.eql.db
Column-level configuration settings are held in this immutable descriptor.
ColumnSettings(ConfigurationDBRef.MetadataOriginEnum, ConfigurationDBRef.ColumnChangeCaseEnum, Map<Integer, String>) - Constructor for class net.esper.eql.db.ColumnSettings
Ctor.
COMMA - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COMMA - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
commit() - Method in interface net.esper.eql.variable.VariableService
Commits the variable outstanding changes.
commit() - Method in class net.esper.eql.variable.VariableServiceImpl
 
compare(DoubleRange, DoubleRange) - Method in class net.esper.filter.DoubleRangeComparator
 
compare(FilterValueSetParam, FilterValueSetParam) - Method in class net.esper.filter.FilterValueSetParamComparator
 
compare(Object, Object) - Method in interface net.esper.type.RelationalOpEnum.Computer
Compares objects and returns boolean indicating larger (true) or smaller (false).
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.GEDoubleComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.GELongComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.GEStringComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.GTDoubleComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.GTLongComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.GTStringComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.LEDoubleComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.LELongComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.LEStringComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.LTDoubleComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.LTLongComputer
 
compare(Object, Object) - Method in class net.esper.type.RelationalOpEnum.LTStringComputer
 
compare(String) - Method in class net.esper.util.LikeUtil
Execute the string.
compare(MultiKeyUntyped, MultiKeyUntyped) - Method in class net.esper.util.MultiKeyComparator
 
compareTo(Object) - Method in class net.esper.eql.lookup.JoinedPropDesc
 
compareTo(ScheduleSlot) - Method in class net.esper.schedule.ScheduleSlot
 
compareValues(Object, Object, boolean) - Static method in class net.esper.eql.core.OrderByProcessorSimple
Compares values for sorting.
compile(EventAdapterService, MethodResolutionService, PatternObjectResolutionService, TimeProvider, NamedWindowService, VariableService) - Method in class net.esper.eql.spec.DBStatementStreamSpec
 
compile(EventAdapterService, MethodResolutionService, PatternObjectResolutionService, TimeProvider, NamedWindowService, VariableService) - Method in class net.esper.eql.spec.FilterStreamSpecRaw
 
compile(EventAdapterService, MethodResolutionService, PatternObjectResolutionService, TimeProvider, NamedWindowService, VariableService) - Method in class net.esper.eql.spec.MethodStreamSpec
 
compile(EventAdapterService, MethodResolutionService, PatternObjectResolutionService, TimeProvider, NamedWindowService, VariableService) - Method in class net.esper.eql.spec.PatternStreamSpecRaw
 
compile(EventAdapterService, MethodResolutionService, PatternObjectResolutionService, TimeProvider, NamedWindowService, VariableService) - Method in interface net.esper.eql.spec.StreamSpecRaw
Compiles a raw stream specification consisting event type information and filter expressions to an validated, optimized form for use with filter service
compileEQL(String) - Method in interface net.esper.client.EPAdministrator
Compiles a given EQL into an object model representation of the query.
compileEQL(String) - Method in class net.esper.core.EPAdministratorImpl
 
composeName(Name, Name) - Method in class net.esper.core.EngineEnvContext
 
composeName(String, String) - Method in class net.esper.core.EngineEnvContext
 
CompositeEventBean - Class in net.esper.event
Event bean wrapper for events that consists of a Map of name tags as key values and event bean wrappers as value objects, for use by pattern expressions.
CompositeEventBean(Map<String, EventBean>, EventType) - Constructor for class net.esper.event.CompositeEventBean
Ctor.
CompositeEventType - Class in net.esper.event
Event type for events that itself have event properties that are event wrappers.
CompositeEventType(String, Map<String, EventType>) - Constructor for class net.esper.event.CompositeEventType
Ctor.
compress(Map<ScheduleUnit, SortedSet<Integer>>) - Static method in class net.esper.schedule.ScheduleSpec
Function to reduce value sets for unit that cover the whole range down to a wildcard.
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BAndBoolean
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BAndByte
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BAndInt
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BAndLong
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BAndShort
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BOrBoolean
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BOrByte
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BOrInt
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BOrLong
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BOrShort
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BXorBoolean
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BXorByte
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BXorInt
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BXorLong
 
compute(Object, Object) - Method in class net.esper.type.BitWiseOpEnum.BXorShort
 
compute(Object, Object) - Method in interface net.esper.type.BitWiseOpEnum.Computer
Computes using the 2 numbers or boolean a result object.
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.AddDouble
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.AddFloat
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.AddInt
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.AddLong
 
compute(Number, Number) - Method in interface net.esper.type.MathArithTypeEnum.Computer
Computes using the 2 numbers a result number.
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.DivideDouble
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.DivideFloat
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.DivideInt
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.DivideLong
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.ModuloDouble
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.ModuloFloat
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.ModuloInt
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.ModuloLong
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.MultiplyDouble
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.MultiplyFloat
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.MultiplyInt
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.MultiplyLong
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.SubtractDouble
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.SubtractFloat
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.SubtractInt
 
compute(Number, Number) - Method in class net.esper.type.MathArithTypeEnum.SubtractLong
 
computeBestPath(int, QueryGraph) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Compute a best chain or path for lookups to take for the lookup stream passed in and the query property relationships.
computeCartesian(List<EventBean[]>, int[], List<EventBean[]>, int[], List<EventBean[]>) - Static method in class net.esper.eql.join.assemble.CartesianUtil
Form the 2-ary cartesian product between zero or more events from 2 streams.
computeCombined(int[][]) - Static method in class net.esper.eql.join.assemble.RootCartProdAssemblyNode
Compute an array of supersets of sub stream numbers per stream, for at least 3 or more streams.
computeNavigableDepth(int, int[], QueryGraph) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Given a chain of streams to look up and indexing information, compute the index within the chain of the first non-index lookup.
computeNextOccurance(ScheduleSpec, long) - Static method in class net.esper.schedule.ScheduleComputeHelper
Computes the next lowest date in milliseconds based on a specification and the from-time passed in.
computeWaitMSec(long, long, long) - Static method in class net.esper.eql.view.OutputConditionTime
Given a current time and a reference time and an interval size, compute the amount of milliseconds till the next interval.
computeWaitMSec(long, long, long) - Static method in class net.esper.view.window.TimeBatchView
Given a current time and a reference time and an interval size, compute the amount of milliseconds till the next interval.
concat(String, String...) - Static method in class net.esper.client.soda.Expressions
Concatenation.
CONCAT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CONCAT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
concatenationExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
ConcatExpression - Class in net.esper.client.soda
Concatenation expression that concatenates the result of child expressions to the expression.
ConcatExpression() - Constructor for class net.esper.client.soda.ConcatExpression
 
Configuration - Class in net.esper.client
An instance of Configuration allows the application to specify properties to be used when creating a EPServiceProvider.
Configuration() - Constructor for class net.esper.client.Configuration
Constructs an empty configuration.
Configuration.PropertyResolutionStyle - Enum in net.esper.client
Enumeration of different resolution styles for resolving property names.
ConfigurationAdapterLoader - Class in net.esper.client
Holds configuration for an input/output adapter loader.
ConfigurationAdapterLoader() - Constructor for class net.esper.client.ConfigurationAdapterLoader
Ctor.
ConfigurationDBRef - Class in net.esper.client
Container for database configuration information, such as options around getting a database connection and options to control the lifecycle of connections and set connection parameters.
ConfigurationDBRef() - Constructor for class net.esper.client.ConfigurationDBRef
Ctor.
ConfigurationDBRef.CacheReferenceType - Enum in net.esper.client
Enum indicating what kind of references are used to store the cache map's keys and values.
ConfigurationDBRef.ColumnChangeCaseEnum - Enum in net.esper.client
Controls how output column names get reflected in the event type.
ConfigurationDBRef.ConnectionFactoryDesc - Interface in net.esper.client
Marker for different connection factory settings.
ConfigurationDBRef.ConnectionLifecycleEnum - Enum in net.esper.client
Enum controlling connection lifecycle.
ConfigurationDBRef.ConnectionSettings - Class in net.esper.client
Supplies connectioon-level settings for a given database name.
ConfigurationDBRef.ConnectionSettings() - Constructor for class net.esper.client.ConfigurationDBRef.ConnectionSettings
 
ConfigurationDBRef.DataCacheDesc - Interface in net.esper.client
Marker for different cache settings.
ConfigurationDBRef.DataSourceConnection - Class in net.esper.client
Connection factory settings for using a DataSource.
ConfigurationDBRef.DataSourceConnection(String, Properties) - Constructor for class net.esper.client.ConfigurationDBRef.DataSourceConnection
Ctor.
ConfigurationDBRef.DriverManagerConnection - Class in net.esper.client
Connection factory settings for using a DriverManager.
ConfigurationDBRef.DriverManagerConnection(String, String, Properties) - Constructor for class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Ctor.
ConfigurationDBRef.DriverManagerConnection(String, String, String, String) - Constructor for class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Ctor.
ConfigurationDBRef.DriverManagerConnection(String, String, String, String, Properties) - Constructor for class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Ctor.
ConfigurationDBRef.ExpiryTimeCacheDesc - Class in net.esper.client
Expiring cache settings.
ConfigurationDBRef.ExpiryTimeCacheDesc(double, double, ConfigurationDBRef.CacheReferenceType) - Constructor for class net.esper.client.ConfigurationDBRef.ExpiryTimeCacheDesc
Ctor.
ConfigurationDBRef.LRUCacheDesc - Class in net.esper.client
LRU cache settings.
ConfigurationDBRef.LRUCacheDesc(int) - Constructor for class net.esper.client.ConfigurationDBRef.LRUCacheDesc
Ctor.
ConfigurationDBRef.MetadataOriginEnum - Enum in net.esper.client
Indicates how the engine retrieves metadata about a statement's output columns.
ConfigurationEngineDefaults - Class in net.esper.client
Provides access to engine configuration defaults for modification.
ConfigurationEngineDefaults() - Constructor for class net.esper.client.ConfigurationEngineDefaults
Ctor.
ConfigurationEngineDefaults.EventMeta - Class in net.esper.client
Event representation metadata.
ConfigurationEngineDefaults.EventMeta() - Constructor for class net.esper.client.ConfigurationEngineDefaults.EventMeta
Ctor.
ConfigurationEngineDefaults.Logging - Class in net.esper.client
Holds view logging settings other then the Apache commons or Log4J settings.
ConfigurationEngineDefaults.Logging() - Constructor for class net.esper.client.ConfigurationEngineDefaults.Logging
Ctor - sets up defaults.
ConfigurationEngineDefaults.Threading - Class in net.esper.client
Holds threading settings.
ConfigurationEngineDefaults.Threading() - Constructor for class net.esper.client.ConfigurationEngineDefaults.Threading
Ctor - sets up defaults.
ConfigurationEngineDefaults.Threading.Locking - Enum in net.esper.client
Enumeration of blocking techniques.
ConfigurationEngineDefaults.Variables - Class in net.esper.client
Holds variables settings.
ConfigurationEngineDefaults.Variables() - Constructor for class net.esper.client.ConfigurationEngineDefaults.Variables
Ctor - sets up defaults.
ConfigurationEngineDefaults.ViewResources - Class in net.esper.client
Holds view resources settings.
ConfigurationEngineDefaults.ViewResources() - Constructor for class net.esper.client.ConfigurationEngineDefaults.ViewResources
Ctor - sets up defaults.
ConfigurationEventTypeLegacy - Class in net.esper.client
Configuration information for legacy (non-JavaBean) event types.
ConfigurationEventTypeLegacy() - Constructor for class net.esper.client.ConfigurationEventTypeLegacy
Ctor.
ConfigurationEventTypeLegacy.AccessorStyle - Enum in net.esper.client
Accessor style defines the methods of a class that are automatically exposed via event property.
ConfigurationEventTypeLegacy.CodeGeneration - Enum in net.esper.client
Enum to control code generation.
ConfigurationEventTypeLegacy.LegacyFieldPropDesc - Class in net.esper.client
Encapsulates information about an accessor field backing a named event property.
ConfigurationEventTypeLegacy.LegacyFieldPropDesc(String, String) - Constructor for class net.esper.client.ConfigurationEventTypeLegacy.LegacyFieldPropDesc
Ctor.
ConfigurationEventTypeLegacy.LegacyMethodPropDesc - Class in net.esper.client
Encapsulates information about an accessor method backing a named event property.
ConfigurationEventTypeLegacy.LegacyMethodPropDesc(String, String) - Constructor for class net.esper.client.ConfigurationEventTypeLegacy.LegacyMethodPropDesc
Ctor.
ConfigurationEventTypeXMLDOM - Class in net.esper.client
Configuration object for enabling the engine to process events represented as XML DOM document nodes.
ConfigurationEventTypeXMLDOM() - Constructor for class net.esper.client.ConfigurationEventTypeXMLDOM
Ctor.
ConfigurationEventTypeXMLDOM.XPathPropertyDesc - Class in net.esper.client
Descriptor class for event properties that are resolved via XPath-expression.
ConfigurationEventTypeXMLDOM.XPathPropertyDesc(String, String, QName) - Constructor for class net.esper.client.ConfigurationEventTypeXMLDOM.XPathPropertyDesc
Ctor.
ConfigurationException - Exception in net.esper.client
Thrown to indicate a configuration problem.
ConfigurationException(String) - Constructor for exception net.esper.client.ConfigurationException
Ctor.
ConfigurationException(String, Throwable) - Constructor for exception net.esper.client.ConfigurationException
Ctor for an inner exception and message.
ConfigurationException(Throwable) - Constructor for exception net.esper.client.ConfigurationException
Ctor - just an inner exception.
ConfigurationInformation - Interface in net.esper.client
Provides configurations for an engine instance.
ConfigurationMethodRef - Class in net.esper.client
Holds configuration information for data caches for use in method invocations in the from-clause.
ConfigurationMethodRef() - Constructor for class net.esper.client.ConfigurationMethodRef
 
ConfigurationOperations - Interface in net.esper.client
Provides configuration operations for configuration-time and runtime parameters.
ConfigurationOperationsImpl - Class in net.esper.core
Provides runtime engine configuration operations.
ConfigurationOperationsImpl(EventAdapterService, EngineImportService, VariableService) - Constructor for class net.esper.core.ConfigurationOperationsImpl
Ctor.
ConfigurationPlugInAggregationFunction - Class in net.esper.client
Configuration information for plugging in a custom aggregation function.
ConfigurationPlugInAggregationFunction() - Constructor for class net.esper.client.ConfigurationPlugInAggregationFunction
Ctor.
ConfigurationPlugInPatternObject - Class in net.esper.client
Configuration information for plugging in a custom view.
ConfigurationPlugInPatternObject() - Constructor for class net.esper.client.ConfigurationPlugInPatternObject
Ctor.
ConfigurationPlugInPatternObject.PatternObjectType - Enum in net.esper.client
Choice for type of pattern object.
ConfigurationPlugInView - Class in net.esper.client
Configuration information for plugging in a custom view.
ConfigurationPlugInView() - Constructor for class net.esper.client.ConfigurationPlugInView
Ctor.
ConfigurationVariable - Class in net.esper.client
Provides variable configuration.
ConfigurationVariable() - Constructor for class net.esper.client.ConfigurationVariable
 
configure() - Method in class net.esper.client.Configuration
Use the configuration specified in an application resource named esper.cfg.xml.
configure(String) - Method in class net.esper.client.Configuration
Use the configuration specified in the given application resource.
configure(URL) - Method in class net.esper.client.Configuration
Use the configuration specified by the given URL.
configure(File) - Method in class net.esper.client.Configuration
Use the configuration specified in the given application file.
configure(Document) - Method in class net.esper.client.Configuration
Use the mappings and properties specified in the given XML document.
Conjunction - Class in net.esper.client.soda
Conjunction represents a logical AND allowing multiple sub-expressions to be connected by AND.
Conjunction() - Constructor for class net.esper.client.soda.Conjunction
Ctor - for use to create an expression tree, without child expression.
Conjunction(Expression, Expression, Expression...) - Constructor for class net.esper.client.soda.Conjunction
Ctor.
ConnectionCache - Class in net.esper.eql.db
Base class for a Connection and PreparedStatement cache.
ConnectionCache(DatabaseConnectionFactory, String) - Constructor for class net.esper.eql.db.ConnectionCache
Ctor.
ConnectionCacheImpl - Class in net.esper.eql.db
Caches the Connection and PreparedStatement instance for reuse.
ConnectionCacheImpl(DatabaseConnectionFactory, String) - Constructor for class net.esper.eql.db.ConnectionCacheImpl
Ctor.
ConnectionNoCacheImpl - Class in net.esper.eql.db
Implementation of a connection cache that simply doesn't cache but gets a new connection and statement every request, and closes these every time a client indicates done.
ConnectionNoCacheImpl(DatabaseConnectionFactory, String) - Constructor for class net.esper.eql.db.ConnectionNoCacheImpl
Ctor.
constant(Object) - Static method in class net.esper.client.soda.Expressions
Constant.
constant(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
constant() - Method in class net.esper.eql.generated.EQLStatementParser
 
ConstantExpression - Class in net.esper.client.soda
Constant value returns a fixed value for use in expressions.
ConstantExpression(Object) - Constructor for class net.esper.client.soda.ConstantExpression
Ctor.
ConstructorHelper - Class in net.esper.util
Helper class to find and invoke a class constructors that matches the types of arguments supplied.
ConstructorHelper() - Constructor for class net.esper.util.ConstructorHelper
 
contains(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
 
contains(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
 
contains(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.Values
 
contains(Object) - Method in class net.esper.collection.ArrayBackedCollection
 
contains(FilterHandle) - Method in class net.esper.filter.FilterHandleSetNode
Returns an indication whether the filter callback exists in this node.
containsAll(Collection) - Method in class net.esper.collection.ArrayBackedCollection
 
containsKey(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Checks whether the map contains the specified key.
containsKey(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Checks whether the map contains the specified key.
containsValue(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Checks whether the map contains the specified value.
containsValue(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Checks whether the map contains the specified value.
continueOutputProcessing(boolean, boolean) - Method in interface net.esper.eql.view.OutputCallback
Invoked to perform output processing.
continueOutputProcessingJoin(boolean, boolean) - Method in class net.esper.eql.view.OutputProcessViewPolicy
Called once the output condition has been met.
continueOutputProcessingView(boolean, boolean) - Method in class net.esper.eql.view.OutputProcessViewPolicy
Called once the output condition has been met.
convert(RecognitionException, String) - Static method in exception net.esper.eql.parse.EPStatementSyntaxException
Converts from a syntax error to a nice statement exception.
convert(TokenStreamException, String) - Static method in exception net.esper.eql.parse.EPStatementSyntaxException
Converts from a syntax (token stream) error to a nice statement exception.
convertEndOfInput(RecognitionException, String, String) - Static method in exception net.esper.eql.parse.EPStatementSyntaxException
Converts end-of-input error from a syntax error to a nice statement exception.
convertEndOfInput(RecognitionException, String) - Static method in exception net.esper.eql.parse.EPStatementSyntaxException
Converts end-of-input error from a syntax error to a nice statement exception.
convertKey(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Converts input keys to another object for storage in the map.
copy(Object) - Static method in class net.esper.util.SerializableObjectCopier
Deep copies the input object.
copySortParameters(List<FilterValueSetParam>) - Static method in class net.esper.filter.IndexTreeBuilder
Copy the parameter list - this also sorts the parameter list.
CorrelationBean - Class in net.esper.view.stat
Bean for calculating the correlation (same to Microsoft Excel CORREL function).
CorrelationBean() - Constructor for class net.esper.view.stat.CorrelationBean
 
CorrelationView - Class in net.esper.view.stat
A view that calculates correlation on two fields.
CorrelationView(StatementContext, String, String) - Constructor for class net.esper.view.stat.CorrelationView
Constructor.
CorrelationViewFactory - Class in net.esper.view.stat
Factory for CorrelationView instances.
CorrelationViewFactory() - Constructor for class net.esper.view.stat.CorrelationViewFactory
 
count(String) - Static method in class net.esper.client.soda.Expressions
Count aggregation function.
count(Expression) - Static method in class net.esper.client.soda.Expressions
Count aggregation function.
COUNT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COUNT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CountAggregator - Class in net.esper.eql.agg
Counts all datapoints including null values.
CountAggregator() - Constructor for class net.esper.eql.agg.CountAggregator
 
countDistinct(String) - Static method in class net.esper.client.soda.Expressions
Count aggregation function considering distinct values only.
countDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Count aggregation function considering distinct values only.
CountProjectionExpression - Class in net.esper.client.soda
Count of the (distinct) values returned by an expression, equivalent to "count(distinct property)"
CountProjectionExpression(boolean) - Constructor for class net.esper.client.soda.CountProjectionExpression
Ctor - for use to create an expression tree, without inner expression
CountProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.CountProjectionExpression
Ctor - adds the expression to project.
countStar() - Static method in class net.esper.client.soda.Expressions
Count aggregation function not counting values, equivalent to "count(*)".
CountStarProjectionExpression - Class in net.esper.client.soda
Count of (distinct) rows, equivalent to "count(*)"
CountStarProjectionExpression() - Constructor for class net.esper.client.soda.CountStarProjectionExpression
Ctor - for use to create an expression tree, without inner expression.
create(EPStatementObjectModel, String) - Method in interface net.esper.client.EPAdministrator
Creates and starts an EQL statement.
create(EPStatementObjectModel) - Method in interface net.esper.client.EPAdministrator
Creates and starts an EQL statement.
create(EPPreparedStatement, String) - Method in interface net.esper.client.EPAdministrator
Creates and starts a prepared statement.
create(EPPreparedStatement) - Method in interface net.esper.client.EPAdministrator
Creates and starts a prepared statement.
create(String, String) - Static method in class net.esper.client.soda.CreateVariableClause
Creates a create-variable syntax for declaring a variable.
create(String, String, Expression) - Static method in class net.esper.client.soda.CreateVariableClause
Creates a create-variable syntax for declaring a variable.
create(String, View) - Static method in class net.esper.client.soda.CreateWindowClause
Creates a clause to create a named window.
create(String, View...) - Static method in class net.esper.client.soda.CreateWindowClause
Creates a clause to create a named window.
create(String) - Static method in class net.esper.client.soda.Filter
Creates a filter to the given named event type.
create(String, Expression) - Static method in class net.esper.client.soda.Filter
Creates a filter to the given named event type and filter expression.
create(Filter) - Static method in class net.esper.client.soda.FilterStream
Creates a stream using a filter that provides the event type name and filter expression to filter for.
create(String) - Static method in class net.esper.client.soda.FilterStream
Creates a stream of events of the given name.
create(String, String) - Static method in class net.esper.client.soda.FilterStream
Creates a stream of events of the given event type name and names that stream.
create(Filter, String) - Static method in class net.esper.client.soda.FilterStream
Creates a stream using a filter that provides the event type name and filter expression to filter for.
create(String, Expression) - Static method in class net.esper.client.soda.FilterStream
Creates a stream of events of the given event type name and names that stream.
create() - Static method in class net.esper.client.soda.FromClause
Creates an empty from-clause to which one adds streams via the add methods.
create(Stream, OuterJoinQualifier, Stream) - Static method in class net.esper.client.soda.FromClause
Creates a from-clause that lists 2 projected streams joined via outer join.
create(Stream...) - Static method in class net.esper.client.soda.FromClause
Creates a from clause that selects from a single stream.
create() - Static method in class net.esper.client.soda.GroupByClause
Creates an empty group-by clause, to add to via add methods.
create(String...) - Static method in class net.esper.client.soda.GroupByClause
Creates a group-by clause from property names.
create(Expression...) - Static method in class net.esper.client.soda.GroupByClause
Creates a group-by clause from expressions.
create(String) - Static method in class net.esper.client.soda.InsertIntoClause
Creates the insert-into clause.
create(String, String...) - Static method in class net.esper.client.soda.InsertIntoClause
Creates the insert-into clause.
create(String, String[], StreamSelector) - Static method in class net.esper.client.soda.InsertIntoClause
Creates the insert-into clause.
create(String, String) - Static method in class net.esper.client.soda.MethodInvocationStream
Creates a new method-invocation-based stream without parameters.
create(String, String, String) - Static method in class net.esper.client.soda.MethodInvocationStream
Creates a new method-invocation-based stream without parameters.
create(String, String) - Static method in class net.esper.client.soda.OnDeleteClause
Creates an on-delete clause.
create(String, String) - Static method in class net.esper.client.soda.OnSelectClause
Creates an on-select clause.
create(String, Expression) - Static method in class net.esper.client.soda.OnSetClause
Creates a new on-set clause for setting variables, and adds a variable to set.
create() - Static method in class net.esper.client.soda.OrderByClause
Create an empty order-by clause.
create(String...) - Static method in class net.esper.client.soda.OrderByClause
Create an order-by clause.
create(Expression...) - Static method in class net.esper.client.soda.OrderByClause
Create an order-by clause.
create(String, OuterJoinType, String) - Static method in class net.esper.client.soda.OuterJoinQualifier
Creates qualifier.
create(OutputLimitSelector, double, OutputLimitUnit) - Static method in class net.esper.client.soda.OutputLimitClause
Creates an output limit clause.
create(OutputLimitSelector, String, OutputLimitUnit) - Static method in class net.esper.client.soda.OutputLimitClause
Creates an output limit clause.
create(double, OutputLimitUnit) - Static method in class net.esper.client.soda.OutputLimitClause
Creates an output limit clause.
create(String, OutputLimitUnit) - Static method in class net.esper.client.soda.OutputLimitClause
Creates an output limit clause.
create(PatternExpr) - Static method in class net.esper.client.soda.PatternStream
Creates a pattern stream from a pattern expression.
create(PatternExpr, String) - Static method in class net.esper.client.soda.PatternStream
Creates a named pattern stream from a pattern expression.
create() - Static method in class net.esper.client.soda.SelectClause
Creates an empty select-clause to be added to via add methods.
create(String...) - Static method in class net.esper.client.soda.SelectClause
Creates a select-clause consisting of a list of property names.
create(StreamSelector) - Static method in class net.esper.client.soda.SelectClause
Creates an empty select-clause.
create(StreamSelector, String...) - Static method in class net.esper.client.soda.SelectClause
Creates a select-clause consisting of a list of property names.
create(String, String) - Static method in class net.esper.client.soda.SQLStream
Creates a new SQL-based stream.
create(String, String, String) - Static method in class net.esper.client.soda.SQLStream
Creates a new SQL-based stream.
create(String, String, String, String) - Static method in class net.esper.client.soda.SQLStream
Creates a new SQL-based stream.
create(String, String) - Static method in class net.esper.client.soda.View
Creates a view.
create(String, String, List<Object>) - Static method in class net.esper.client.soda.View
Creates a view.
create(String, String, Object...) - Static method in class net.esper.client.soda.View
Creates a view.
create(EPStatementObjectModel) - Method in class net.esper.core.EPAdministratorImpl
 
create(EPStatementObjectModel, String) - Method in class net.esper.core.EPAdministratorImpl
 
create(EPPreparedStatement, String) - Method in class net.esper.core.EPAdministratorImpl
 
create(EPPreparedStatement) - Method in class net.esper.core.EPAdministratorImpl
 
CREATE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CREATE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
create(PatternObserverSpec) - Method in interface net.esper.pattern.PatternObjectResolutionService
Creates an observer factory considering configured plugged-in resources.
create(PatternGuardSpec) - Method in interface net.esper.pattern.PatternObjectResolutionService
Creates a guard factory considering configured plugged-in resources.
create(PatternObserverSpec) - Method in class net.esper.pattern.PatternObjectResolutionServiceImpl
 
create(PatternGuardSpec) - Method in class net.esper.pattern.PatternObjectResolutionServiceImpl
 
create(Class) - Static method in class net.esper.type.PrimitiveValueFactory
Create a placeholder instance for the primitive Java type passed in.
create() - Method in class net.esper.util.GenericFactory
Create instance of class.
create(String, String) - Method in interface net.esper.view.ViewResolutionService
Instantiates a ViewFactory based on the view namespace and name stored in the view spec.
create(String, String) - Method in class net.esper.view.ViewResolutionServiceImpl
 
CREATE_VARIABLE_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CREATE_VARIABLE_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CREATE_WINDOW_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CREATE_WINDOW_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
CREATE_WINDOW_SELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CREATE_WINDOW_SELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
createAddToEventType(EventType, String[], Class[]) - Method in interface net.esper.event.EventAdapterService
Create an event type based on the original type passed in adding one or more properties.
createAddToEventType(EventType, String[], Class[]) - Method in class net.esper.event.EventAdapterServiceImpl
 
createAndStart(StatementSpecRaw, String, boolean, String) - Method in interface net.esper.core.StatementLifecycleSvc
Create and start the statement.
createAndStart(StatementSpecRaw, String, boolean, String) - Method in class net.esper.core.StatementLifecycleSvcImpl
 
createAndStart(StatementSpecRaw, String, boolean, String, String, Map<String, Object>) - Method in class net.esper.core.StatementLifecycleSvcImpl
Creates and starts statement.
createAnonymousCompositeType(Map<String, EventType>) - Method in interface net.esper.event.EventAdapterService
Creates an unnamed composite event type with event properties that are name-value pairs with values being other event types.
createAnonymousCompositeType(Map<String, EventType>) - Method in class net.esper.event.EventAdapterServiceImpl
 
createAnonymousMapType(Map<String, Class>) - Method in interface net.esper.event.EventAdapterService
Creates a new anonymous EventType instance for an event type that contains a map of name value pairs.
createAnonymousMapType(Map<String, Class>) - Method in class net.esper.event.EventAdapterServiceImpl
 
createAnonymousWrapperType(EventType, Map<String, Class>) - Method in interface net.esper.event.EventAdapterService
Create a new anonymous event type with the given underlying event type, as well as the additional given properties.
createAnonymousWrapperType(EventType, Map<String, Class>) - Method in class net.esper.event.EventAdapterServiceImpl
 
createBeanType(String, Class) - Method in class net.esper.event.BeanEventAdapter
Creates a new EventType object for a java bean of the specified class if this is the first time the class has been seen.
createBeanType(String, Class) - Method in interface net.esper.event.BeanEventTypeFactory
Returns the bean event type for a given class assigning the given alias.
createBuilder(ConfigurationEventTypeLegacy) - Static method in class net.esper.event.property.PropertyListBuilderFactory
Creates an implementation for a builer considering the accessor style and code generation flags for a given class.
createCondition(OutputLimitSpec, StatementContext, OutputCallback) - Method in interface net.esper.eql.view.OutputConditionFactory
Creates an output condition instance.
createCondition(OutputLimitSpec, StatementContext, OutputCallback) - Method in class net.esper.eql.view.OutputConditionFactoryDefault
Creates an output condition instance.
createContext(StatementContext, int, EvalRootNode) - Method in interface net.esper.pattern.PatternContextFactory
Create a pattern context.
createContext(StatementContext, int, EvalRootNode) - Method in class net.esper.pattern.PatternContextFactoryDefault
 
createDBStatementView(int, DBStatementStreamSpec, DatabaseConfigService, EventAdapterService, EPStatementHandle) - Static method in class net.esper.eql.db.DatabasePollingViewableFactory
Creates the viewable for polling via database SQL query.
createEntry(AbstractHashedMap.HashEntry, int, Object, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Creates an entry to store the key-value data.
createEntry(AbstractHashedMap.HashEntry, int, Object, Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Creates a ReferenceEntry instead of a HashEntry.
createEntrySetIterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Creates an entry set iterator.
createEntrySetIterator() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Creates an entry set iterator.
createEQL(String) - Method in interface net.esper.client.EPAdministrator
Creates and starts an EQL statement.
createEQL(String, String) - Method in interface net.esper.client.EPAdministrator
Create and starts an EQL statement.
createEQL(String) - Method in class net.esper.core.EPAdministratorImpl
 
createEQL(String, String) - Method in class net.esper.core.EPAdministratorImpl
 
createEventType(StatementContext) - Static method in class net.esper.view.stat.CorrelationView
Creates the event type for this view.
createEventType(StatementContext) - Static method in class net.esper.view.stat.MultiDimStatsView
Creates the event type for this view.
createEventType(StatementContext) - Static method in class net.esper.view.stat.RegressionLinestView
Creates the event type for this view.
createEventType(StatementContext) - Static method in class net.esper.view.stat.UnivariateStatisticsView
Creates the event type for this view.
createEventType(StatementContext) - Static method in class net.esper.view.stat.WeightedAverageView
Creates the event type for this view.
createEventType(StatementContext) - Static method in class net.esper.view.std.SizeView
Creates the event type for this view
createFactories(int, EventType, List<ViewSpec>, StatementContext) - Method in interface net.esper.view.ViewService
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.
createFactories(int, EventType, List<ViewSpec>, StatementContext) - Method in class net.esper.view.ViewServiceImpl
 
createIndex(EventType, String, FilterOperator) - Static method in class net.esper.filter.IndexFactory
Factory for indexes that store filter parameter constants for a given event property and filter operator.
createKeySetIterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Creates a key set iterator.
createKeySetIterator() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Creates an key set iterator.
createLookupPlan(QueryGraph, int, int, QueryPlanIndex, EventType[]) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
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.
createMapFromValues(Map<String, Object>, EventType) - Method in interface net.esper.event.EventAdapterService
Create an event wrapper bean from a set of event properties (name and value objectes) stored in a Map.
createMapFromValues(Map<String, Object>, EventType) - Method in class net.esper.event.EventAdapterServiceImpl
 
createNewVariable(String, Class, Object, StatementExtensionSvcContext) - Method in interface net.esper.eql.variable.VariableService
Creates a new variable.
createNewVariable(String, Class, Object, StatementExtensionSvcContext) - Method in class net.esper.eql.variable.VariableServiceImpl
 
createOnDelete(String, String) - Static method in class net.esper.client.soda.OnClause
Creates an on-delete clause for deleting from a named window.
createOnSelect(String, String) - Static method in class net.esper.client.soda.OnClause
Creates an on-select clause for selecting from a named window.
createOnSet(String, Expression) - Static method in class net.esper.client.soda.OnClause
Creates an on-set clause for setting variable values.
createPattern(String) - Method in interface net.esper.client.EPAdministrator
Create and starts an event pattern statement for the expressing string passed.
createPattern(String, String) - Method in interface net.esper.client.EPAdministrator
Create and starts an event pattern statement for the expressing string passed and assign the name passed.
createPattern(String) - Method in class net.esper.core.EPAdministratorImpl
 
createPattern(String, String) - Method in class net.esper.core.EPAdministratorImpl
 
createPollMethodView(int, MethodStreamSpec, EventAdapterService, EPStatementHandle, MethodResolutionService, EngineImportService, SchedulingService, ScheduleBucket) - Static method in class net.esper.eql.core.MethodPollingViewableFactory
Creates a method-invocation polling view for use as a stream that calls a method, or pulls results from cache.
createSelectionList(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
createSelectionList() - Method in class net.esper.eql.generated.EQLStatementParser
 
createSelectionListElement(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
createSelectionListElement() - Method in class net.esper.eql.generated.EQLStatementParser
 
createServicesContext(EPServiceProvider, ConfigurationInformation) - Method in interface net.esper.core.EPServicesContextFactory
Factory method for a new set of engine services.
createServicesContext(EPServiceProvider, ConfigurationInformation) - Method in class net.esper.core.EPServicesContextFactoryDefault
 
createStarted(StatementSpecRaw, String, boolean, String, String, Map<String, Object>) - Method in class net.esper.core.StatementLifecycleSvcImpl
Creates a started statement.
createStopped(StatementSpecRaw, String, boolean, String, String, Map<String, Object>) - Method in class net.esper.core.StatementLifecycleSvcImpl
Create stopped statement.
createStream(FilterSpecCompiled, FilterService, EPStatementHandle, boolean) - Method in interface net.esper.view.stream.StreamFactoryService
Create or reuse existing EventStream instance representing that event filter.
createStream(FilterSpecCompiled, FilterService, EPStatementHandle, boolean) - Method in class net.esper.view.stream.StreamFactorySvcImpl
See the method of the same name in StreamFactoryService.
createStreamPlan(int, int[], QueryGraph, QueryPlanIndex[], EventType[]) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Walks the chain of lookups and constructs lookup strategy and plan specification based on the index specifications.
createStreamWildcard(String) - Static method in class net.esper.client.soda.SelectClause
Creates a select-clause with a single stream wildcard selector (e.g.
createSubcontext(Name) - Method in class net.esper.core.EngineEnvContext
 
createSubcontext(String) - Method in class net.esper.core.EngineEnvContext
 
createValuesIterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Creates a values iterator.
createValuesIterator() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Creates an values iterator.
CreateVariableClause - Class in net.esper.client.soda
Represents a create-variable syntax for creating a new variable.
CreateVariableClause(String, String, Expression) - Constructor for class net.esper.client.soda.CreateVariableClause
Ctor.
CreateVariableDesc - Class in net.esper.eql.spec
Descriptor for create-variable statements.
CreateVariableDesc(String, String, ExprNode) - Constructor for class net.esper.eql.spec.CreateVariableDesc
Ctor.
createVariableExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
createVariableExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
CreateVariableView - Class in net.esper.eql.variable
View for handling create-variable syntax.
CreateVariableView(EventAdapterService, VariableService, String) - Constructor for class net.esper.eql.variable.CreateVariableView
Ctor.
createViews(Viewable, List<ViewFactory>, StatementContext) - Method in interface net.esper.view.ViewService
Creates the views given a chain of view factories.
createViews(Viewable, List<ViewFactory>, StatementContext) - Method in class net.esper.view.ViewServiceImpl
 
createWildcard() - Static method in class net.esper.client.soda.SelectClause
Creates a wildcard select-clause, additional expressions can still be added.
createWildcard(StreamSelector) - Static method in class net.esper.client.soda.SelectClause
Creates a wildcard select-clause, additional expressions can still be added.
CreateWindowClause - Class in net.esper.client.soda
Create a named window, defining the parameter of the named window such as window name and data window view name(s).
CreateWindowClause(String, View[]) - Constructor for class net.esper.client.soda.CreateWindowClause
Ctor.
CreateWindowClause(String, List<View>) - Constructor for class net.esper.client.soda.CreateWindowClause
Ctor.
CreateWindowDesc - Class in net.esper.eql.spec
Specification for creating a named window.
CreateWindowDesc(String, List<ViewSpec>) - Constructor for class net.esper.eql.spec.CreateWindowDesc
Ctor.
createWindowExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
createWindowExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
createWrapper(EventBean, Map<String, Object>, EventType) - Method in interface net.esper.event.EventAdapterService
Creata a wrapper around an event and some additional properties
createWrapper(EventBean, Map<String, Object>, EventType) - Method in class net.esper.event.EventAdapterServiceImpl
 
CronParameter - Class in net.esper.type
Hold parameters for timer:at.
CronParameter(String, String) - Constructor for class net.esper.type.CronParameter
Ctor.
CronParameter.CronOperator - Enum in net.esper.type
Enumeration for special keywords in crontab timer.
Cube - Interface in net.esper.view.stat.olap
Interface for querying multidimensional data.
CubeCellStringRenderer - Class in net.esper.indicator.pretty
Utility class that takes a cube and renders it as a flattened table of string and double.
CubeCellStringRenderer() - Constructor for class net.esper.indicator.pretty.CubeCellStringRenderer
 
CubeDerivedValueHelper - Class in net.esper.view.stat.olap
Strategy for deriving a measure cube from a fact cube.
CubeDerivedValueHelper() - Constructor for class net.esper.view.stat.olap.CubeDerivedValueHelper
 
CubeDimensionHelper - Class in net.esper.view.stat.olap
Utility methods for dealing with Cube multidimensional tables (OLAP style).
CubeDimensionHelper() - Constructor for class net.esper.view.stat.olap.CubeDimensionHelper
 
CubeImpl - Class in net.esper.view.stat.olap
Cube implementation derives the cells of the cube from a measures list and a MultidimCube containing BaseStatisticsBean.
CubeImpl(MultidimCube<BaseStatisticsBean>, String[]) - Constructor for class net.esper.view.stat.olap.CubeImpl
Constructor.
CubeTabularDataRenderer - Class in net.esper.indicator.pretty
Renders a Cube multidimensional table a TabularData from the JMX OpenMbean interface.
CubeTabularDataRenderer() - Constructor for class net.esper.indicator.pretty.CubeTabularDataRenderer
 
CURRENT_TIMESTAMP - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
CURRENT_TIMESTAMP - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
currentEntry() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
Current entry.
CurrentTimeEvent - Class in net.esper.client.time
Event for externally controlling the time within an EPRuntime instance.
CurrentTimeEvent(long) - Constructor for class net.esper.client.time.CurrentTimeEvent
Constructor.
currentTimestamp() - Static method in class net.esper.client.soda.Expressions
Current system time supplies internal-timer provided time or the time provided by external timer events.
CurrentTimestampExpression - Class in net.esper.client.soda
Current timestamp supplies the current engine time in an expression.
CurrentTimestampExpression() - Constructor for class net.esper.client.soda.CurrentTimestampExpression
Ctor.
CurrentValue<T> - Class in net.esper.eql.variable
A holder for versioned values that holds a current version-value and a prior version-value pair.
CurrentValue(VersionedValue<T>, VersionedValue<T>) - Constructor for class net.esper.eql.variable.CurrentValue
Ctor.
Cursor - Class in net.esper.eql.join.rep
This class supplies position information for LookupInstructionExec to use for iterating over events for lookup.
Cursor(EventBean, int, Node) - Constructor for class net.esper.eql.join.rep.Cursor
Ctor.

D

data - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Map entries
DATABASE_JOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DATABASE_JOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DatabaseConfigException - Exception in net.esper.eql.db
Exception to indicate that a stream name could not be resolved.
DatabaseConfigException(String) - Constructor for exception net.esper.eql.db.DatabaseConfigException
Ctor.
DatabaseConfigException(String, Throwable) - Constructor for exception net.esper.eql.db.DatabaseConfigException
Ctor.
DatabaseConfigService - Interface in net.esper.eql.db
Service providing database connection factory and configuration information for use with historical data polling.
DatabaseConfigServiceImpl - Class in net.esper.eql.db
Implementation provides database instance services such as connection factory and connection settings.
DatabaseConfigServiceImpl(Map<String, ConfigurationDBRef>, SchedulingService, ScheduleBucket) - Constructor for class net.esper.eql.db.DatabaseConfigServiceImpl
Ctor.
DatabaseConnectionFactory - Interface in net.esper.eql.db
Factory for new database connections.
DatabaseDMConnFactory - Class in net.esper.eql.db
Database connection factory using DriverManager to obtain connections.
DatabaseDMConnFactory(ConfigurationDBRef.DriverManagerConnection, ConfigurationDBRef.ConnectionSettings) - Constructor for class net.esper.eql.db.DatabaseDMConnFactory
Ctor.
DatabaseDSConnFactory - Class in net.esper.eql.db
Database connection factory using InitialContext and DataSource to obtain connections.
DatabaseDSConnFactory(ConfigurationDBRef.DataSourceConnection, ConfigurationDBRef.ConnectionSettings) - Constructor for class net.esper.eql.db.DatabaseDSConnFactory
Ctor.
databaseJoinExpression(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
databaseJoinExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
DatabasePollingViewable - Class in net.esper.eql.db
Implements a poller viewable that uses a polling strategy, a cache and some input parameters extracted from event streams to perform the polling.
DatabasePollingViewable(int, List<String>, PollExecStrategy, DataCache, EventType) - Constructor for class net.esper.eql.db.DatabasePollingViewable
Ctor.
DatabasePollingViewableFactory - Class in net.esper.eql.db
Factory for a view onto historical data via SQL statement.
DatabasePollingViewableFactory() - Constructor for class net.esper.eql.db.DatabasePollingViewableFactory
 
databaseReferences - Variable in class net.esper.client.Configuration
The java-style class and package name imports that will be used to resolve partial class names.
DatabaseTypeBinding - Interface in net.esper.util
Binding from database output column type to Java object.
DatabaseTypeEnum - Enum in net.esper.util
Enumeration of the different Java built-in types that are used to represent database output column values.
DataCache - Interface in net.esper.eql.db
Implementations serve as caches for historical or reference data retrieved via lookup keys consisting or one or more rows represented by a list of events.
DataCacheExpiringImpl - Class in net.esper.eql.db
Implements an expiry-time cache that evicts data when data becomes stale after a given number of seconds.
DataCacheExpiringImpl(double, double, ConfigurationDBRef.CacheReferenceType, SchedulingService, ScheduleSlot, EPStatementHandle) - Constructor for class net.esper.eql.db.DataCacheExpiringImpl
Ctor.
DataCacheFactory - Class in net.esper.eql.db
Factory for data caches for use caching database query results and method invocation results.
DataCacheFactory() - Constructor for class net.esper.eql.db.DataCacheFactory
 
DataCacheLRUImpl - Class in net.esper.eql.db
Query result data cache implementation that uses a least-recently-used algorithm to store and evict query results.
DataCacheLRUImpl(int) - Constructor for class net.esper.eql.db.DataCacheLRUImpl
Ctor.
DataCacheNullImpl - Class in net.esper.eql.db
Null implementation for a data cache that doesn't ever hit.
DataCacheNullImpl() - Constructor for class net.esper.eql.db.DataCacheNullImpl
 
DataWindowView - Interface in net.esper.view
Tag interface for data window views.
DataWindowViewFactory - Interface in net.esper.view
Marker interface for use with view factories that create data window views only.
DAY_PART - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DAY_PART - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
dayPart(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
dayPart() - Method in class net.esper.eql.generated.EQLStatementParser
 
DBFROM_CLAUSE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DBFROM_CLAUSE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DBOutputTypeDesc - Class in net.esper.eql.db
Descriptor for SQL output columns.
DBOutputTypeDesc(int, String, DatabaseTypeBinding) - Constructor for class net.esper.eql.db.DBOutputTypeDesc
Ctor.
DBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DBStatementStreamSpec - Class in net.esper.eql.spec
Specification object for historical data poll via database SQL statement.
DBStatementStreamSpec(String, List<ViewSpec>, String, String, String) - Constructor for class net.esper.eql.spec.DBStatementStreamSpec
Ctor.
DBWHERE_CLAUSE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DBWHERE_CLAUSE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DebugFacility - Class in net.esper.util
Utility class for enabling certain debugging using system properties.
DebugFacility() - Constructor for class net.esper.util.DebugFacility
 
DEC - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DEC - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DecoratingEventBean - Interface in net.esper.event
Interface for event types that provide decorating event properties as a name-value map.
decrIndent() - Method in class net.esper.util.IndentWriter
Decrease the indentation one level.
deepEquals(ExprNode, ExprNode) - Static method in class net.esper.eql.expression.ExprNode
Compare two expression nodes and their children in exact child-node sequence, returning true if the 2 expression nodes trees are equals, or false if they are not equals.
DEFAULT_CAPACITY - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
The default capacity to use
DEFAULT_LOAD_FACTOR - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
The default load factor to use
DEFAULT_THRESHOLD - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
The default threshold to use
DefaultMapEntry - Class in net.esper.collection.apachecommons
A restricted implementation of Map.Entry that prevents the Map.Entry contract from being broken.
DefaultMapEntry(Object, Object) - Constructor for class net.esper.collection.apachecommons.DefaultMapEntry
Constructs a new entry with the specified key and given value.
DefaultMapEntry(KeyValue) - Constructor for class net.esper.collection.apachecommons.DefaultMapEntry
Constructs a new entry from the specified KeyValue.
DefaultMapEntry(Map.Entry) - Constructor for class net.esper.collection.apachecommons.DefaultMapEntry
Constructs a new entry from the specified Map.Entry.
DELETE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DELETE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
dereference(K) - Method in class net.esper.collection.RefCountedMap
Decreases the reference count for a given key by one.
derive(String[], MultidimCube<BaseStatisticsBean>) - Static method in class net.esper.view.stat.olap.CubeDerivedValueHelper
Derive given statistical measures from the multidim.
derivedMeasures - Variable in class net.esper.view.stat.MultiDimStatsViewFactory
Derived fields.
DESC - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DESC - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
destroy() - Method in interface net.esper.adapter.AdapterLoader
Destroys adapter loader and adapters loaded.
destroy() - Method in interface net.esper.client.EPServiceProvider
Destroys the service.
destroy() - Method in interface net.esper.client.EPStatement
Destroy the statement releasing all statement resources.
destroy() - Method in interface net.esper.collection.ViewUpdatedCollection
De-allocate resources held by the collection.
destroy() - Method in class net.esper.core.EPAdministratorImpl
Destroys an engine instance.
destroy() - Method in class net.esper.core.EPRuntimeImpl
Destroy for destroying an engine instance: sets references to null and clears thread-locals
destroy() - Method in class net.esper.core.EPServiceProviderImpl
 
destroy() - Method in class net.esper.core.EPServicesContext
Destroy services.
destroy() - Method in class net.esper.core.EPStatementImpl
 
destroy() - Method in interface net.esper.core.ExtensionServicesContext
Invoked to destroy the extension services, when an existing engine is initialized.
destroy(String) - Method in interface net.esper.core.StatementLifecycleSvc
Destroy statement by statement id.
destroy() - Method in interface net.esper.core.StatementLifecycleSvc
Destroy the service.
destroy() - Method in class net.esper.core.StatementLifecycleSvcImpl
 
destroy(String) - Method in class net.esper.core.StatementLifecycleSvcImpl
 
destroy() - Method in class net.esper.eql.core.MethodPollingExecStrategy
 
destroy() - Method in class net.esper.eql.db.ConnectionCache
Destroys cache closing all resources cached, if any.
destroy() - Method in class net.esper.eql.db.ConnectionCacheImpl
 
destroy() - Method in class net.esper.eql.db.ConnectionNoCacheImpl
 
destroy() - Method in interface net.esper.eql.db.PollExecStrategy
Indicate we are no going to use this object again.
destroy() - Method in class net.esper.eql.db.PollExecStrategyDBQuery
 
destroy() - Method in interface net.esper.eql.join.JoinSetComposer
Destroy stateful index tables, if any.
destroy() - Method in class net.esper.eql.join.JoinSetComposerImpl
 
destroy() - Method in class net.esper.eql.named.NamedWindowIndexRepository
Destroy indexes.
destroy() - Method in class net.esper.eql.named.NamedWindowProcessor
Deletes a named window and removes any associated resources.
destroy() - Method in class net.esper.eql.named.NamedWindowRootView
Destroy and clear resources.
destroy() - Method in interface net.esper.eql.named.NamedWindowService
Clear out the service.
destroy() - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
destroy() - Method in class net.esper.eql.named.NamedWindowTailView
Destroy the view.
destroy() - Method in class net.esper.filter.EventTypeIndex
Destroy the service.
destroy() - Method in class net.esper.filter.EventTypeIndexBuilder
Destroy the service.
destroy() - Method in interface net.esper.filter.FilterService
Destroy the service.
destroy() - Method in class net.esper.filter.FilterServiceImpl
 
destroy() - Method in interface net.esper.schedule.SchedulingService
Destroy the service.
destroy() - Method in class net.esper.schedule.SchedulingServiceImpl
 
destroy() - Method in class net.esper.view.internal.PriorEventBufferMulti
 
destroy() - Method in class net.esper.view.internal.PriorEventBufferSingle
 
destroy() - Method in class net.esper.view.internal.PriorEventBufferUnbound
 
destroy() - Method in interface net.esper.view.stream.StreamFactoryService
Destroy the service.
destroy() - Method in class net.esper.view.stream.StreamFactorySvcImpl
 
destroy() - Method in class net.esper.view.window.IStreamRandomAccess
 
destroy() - Method in class net.esper.view.window.IStreamRelativeAccess
 
destroyAllStatements() - Method in interface net.esper.client.EPAdministrator
Stops and destroys all statements.
destroyAllStatements() - Method in class net.esper.core.EPAdministratorImpl
 
destroyAllStatements() - Method in interface net.esper.core.StatementLifecycleSvc
Destroys all started statements.
destroyAllStatements() - Method in class net.esper.core.StatementLifecycleSvcImpl
 
destroyEntry(AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Kills an entry ready for the garbage collector.
destroySubcontext(Name) - Method in class net.esper.core.EngineEnvContext
 
destroySubcontext(String) - Method in class net.esper.core.EngineEnvContext
 
determineMethod(Class) - Method in class net.esper.event.property.DynamicIndexedPropertyGetter
 
determineMethod(Class) - Method in class net.esper.event.property.DynamicMappedPropertyGetter
 
determineMethod(Class) - Method in class net.esper.event.property.DynamicPropertyGetterBase
To be implemented to return the method required, or null to indicate an appropriate method could not be found.
determineMethod(Class) - Method in class net.esper.event.property.DynamicSimplePropertyGetter
 
determineStreamNames(List<StreamSpecCompiled>) - Static method in class net.esper.core.EPStatementStartMethod
Returns a stream name assigned for each stream, generated if none was supplied.
Dimension - Interface in net.esper.view.stat.olap
Dimensions are a structural attribute of cubes.
DimensionImpl - Class in net.esper.view.stat.olap
Implements the dimension interface.
DimensionImpl(String[]) - Constructor for class net.esper.view.stat.olap.DimensionImpl
Constructor.
DimensionMember - Interface in net.esper.view.stat.olap
DimensionMember models instances of dimensional members.
DimensionMemberImpl - Class in net.esper.view.stat.olap
Serves up Cube dimension member information - the members dimension and its key values.
DimensionMemberImpl(Object[]) - Constructor for class net.esper.view.stat.olap.DimensionMemberImpl
Constructor.
DimensionMemberRenderHelper - Class in net.esper.indicator.pretty
Utility methods for rendering dimension members as a string.
DimensionMemberRenderHelper() - Constructor for class net.esper.indicator.pretty.DimensionMemberRenderHelper
 
Disjunction - Class in net.esper.client.soda
Disjunction represents a logical OR allowing multiple sub-expressions to be connected by OR.
Disjunction() - Constructor for class net.esper.client.soda.Disjunction
Ctor - for use to create an expression tree, without child expression.
Disjunction(Expression, Expression, Expression...) - Constructor for class net.esper.client.soda.Disjunction
Ctor.
dispatch() - Method in interface net.esper.dispatch.DispatchService
Execute all Dispatchable implementations added to the service since the last invocation of this method.
dispatch() - Method in class net.esper.dispatch.DispatchServiceImpl
 
dispatch() - Method in interface net.esper.eql.named.NamedWindowService
Dispatch events of the insert and remove stream of named windows to consumers, as part of the main event processing or dispatch loop.
dispatch() - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
Dispatchable - Interface in net.esper.dispatch
Implementations are executed when the DispatchService receives a dispatch invocation.
dispatchOnStop() - Method in class net.esper.core.UpdateDispatchViewBase
Dispatches when the statement is stopped any remaining results.
dispatchService - Variable in class net.esper.core.UpdateDispatchViewBase
Dispatches events to listeners.
DispatchService - Interface in net.esper.dispatch
Service for dispatching internally (for operators/views processing results of prior operators/views) and externally (dispatch events to UpdateListener implementations).
DispatchServiceImpl - Class in net.esper.dispatch
Implements dispatch service using a thread-local linked list of Dispatchable instances.
DispatchServiceImpl() - Constructor for class net.esper.dispatch.DispatchServiceImpl
 
DispatchServiceProvider - Class in net.esper.dispatch
Provider of implementations for the dispatch service.
DispatchServiceProvider() - Constructor for class net.esper.dispatch.DispatchServiceProvider
 
DISTINCT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DISTINCT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DistinctValueAggregator - Class in net.esper.eql.agg
AggregationMethod for use on top of another aggregator that handles unique value aggregation (versus all-value aggregation) for the underlying aggregator.
DistinctValueAggregator(AggregationMethod, Class) - Constructor for class net.esper.eql.agg.DistinctValueAggregator
Ctor.
DIV - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DIV - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DIV_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DIV_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
divide(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Division.
divide(String, String) - Static method in class net.esper.client.soda.Expressions
Division.
doListPropertyNames() - Method in class net.esper.event.BaseConfigurableEventType
Subclasses must implement this to supply a list of valid property names.
doListPropertyNames() - Method in class net.esper.event.xml.BaseXMLEventType
 
doListPropertyNames() - Method in class net.esper.event.xml.SchemaXMLEventType
 
DOMElementIterator - Class in net.esper.util
Iterator over DOM nodes that positions between elements.
DOMElementIterator(NodeList) - Constructor for class net.esper.util.DOMElementIterator
Ctor.
done() - Method in class net.esper.core.InsertIntoLatchSpin
Called to indicate that the latch completed and a later latch can start.
done() - Method in class net.esper.core.InsertIntoLatchWait
Called to indicate that the latch completed and a later latch can start.
done() - Method in class net.esper.eql.core.MethodPollingExecStrategy
 
done() - Method in interface net.esper.eql.db.PollExecStrategy
Indicate we are done polling and can release resources.
done() - Method in class net.esper.eql.db.PollExecStrategyDBQuery
 
doneWith(Pair<Connection, PreparedStatement>) - Method in class net.esper.eql.db.ConnectionCache
Indicate to return the connection and statement pair after use.
doneWith(Pair<Connection, PreparedStatement>) - Method in class net.esper.eql.db.ConnectionCacheImpl
 
doneWith(Pair<Connection, PreparedStatement>) - Method in class net.esper.eql.db.ConnectionNoCacheImpl
 
doReadObject(ObjectInputStream) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Reads the map data from the stream.
doReadObject(ObjectInputStream) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Replaces the superclassm method to read the state of this class.
doResolvePropertyGetter(String) - Method in class net.esper.event.BaseConfigurableEventType
Subclasses must implement this and supply a getter to a given property.
doResolvePropertyGetter(String) - Method in class net.esper.event.xml.SchemaXMLEventType
 
doResolvePropertyGetter(String) - Method in class net.esper.event.xml.SimpleXMLEventType
 
doResolvePropertyType(String) - Method in class net.esper.event.BaseConfigurableEventType
Subclasses must implement this and return a type for a property.
doResolvePropertyType(String) - Method in class net.esper.event.xml.SchemaXMLEventType
 
doResolvePropertyType(String) - Method in class net.esper.event.xml.SimpleXMLEventType
 
DOT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DOT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DOUBLE_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DOUBLE_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
DoubleRange - Class in net.esper.filter
Holds a range of double values with a minimum (start) value and a maximum (end) value.
DoubleRange(Double, Double) - Constructor for class net.esper.filter.DoubleRange
Constructor - takes range endpoints.
DoubleRangeComparator - Class in net.esper.filter
Comparator for DoubleRange values.
DoubleRangeComparator() - Constructor for class net.esper.filter.DoubleRangeComparator
 
DoubleSumAggregator - Class in net.esper.eql.agg
Sum for double values.
DoubleSumAggregator() - Constructor for class net.esper.eql.agg.DoubleSumAggregator
 
DoubleValue - Class in net.esper.type
Placeholder for a double value in an event expression.
DoubleValue() - Constructor for class net.esper.type.DoubleValue
Constructor.
DoubleValue(Double) - Constructor for class net.esper.type.DoubleValue
Constructor setting the value.
doWriteObject(ObjectOutputStream) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Writes the map data to the stream.
doWriteObject(ObjectOutputStream) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Replaces the superclass method to store the state of this class.
dropStream(FilterSpecCompiled, FilterService, boolean) - Method in interface net.esper.view.stream.StreamFactoryService
Drop the event stream associated with the filter passed in.
dropStream(FilterSpecCompiled, FilterService, boolean) - Method in class net.esper.view.stream.StreamFactorySvcImpl
See the method of the same name in StreamFactoryService.
dumpAST(AST) - Static method in class net.esper.util.DebugFacility
Dump the AST node to system.out.
dumpChildViews(String, Viewable) - Static method in class net.esper.view.ViewSupport
Convenience method for logging the child views of a Viewable.
dumpDebug(String) - Method in class net.esper.eql.expression.ExprNode
Recursively print out all nodes.
dumpDebug(String) - Method in class net.esper.pattern.EvalNode
Recursively print out all nodes.
dumpUpdateParams(String, Object[], Object[]) - Static method in class net.esper.view.ViewSupport
Convenience method for logging the parameters passed to the update method.
DuplicatePropertyException - Exception in net.esper.eql.core
Indicates a property exists in multiple streams.
DuplicatePropertyException(String) - Constructor for exception net.esper.eql.core.DuplicatePropertyException
Ctor.
DynamicIndexedProperty - Class in net.esper.event.property
Represents a dynamic indexed property of a given name.
DynamicIndexedProperty(String, int) - Constructor for class net.esper.event.property.DynamicIndexedProperty
Ctor.
DynamicIndexedPropertyGetter - Class in net.esper.event.property
Getter for a dynamic indexed property (syntax field.indexed[0]?), using vanilla reflection.
DynamicIndexedPropertyGetter(String, int) - Constructor for class net.esper.event.property.DynamicIndexedPropertyGetter
Ctor.
DynamicMappedProperty - Class in net.esper.event.property
Represents a dynamic mapped property of a given name.
DynamicMappedProperty(String, String) - Constructor for class net.esper.event.property.DynamicMappedProperty
Ctor.
DynamicMappedPropertyGetter - Class in net.esper.event.property
Getter for a dynamic mapped property (syntax field.mapped('key')?), using vanilla reflection.
DynamicMappedPropertyGetter(String, String) - Constructor for class net.esper.event.property.DynamicMappedPropertyGetter
Ctor.
DynamicProperty - Interface in net.esper.event.property
Marker interface for dynamic properties.
DynamicPropertyDescriptor - Class in net.esper.event.property
Provides method information for dynamic (unchecked) properties of each class for use in obtaining property values.
DynamicPropertyDescriptor(Class, FastMethod, boolean) - Constructor for class net.esper.event.property.DynamicPropertyDescriptor
Ctor.
DynamicPropertyGetterBase - Class in net.esper.event.property
Base class for getters for a dynamic property (syntax field.inner?), caches methods to use for classes.
DynamicPropertyGetterBase() - Constructor for class net.esper.event.property.DynamicPropertyGetterBase
Ctor.
DynamicSimpleProperty - Class in net.esper.event.property
Represents a dynamic simple property of a given name.
DynamicSimpleProperty(String) - Constructor for class net.esper.event.property.DynamicSimpleProperty
Ctor.
DynamicSimplePropertyGetter - Class in net.esper.event.property
Getter for a dynamic property (syntax field.inner?), using vanilla reflection.
DynamicSimplePropertyGetter(String) - Constructor for class net.esper.event.property.DynamicSimplePropertyGetter
Ctor.

E

ELSE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ELSE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
elseClause() - Method in class net.esper.eql.generated.EQLStatementParser
 
emit(Object) - Method in interface net.esper.client.EPRuntime
Emit an event object to any registered EmittedListener instances listening to the default channel.
emit(Object, String) - Method in interface net.esper.client.EPRuntime
Emit an event object to any registered EmittedListener instances on the specified channel.
emit(Object) - Method in class net.esper.core.EPRuntimeImpl
 
emit(Object, String) - Method in class net.esper.core.EPRuntimeImpl
 
emitEvent(Object, String) - Method in interface net.esper.emit.EmitService
Emit an event to the specified channel.
emitEvent(Object, String) - Method in class net.esper.emit.EmitServiceImpl
 
EmitService - Interface in net.esper.emit
The emit service is a simple publish-subscribe mechanism for sending events out of the runtime to emitted event listeners that registered interest in the same or default channel that an event was emitted to.
EmitServiceImpl - Class in net.esper.emit
Implementation of the event emit service.
EmitServiceImpl() - Constructor for class net.esper.emit.EmitServiceImpl
Constructor.
EmitServiceProvider - Class in net.esper.emit
Static factory for implementations of the EmitService interface.
EmitServiceProvider() - Constructor for class net.esper.emit.EmitServiceProvider
 
emitted(Object) - Method in interface net.esper.client.EmittedListener
Called to indicate an event emitted.
EmittedListener - Interface in net.esper.client
Listener interface for events emitted from an EPRuntime.
EmptyIterator - Class in net.esper.collection.apachecommons
Provides an implementation of an empty iterator.
EmptyIterator() - Constructor for class net.esper.collection.apachecommons.EmptyIterator
Constructor.
EmptyMapIterator - Class in net.esper.collection.apachecommons
Provides an implementation of an empty map iterator.
EmptyMapIterator() - Constructor for class net.esper.collection.apachecommons.EmptyMapIterator
Constructor.
ENABLED_INFO - Static variable in class net.esper.util.ThreadLogUtil
Enable info logging.
ENABLED_TRACE - Static variable in class net.esper.util.ThreadLogUtil
Enable trace logging.
end() - Method in class net.esper.eql.generated.EQLBaseWalker
 
END - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
END - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
end() - Method in class net.esper.eql.parse.EQLTreeWalker
End processing of the AST tree, check that expression nodes found their homes.
endPattern() - Method in class net.esper.eql.generated.EQLBaseWalker
 
endPattern() - Method in class net.esper.eql.parse.EQLTreeWalker
End processing of the AST tree for stand-alone pattern expressions.
engineDefaults - Variable in class net.esper.client.Configuration
Saves engine default configs such as threading settings
EngineEnvContext - Class in net.esper.core
Implements a JNDI context for providing a directory for engine-external resources such as adapters.
EngineEnvContext() - Constructor for class net.esper.core.EngineEnvContext
Ctor.
EngineImportException - Exception in net.esper.eql.core
Indicates a problem importing classes, aggregation functions and the like.
EngineImportException(String) - Constructor for exception net.esper.eql.core.EngineImportException
Ctor.
EngineImportException(String, Exception) - Constructor for exception net.esper.eql.core.EngineImportException
Ctor.
EngineImportService - Interface in net.esper.eql.core
Service for engine-level resolution of static methods and aggregation methods.
EngineImportServiceImpl - Class in net.esper.eql.core
Implementation for engine-level imports.
EngineImportServiceImpl() - Constructor for class net.esper.eql.core.EngineImportServiceImpl
Ctor.
EngineImportUndefinedException - Exception in net.esper.eql.core
Indicates a problem importing classes, aggregation functions and the like.
EngineImportUndefinedException(String) - Constructor for exception net.esper.eql.core.EngineImportUndefinedException
Ctor.
EngineImportUndefinedException(String, Exception) - Constructor for exception net.esper.eql.core.EngineImportUndefinedException
Ctor.
EngineSettingsService - Class in net.esper.eql.core
Service for engine-level settings around threading and concurrency.
EngineSettingsService(ConfigurationEngineDefaults) - Constructor for class net.esper.eql.core.EngineSettingsService
Ctor.
ensureCapacity(int) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Changes the size of the data structure to the capacity proposed.
enter(Object) - Method in interface net.esper.eql.agg.AggregationMethod
Apply the value as entering aggregation (entering window).
enter(Object) - Method in class net.esper.eql.agg.AvedevAggregator
 
enter(Object) - Method in class net.esper.eql.agg.AvgAggregator
 
enter(Object) - Method in class net.esper.eql.agg.CountAggregator
 
enter(Object) - Method in class net.esper.eql.agg.DistinctValueAggregator
 
enter(Object) - Method in class net.esper.eql.agg.DoubleSumAggregator
 
enter(Object) - Method in class net.esper.eql.agg.FloatSumAggregator
 
enter(Object) - Method in class net.esper.eql.agg.IntegerSumAggregator
 
enter(Object) - Method in class net.esper.eql.agg.LongSumAggregator
 
enter(Object) - Method in class net.esper.eql.agg.MedianAggregator
 
enter(Object) - Method in class net.esper.eql.agg.MinMaxAggregator
 
enter(Object) - Method in class net.esper.eql.agg.NonNullCountAggregator
 
enter(Object) - Method in class net.esper.eql.agg.NumIntegerSumAggregator
 
enter(Object) - Method in class net.esper.eql.agg.StddevAggregator
 
entryHashCode(AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the hashCode field from a HashEntry.
entryIterator() - Method in class net.esper.collection.RefCountedSet
Returns an iterator over the entry set.
entryKey(AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the key field from a HashEntry.
entryNext(AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the next field from a HashEntry.
entrySet - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Entry set
entrySet() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the entrySet view of the map.
entrySet() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Returns a set view of this map's entries.
entryValue(AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the value field from a HashEntry.
EOF - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EOF - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EPAdministrator - Interface in net.esper.client
Administrative interface to the event stream processing engine.
EPAdministratorImpl - Class in net.esper.core
Implementation for the admin interface.
EPAdministratorImpl(EPServicesContext, ConfigurationOperations) - Constructor for class net.esper.core.EPAdministratorImpl
Constructor - takes the services context as argument.
EPBaseNamedObject - Class in net.esper.client.soda
Base class for named engine objects such as views, patterns guards and observers.
EPBaseNamedObject(String, String, List<Object>) - Constructor for class net.esper.client.soda.EPBaseNamedObject
Ctor.
EPException - Exception in net.esper.client
This exception is thrown to indicate a problem in administration and runtime.
EPException(String) - Constructor for exception net.esper.client.EPException
Ctor.
EPException(String, Throwable) - Constructor for exception net.esper.client.EPException
Ctor for an inner exception and message.
EPException(Throwable) - Constructor for exception net.esper.client.EPException
Ctor - just an inner exception.
EPIterable - Interface in net.esper.client
Interface to iterate over events.
EPListenable - Interface in net.esper.client
Interface to add and remove update listeners.
EPPreparedStatement - Interface in net.esper.client
Precompiled statement that is prepared with substitution parameters and that can be created and started efficiently multiple times with different actual values for parameters.
EPPreparedStatementImpl - Class in net.esper.client
Prepared statement implementation that stores the statement object model and a list of substitution parameters, to be mapped into an internal representation upon creation.
EPPreparedStatementImpl(EPStatementObjectModel, Map<Integer, SubstitutionParameterExpression>) - Constructor for class net.esper.client.EPPreparedStatementImpl
Ctor.
EPRuntime - Interface in net.esper.client
Interface to event stream processing runtime services.
EPRuntimeImpl - Class in net.esper.core
Implements runtime interface.
EPRuntimeImpl(EPServicesContext) - Constructor for class net.esper.core.EPRuntimeImpl
Constructor.
EPServiceProvider - Interface in net.esper.client
This class provides access to the EPRuntime and EPAdministrator implementations.
EPServiceProviderImpl - Class in net.esper.core
Service provider encapsulates the engine's services for runtime and administration interfaces.
EPServiceProviderImpl(Configuration, String) - Constructor for class net.esper.core.EPServiceProviderImpl
Constructor - initializes services.
EPServiceProviderManager - Class in net.esper.client
Factory for instances of EPServiceProvider.
EPServiceProviderManager() - Constructor for class net.esper.client.EPServiceProviderManager
 
EPServiceProviderSPI - Interface in net.esper.core
A service provider interface that makes available internal engine services.
EPServicesContext - Class in net.esper.core
Convenience class to hold implementations for all services.
EPServicesContext(String, SchedulingService, EventAdapterService, EngineImportService, EngineSettingsService, DatabaseConfigService, PluggableObjectCollection, StatementLockFactory, ManagedReadWriteLock, ExtensionServicesContext, EngineEnvContext, StatementContextFactory, PluggableObjectCollection, OutputConditionFactory, TimerService, FilterService, StreamFactoryService, NamedWindowService, VariableService) - Constructor for class net.esper.core.EPServicesContext
Constructor - sets up new set of services.
EPServicesContextFactory - Interface in net.esper.core
Interface for a factory class to provide services in a services context for an engine instance.
epServicesContextFactoryClassName - Variable in class net.esper.client.Configuration
Optional classname to use for constructing services context.
EPServicesContextFactoryDefault - Class in net.esper.core
Factory for services context.
EPServicesContextFactoryDefault() - Constructor for class net.esper.core.EPServicesContextFactoryDefault
 
EPStatement - Interface in net.esper.client
Statement interface that provides methods to start, stop and destroy a statement as well as get statement information such as statement name, expression text and current state.
EPStatementDesc - Class in net.esper.core
Statement information for use to perform statement lifecycle management.
EPStatementDesc(EPStatementSPI, EPStatementStartMethod, EPStatementStopMethod, String) - Constructor for class net.esper.core.EPStatementDesc
Ctor.
EPStatementDispatch - Interface in net.esper.core
Interface for statement-level dispatch.
EPStatementException - Exception in net.esper.client
This exception is thrown to indicate a problem in statement creation, such as syntax error or type checking problem etc.
EPStatementException(String, String) - Constructor for exception net.esper.client.EPStatementException
Ctor.
EPStatementHandle - Class in net.esper.core
Class exists once per statement and hold statement resource lock(s).
EPStatementHandle(String, ManagedLock, String, boolean) - Constructor for class net.esper.core.EPStatementHandle
Ctor.
EPStatementHandleCallback - Class in net.esper.core
Statement resource handle and callback for use with FilterService and SchedulingService.
EPStatementHandleCallback(EPStatementHandle, FilterHandleCallback) - Constructor for class net.esper.core.EPStatementHandleCallback
Ctor.
EPStatementHandleCallback(EPStatementHandle, ScheduleHandleCallback) - Constructor for class net.esper.core.EPStatementHandleCallback
Ctor.
EPStatementImpl - Class in net.esper.core
Statement implementation for EQL statements.
EPStatementImpl(EPServiceProvider, String, String, String, boolean, DispatchService, StatementLifecycleSvc, long, boolean, boolean, long, EPStatementHandle, VariableService) - Constructor for class net.esper.core.EPStatementImpl
Ctor.
EPStatementListenerSet - Class in net.esper.core
Provides update listeners for use by statement instances, and the management methods around these.
EPStatementListenerSet() - Constructor for class net.esper.core.EPStatementListenerSet
Ctor.
EPStatementListenerSet(CopyOnWriteArraySet<UpdateListener>, CopyOnWriteArraySet<StatementAwareUpdateListener>) - Constructor for class net.esper.core.EPStatementListenerSet
Ctor.
EPStatementObjectModel - Class in net.esper.client.soda
Object model of an EQL statement.
EPStatementObjectModel() - Constructor for class net.esper.client.soda.EPStatementObjectModel
Ctor.
EPStatementObjectModelHelper - Class in net.esper.core
Helper methods for use by the statement object model.
EPStatementObjectModelHelper() - Constructor for class net.esper.core.EPStatementObjectModelHelper
 
EPStatementSPI - Interface in net.esper.core
Statement SPI for statements operations for state transitions and internal management.
EPStatementStartMethod - Class in net.esper.core
Starts and provides the stop method for EQL statements.
EPStatementStartMethod(StatementSpecCompiled, EPServicesContext, StatementContext) - Constructor for class net.esper.core.EPStatementStartMethod
Ctor.
EPStatementState - Enum in net.esper.client
Enumerates all statement states.
EPStatementStopMethod - Interface in net.esper.core
Method to call to stop an EPStatement.
EPStatementSyntaxException - Exception in net.esper.eql.parse
This exception is thrown to indicate a problem in statement creation.
EPStatementSyntaxException(String, String) - Constructor for exception net.esper.eql.parse.EPStatementSyntaxException
Ctor.
eq(String, Object) - Static method in class net.esper.client.soda.Expressions
Equals between a property and a constant.
eq(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Equals between expression results.
EQLBaseWalker - Class in net.esper.eql.generated
 
EQLBaseWalker() - Constructor for class net.esper.eql.generated.EQLBaseWalker
 
EqlEvalTokenTypes - Interface in net.esper.eql.generated
 
eqlExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
EQLParameterType - Interface in net.esper.type
Interface for parameter types that can represent themselves as an EQL syntax.
EQLStatementLexer - Class in net.esper.eql.generated
 
EQLStatementLexer(InputStream) - Constructor for class net.esper.eql.generated.EQLStatementLexer
 
EQLStatementLexer(Reader) - Constructor for class net.esper.eql.generated.EQLStatementLexer
 
EQLStatementLexer(InputBuffer) - Constructor for class net.esper.eql.generated.EQLStatementLexer
 
EQLStatementLexer(LexerSharedInputState) - Constructor for class net.esper.eql.generated.EQLStatementLexer
 
EQLStatementParser - Class in net.esper.eql.generated
 
EQLStatementParser(TokenBuffer, int) - Constructor for class net.esper.eql.generated.EQLStatementParser
 
EQLStatementParser(TokenBuffer) - Constructor for class net.esper.eql.generated.EQLStatementParser
 
EQLStatementParser(TokenStream, int) - Constructor for class net.esper.eql.generated.EQLStatementParser
 
EQLStatementParser(TokenStream) - Constructor for class net.esper.eql.generated.EQLStatementParser
 
EQLStatementParser(ParserSharedInputState) - Constructor for class net.esper.eql.generated.EQLStatementParser
 
EqlTokenTypes - Interface in net.esper.eql.generated
 
EQLTreeWalker - Class in net.esper.eql.parse
Called during the walks of a EQL expression AST tree as specified in the grammar file.
EQLTreeWalker(EngineImportService, VariableService) - Constructor for class net.esper.eql.parse.EQLTreeWalker
Ctor.
eqProperty(String, String) - Static method in class net.esper.client.soda.Expressions
Equals between properties.
EQUAL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EQUAL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
equals(Object) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
 
equals(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Compares this map with another.
equals(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
 
equals(Object) - Method in class net.esper.collection.apachecommons.AbstractMapEntry
Compares this Map.Entry with another Map.Entry.
equals(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Compares this map entry to another.
equals(Object) - Method in class net.esper.collection.InterchangeablePair
 
equals(Object) - Method in class net.esper.collection.MultiKey
 
equals(Object) - Method in class net.esper.collection.MultiKeyUntyped
 
equals(Object) - Method in class net.esper.collection.Pair
 
equals(Object) - Method in class net.esper.collection.UniformPair
 
equals(Object) - Method in class net.esper.core.EPStatementHandle
 
EQUALS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EQUALS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
equals(Object) - Method in class net.esper.eql.join.plan.QueryGraphKey
 
equals(Object) - Method in class net.esper.eql.lookup.JoinedPropDesc
 
equals(Object) - Method in class net.esper.eql.spec.ObjectSpec
 
equals(Object) - Method in class net.esper.event.CompositeEventType
 
equals(Object) - Method in class net.esper.event.EventPropertyDescriptor
 
equals(Object) - Method in class net.esper.event.MapEventType
 
equals(Object) - Method in class net.esper.event.WrapperEventType
 
equals(Object) - Method in class net.esper.event.xml.BaseXMLEventType
 
equals(Object) - Method in class net.esper.filter.DoubleRange
 
equals(Object) - Method in class net.esper.filter.FilterSpecCompiled
 
equals(Object) - Method in class net.esper.filter.FilterSpecParam
 
equals(Object) - Method in class net.esper.filter.FilterSpecParamConstant
 
equals(Object) - Method in class net.esper.filter.FilterSpecParamEventProp
 
equals(Object) - Method in class net.esper.filter.FilterSpecParamExprNode
 
equals(Object) - Method in class net.esper.filter.FilterSpecParamIn
 
equals(Object) - Method in class net.esper.filter.FilterSpecParamRange
 
equals(Object) - Method in class net.esper.filter.InSetOfValuesConstant
 
equals(Object) - Method in class net.esper.filter.InSetOfValuesEventProp
 
equals(Object) - Method in class net.esper.filter.RangeValueDouble
 
equals(Object) - Method in class net.esper.filter.RangeValueEventProp
 
equals(Object) - Method in class net.esper.pattern.EvalNodeNumber
 
equals(Object) - Method in class net.esper.pattern.MatchedEventMapImpl
 
equals(Object) - Method in class net.esper.schedule.ScheduleSlot
 
equals(Object) - Method in class net.esper.schedule.ScheduleSpec
 
equals(Object) - Method in class net.esper.type.TimePeriodParameter
 
equals(Object) - Method in class net.esper.util.PlaceholderParser.ParameterFragment
 
equals(Object) - Method in class net.esper.util.PlaceholderParser.TextFragment
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprAggregateNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprAndNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprArrayNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprBetweenNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprBitWiseNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprCaseNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprCastNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprCoalesceNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprConcatNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprConstantNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprEqualsNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprIdentNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprInNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprInstanceofNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprLikeNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprMathNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprNode
Return true if a expression node semantically equals the current node, or false if not.
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprNotNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprOrNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprPreviousNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprPriorNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprPropertyExistsNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprRegexpNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprSubselectNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprSubstitutionNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprTimestampNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprVariableNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprAggregateNode
Return true if a expression aggregate node semantically equals the current node, or false if not.
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprAvedevNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprAvgNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprCountNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprMedianNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprPlugInAggFunctionNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprStddevNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprSumNode
 
ERROR_MSG_DATAWINDOWS - Static variable in interface net.esper.eql.named.NamedWindowService
Error message for data windows required.
ERROR_MSG_NO_DATAWINDOW_ALLOWED - Static variable in interface net.esper.eql.named.NamedWindowService
Error message for no data window allowed.
ESC - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ESC - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ESCAPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ESCAPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ESPER_DEFAULT_CONFIG - Static variable in class net.esper.client.Configuration
Default name of the configuration file.
EVAL_AND_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVAL_AND_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVAL_BITWISE_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVAL_BITWISE_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVAL_EQUALS_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVAL_EQUALS_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVAL_IDENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVAL_IDENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVAL_NOTEQUALS_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVAL_NOTEQUALS_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVAL_OR_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVAL_OR_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
evalAndExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
EvalAndNode - Class in net.esper.pattern
This class represents an 'and' operator in the evaluation tree representing an event expressions.
EvalAndNode() - Constructor for class net.esper.pattern.EvalAndNode
 
EvalAndStateNode - Class in net.esper.pattern
This class represents the state of an "and" operator in the evaluation state tree.
EvalAndStateNode(Evaluator, EvalAndNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalAndStateNode
Constructor.
evalEqualsExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
EvalEveryNode - Class in net.esper.pattern
This class represents an 'every' operator in the evaluation tree representing an event expression.
EvalEveryNode() - Constructor for class net.esper.pattern.EvalEveryNode
 
EvalEveryStateNode - Class in net.esper.pattern
Contains the state collected by an "every" operator.
EvalEveryStateNode(Evaluator, EvalEveryNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalEveryStateNode
Constructor.
evalExprChoice(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
EvalFilterNode - Class in net.esper.pattern
This class represents a filter of events in the evaluation tree representing any event expressions.
EvalFilterNode(FilterSpecRaw, String) - Constructor for class net.esper.pattern.EvalFilterNode
Constructor.
EvalFilterStateNode - Class in net.esper.pattern
This class contains the state of a single filter expression in the evaluation state tree.
EvalFilterStateNode(Evaluator, EvalFilterNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalFilterStateNode
Constructor.
EvalFollowedByNode - Class in net.esper.pattern
This class represents a followed-by operator in the evaluation tree representing any event expressions.
EvalFollowedByNode() - Constructor for class net.esper.pattern.EvalFollowedByNode
 
EvalFollowedByStateNode - Class in net.esper.pattern
This class represents the state of a followed-by operator in the evaluation state tree.
EvalFollowedByStateNode(Evaluator, EvalFollowedByNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalFollowedByStateNode
Constructor.
EvalGuardNode - Class in net.esper.pattern
This class represents a guard in the evaluation tree representing an event expressions.
EvalGuardNode(PatternGuardSpec) - Constructor for class net.esper.pattern.EvalGuardNode
Constructor.
EvalGuardStateNode - Class in net.esper.pattern
This class represents the state of a "within" operator in the evaluation state tree.
EvalGuardStateNode(Evaluator, EvalGuardNode, MatchedEventMap, PatternContext, Object) - Constructor for class net.esper.pattern.EvalGuardStateNode
Constructor.
EvalNode - Class in net.esper.pattern
Superclass of all nodes in an evaluation tree representing an event pattern expression.
EvalNodeAnalysisResult - Class in net.esper.pattern
Result of analysis of pattern expression node tree.
EvalNodeAnalysisResult() - Constructor for class net.esper.pattern.EvalNodeAnalysisResult
 
EvalNodeNumber - Class in net.esper.pattern
A node number assigned to evaluation nodes in a tree-structure.
EvalNodeNumber() - Constructor for class net.esper.pattern.EvalNodeNumber
Constructs a root node number.
EvalNotNode - Class in net.esper.pattern
This class represents an 'not' operator in the evaluation tree representing any event expressions.
EvalNotNode() - Constructor for class net.esper.pattern.EvalNotNode
 
EvalNotStateNode - Class in net.esper.pattern
This class contains the state of an 'not' operator in the evaluation state tree.
EvalNotStateNode(Evaluator, EvalNotNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalNotStateNode
Constructor.
EvalObserverNode - Class in net.esper.pattern
This class represents an observer expression in the evaluation tree representing an pattern expression.
EvalObserverNode(PatternObserverSpec) - Constructor for class net.esper.pattern.EvalObserverNode
Constructor.
EvalObserverStateNode - Class in net.esper.pattern
This class represents the state of an eventObserver sub-expression in the evaluation state tree.
EvalObserverStateNode(Evaluator, EvalObserverNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalObserverStateNode
Constructor.
evalOrExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
EvalOrNode - Class in net.esper.pattern
This class represents an 'or' operator in the evaluation tree representing any event expressions.
EvalOrNode() - Constructor for class net.esper.pattern.EvalOrNode
 
EvalOrStateNode - Class in net.esper.pattern
This class represents the state of a "or" operator in the evaluation state tree.
EvalOrStateNode(Evaluator, EvalOrNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalOrStateNode
Constructor.
evalRelationalExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
EvalRootNode - Class in net.esper.pattern
This class is always the root node in the evaluation tree representing an event expression.
EvalRootNode() - Constructor for class net.esper.pattern.EvalRootNode
 
EvalRootState - Interface in net.esper.pattern
Interface for a root state node accepting a callback to use to indicate pattern results.
EvalRootStateNode - Class in net.esper.pattern
This class is always the root node in the evaluation state tree representing any activated event expression.
EvalRootStateNode(EvalNode, MatchedEventMap, PatternContext) - Constructor for class net.esper.pattern.EvalRootStateNode
Constructor.
EvalStateNode - Class in net.esper.pattern
Superclass of all state nodes in an evaluation node tree representing an event expressions.
EvalStateNode(EvalNode, Evaluator, Object) - Constructor for class net.esper.pattern.EvalStateNode
Constructor.
EvalStateNodePrinterVisitor - Class in net.esper.pattern
Visitor class for printing out an evaluation state tree where each node is printed indented according to its depth in the tree.
EvalStateNodePrinterVisitor() - Constructor for class net.esper.pattern.EvalStateNodePrinterVisitor
 
EvalStateNodeVisitor - Interface in net.esper.pattern
Interface for visiting each element in the evaluation node tree for an event expression (see Visitor pattern).
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprAggregateNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprAndNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprArrayNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprBetweenNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprBitWiseNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprCaseNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprCastNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprCoalesceNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprConcatNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprConstantNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprEqualsNode
 
evaluate(EventBean[], boolean) - Method in interface net.esper.eql.expression.ExprEvaluator
Evaluate event tuple and return result.
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprIdentNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprInNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprInstanceofNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprLikeNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprMathNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprNotNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprOrNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprPreviousNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprPriorNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprPropertyExistsNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprRegexpNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
evaluate(EventBean[], boolean, Set<EventBean>) - Method in class net.esper.eql.expression.ExprSubselectExistsNode
 
evaluate(EventBean[], boolean, Set<EventBean>) - Method in class net.esper.eql.expression.ExprSubselectInNode
 
evaluate(EventBean[], boolean, Set<EventBean>) - Method in class net.esper.eql.expression.ExprSubselectNode
Evaluate the lookup expression returning an evaluation result object.
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprSubselectNode
 
evaluate(EventBean[], boolean, Set<EventBean>) - Method in class net.esper.eql.expression.ExprSubselectRowNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprSubstitutionNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprTimestampNode
 
evaluate(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprVariableNode
 
evaluate(EventBean) - Method in class net.esper.filter.ExprNodeAdapter
Evaluate the boolean expression given the event as a stream zero event.
evaluate(EventBean, Collection<FilterHandle>) - Method in interface net.esper.filter.FilterService
Finds matching filters to the event passed in and invokes their associated callback method.
evaluate(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterServiceImpl
 
evaluate(Collection<ScheduleHandle>) - Method in interface net.esper.schedule.SchedulingService
Evaluate the current time and add to the collection any handles scheduled for execution.
evaluate(Collection<ScheduleHandle>) - Method in class net.esper.schedule.SchedulingServiceImpl
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalAndStateNode
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalEveryStateNode
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalFollowedByStateNode
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalGuardStateNode
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalNotStateNode
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalOrStateNode
 
evaluateFalse(EvalStateNode) - Method in class net.esper.pattern.EvalRootStateNode
 
evaluateFalse(EvalStateNode) - Method in interface net.esper.pattern.Evaluator
Indicate a change in truth value to false.
evaluatePropertyExists(EventBean[], boolean) - Method in class net.esper.eql.expression.ExprIdentNode
Returns true if the property exists, or false if not.
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalAndStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalEveryStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalFollowedByStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalGuardStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalNotStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalOrStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in class net.esper.pattern.EvalRootStateNode
 
evaluateTrue(MatchedEventMap, EvalStateNode, boolean) - Method in interface net.esper.pattern.Evaluator
Indicate a change in truth value to true.
Evaluator - Interface in net.esper.pattern
Interface for nodes in an expression evaluation state tree that are being informed by a child that the event expression fragments (subtrees) which the child represents has turned true (evaluateTrue method) or false (evaluateFalse).
evaluators - Variable in class net.esper.eql.agg.AggregationServiceBase
Evaluation nodes under.
EVENT_FILTER_BETWEEN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_BETWEEN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_IDENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_IDENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_IN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_IN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_NAME_TAG - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_NAME_TAG - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_NOT_BETWEEN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_NOT_BETWEEN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_NOT_IN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_NOT_IN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_NOT_RANGE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_NOT_RANGE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_PARAM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_PARAM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_FILTER_RANGE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_FILTER_RANGE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_LIMIT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_LIMIT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_DYNAMIC_INDEXED - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_DYNAMIC_INDEXED - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_DYNAMIC_MAPPED - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_DYNAMIC_MAPPED - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_DYNAMIC_SIMPLE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_DYNAMIC_SIMPLE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_INDEXED - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_INDEXED - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_MAPPED - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_MAPPED - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EVENT_PROP_SIMPLE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENT_PROP_SIMPLE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EventAdapterException - Exception in net.esper.event
This exception is thrown to indicate a problem resolving an event type by name.
EventAdapterException(String) - Constructor for exception net.esper.event.EventAdapterException
Ctor.
EventAdapterException(String, Throwable) - Constructor for exception net.esper.event.EventAdapterException
Ctor.
EventAdapterService - Interface in net.esper.event
Interface for a service to resolve event names to event type.
EventAdapterServiceImpl - Class in net.esper.event
Implementation for resolving event name to event type.
EventAdapterServiceImpl() - Constructor for class net.esper.event.EventAdapterServiceImpl
Ctor.
EventBean - Interface in net.esper.event
Interface for event representation.
EventBeanUtility - Class in net.esper.event
Method to getSelectListEvents events in collections to other collections or other event types.
EventBeanUtility() - Constructor for class net.esper.event.EventBeanUtility
 
eventClasses - Variable in class net.esper.client.Configuration
Map of event name and fully-qualified Java class name.
EventCollection - Interface in net.esper.view
Interface that marks an event collection.
EventEvaluator - Interface in net.esper.filter
Interface for matching an event instance based on the event's property values to filters, specifically filter parameter constants or ranges.
eventFilterExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
eventFilterExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
EventObserver - Interface in net.esper.pattern.observer
Observers observe and indicate other external events such as timing events.
EventObserverSupport - Class in net.esper.pattern.observer
Abstract class for applications to extend to implement a pattern observer.
EventObserverSupport() - Constructor for class net.esper.pattern.observer.EventObserverSupport
 
eventProperty() - Method in class net.esper.eql.generated.EQLStatementParser
 
eventPropertyAtomic(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
eventPropertyAtomic() - Method in class net.esper.eql.generated.EQLStatementParser
 
EventPropertyDescriptor - Class in net.esper.event
Encapsulates the event property information available after introspecting an event's class members for getter methods.
EventPropertyDescriptor(String, String, Method, EventPropertyType) - Constructor for class net.esper.event.EventPropertyDescriptor
Ctor.
EventPropertyDescriptor(String, String, Field, EventPropertyType) - Constructor for class net.esper.event.EventPropertyDescriptor
Ctor.
eventPropertyExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
EventPropertyGetter - Interface in net.esper.event
Get property values from an event instance for a given event property.
eventPropertyOrLibFunction() - Method in class net.esper.eql.generated.EQLStatementParser
 
EventPropertyType - Enum in net.esper.event
Enumeration of property types.
EVENTS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVENTS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
EventStream - Interface in net.esper.view
A streams is a conduct for incoming events.
EventTable - Interface in net.esper.eql.join.table
Table of events allowing add and remove.
EventType - Interface in net.esper.event
This interface provides metadata on events.
eventTypeAutoAliasPackages - Variable in class net.esper.client.Configuration
Saves the Java packages to search to resolve event type aliases.
EventTypeIndex - Class in net.esper.filter
Mapping of event type to a tree-like structure containing filter parameter constants in indexes FilterParamIndexBase and filter callbacks in FilterHandleSetNode.
EventTypeIndex() - Constructor for class net.esper.filter.EventTypeIndex
Constructor.
EventTypeIndexBuilder - Class in net.esper.filter
This class is responsible for changes to EventTypeIndex for addition and removal of filters.
EventTypeIndexBuilder(EventTypeIndex) - Constructor for class net.esper.filter.EventTypeIndexBuilder
Constructor - takes the event type index to manipulate as its parameter.
eventTypesLegacy - Variable in class net.esper.client.Configuration
Map of event type alias and Legacy-type event configuration.
eventTypesXMLDOM - Variable in class net.esper.client.Configuration
Map of event type alias and XML DOM configuration.
every(PatternExpr) - Static method in class net.esper.client.soda.Patterns
Pattern-every expression control the lifecycle of the pattern sub-expression.
EVERY_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVERY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
everyFilter(String) - Static method in class net.esper.client.soda.Patterns
Pattern every-operator and filter in combination, equivalent to the "every MyEvent" syntax.
everyFilter(String, String) - Static method in class net.esper.client.soda.Patterns
Pattern every-operator and filter in combination, equivalent to the "every tag=MyEvent" syntax.
everyFilter(Filter) - Static method in class net.esper.client.soda.Patterns
Pattern every-operator and filter in combination, equivalent to the "every MyEvent(vol > 100)" syntax.
everyFilter(Filter, String) - Static method in class net.esper.client.soda.Patterns
Pattern every-operator and filter in combination, equivalent to the "every tag=MyEvent(vol > 100)" syntax.
ExecNode - Class in net.esper.eql.join.exec
Interface for an execution node that looks up events and builds a result set contributing to an overall join result set.
ExecNode() - Constructor for class net.esper.eql.join.exec.ExecNode
 
ExecNodeQueryStrategy - Class in net.esper.eql.join
Query strategy for building a join tuple set by using an execution node tree.
ExecNodeQueryStrategy(int, int, ExecNode) - Constructor for class net.esper.eql.join.ExecNodeQueryStrategy
CTor.
execute() - Method in interface net.esper.core.EPStatementDispatch
Execute dispatch.
execute() - Method in class net.esper.core.PatternListenerDispatch
 
execute() - Method in class net.esper.core.UpdateDispatchFutureSpin
 
execute() - Method in class net.esper.core.UpdateDispatchFutureWait
 
execute() - Method in class net.esper.core.UpdateDispatchViewBase
 
execute() - Method in interface net.esper.dispatch.Dispatchable
Execute dispatch.
execute() - Method in class net.esper.eql.join.JoinExecStrategyDispatchable
 
ExecutionPathDebugLog - Class in net.esper.util
Utility class that control debug-level logging in the execution path beyond which is controlled by Log4j.
ExecutionPathDebugLog() - Constructor for class net.esper.util.ExecutionPathDebugLog
 
EXISTS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EXISTS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
exists(EventType, String) - Static method in class net.esper.view.PropertyCheckHelper
Check if the field identified by the field name exists according to the schema.
exists(EventType, String, String) - Static method in class net.esper.view.PropertyCheckHelper
Check if the fields identified by the field names both exists according to the schema.
EXISTS_SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EXISTS_SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
existsProperty(String) - Static method in class net.esper.client.soda.Expressions
Exists-function for use with dynamic properties to test property existence.
existsSubSelectExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
expectedModCount - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
The modification count expected
expire() - Method in class net.esper.view.ext.TimeOrderView
This method removes (expires) objects from the window and schedules a new callback for the time when the next oldest message would expire from the window.
expire() - Method in class net.esper.view.window.TimeWindowView
This method removes (expires) objects from the window and schedules a new callback for the time when the next oldest message would expire from the window.
expireEvents(long) - Method in class net.esper.collection.TimeWindow
Return and remove events in time-slots earlier (less) then the timestamp passed in, returning the list of events expired.
EXPONENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EXPONENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ExprAggregateNode - Class in net.esper.eql.expression
Base expression node that represents an aggregation function such as 'sum' or 'count'.
ExprAggregateNode(boolean) - Constructor for class net.esper.eql.expression.ExprAggregateNode
Ctor.
ExprAndNode - Class in net.esper.eql.expression
Represents an And-condition.
ExprAndNode() - Constructor for class net.esper.eql.expression.ExprAndNode
 
ExprArrayNode - Class in net.esper.eql.expression
Represents an array in a filter expressiun tree.
ExprArrayNode() - Constructor for class net.esper.eql.expression.ExprArrayNode
Ctor.
ExprAvedevNode - Class in net.esper.eql.expression
Represents the avedev(...) aggregate function is an expression tree.
ExprAvedevNode(boolean) - Constructor for class net.esper.eql.expression.ExprAvedevNode
Ctor.
ExprAvgNode - Class in net.esper.eql.expression
Represents the avg(...) aggregate function is an expression tree.
ExprAvgNode(boolean) - Constructor for class net.esper.eql.expression.ExprAvgNode
Ctor.
ExprBetweenNode - Class in net.esper.eql.expression
Represents the between-clause function in an expression tree.
ExprBetweenNode(boolean, boolean, boolean) - Constructor for class net.esper.eql.expression.ExprBetweenNode
Ctor.
ExprBitWiseNode - Class in net.esper.eql.expression
Represents the bit-wise operators in an expression tree.
ExprBitWiseNode(BitWiseOpEnum) - Constructor for class net.esper.eql.expression.ExprBitWiseNode
Ctor.
ExprCaseNode - Class in net.esper.eql.expression
Represents the case-when-then-else control flow function is an expression tree.
ExprCaseNode(boolean) - Constructor for class net.esper.eql.expression.ExprCaseNode
Ctor.
ExprCastNode - Class in net.esper.eql.expression
Represents the CAST(expression, type) function is an expression tree.
ExprCastNode(String) - Constructor for class net.esper.eql.expression.ExprCastNode
Ctor.
ExprCastNode.ByteCaster - Class in net.esper.eql.expression
Cast implementation for numeric values.
ExprCastNode.ByteCaster() - Constructor for class net.esper.eql.expression.ExprCastNode.ByteCaster
 
ExprCastNode.Caster - Interface in net.esper.eql.expression
Interface for casting.
ExprCastNode.DoubleCaster - Class in net.esper.eql.expression
Cast implementation for numeric values.
ExprCastNode.DoubleCaster() - Constructor for class net.esper.eql.expression.ExprCastNode.DoubleCaster
 
ExprCastNode.FloatCaster - Class in net.esper.eql.expression
Cast implementation for numeric values.
ExprCastNode.FloatCaster() - Constructor for class net.esper.eql.expression.ExprCastNode.FloatCaster
 
ExprCastNode.IntCaster - Class in net.esper.eql.expression
Cast implementation for numeric values.
ExprCastNode.IntCaster() - Constructor for class net.esper.eql.expression.ExprCastNode.IntCaster
 
ExprCastNode.LongCaster - Class in net.esper.eql.expression
Cast implementation for numeric values.
ExprCastNode.LongCaster() - Constructor for class net.esper.eql.expression.ExprCastNode.LongCaster
 
ExprCastNode.ShortCaster - Class in net.esper.eql.expression
Cast implementation for numeric values.
ExprCastNode.ShortCaster() - Constructor for class net.esper.eql.expression.ExprCastNode.ShortCaster
 
ExprCastNode.TypeCaster - Class in net.esper.eql.expression
Cast implementation for non-numeric values.
ExprCastNode.TypeCaster(Class) - Constructor for class net.esper.eql.expression.ExprCastNode.TypeCaster
Ctor.
exprChoice(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
ExprCoalesceNode - Class in net.esper.eql.expression
Represents the COALESCE(a,b,...) function is an expression tree.
ExprCoalesceNode() - Constructor for class net.esper.eql.expression.ExprCoalesceNode
 
ExprConcatNode - Class in net.esper.eql.expression
Represents a simple Math (+/-/divide/*) in a filter expression tree.
ExprConcatNode() - Constructor for class net.esper.eql.expression.ExprConcatNode
Ctor.
ExprConstantNode - Class in net.esper.eql.expression
Represents a constant in an expressiun tree.
ExprConstantNode(Object) - Constructor for class net.esper.eql.expression.ExprConstantNode
Ctor.
ExprCountNode - Class in net.esper.eql.expression
Represents the count(...) and count(*) and count(distinct ...) aggregate function is an expression tree.
ExprCountNode(boolean) - Constructor for class net.esper.eql.expression.ExprCountNode
Ctor.
ExprEqualsNode - Class in net.esper.eql.expression
Represents an equals (=) comparator in a filter expressiun tree.
ExprEqualsNode(boolean) - Constructor for class net.esper.eql.expression.ExprEqualsNode
Ctor.
Expression - Interface in net.esper.client.soda
Interface representing an expression for use in select-clauses, where-clauses, having-clauses, order-by clauses and streams based on filters and pattern filter expressions.
expression() - Method in class net.esper.eql.generated.EQLStatementParser
 
ExpressionBase - Class in net.esper.client.soda
Base expression.
ExpressionBase() - Constructor for class net.esper.client.soda.ExpressionBase
Ctor.
expressionList() - Method in class net.esper.eql.generated.EQLStatementParser
 
Expressions - Class in net.esper.client.soda
Convenience factory for creating Expression instances.
Expressions() - Constructor for class net.esper.client.soda.Expressions
 
ExprEvaluator - Interface in net.esper.eql.expression
Interface for evaluating of an event tuple.
ExprIdentNode - Class in net.esper.eql.expression
Represents an stream property identifier in a filter expressiun tree.
ExprIdentNode(String) - Constructor for class net.esper.eql.expression.ExprIdentNode
Ctor.
ExprIdentNode(String, String) - Constructor for class net.esper.eql.expression.ExprIdentNode
Ctor.
ExprInNode - Class in net.esper.eql.expression
Represents the in-clause (set check) function in an expression tree.
ExprInNode(boolean) - Constructor for class net.esper.eql.expression.ExprInNode
Ctor.
ExprInstanceofNode - Class in net.esper.eql.expression
Represents the INSTANCEOF(a,b,...) function is an expression tree.
ExprInstanceofNode(String[]) - Constructor for class net.esper.eql.expression.ExprInstanceofNode
Ctor.
ExprLikeNode - Class in net.esper.eql.expression
Represents the like-clause in an expression tree.
ExprLikeNode(boolean) - Constructor for class net.esper.eql.expression.ExprLikeNode
Ctor.
ExprMathNode - Class in net.esper.eql.expression
Represents a simple Math (+/-/divide/*) in a filter expression tree.
ExprMathNode(MathArithTypeEnum) - Constructor for class net.esper.eql.expression.ExprMathNode
Ctor.
ExprMedianNode - Class in net.esper.eql.expression
Represents the median(...) aggregate function is an expression tree.
ExprMedianNode(boolean) - Constructor for class net.esper.eql.expression.ExprMedianNode
Ctor.
ExprMinMaxAggrNode - Class in net.esper.eql.expression
Represents the min/max(distinct? ...) aggregate function is an expression tree.
ExprMinMaxAggrNode(boolean, MinMaxTypeEnum) - Constructor for class net.esper.eql.expression.ExprMinMaxAggrNode
Ctor.
ExprMinMaxRowNode - Class in net.esper.eql.expression
Represents the MAX(a,b) and MIN(a,b) functions is an expression tree.
ExprMinMaxRowNode(MinMaxTypeEnum) - Constructor for class net.esper.eql.expression.ExprMinMaxRowNode
Ctor.
ExprNode - Class in net.esper.eql.expression
Superclass for filter nodes in a filter expression tree.
ExprNode() - Constructor for class net.esper.eql.expression.ExprNode
Constructor creates a list of child nodes.
ExprNode.MappedPropertyParseResult - Class in net.esper.eql.expression
Encapsulates the parse result parsing a mapped property as a class and method name with args.
ExprNode.MappedPropertyParseResult(String, String, String) - Constructor for class net.esper.eql.expression.ExprNode.MappedPropertyParseResult
Returns the parse result of the mapped property.
ExprNodeAdapter - Class in net.esper.filter
Adapter for use by FilterParamIndexBooleanExpr to evaluate boolean expressions, providing events per stream to expression nodes.
ExprNodeAdapter(ExprNode, EventBean[], VariableService) - Constructor for class net.esper.filter.ExprNodeAdapter
Ctor.
ExprNodeIdentifierVisitor - Class in net.esper.eql.expression
Visitor that collects event property identifier information under expression nodes.
ExprNodeIdentifierVisitor(boolean) - Constructor for class net.esper.eql.expression.ExprNodeIdentifierVisitor
Ctor.
ExprNodeSubselectVisitor - Class in net.esper.eql.expression
Visitor that collects ExprSubselectNode instances.
ExprNodeSubselectVisitor() - Constructor for class net.esper.eql.expression.ExprNodeSubselectVisitor
Ctor.
ExprNodeVariableVisitor - Class in net.esper.eql.expression
Visitor for expression node trees that determines if the expressions within contain a variable.
ExprNodeVariableVisitor() - Constructor for class net.esper.eql.expression.ExprNodeVariableVisitor
 
ExprNodeVisitor - Interface in net.esper.eql.expression
Visitor interface for use with expression node trees.
ExprNotNode - Class in net.esper.eql.expression
Represents a NOT expression in an expression tree.
ExprNotNode() - Constructor for class net.esper.eql.expression.ExprNotNode
 
ExprOrNode - Class in net.esper.eql.expression
Represents an OR expression in a filter expression tree.
ExprOrNode() - Constructor for class net.esper.eql.expression.ExprOrNode
 
ExprPlugInAggFunctionNode - Class in net.esper.eql.expression
Represents a custom aggregation function in an expresson tree.
ExprPlugInAggFunctionNode(boolean, AggregationSupport, String) - Constructor for class net.esper.eql.expression.ExprPlugInAggFunctionNode
Ctor.
ExprPreviousNode - Class in net.esper.eql.expression
Represents the 'prev' previous event function in an expression node tree.
ExprPreviousNode() - Constructor for class net.esper.eql.expression.ExprPreviousNode
 
ExprPriorNode - Class in net.esper.eql.expression
Represents the 'prior' prior event function in an expression node tree.
ExprPriorNode() - Constructor for class net.esper.eql.expression.ExprPriorNode
 
ExprPropertyExistsNode - Class in net.esper.eql.expression
Represents the EXISTS(property) function in an expression tree.
ExprPropertyExistsNode() - Constructor for class net.esper.eql.expression.ExprPropertyExistsNode
Ctor.
ExprRegexpNode - Class in net.esper.eql.expression
Represents the regexp-clause in an expression tree.
ExprRegexpNode(boolean) - Constructor for class net.esper.eql.expression.ExprRegexpNode
Ctor.
ExprRelationalOpNode - Class in net.esper.eql.expression
Represents a lesser or greater then (/>=) expression in a filter expression tree.
ExprRelationalOpNode(RelationalOpEnum) - Constructor for class net.esper.eql.expression.ExprRelationalOpNode
Ctor.
ExprStaticMethodNode - Class in net.esper.eql.expression
Represents an invocation of a static library method in the expression tree.
ExprStaticMethodNode(String, String) - Constructor for class net.esper.eql.expression.ExprStaticMethodNode
Ctor.
ExprStddevNode - Class in net.esper.eql.expression
Represents the stddev(...) aggregate function is an expression tree.
ExprStddevNode(boolean) - Constructor for class net.esper.eql.expression.ExprStddevNode
Ctor.
ExprStreamInstanceMethodNode - Class in net.esper.eql.expression
Represents an invocation of a instance method on an event of a given stream in the expression tree.
ExprStreamInstanceMethodNode(String, String) - Constructor for class net.esper.eql.expression.ExprStreamInstanceMethodNode
Ctor.
ExprStreamUnderlyingNode - Class in net.esper.eql.expression
Represents an stream selector that returns the streams underlying event, or null if undefined.
ExprStreamUnderlyingNode(String) - Constructor for class net.esper.eql.expression.ExprStreamUnderlyingNode
Ctor.
ExprSubselectExistsNode - Class in net.esper.eql.expression
Represents an exists-subselect in an expression tree.
ExprSubselectExistsNode(StatementSpecRaw) - Constructor for class net.esper.eql.expression.ExprSubselectExistsNode
Ctor.
ExprSubselectInNode - Class in net.esper.eql.expression
Represents a subselect in an expression tree.
ExprSubselectInNode(StatementSpecRaw) - Constructor for class net.esper.eql.expression.ExprSubselectInNode
Ctor.
ExprSubselectNode - Class in net.esper.eql.expression
Represents a subselect in an expression tree.
ExprSubselectNode(StatementSpecRaw) - Constructor for class net.esper.eql.expression.ExprSubselectNode
Ctor.
ExprSubselectRowNode - Class in net.esper.eql.expression
Represents a subselect in an expression tree.
ExprSubselectRowNode(StatementSpecRaw) - Constructor for class net.esper.eql.expression.ExprSubselectRowNode
Ctor.
ExprSubstitutionNode - Class in net.esper.eql.expression
Represents a substitution value to be substituted in an expression tree, not valid for any purpose of use as an expression, however can take a place in an expression tree.
ExprSubstitutionNode(int) - Constructor for class net.esper.eql.expression.ExprSubstitutionNode
Ctor.
ExprSumNode - Class in net.esper.eql.expression
Represents the sum(...) aggregate function is an expression tree.
ExprSumNode(boolean) - Constructor for class net.esper.eql.expression.ExprSumNode
Ctor.
ExprTimestampNode - Class in net.esper.eql.expression
Represents the CURRENT_TIMESTAMP() function or reserved keyword in an expression tree.
ExprTimestampNode() - Constructor for class net.esper.eql.expression.ExprTimestampNode
Ctor.
ExprValidationException - Exception in net.esper.eql.expression
Thrown to indicate a validation error in a filter expression.
ExprValidationException(String) - Constructor for exception net.esper.eql.expression.ExprValidationException
Ctor.
ExprValidationException(String, Throwable) - Constructor for exception net.esper.eql.expression.ExprValidationException
Ctor.
ExprValidator - Interface in net.esper.eql.expression
Validation interface for expression nodes.
ExprVariableNode - Class in net.esper.eql.expression
Represents a variable in an expression tree.
ExprVariableNode(String) - Constructor for class net.esper.eql.expression.ExprVariableNode
Ctor.
ExtensionServicesContext - Interface in net.esper.core
Marker interface for extension services that provide additional engine or statement-level extensions, such as views backed by a write-behind store.
ExternallyTimedWindowView - Class in net.esper.view.window
View for a moving window extending the specified amount of time into the past, driven entirely by external timing supplied within long-type timestamp values in a field of the event beans that the view receives.
ExternallyTimedWindowView(ExternallyTimedWindowViewFactory, String, long, ViewUpdatedCollection, boolean) - Constructor for class net.esper.view.window.ExternallyTimedWindowView
Constructor.
ExternallyTimedWindowViewFactory - Class in net.esper.view.window
Factory for ExternallyTimedWindowView.
ExternallyTimedWindowViewFactory() - Constructor for class net.esper.view.window.ExternallyTimedWindowViewFactory
 

F

faculty(int) - Static method in class net.esper.collection.PermutationEnumeration
Computes faculty of N.
fieldName - Variable in class net.esper.view.stat.UnivariateStatisticsViewFactory
Property name of data field.
fieldNameWeight - Variable in class net.esper.view.stat.WeightedAverageViewFactory
Property name of weight field.
fieldNameX - Variable in class net.esper.view.stat.CorrelationViewFactory
Property name of X field.
fieldNameX - Variable in class net.esper.view.stat.RegressionLinestViewFactory
Property name of X field.
fieldNameX - Variable in class net.esper.view.stat.WeightedAverageViewFactory
Property name of X field.
fieldNameY - Variable in class net.esper.view.stat.CorrelationViewFactory
Property name of Y field.
fieldNameY - Variable in class net.esper.view.stat.RegressionLinestViewFactory
Property name of Y field.
fillEquivalentNav(QueryGraph) - Static method in class net.esper.eql.join.plan.QueryGraph
Fill in equivalent key properties (navigation entries) on all streams.
Filter - Class in net.esper.client.soda
Filter defines the event type to be filtered for, and an optional expression that returns true if the filter should consider the event, or false to reject the event.
Filter(String) - Constructor for class net.esper.client.soda.Filter
Ctor.
Filter(String, Expression) - Constructor for class net.esper.client.soda.Filter
Ctor.
filter(String) - Static method in class net.esper.client.soda.Patterns
Filter expression for use in patterns, equivalent to the simple "MyEvent" syntax.
filter(String, String) - Static method in class net.esper.client.soda.Patterns
Filter expression for use in patterns, equivalent to the simple "tag=MyEvent" syntax.
filter(Filter) - Static method in class net.esper.client.soda.Patterns
Filter expression for use in patterns, equivalent to the "MyEvent(vol > 100)" syntax.
filter(Filter, String) - Static method in class net.esper.client.soda.Patterns
Filter expression for use in patterns, equivalent to the "tag=MyEvent(vol > 100)" syntax.
filter(ExprNode, Set<MultiKey<EventBean>>, boolean) - Static method in class net.esper.eql.join.JoinSetFilter
Filter event by applying the filter nodes evaluation method.
filterAtom(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
filterEvents(ExprEvaluator, EventBean[], boolean) - Static method in class net.esper.eql.view.FilterExprView
Filters events using the supplied evaluator.
filterExpr - Variable in class net.esper.eql.expression.ExprSubselectNode
The validate filter expression.
FilterExprAnalyzer - Class in net.esper.eql.join.plan
Analyzes a filter expression and builds a query graph model.
FilterExprAnalyzer() - Constructor for class net.esper.eql.join.plan.FilterExprAnalyzer
 
FilterExprView - Class in net.esper.eql.view
Simple filter view filtering events using a filter expression tree.
FilterExprView(ExprEvaluator) - Constructor for class net.esper.eql.view.FilterExprView
Ctor.
FilterExprViewIterator - Class in net.esper.eql.view
Iterator for reading and filtering a source event iterator.
FilterExprViewIterator(Iterator<EventBean>, ExprEvaluator) - Constructor for class net.esper.eql.view.FilterExprViewIterator
Ctor.
FilterHandle - Interface in net.esper.filter
Marker interface for use with FilterService.
FilterHandleCallback - Interface in net.esper.filter
Interface for a callback method to be called when an event matches a filter specification.
FilterHandleSetNode - Class in net.esper.filter
This class holds a list of indizes storing filter constants in FilterParamIndexBase nodes and a set of FilterHandle.
FilterHandleSetNode() - Constructor for class net.esper.filter.FilterHandleSetNode
Constructor.
filterIdentifier(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
FilterOperator - Enum in net.esper.filter
Defines the different operator types available for event filters.
filterParam(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
filterParamComparator(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
FilterParamExprMap - Class in net.esper.filter
A two-sided map for filter parameters mapping filter expression nodes to filter parameters and back.
FilterParamExprMap() - Constructor for class net.esper.filter.FilterParamExprMap
Ctor.
FilterParamIndexBase - Class in net.esper.filter
Each implementation of this abstract class represents an index of filter parameter constants supplied in filter parameters in filter specifications that feature the same event property and operator.
FilterParamIndexBase(FilterOperator) - Constructor for class net.esper.filter.FilterParamIndexBase
Constructor.
FilterParamIndexBooleanExpr - Class in net.esper.filter
Index that simply maintains a list of boolean expressions.
FilterParamIndexBooleanExpr(EventType) - Constructor for class net.esper.filter.FilterParamIndexBooleanExpr
Constructs the index for multiple-exact matches.
FilterParamIndexCompare - Class in net.esper.filter
Index for filter parameter constants for the comparison operators (less, greater, etc).
FilterParamIndexCompare(String, FilterOperator, EventType) - Constructor for class net.esper.filter.FilterParamIndexCompare
Constructs the index for matching comparison operators (<, >, <=, >=).
FilterParamIndexEquals - Class in net.esper.filter
Index for filter parameter constants to match using the equals (=) operator.
FilterParamIndexEquals(String, EventType) - Constructor for class net.esper.filter.FilterParamIndexEquals
Constructs the index for exact matches.
FilterParamIndexIn - Class in net.esper.filter
Index for filter parameter constants to match using the 'in' operator to match against a supplied set of values (i.e.
FilterParamIndexIn(String, EventType) - Constructor for class net.esper.filter.FilterParamIndexIn
Constructs the index for multiple-exact matches.
FilterParamIndexNotEquals - Class in net.esper.filter
Index for filter parameter constants to match using the equals (=) operator.
FilterParamIndexNotEquals(String, EventType) - Constructor for class net.esper.filter.FilterParamIndexNotEquals
Constructs the index for exact matches.
FilterParamIndexNotIn - Class in net.esper.filter
Index for filter parameter constants to match using the 'not in' operator to match against a all other values then the supplied set of values.
FilterParamIndexNotIn(String, EventType) - Constructor for class net.esper.filter.FilterParamIndexNotIn
Constructs the index for multiple-exact matches.
FilterParamIndexNotRange - Class in net.esper.filter
Index for filter parameter constants for the not range operators (range open/closed/half).
FilterParamIndexNotRange(String, FilterOperator, EventType) - Constructor for class net.esper.filter.FilterParamIndexNotRange
Constructs the index for matching ranges.
FilterParamIndexPropBase - Class in net.esper.filter
Each implementation of this abstract class represents an index of filter parameter constants supplied in filter parameters in filter specifications that feature the same event property and operator.
FilterParamIndexPropBase(String, FilterOperator, EventType) - Constructor for class net.esper.filter.FilterParamIndexPropBase
Constructor.
FilterParamIndexRange - Class in net.esper.filter
Index for filter parameter constants for the range operators (range open/closed/half).
FilterParamIndexRange(String, FilterOperator, EventType) - Constructor for class net.esper.filter.FilterParamIndexRange
Constructs the index for matching ranges.
FilterService - Interface in net.esper.filter
Interface for filtering events by event type and event property values.
FilterServiceImpl - Class in net.esper.filter
Implementation of the filter service interface.
FilterServiceImpl() - Constructor for class net.esper.filter.FilterServiceImpl
Constructor.
FilterServiceProvider - Class in net.esper.filter
Static factory for implementations of the FilterService interface.
FilterServiceProvider() - Constructor for class net.esper.filter.FilterServiceProvider
 
FilterSpecCompiled - Class in net.esper.filter
Contains the filter criteria to sift through events.
FilterSpecCompiled(EventType, List<FilterSpecParam>) - Constructor for class net.esper.filter.FilterSpecCompiled
Constructor - validates parameter list against event type, throws exception if invalid property names or mismatcing filter operators are found.
FilterSpecCompiler - Class in net.esper.filter
Helper to compile (validate and optimize) filter expressions as used in pattern and filter-based streams.
FilterSpecCompiler() - Constructor for class net.esper.filter.FilterSpecCompiler
 
FilterSpecParam - Class in net.esper.filter
This class represents one filter parameter in an FilterSpecCompiled filter specification.
FilterSpecParamConstant - Class in net.esper.filter
This class represents a single, constant value filter parameter in an FilterSpecCompiled filter specification.
FilterSpecParamConstant(String, FilterOperator, Object) - Constructor for class net.esper.filter.FilterSpecParamConstant
Constructor.
FilterSpecParamEventProp - Class in net.esper.filter
This class represents a filter parameter containing a reference to another event's property in the event pattern result, for use to describe a filter parameter in a FilterSpecCompiled filter specification.
FilterSpecParamEventProp(String, FilterOperator, String, String, boolean, Class) - Constructor for class net.esper.filter.FilterSpecParamEventProp
Constructor.
FilterSpecParamExprNode - Class in net.esper.filter
This class represents an arbitrary expression node returning a boolean value as a filter parameter in an FilterSpecCompiled filter specification.
FilterSpecParamExprNode(String, FilterOperator, ExprNode, LinkedHashMap<String, EventType>, VariableService) - Constructor for class net.esper.filter.FilterSpecParamExprNode
Ctor.
FilterSpecParamIn - Class in net.esper.filter
This class represents a 'in' filter parameter in an FilterSpecCompiled filter specification.
FilterSpecParamIn(String, FilterOperator, List<FilterSpecParamInValue>) - Constructor for class net.esper.filter.FilterSpecParamIn
Ctor.
FilterSpecParamInValue - Interface in net.esper.filter
Denotes a value for use by the in-keyword within a list of values
FilterSpecParamRange - Class in net.esper.filter
This class represents a range filter parameter in an FilterSpecCompiled filter specification.
FilterSpecParamRange(String, FilterOperator, FilterSpecParamRangeValue, FilterSpecParamRangeValue) - Constructor for class net.esper.filter.FilterSpecParamRange
Constructor.
FilterSpecParamRangeValue - Interface in net.esper.filter
Interface for range-type filter parameters for type checking and to obtain the filter values for endpoints based on prior results.
FilterSpecRaw - Class in net.esper.eql.spec
Filter definition in an un-validated and un-resolved form.
FilterSpecRaw(String, List<ExprNode>) - Constructor for class net.esper.eql.spec.FilterSpecRaw
Ctor.
FilterSpecRaw() - Constructor for class net.esper.eql.spec.FilterSpecRaw
Default ctor.
FilterStream - Class in net.esper.client.soda
A stream upon which projections (views) can be added that selects events by name and filter expression.
FilterStream(Filter) - Constructor for class net.esper.client.soda.FilterStream
Ctor.
FilterStream(Filter, String) - Constructor for class net.esper.client.soda.FilterStream
Ctor.
FilterStream(Filter, String, List<View>) - Constructor for class net.esper.client.soda.FilterStream
Ctor.
FilterStreamSpecCompiled - Class in net.esper.eql.spec
Specification for building an event stream out of a filter for events (supplying type and basic filter criteria) and views onto these events which are staggered onto each other to supply a final stream of events.
FilterStreamSpecCompiled(FilterSpecCompiled, List<ViewSpec>, String) - Constructor for class net.esper.eql.spec.FilterStreamSpecCompiled
Ctor.
FilterStreamSpecRaw - Class in net.esper.eql.spec
Unvalided filter-based stream specification.
FilterStreamSpecRaw(FilterSpecRaw, List<ViewSpec>, String) - Constructor for class net.esper.eql.spec.FilterStreamSpecRaw
Ctor.
FilterStreamSpecRaw() - Constructor for class net.esper.eql.spec.FilterStreamSpecRaw
Default ctor.
FilterValueSet - Interface in net.esper.filter
Contains the filter criteria to sift through events.
FilterValueSetImpl - Class in net.esper.filter
Container for filter values for use by the FilterService to filter and distribute incoming events.
FilterValueSetImpl(EventType, List<FilterValueSetParam>) - Constructor for class net.esper.filter.FilterValueSetImpl
Ctor.
FilterValueSetParam - Interface in net.esper.filter
This interface represents one filter parameter in an FilterValueSet filter specification.
FilterValueSetParamComparator - Class in net.esper.filter
Sort comparator for filter parameters that sorts filter parameters according to filter operator type, and within the same filter operator sorts by event property name.
FilterValueSetParamComparator() - Constructor for class net.esper.filter.FilterValueSetParamComparator
 
FilterValueSetParamImpl - Class in net.esper.filter
Filter parameter value defining the event property to filter, the filter operator, and the filter value.
FilterValueSetParamImpl(String, FilterOperator, Object) - Constructor for class net.esper.filter.FilterValueSetParamImpl
Ctor.
findDescendent(Viewable, Viewable) - Static method in class net.esper.view.ViewSupport
Find the descendent view in the view tree under the parent view returning the list of view nodes between the parent view and the descendent view.
findIndex(SortedSet<FilterValueSetParam>, List<FilterParamIndexBase>) - Static method in class net.esper.filter.IndexHelper
Find an index that matches one of the filter parameters passed.
findInsertIndex(double) - Method in class net.esper.collection.SortedDoubleVector
Returns the index into which to insert to.
findParameter(SortedSet<FilterValueSetParam>, FilterParamIndexBase) - Static method in class net.esper.filter.IndexHelper
Determine among the passed in filter parameters any parameter that matches the given index on property name and filter operator type.
findPropertyMapping(XSComplexTypeDefinition, String) - Static method in class net.esper.event.xml.SchemaUtil
Finds an apropiate definition for the given property, starting at the given definition.
findRootElement(XSModel, String, String) - Static method in class net.esper.event.xml.SchemaUtil
Returns the root element for a given schema given a root element name and namespace.
fireStatementStopped() - Method in interface net.esper.view.StatementStopService
Used by the engine to indicate a statement stopped, invoking any callbacks registered.
fireStatementStopped() - Method in class net.esper.view.StatementStopServiceImpl
 
FIRST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FIRST - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
flatten(List<EventBean[]>) - Static method in class net.esper.event.EventBeanUtility
Flatten the vector of arrays to an array.
flattenBatchJoin(List<UniformPair<Set<MultiKey<EventBean>>>>) - Static method in class net.esper.event.EventBeanUtility
Flattens a list of pairs of join result sets.
flattenBatchStream(List<UniformPair<EventBean[]>>) - Static method in class net.esper.event.EventBeanUtility
Flatten the vector of arrays to an array.
FLOAT_SUFFIX - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FLOAT_SUFFIX - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
FLOAT_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FLOAT_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
FloatSumAggregator - Class in net.esper.eql.agg
Sum for float values.
FloatSumAggregator() - Constructor for class net.esper.eql.agg.FloatSumAggregator
 
FloatValue - Class in net.esper.type
Placeholder for a float value in an event expression.
FloatValue() - Constructor for class net.esper.type.FloatValue
 
flush() - Method in class net.esper.collection.FlushedEventBuffer
Empty buffer.
FlushedEventBuffer - Class in net.esper.collection
Buffer for events - accumulates events until flushed.
FlushedEventBuffer() - Constructor for class net.esper.collection.FlushedEventBuffer
 
FOLLOWED_BY - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FOLLOWED_BY - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
FOLLOWED_BY_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FOLLOWED_BY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
followedBy(PatternExpr, PatternExpr, PatternExpr...) - Static method in class net.esper.client.soda.Patterns
Pattern followed-by expression, allows adding sub-expressions that are connected by a followed-by.
followedBy() - Static method in class net.esper.client.soda.Patterns
Pattern followed-by expression, allows adding sub-expressions that are connected by a followed-by.
followedByExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
forName(String, String) - Static method in enum net.esper.pattern.guard.GuardEnum
Returns the enum for the given namespace and name.
forName(String, String) - Static method in enum net.esper.pattern.observer.ObserverEnum
Returns observer enum for namespace name and observer name.
forName(String, String) - Static method in enum net.esper.view.ViewEnum
Returns the view enumeration value given the name of the view.
frequencyOperand() - Method in class net.esper.eql.generated.EQLStatementParser
 
FrequencyParameter - Class in net.esper.type
Encapsulates a parameter specifying a frequency, i.e.
FrequencyParameter(int) - Constructor for class net.esper.type.FrequencyParameter
Ctor.
FROM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FROM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
FromClause - Class in net.esper.client.soda
The from-clause names the streams to select upon.
FromClause(Stream, OuterJoinQualifier, Stream) - Constructor for class net.esper.client.soda.FromClause
Ctor for an outer join between two streams.
FromClause(Stream...) - Constructor for class net.esper.client.soda.FromClause
Ctor.
fromClause(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
FULL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FULL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
FULL_OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FULL_OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
FullTableScanLookupPlan - Class in net.esper.eql.join.plan
Plan for a full table scan.
FullTableScanLookupPlan(int, int, int) - Constructor for class net.esper.eql.join.plan.FullTableScanLookupPlan
Ctor.
FullTableScanLookupStrategy - Class in net.esper.eql.join.exec
Lookup on an unindexed table returning the full table as matching events.
FullTableScanLookupStrategy(UnindexedEventTable) - Constructor for class net.esper.eql.join.exec.FullTableScanLookupStrategy
Ctor.
FullTableScanLookupStrategy - Class in net.esper.eql.lookup
Lookup on an unindexed table returning the full table as matching events.
FullTableScanLookupStrategy(UnindexedEventTable) - Constructor for class net.esper.eql.lookup.FullTableScanLookupStrategy
Ctor.
funcIdent() - Method in class net.esper.eql.generated.EQLStatementParser
 
functionName - Variable in class net.esper.eql.agg.AggregationSupport
Provides the aggregation function name.

G

ge(String, Object) - Static method in class net.esper.client.soda.Expressions
Greater-or-equal between a property and a constant.
ge(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Greater-or-equals between expression results.
GE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
generate(Object) - Static method in class net.esper.util.UuidGenerator
Returns a unique uuid.
generateGroupKey(EventBean[], boolean) - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
Generates the group-by key for the row
generateGroupKey(EventBean[], boolean) - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
Generates the group-by key for the row
generateMatchEvents(MatchedEventMap, EvalStateNode, Map<EvalStateNode, List<MatchedEventMap>>) - Static method in class net.esper.pattern.EvalAndStateNode
Generate a list of matching event combinations constisting of the events per child that are passed in.
generateMatchEvents(ArrayList<List<MatchedEventMap>>, int, List<MatchedEventMap>, MatchedEventMap) - Static method in class net.esper.pattern.EvalAndStateNode
For each combination of MatchedEventMap instance in all collections, add an entry to the list.
GenericFactory<T> - Class in net.esper.util
Factory for an instance of any type.
GenericFactory(Class<T>) - Constructor for class net.esper.util.GenericFactory
Ctor.
geProperty(String, String) - Static method in class net.esper.client.soda.Expressions
Greater-or-equal between properties.
get(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the value mapped to the key specified.
get(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Gets the value mapped to the key specified.
get(Object) - Method in class net.esper.collection.IndexedDataCollection
Returns a list of value objects for the given key, or null if there are no value objects for this key.
get(int) - Method in class net.esper.collection.MultiKey
Returns the key object at the specified position.
get(int) - Method in class net.esper.collection.MultiKeyUntyped
Returns the key object at the specified position.
get(K) - Method in class net.esper.collection.RefCountedMap
Get the value for a given key, returning null if the key was not found.
get(int) - Method in class net.esper.collection.RollingEventBuffer
Get an event prior to the last event posted given a number of events before the last.
get(String) - Method in class net.esper.event.BeanEventBean
 
get(EventBean) - Method in class net.esper.event.CGLibPropertyGetter
 
get(String) - Method in class net.esper.event.CompositeEventBean
 
get(String) - Method in interface net.esper.event.EventBean
Returns the value of an event property.
get(EventBean) - Method in interface net.esper.event.EventPropertyGetter
Return the value for the property in the event object specified when the instance was obtained.
get(String) - Method in class net.esper.event.MapEventBean
 
get(EventBean) - Method in class net.esper.event.property.ArrayFastPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.ArrayFieldPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.ArrayMethodPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.DynamicPropertyGetterBase
 
get(EventBean) - Method in class net.esper.event.property.KeyedFastPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.KeyedMethodPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.MapIndexedPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.MapMappedPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.MapNestedPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.MapPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.NestedPropertyGetter
 
get(EventBean) - Method in class net.esper.event.ReflectionPropFieldGetter
 
get(EventBean) - Method in class net.esper.event.ReflectionPropMethodGetter
 
get(String) - Method in class net.esper.event.WrapperEventBean
 
get(String) - Method in class net.esper.event.xml.XMLEventBean
 
get(EventBean) - Method in class net.esper.event.xml.XPathPropertyGetter
 
get(EventType) - Method in class net.esper.filter.EventTypeIndex
Returns the root node for the given event type, or null if this event type has not been seen before.
get(Object) - Method in class net.esper.filter.FilterParamIndexBase
Get the event evaluation instance associated with the constant.
get(Object) - Method in class net.esper.filter.FilterParamIndexBooleanExpr
 
get(Object) - Method in class net.esper.filter.FilterParamIndexCompare
 
get(Object) - Method in class net.esper.filter.FilterParamIndexEquals
 
get(Object) - Method in class net.esper.filter.FilterParamIndexIn
 
get(Object) - Method in class net.esper.filter.FilterParamIndexNotEquals
 
get(Object) - Method in class net.esper.filter.FilterParamIndexNotIn
 
get(Object) - Method in class net.esper.filter.FilterParamIndexNotRange
 
get(Object) - Method in class net.esper.filter.FilterParamIndexPropBase
Get the event evaluation instance associated with the constant.
get(Object) - Method in class net.esper.filter.FilterParamIndexRange
 
getAccessor() - Method in class net.esper.view.window.RandomAccessByIndexGetter
Returns the index for access.
getAccessor(EventBean) - Method in class net.esper.view.window.RelativeAccessByEventNIndexGetter
Returns the access into window contents given an event.
getAccessorField() - Method in class net.esper.event.EventPropertyDescriptor
Returns the accessor field.
getAccessorFieldName() - Method in class net.esper.client.ConfigurationEventTypeLegacy.LegacyFieldPropDesc
Returns the accessor field name.
getAccessorMethodName() - Method in class net.esper.client.ConfigurationEventTypeLegacy.LegacyMethodPropDesc
Returns the accessor method name.
getAccessorStyle() - Method in class net.esper.client.ConfigurationEventTypeLegacy
Returns the accessor style.
getAdapterLoaders() - Method in class net.esper.client.Configuration
 
getAdapterLoaders() - Method in interface net.esper.client.ConfigurationInformation
Returns a list of configured adapter loaders.
getAdditionalLeftNodes() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns additional properties in the on-clause, if any, that are connected via logical-and
getAdditionalProperties() - Method in class net.esper.client.soda.OuterJoinQualifier
Returns optional additional properties in the on-clause of the outer join.
getAdditionalRightNodes() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns additional properties in the on-clause, if any, that are connected via logical-and
getAggregatesBottomUp(ExprNode, List<ExprAggregateNode>) - Static method in class net.esper.eql.expression.ExprAggregateNode
Populates into the supplied list all aggregation functions within this expression, if any.
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprAggregateNode
Returns the aggregation function name for representation in a generate expression string.
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprAvedevNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprAvgNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprCountNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprMedianNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprPlugInAggFunctionNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprStddevNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprSumNode
 
getAlias() - Method in class net.esper.event.BeanEventType
Returns the event type alias.
getAlias() - Method in class net.esper.event.CompositeEventType
Returns the event type alias.
getAlias() - Method in class net.esper.event.MapEventType
Returns the event type alias.
getAlias() - Method in class net.esper.event.WrapperEventType
Returns the event type alias.
getAndFlush() - Method in class net.esper.collection.FlushedEventBuffer
Get the events currently buffered.
getArgString() - Method in class net.esper.eql.expression.ExprNode.MappedPropertyParseResult
Returns the method argument.
getArithmaticCoercionType(Class, Class) - Static method in class net.esper.util.JavaClassHelper
Returns the coercion type for the 2 numeric types for use in arithmatic.
getArray() - Method in class net.esper.collection.ArrayBackedCollection
Returns the backing object array, valid until the current size.
getArray() - Method in class net.esper.collection.MultiKey
Returns the key value array.
getAsName() - Method in class net.esper.client.soda.SelectClauseElement
Returns the optional "as"-name of the expression, or null if not defined
getAssignedName() - Method in class net.esper.eql.spec.SelectExprElementCompiledSpec
Returns the name of the item in the select clause.
getAssignment() - Method in class net.esper.eql.spec.CreateVariableDesc
Returns the assignment expression, or null if none
getAssignments() - Method in class net.esper.client.soda.OnSetClause
Returns the list of variable assignments.
getAssignments() - Method in class net.esper.eql.spec.OnTriggerSetDesc
Returns a list of all variables assignment by the on-set
getAttribute(String) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
 
getAttribute(String) - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
getAttributes(String[]) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
 
getAttributes(String[]) - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
getAutoCommit() - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Returns a boolean indicating auto-commit, or null if not set and default accepted.
getBinaryOp() - Method in class net.esper.client.soda.BitwiseOpExpression
Returns the binary operator.
getBinding() - Method in enum net.esper.util.DatabaseTypeEnum
Returns the binding for this enumeration value for reading the database result set and returning the right Java type.
getBitWiseOpEnum() - Method in class net.esper.eql.expression.ExprBitWiseNode
Returns the bitwise operator.
getBoxedClassName(String) - Static method in class net.esper.util.JavaClassHelper
Returns for the class name given the class name of the boxed (wrapped) type if the class name is one of the Java primitive types.
getBoxedType(Class) - Static method in class net.esper.util.JavaClassHelper
Returns the boxed class for the given class, or the class itself if already boxed or not a primitive type.
getBucketNum() - Method in class net.esper.schedule.ScheduleSlot
Returns the bucket number.
getBuffer() - Method in class net.esper.view.internal.PriorEventView
Returns the underlying buffer used for access to prior events.
getBuiltinIdentifiers() - Method in class net.esper.eql.db.SQLParameterDesc
Returns built-in identifiers.
getBuiltinPatternObjects() - Static method in class net.esper.pattern.PatternObjectHelper
Returns the built-in pattern objects.
getBuiltinViews() - Static method in class net.esper.view.ViewEnumHelper
Returns a collection of plug-in views.
getCached(Object[]) - Method in interface net.esper.eql.db.DataCache
Ask the cache if the keyed value is cached, returning a list or rows if the key is in the cache, or returning null to indicate no such key cached.
getCached(Object[]) - Method in class net.esper.eql.db.DataCacheExpiringImpl
 
getCached(Object[]) - Method in class net.esper.eql.db.DataCacheLRUImpl
Retrieves an entry from the cache.
getCached(Object[]) - Method in class net.esper.eql.db.DataCacheNullImpl
 
getCacheReferenceType() - Method in class net.esper.client.ConfigurationDBRef.ExpiryTimeCacheDesc
Returns the enumeration whether hard, soft or weak reference type are used to control whether the garbage collection can remove entries from cache.
getCacheSize() - Method in class net.esper.eql.db.DataCacheLRUImpl
Returns the maximum cache size.
getCatalog() - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Gets the name of the catalog to set on new database connections, or null for default.
getCell(MultiKeyUntyped) - Method in interface net.esper.view.stat.olap.MultidimCube
Get a cell, returns null if the cell does not yet exist.
getCell(MultiKeyUntyped) - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
getCellAddMembers(MultiKeyUntyped) - Method in interface net.esper.view.stat.olap.MultidimCube
Get a cell adding the coordinate members if the cell does not yet exist.
getCellAddMembers(MultiKeyUntyped) - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
getCells() - Method in interface net.esper.view.stat.olap.MultidimCube
Returns all cells.
getCells() - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
getChain() - Method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder.BestChainResult
Returns chain of stream numbers.
getChildNodes() - Method in class net.esper.eql.expression.ExprNode
Returns list of child nodes.
getChildNodes() - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Returns child nodes.
getChildNodes() - Method in class net.esper.eql.join.plan.NestedIterationNode
Returns list of child nodes.
getChildNodes() - Method in class net.esper.pattern.EvalNode
Returns list of child nodes.
getChildNumber() - Method in class net.esper.pattern.EvalNodeNumber
Returns the child number.
getChildren() - Method in interface net.esper.client.soda.Expression
Returns the list of sub-expressions (child expressions) to the current expression node.
getChildren() - Method in class net.esper.client.soda.ExpressionBase
Returns the list of sub-expressions to the current expression.
getChildren() - Method in interface net.esper.client.soda.PatternExpr
Returns the list of pattern sub-expressions (child expressions) to the current pattern expression node.
getChildren() - Method in class net.esper.client.soda.PatternExprBase
 
getChildren() - Method in class net.esper.client.soda.PatternGuardExpr
 
getChildren() - Method in class net.esper.client.soda.PatternObserverExpr
 
getClassForName(String) - Static method in class net.esper.util.JavaClassHelper
Returns the class given a fully-qualified class name.
getClassForSimpleName(String) - Static method in class net.esper.util.JavaClassHelper
Returns the boxed class for the given classname, recognizing all primitive and abbreviations, uppercase and lowercase.
getClassIdentifier() - Method in class net.esper.eql.expression.ExprCastNode
Returns the name of the type of cast to.
getClassIdentifiers() - Method in class net.esper.eql.expression.ExprInstanceofNode
Returns the list of class names or types to check instance of.
getClassName() - Method in class net.esper.client.ConfigurationAdapterLoader
Returns the loader class name.
getClassName() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the driver manager class name.
getClassName() - Method in class net.esper.client.soda.MethodInvocationStream
Returns the name of the class providing the method.
getClassName() - Method in class net.esper.client.soda.StaticMethodExpression
Returns the class name.
getClassName() - Method in class net.esper.eql.db.DBOutputTypeDesc
Returns the class name that getObject() on the output column produces.
getClassName() - Method in class net.esper.eql.expression.ExprNode.MappedPropertyParseResult
Returns class name.
getClassName() - Method in class net.esper.eql.expression.ExprStaticMethodNode
Returns the class name.
getClassName() - Method in class net.esper.eql.spec.MethodStreamSpec
Returns the class name.
getClasspathResourceAsURL(String, String) - Static method in class net.esper.util.ResourceLoader
Returns an URL from an application resource in the classpath.
getClassPropertyResolutionStyle() - Method in class net.esper.client.ConfigurationEngineDefaults.EventMeta
Returns the property resolution style to use for resolving property names of Java classes.
getClazz() - Method in class net.esper.event.BeanEventType.SimplePropertyInfo
Returns the return type.
getClazz() - Method in class net.esper.event.property.DynamicPropertyDescriptor
Returns the class for the method.
getClazz() - Method in enum net.esper.pattern.guard.GuardEnum
Gets the implementation class.
getClazz() - Method in enum net.esper.pattern.observer.ObserverEnum
Gets the implementation class.
getClockType() - Method in class net.esper.client.time.TimerControlEvent
Returns clocking type.
getCodeGeneration() - Method in class net.esper.client.ConfigurationEventTypeLegacy
Returns the code generation flag.
getCoercionType() - Method in class net.esper.eql.expression.ExprInNode
Returns the coercion type to use if coercion is required.
getCoercionType() - Method in class net.esper.eql.lookup.JoinedPropDesc
Returns the coercion type of key to index field.
getCoercionType() - Method in class net.esper.filter.FilterSpecParamEventProp
Returns the numeric coercion type.
getCoercionTypes(String[]) - Method in class net.esper.eql.join.plan.QueryPlanIndex
Returns a list of coercion types for a given index.
getCoercionTypes(EventType[], int, int, String[], String[]) - Static method in class net.esper.eql.join.plan.TwoStreamQueryPlanBuilder
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.
getCoercionTypes(Collection<JoinedPropDesc>) - Static method in class net.esper.eql.lookup.JoinedPropDesc
Returns the key coercion types.
getCoercionTypes(JoinedPropDesc[]) - Static method in class net.esper.eql.lookup.JoinedPropDesc
Returns the key coercion types.
getCoercionTypesPerIndex() - Method in class net.esper.eql.join.plan.QueryPlanIndex
Returns property names of all indexes.
getColumnCaseConversionEnum() - Method in class net.esper.eql.db.ColumnSettings
Returns the change case policy.
getColumnChangeCase() - Method in class net.esper.client.ConfigurationDBRef
Returns enum value determining how the engine changes case on output column names returned from statement or statement result set metadata.
getColumnField() - Method in class net.esper.view.stat.MultiDimStatsView
Returns the name of the field to extract the column values from.
getColumnNames() - Method in class net.esper.client.soda.InsertIntoClause
Returns a list of column names specified optionally in the insert-into clause, or empty if none specified.
getColumnNames() - Method in class net.esper.eql.spec.InsertIntoDesc
Returns a list of column names specified optionally in the insert-into clause, or empty if none specified.
getCommonCoercionType(Class[]) - Static method in class net.esper.util.JavaClassHelper
Determines a common denominator type to which one or more types can be casted or coerced.
getCompareToCoercionType(Class, Class) - Static method in class net.esper.util.JavaClassHelper
Returns for 2 classes to be compared via relational operator the Class type of common comparison.
getComputeDescription() - Method in enum net.esper.type.BitWiseOpEnum
Returns string rendering of enum.
getComputer(Class) - Method in enum net.esper.type.BitWiseOpEnum
Returns number or boolean computation for the target coercion type.
getComputer(Class) - Method in enum net.esper.type.MathArithTypeEnum
Returns number cruncher for the target coercion type.
getComputer(Class) - Method in enum net.esper.type.RelationalOpEnum
Returns the computer to use for the relational operation based on the coercion type.
getConfigProperties() - Method in class net.esper.client.ConfigurationAdapterLoader
Returns loader configuration properties.
getConfiguration() - Method in interface net.esper.client.EPAdministrator
Returns configuration operations for runtime engine configuration.
getConfiguration() - Method in class net.esper.core.EPAdministratorImpl
 
getConfigurationEventTypeXMLDOM() - Method in class net.esper.event.xml.BaseXMLEventType
Returns the configuration XML for the XML type.
getConfigurationInputStream(String) - Static method in class net.esper.client.Configuration
Get the configuration file as an InputStream.
getConfigurationMethodRef(String) - Method in interface net.esper.eql.core.EngineImportService
Returns the method invocation caches for the from-clause for a class.
getConfigurationMethodRef(String) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
getConnection() - Method in class net.esper.eql.db.ConnectionCache
Returns a cached or new connection and statement pair.
getConnection() - Method in class net.esper.eql.db.ConnectionCacheImpl
 
getConnection() - Method in class net.esper.eql.db.ConnectionNoCacheImpl
 
getConnection() - Method in interface net.esper.eql.db.DatabaseConnectionFactory
Creates a new database connection.
getConnection() - Method in class net.esper.eql.db.DatabaseDMConnFactory
 
getConnection() - Method in class net.esper.eql.db.DatabaseDSConnFactory
 
getConnectionCache(String, String) - Method in interface net.esper.eql.db.DatabaseConfigService
Returns true to indicate a setting to retain connections between lookups.
getConnectionCache(String, String) - Method in class net.esper.eql.db.DatabaseConfigServiceImpl
 
getConnectionFactory(String) - Method in interface net.esper.eql.db.DatabaseConfigService
Returns a connection factory for a configured database.
getConnectionFactory(String) - Method in class net.esper.eql.db.DatabaseConfigServiceImpl
 
getConnectionFactoryDesc() - Method in class net.esper.client.ConfigurationDBRef
Returns the descriptor controlling connection creation settings.
getConnectionLifecycleEnum() - Method in class net.esper.client.ConfigurationDBRef
Returns the setting to control whether a new connection is obtained for each lookup, or connections are retained between lookups.
getConnectionSettings() - Method in class net.esper.client.ConfigurationDBRef
Returns the connection settings for this database.
getConstant() - Method in class net.esper.client.soda.ConstantExpression
Returns the constant value that the expression represents.
getConstant() - Method in class net.esper.eql.spec.SubstitutionParameterExpression
Returns the constant value that the expression represents.
getConstant() - Method in class net.esper.filter.InSetOfValuesConstant
Returns the constant value.
getConstantIndexNumber() - Method in class net.esper.eql.expression.ExprPriorNode
Returns the index of the prior.
getContext() - Method in interface net.esper.client.EPServiceProvider
Provides naming context for public named objects.
getContext() - Method in class net.esper.core.EPServiceProviderImpl
 
getContext() - Method in interface net.esper.core.EPServiceProviderSPI
Returns the engine environment context for engine-external resources such as adapters.
getContextLookupName() - Method in class net.esper.client.ConfigurationDBRef.DataSourceConnection
Returns the object name to look up in context.
getCorrelation() - Method in class net.esper.view.stat.CorrelationBean
Return the correlation value for the two data series (Microsoft Excel function CORREL).
getCreateVariable() - Method in class net.esper.client.soda.EPStatementObjectModel
Returns the create-variable clause if this is a statement creating a variable, or null if not.
getCreateVariableDesc() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the create-variable statement descriptor.
getCreateVariableDesc() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the descriptor for create-variable statements.
getCreateWindow() - Method in class net.esper.client.soda.EPStatementObjectModel
Returns the create-window clause for creating named windows, or null if this statement does not create a named window.
getCreateWindowDesc() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the specification for an create-window statement.
getCreateWindowDesc() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the create-window specification.
getCurrentAndPriorValue() - Method in class net.esper.eql.variable.VersionedValueList
Returns the current and prior version.
getCurrentThread() - Method in class net.esper.eql.variable.VariableVersionThreadLocal
Returns the version and uncommitted values for the current thread.
getCurrentVersion() - Method in class net.esper.eql.variable.CurrentValue
Returns the current version.
getCursors(int) - Method in interface net.esper.eql.join.rep.Repository
Supply events for performing look ups for a given stream.
getCursors(int) - Method in class net.esper.eql.join.rep.RepositoryImpl
 
getDatabaseName() - Method in class net.esper.client.soda.SQLStream
Returns the database name.
getDatabaseName() - Method in class net.esper.eql.spec.DBStatementStreamSpec
Returns the database name.
getDatabaseReferences() - Method in class net.esper.client.Configuration
 
getDatabaseReferences() - Method in interface net.esper.client.ConfigurationInformation
Returns a map of string database names to database configuration options.
getDatabaseRefService() - Method in class net.esper.core.EPServicesContext
Returns the database settings service.
getDataCache(String, EPStatementHandle) - Method in interface net.esper.eql.db.DatabaseConfigService
Returns a new cache implementation for this database.
getDataCache(String, EPStatementHandle) - Method in class net.esper.eql.db.DatabaseConfigServiceImpl
 
getDataCache(ConfigurationDBRef.DataCacheDesc, EPStatementHandle, SchedulingService, ScheduleBucket) - Static method in class net.esper.eql.db.DataCacheFactory
Creates a cache implementation for the strategy as defined by the cache descriptor.
getDataCacheDesc() - Method in class net.esper.client.ConfigurationDBRef
Return a query result data cache descriptor.
getDataCacheDesc() - Method in class net.esper.client.ConfigurationMethodRef
Return a method invocation result data cache descriptor.
getDecoratingProperties() - Method in interface net.esper.event.DecoratingEventBean
Returns decorating properties.
getDecoratingProperties() - Method in class net.esper.event.WrapperEventBean
 
getDeepSuperTypes() - Method in class net.esper.event.BeanEventType
 
getDeepSuperTypes() - Method in class net.esper.event.CompositeEventType
 
getDeepSuperTypes() - Method in interface net.esper.event.EventType
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.
getDeepSuperTypes() - Method in class net.esper.event.MapEventType
 
getDeepSuperTypes() - Method in class net.esper.event.WrapperEventType
 
getDeepSuperTypes() - Method in class net.esper.event.xml.BaseXMLEventType
 
getDefault() - Static method in enum net.esper.client.Configuration.PropertyResolutionStyle
Returns the default property resolution style.
getDefault() - Static method in enum net.esper.client.ConfigurationDBRef.CacheReferenceType
The default policy is set to WEAK to reduce the chance that out-of-memory errors occur as caches fill, and stay backwards compatible with prior Esper releases.
getDefaultNamespace() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns the default namespace.
getDefaultPropertyResolutionStyle() - Method in class net.esper.event.BeanEventAdapter
Gets the default property resolution style for Java class properties.
getDefaultPropertyResolutionStyle() - Method in interface net.esper.event.BeanEventTypeFactory
Returns the default property resolution style.
getDefaultProvider() - Static method in class net.esper.client.EPServiceProviderManager
Returns the default EPServiceProvider.
getDefaultProvider(Configuration) - Static method in class net.esper.client.EPServiceProviderManager
Returns the default EPServiceProvider.
getDeltaData() - Method in class net.esper.eql.named.NamedWindowConsumerDispatchUnit
Returns the data to dispatch.
getDepth() - Method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder.BestChainResult
Returns depth of lookups via index in chain.
getDerivedMeasures() - Method in class net.esper.view.stat.MultiDimStatsView
Returns the names of measures to derive from facts.
getDescendentNodesBottomUp(BaseAssemblyNode) - Static method in class net.esper.eql.join.assemble.BaseAssemblyNode
Returns all descendent nodes to the top node in a list in which the utmost descendants are listed first and the top node itself is listed last.
getDescriptor() - Method in class net.esper.event.BeanEventType.SimplePropertyInfo
Returns the property info.
getDimension() - Method in interface net.esper.view.stat.olap.DimensionMember
Returns the dimension the member belongs to.
getDimension() - Method in class net.esper.view.stat.olap.DimensionMemberImpl
 
getDimensionNames() - Method in interface net.esper.view.stat.olap.MultidimCube
Returns array containing name of each dimension including the name of the cell.
getDimensionNames() - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
getDimensions() - Method in interface net.esper.view.stat.olap.Cube
Returns dimensions.
getDimensions() - Method in class net.esper.view.stat.olap.CubeImpl
 
getDimensionSizes(Dimension[]) - Static method in class net.esper.view.stat.olap.CubeDimensionHelper
Compile an array of dimension sizes.
getDispatchService() - Method in class net.esper.core.EPServicesContext
Returns dispatch service responsible for dispatching events to listeners.
getDispatchTo() - Method in class net.esper.eql.named.NamedWindowConsumerDispatchUnit
Returns the destination of the dispatch: a map of statements and their consuming views (one or multiple)
getDisplayLimit() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the type of output limit.
getDouble() - Method in class net.esper.type.DoubleValue
Return the value as an unboxed.
getDoubleValue() - Method in class net.esper.filter.RangeValueDouble
Returns the constant value.
getEmitService() - Method in class net.esper.core.EPServicesContext
Returns service for emitting events.
getEngineDefaults() - Method in class net.esper.client.Configuration
 
getEngineDefaults() - Method in interface net.esper.client.ConfigurationInformation
Returns engine default settings.
getEngineEnvContext() - Method in class net.esper.core.EPServicesContext
Returns the engine environment context for getting access to engine-external resources, such as adapters
getEngineImportService() - Method in class net.esper.core.EPServicesContext
Returns the import and class name resolution service.
getEngineImportService() - Method in class net.esper.eql.spec.StatementSpecMapContext
Returns the engine import service.
getEngineInstanceId() - Method in class net.esper.core.EPServicesContext
Returns the engine instance ID.
getEngineInstanceId() - Method in class net.esper.core.StatementContext
Returns the engine instance id.
getEngineInstanceId() - Method in class net.esper.pattern.PatternContext
Returns the engine instance id.
getEngineSettings() - Method in class net.esper.eql.core.EngineSettingsService
Returns the settings.
getEngineSettingsService() - Method in class net.esper.core.EPServicesContext
Returns engine settings.
getEngineURI() - Method in class net.esper.core.EPServicesContext
Returns the engine URI.
getEngineURI() - Method in class net.esper.core.StatementContext
Returns the engine URI.
getEngineURI() - Method in class net.esper.pattern.PatternContext
Returns the engine URI.
getEntry(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the entry mapped to the key specified.
getEntry(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Gets the entry mapped to the key specified.
getEnum(String) - Static method in enum net.esper.util.DatabaseTypeEnum
Given a type name, matches for simple and fully-qualified Java class name (case-insensitive) as well as case-insensitive type name.
getEnvironment() - Method in class net.esper.core.EngineEnvContext
 
getEnvProperties() - Method in class net.esper.client.ConfigurationDBRef.DataSourceConnection
Returns the environment properties to use to establish the initial context.
getEPAdministrator() - Method in interface net.esper.client.EPServiceProvider
Returns a class instance of EPAdministrator.
getEPAdministrator() - Method in class net.esper.core.EPServiceProviderImpl
 
getEPRuntime() - Method in interface net.esper.client.EPServiceProvider
Returns a class instance of EPRuntime.
getEPRuntime() - Method in class net.esper.core.EPServiceProviderImpl
 
getEPServicesContextFactoryClassName() - Method in class net.esper.client.Configuration
 
getEPServicesContextFactoryClassName() - Method in interface net.esper.client.ConfigurationInformation
Returns the service context factory class name
getEpStatement() - Method in class net.esper.core.EPStatementDesc
Returns the statement.
getEpStatement() - Method in class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Returns the statement.
getEpStatementHandle() - Method in class net.esper.core.EPStatementHandleCallback
Returns the statement handle.
getEpStatementHandle() - Method in class net.esper.core.StatementContext
Returns the statement's resource locks.
getEpStatementHandle() - Method in class net.esper.pattern.PatternContext
Returns the statement's resource handle for locking.
getEpStatementHandle() - Method in class net.esper.view.ViewFactoryContext
Returns the statement's resource locks.
getEvalNode() - Method in class net.esper.eql.spec.PatternStreamSpecCompiled
Returns the pattern expression evaluation node for the top pattern operator.
getEvalNode() - Method in class net.esper.eql.spec.PatternStreamSpecRaw
Returns the pattern expression evaluation node for the top pattern operator.
getEvent() - Method in class net.esper.eql.join.rep.Cursor
Supplies current event.
getEventAdapterService() - Method in class net.esper.core.EPServiceProviderImpl
 
getEventAdapterService() - Method in interface net.esper.core.EPServiceProviderSPI
Get the EventAdapterService for this engine.
getEventAdapterService() - Method in class net.esper.core.EPServicesContext
Returns event type resolution service.
getEventAdapterService() - Method in class net.esper.core.StatementContext
Returns service for generating events and handling event types.
getEventAdapterService() - Method in class net.esper.pattern.PatternContext
Returns teh service providing event adaptering or wrapping.
getEventAdapterService() - Method in class net.esper.view.ViewFactoryContext
Returns service for generating events and handling event types.
getEventAsName() - Method in class net.esper.pattern.EvalFilterNode
Returns the tag for any matching events to this filter, or null since tags are optional.
getEventBean(String) - Method in class net.esper.event.CompositeEventBean
 
getEventBean(String) - Method in interface net.esper.event.TaggedCompositeEventBean
Returns the event for the tag.
getEventIndex() - Method in class net.esper.eql.join.exec.FullTableScanLookupStrategy
Returns the associated table.
getEventIndex() - Method in class net.esper.eql.lookup.FullTableScanLookupStrategy
Returns the associated table.
getEventMeta() - Method in class net.esper.client.ConfigurationEngineDefaults
Returns event representation default settings.
getEventProcessingRWLock() - Method in class net.esper.core.EPServicesContext
Returns the event processing lock for coordinating statement administration with event processing.
getEventRate() - Method in class net.esper.eql.view.OutputConditionCount
Returns the event rate.
getEvents() - Method in class net.esper.eql.join.rep.Node
Returns the results of the lookup.
getEventSet() - Method in class net.esper.eql.join.table.UnindexedEventTable
Returns events in table.
getEventType() - Method in interface net.esper.client.EPIterable
Returns the type of events the iterable returns.
getEventType() - Method in class net.esper.core.EPStatementImpl
 
getEventType() - Method in class net.esper.core.UpdateDispatchViewBase
 
getEventType() - Method in class net.esper.eql.core.MethodPollingViewable
 
getEventType() - Method in class net.esper.eql.db.DatabasePollingViewable
 
getEventType() - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
Returns event type of the lookup event.
getEventType() - Method in class net.esper.eql.named.NamedWindowConsumerView
 
getEventType() - Method in class net.esper.eql.named.NamedWindowOnDeleteView
 
getEventType() - Method in class net.esper.eql.named.NamedWindowOnSelectView
 
getEventType() - Method in class net.esper.eql.named.NamedWindowRootView
 
getEventType() - Method in class net.esper.eql.named.NamedWindowTailView
 
getEventType() - Method in class net.esper.eql.variable.CreateVariableView
 
getEventType() - Method in class net.esper.eql.variable.OnSetVariableView
 
getEventType() - Method in class net.esper.eql.view.FilterExprView
 
getEventType() - Method in class net.esper.eql.view.InternalRouteView
 
getEventType() - Method in class net.esper.eql.view.IStreamRStreamSelectorView
 
getEventType() - Method in class net.esper.eql.view.OutputProcessView
 
getEventType() - Method in class net.esper.event.BeanEventBean
 
getEventType() - Method in class net.esper.event.CompositeEventBean
 
getEventType() - Method in interface net.esper.event.EventBean
Return the EventType instance that describes the set of properties available for this event.
getEventType() - Method in class net.esper.event.MapEventBean
 
getEventType() - Method in class net.esper.event.WrapperEventBean
 
getEventType() - Method in class net.esper.event.xml.XMLEventBean
 
getEventType() - Method in class net.esper.filter.FilterSpecCompiled
Returns type of event to filter for.
getEventType() - Method in interface net.esper.filter.FilterValueSet
Returns type of event to filter for.
getEventType() - Method in class net.esper.filter.FilterValueSetImpl
Returns event type to filter for.
getEventType() - Method in interface net.esper.view.EventCollection
Provides metadata information about the type of object the event collection contains.
getEventType() - Method in class net.esper.view.ext.SortWindowView
 
getEventType() - Method in class net.esper.view.ext.SortWindowViewFactory
 
getEventType() - Method in class net.esper.view.ext.TimeOrderView
 
getEventType() - Method in class net.esper.view.ext.TimeOrderViewFactory
 
getEventType() - Method in class net.esper.view.internal.BufferView
 
getEventType() - Method in class net.esper.view.internal.PriorEventView
 
getEventType() - Method in class net.esper.view.internal.PriorEventViewFactory
 
getEventType() - Method in class net.esper.view.stat.CorrelationView
 
getEventType() - Method in class net.esper.view.stat.CorrelationViewFactory
 
getEventType() - Method in class net.esper.view.stat.MultiDimStatsView
 
getEventType() - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
getEventType() - Method in class net.esper.view.stat.RegressionLinestView
 
getEventType() - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
getEventType() - Method in class net.esper.view.stat.UnivariateStatisticsView
 
getEventType() - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
getEventType() - Method in class net.esper.view.stat.WeightedAverageView
 
getEventType() - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
getEventType() - Method in class net.esper.view.std.AddPropertyValueView
 
getEventType() - Method in class net.esper.view.std.GroupByView
 
getEventType() - Method in class net.esper.view.std.GroupByViewFactory
 
getEventType() - Method in class net.esper.view.std.LastElementView
 
getEventType() - Method in class net.esper.view.std.LastElementViewFactory
 
getEventType() - Method in class net.esper.view.std.MergeView
 
getEventType() - Method in class net.esper.view.std.MergeViewFactory
 
getEventType() - Method in class net.esper.view.std.SizeView
 
getEventType() - Method in class net.esper.view.std.SizeViewFactory
 
getEventType() - Method in class net.esper.view.std.UniqueByPropertyView
 
getEventType() - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
getEventType() - Method in interface net.esper.view.ViewFactory
Returns the event type that the view that is created by the view factory would create for events posted by the view.
getEventType() - Method in class net.esper.view.ViewFactoryChain
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.
getEventType() - Method in class net.esper.view.window.ExternallyTimedWindowView
 
getEventType() - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
getEventType() - Method in class net.esper.view.window.KeepAllView
 
getEventType() - Method in class net.esper.view.window.KeepAllViewFactory
 
getEventType() - Method in class net.esper.view.window.LengthBatchView
 
getEventType() - Method in class net.esper.view.window.LengthBatchViewFactory
 
getEventType() - Method in class net.esper.view.window.LengthBatchViewRStream
 
getEventType() - Method in class net.esper.view.window.LengthWindowView
 
getEventType() - Method in class net.esper.view.window.LengthWindowViewFactory
 
getEventType() - Method in class net.esper.view.window.LengthWindowViewRStream
 
getEventType() - Method in class net.esper.view.window.TimeAccumView
 
getEventType() - Method in class net.esper.view.window.TimeAccumViewFactory
 
getEventType() - Method in class net.esper.view.window.TimeAccumViewRStream
 
getEventType() - Method in class net.esper.view.window.TimeBatchView
 
getEventType() - Method in class net.esper.view.window.TimeBatchViewFactory
 
getEventType() - Method in class net.esper.view.window.TimeBatchViewRStream
 
getEventType() - Method in class net.esper.view.window.TimeLengthBatchView
 
getEventType() - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
getEventType() - Method in class net.esper.view.window.TimeWindowView
 
getEventType() - Method in class net.esper.view.window.TimeWindowViewFactory
 
getEventType() - Method in class net.esper.view.ZeroDepthStream
 
getEventTypeAlias() - Method in class net.esper.client.soda.Filter
Returns the name of the event type to filter for.
getEventTypeAlias() - Method in class net.esper.eql.spec.FilterSpecRaw
Returns the event type alias of the events we are looking for.
getEventTypeAlias() - Method in class net.esper.eql.spec.InsertIntoDesc
Returns name of event type to use for insert-into stream.
getEventTypeAliases() - Method in class net.esper.client.Configuration
 
getEventTypeAliases() - Method in interface net.esper.client.ConfigurationInformation
Returns the mapping of event type alias to Java class name.
getEventTypeAutoAliasPackages() - Method in class net.esper.client.Configuration
Returns a set of Java package names that Java event classes reside in.
getEventTypes() - Method in interface net.esper.eql.core.StreamTypeService
Returns an array of event types for each event stream in the order declared.
getEventTypes() - Method in class net.esper.eql.core.StreamTypeServiceImpl
 
getEventTypesLegacy() - Method in class net.esper.client.Configuration
 
getEventTypesLegacy() - Method in interface net.esper.client.ConfigurationInformation
Returns the mapping of event type alias to legacy java event type information.
getEventTypesMapEvents() - Method in class net.esper.client.Configuration
 
getEventTypesMapEvents() - Method in interface net.esper.client.ConfigurationInformation
Returns a map keyed by event type alias name, and values being the definition for the event type of the property names and types that make up the event.
getEventTypesXMLDOM() - Method in class net.esper.client.Configuration
 
getEventTypesXMLDOM() - Method in interface net.esper.client.ConfigurationInformation
Returns the mapping of event type alias to XML DOM event type information.
getExecNode() - Method in class net.esper.eql.join.ExecNodeQueryStrategy
Returns execution node.
getExecNodeSpecs() - Method in class net.esper.eql.join.plan.QueryPlan
Return execution node specs.
getExistsTypeByAlias(String) - Method in interface net.esper.event.EventAdapterService
Return the event type for a given event name, or null if none is registered for that name.
getExistsTypeByAlias(String) - Method in class net.esper.event.EventAdapterServiceImpl
 
getExplicitProperties(List<EventPropertyDescriptor>, Class, ConfigurationEventTypeLegacy) - Static method in class net.esper.event.property.PropertyListBuilderExplicit
Populates explicitly-defined properties into the result list.
getExpression() - Method in exception net.esper.client.EPStatementException
Returns expression text for statement.
getExpression() - Method in class net.esper.client.soda.OrderByElement
Returns the order-by value expression.
getExpression() - Method in class net.esper.client.soda.PatternStream
Returns the pattern expression providing events to the stream.
getExpression() - Method in class net.esper.client.soda.SelectClauseElement
Returns the selection expression.
getExpression() - Method in class net.esper.core.StatementContext
Returns the statement expression text
getExpression() - Method in class net.esper.eql.spec.OnTriggerSetAssignment
Returns the expression providing the new variable value, or null if none
getExpressions() - Method in class net.esper.eql.spec.MethodStreamSpec
Returns the parameter expressions.
getExpressionText() - Method in enum net.esper.type.BitWiseOpEnum
Returns the operator as an expression text.
getExpressionText() - Method in enum net.esper.type.MathArithTypeEnum
Returns string representation of enum.
getExpressionText() - Method in enum net.esper.type.MinMaxTypeEnum
Returns textual representation of enum.
getExpressionText() - Method in enum net.esper.type.RelationalOpEnum
Returns string rendering of enum.
getExprNode() - Method in class net.esper.eql.spec.OrderByItem
Returns the order-by expression node.
getExprNode() - Method in class net.esper.filter.FilterSpecParamExprNode
Returns the expression node of the boolean expression this filter parameter represents.
getExprProperties() - Method in class net.esper.eql.expression.ExprNodeIdentifierVisitor
Returns list of event property stream numbers and names that uniquely identify which property is from whcih stream, and the name of each.
getExtensionServicesContext() - Method in class net.esper.core.EPServiceProviderImpl
 
getExtensionServicesContext() - Method in interface net.esper.core.EPServiceProviderSPI
Returns the extension services context.
getExtensionServicesContext() - Method in class net.esper.core.EPServicesContext
Returns extension service for adding custom the services.
getExtensionServicesContext() - Method in class net.esper.core.StatementContext
Returns extension context for statements.
getExtensionServicesContext() - Method in class net.esper.pattern.PatternContext
Returns extension services context for statement (statement-specific).
getExtensionServicesContext() - Method in class net.esper.view.ViewFactoryContext
Returns extension svc.
getFactCube() - Method in class net.esper.view.stat.MultiDimStatsView
For unit testing, returns fact cube.
getFactors(int) - Static method in class net.esper.collection.PermutationEnumeration
Returns factors for computing the permutation.
getFactoryClass() - Method in enum net.esper.view.ViewEnum
Returns a view's factory class.
getFactoryClassName() - Method in class net.esper.client.ConfigurationPlugInPatternObject
Returns the view factory class name.
getFactoryClassName() - Method in class net.esper.client.ConfigurationPlugInView
Returns the view factory class name.
getFactoryNode() - Method in class net.esper.pattern.EvalStateNode
Returns the factory node for the state node.
getFastClass() - Method in class net.esper.event.BeanEventType
Returns the fast class reference, if code generation is used for this type, else null.
getFieldName() - Method in class net.esper.view.stat.UnivariateStatisticsView
Returns field name of the field to report statistics on.
getFieldNameParams(List<Object>, String) - Static method in class net.esper.view.std.GroupByViewFactory
Parses the given view parameters into a list of field names to group-by.
getFieldNameWeight() - Method in class net.esper.view.stat.WeightedAverageView
Returns the name of the field supplying the weight values.
getFieldNameX() - Method in class net.esper.view.stat.BaseBivariateStatisticsView
Returns the field name of the field supplying X data points.
getFieldNameX() - Method in class net.esper.view.stat.WeightedAverageView
Returns the name of the field supplying the X values.
getFieldNameY() - Method in class net.esper.view.stat.BaseBivariateStatisticsView
Returns the field name of the field supplying Y data points.
getFieldProperties() - Method in class net.esper.client.ConfigurationEventTypeLegacy
Returns a list of descriptors specifying explicitly configured field names and their property name.
getFilter() - Method in class net.esper.client.soda.Filter
Returns the optional filter expression that tests the event, or null if no filter expression was defined.
getFilter() - Method in class net.esper.client.soda.FilterStream
Returns the filter.
getFilter() - Method in class net.esper.client.soda.PatternFilterExpr
Returns the filter specification.
getFilterCallback() - Method in class net.esper.core.EPStatementHandleCallback
Returns the statement filter callback, or null if this is a schedule callback handle.
getFilterCallbackCount() - Method in class net.esper.filter.FilterHandleSetNode
Returns the number of filter callbacks stored.
getFilterConstant() - Method in class net.esper.filter.FilterSpecParamConstant
Returns the constant value.
getFilterExpressions() - Method in class net.esper.eql.spec.FilterSpecRaw
Returns the list of filter expressions.
getFilterExpressions() - Method in class net.esper.eql.spec.NamedWindowConsumerStreamSpec
Returns list of filter expressions onto the named window, or no filter expressions if none defined.
getFilterExprRootNode() - Method in class net.esper.eql.spec.StatementSpecRaw
Gets the where clause.
getFilterForValue() - Method in interface net.esper.filter.FilterValueSetParam
Return the filter parameter constant to filter for.
getFilterForValue() - Method in class net.esper.filter.FilterValueSetParamImpl
 
getFilterNodes() - Method in class net.esper.pattern.EvalNodeAnalysisResult
Returns filter nodes.
getFilterOperator() - Method in class net.esper.filter.FilterParamIndexBase
Returns the filter operator that the index matches for.
getFilterOperator() - Method in class net.esper.filter.FilterSpecParam
Returns the filter operator type.
getFilterOperator() - Method in interface net.esper.filter.FilterValueSetParam
Returns the filter operator type.
getFilterOperator() - Method in class net.esper.filter.FilterValueSetParamImpl
 
getFilterParams() - Method in class net.esper.filter.FilterParamExprMap
Returns all filter parameters.
getFilterRootNode() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the WHERE-clause root node of filter expression.
getFilterRootNode() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the WHERE-clause root node of filter expression.
getFilterService() - Method in class net.esper.core.EPServiceProviderImpl
 
getFilterService() - Method in interface net.esper.core.EPServiceProviderSPI
Returns the filter service.
getFilterService() - Method in class net.esper.core.EPServicesContext
Returns filter evaluation service implementation.
getFilterService() - Method in class net.esper.core.StatementContext
Returns the filter service.
getFilterService() - Method in class net.esper.pattern.PatternContext
Returns service to use for filter evaluation.
getFilterSpec() - Method in class net.esper.eql.spec.FilterStreamSpecCompiled
Returns filter specification for which events the stream will getSelectListEvents.
getFilterSpec() - Method in class net.esper.pattern.EvalFilterNode
Returns filter specification.
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.FilterSpecParam
Return the filter parameter constant to filter for.
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.FilterSpecParamConstant
 
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.FilterSpecParamEventProp
 
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.FilterSpecParamExprNode
 
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.FilterSpecParamIn
 
getFilterValue(MatchedEventMap) - Method in interface net.esper.filter.FilterSpecParamInValue
Returns the actual value to filter for from prior matching events
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.FilterSpecParamRange
 
getFilterValue(MatchedEventMap) - Method in interface net.esper.filter.FilterSpecParamRangeValue
Returns the filter value representing the endpoint.
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.InSetOfValuesConstant
 
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.InSetOfValuesEventProp
 
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.RangeValueDouble
 
getFilterValue(MatchedEventMap) - Method in class net.esper.filter.RangeValueEventProp
 
getFirst() - Method in class net.esper.collection.InterchangeablePair
Returns first value within pair.
getFirst() - Method in class net.esper.collection.Pair
Returns first value within pair.
getFirst() - Method in class net.esper.collection.UniformPair
Returns first value within pair.
getForStream() - Method in class net.esper.eql.join.ExecNodeQueryStrategy
Return stream number this strategy is for.
getFrequency() - Method in class net.esper.client.soda.OutputLimitClause
Returns output frequency.
getFrequency() - Method in class net.esper.type.FrequencyParameter
Returns frequency.
getFrequencyVariable() - Method in class net.esper.client.soda.OutputLimitClause
Returns the variable name of the variable providing output rate frequency values, or null if the frequency is a fixed value.
getFromClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the from-clause.
getFromStream() - Method in class net.esper.eql.join.exec.LookupInstructionExec
Returns the stream number of the stream supplying the event to use for lookup.
getFunctionClassName() - Method in class net.esper.client.ConfigurationPlugInAggregationFunction
Returns the aggregation function name.
getFunctionName() - Method in class net.esper.client.soda.PlugInProjectionExpression
Returns the function name.
getFunctionName() - Method in class net.esper.eql.agg.AggregationSupport
Returns the name of the aggregation function.
getGetter(String) - Method in class net.esper.event.BaseConfigurableEventType
 
getGetter(String) - Method in class net.esper.event.BeanEventType
 
getGetter() - Method in class net.esper.event.BeanEventType.SimplePropertyInfo
Returns the getter.
getGetter(String) - Method in class net.esper.event.CompositeEventType
 
getGetter(String) - Method in interface net.esper.event.EventType
Get the getter for a specified event property.
getGetter(String) - Method in class net.esper.event.MapEventType
 
getGetter(BeanEventType) - Method in class net.esper.event.property.DynamicIndexedProperty
 
getGetter(BeanEventType) - Method in class net.esper.event.property.DynamicMappedProperty
 
getGetter(BeanEventType) - Method in class net.esper.event.property.DynamicSimpleProperty
 
getGetter(BeanEventType) - Method in class net.esper.event.property.IndexedProperty
 
getGetter(BeanEventType) - Method in class net.esper.event.property.MappedProperty
 
getGetter(BeanEventType) - Method in class net.esper.event.property.NestedProperty
 
getGetter(BeanEventType) - Method in interface net.esper.event.property.Property
Returns value getter for the property of an event of the given event type.
getGetter(Method, FastClass) - Static method in class net.esper.event.property.PropertyHelper
Return getter for the given method and CGLIB FastClass.
getGetter(BeanEventType) - Method in class net.esper.event.property.SimpleProperty
 
getGetter(String) - Method in class net.esper.event.WrapperEventType
 
getGetter() - Method in class net.esper.filter.FilterParamIndexPropBase
Returns getter for property.
getGetterMap() - Method in class net.esper.event.property.DynamicIndexedProperty
 
getGetterMap() - Method in class net.esper.event.property.DynamicMappedProperty
 
getGetterMap() - Method in class net.esper.event.property.DynamicSimpleProperty
 
getGetterMap() - Method in class net.esper.event.property.IndexedProperty
 
getGetterMap() - Method in class net.esper.event.property.MappedProperty
 
getGetterMap() - Method in class net.esper.event.property.NestedProperty
 
getGetterMap() - Method in interface net.esper.event.property.Property
Returns the getter-method for use with Map event representations.
getGetterMap() - Method in class net.esper.event.property.SimpleProperty
 
getGroupByClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the group-by-clause, or null to indicate that the clause is absent.
getGroupByExpressions() - Method in class net.esper.client.soda.GroupByClause
Returns the expressions providing the grouped-by values.
getGroupByExpressions() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns list of group-by expressions.
getGroupByExpressions() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns list of group-by expressions.
getGroupFieldNames() - Method in class net.esper.view.std.GroupByView
Returns the field name that provides the key valie by which to group by.
getGroupFieldNames() - Method in class net.esper.view.std.GroupByViewFactory
Returns the names of fields to group by
getGroupFieldNames() - Method in class net.esper.view.std.MergeView
Returns the field name that contains the values to group by.
getGuardFactory() - Method in class net.esper.pattern.EvalGuardNode
Returns the guard factory.
getGuardNodes() - Method in class net.esper.pattern.EvalNodeAnalysisResult
Returns guard nodes.
getHasState(String, int, Class, StatementExtensionSvcContext) - Method in interface net.esper.eql.variable.VariableStateHandler
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
getHavingClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the having-clause, or null to indicate that the clause is absent.
getHavingExprRootNode() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns expression root node representing the having-clause, if present, or null if no having clause was supplied.
getHavingExprRootNode() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns expression root node representing the having-clause, if present, or null if no having clause was supplied.
getHigh() - Method in class net.esper.type.RangeParameter
Returns end of range.
getIdent() - Method in class net.esper.eql.spec.MethodStreamSpec
Returns the prefix (method) for the method invocation syntax.
getImports() - Method in class net.esper.client.Configuration
 
getImports() - Method in interface net.esper.client.ConfigurationInformation
Returns the class and package imports.
getImports() - Method in class net.esper.eql.core.EngineImportServiceImpl
For testing, returns imports.
getIndex() - Method in class net.esper.eql.expression.ExprSubstitutionNode
Returns the substitution parameter index.
getIndex() - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
Returns index to look up in.
getIndex() - Method in class net.esper.eql.lookup.IndexedTableLookupStrategy
Returns index to look up in.
getIndex() - Method in class net.esper.eql.spec.SubstitutionParameterExpression
Returns the index of the parameter.
getIndex() - Method in class net.esper.event.property.IndexedProperty
Returns index for indexed access.
getIndexConstant() - Method in class net.esper.view.ViewCapPriorEventAccess
Index or the prior event we are asking for.
getIndexedParams() - Method in class net.esper.eql.spec.StatementSpecUnMapContext
Returns all indexed parameters.
getIndexedParams() - Method in class net.esper.eql.spec.StatementSpecUnMapResult
Returns the substitution paremeters keyed by the parameter's index.
getIndexedProperty(String) - Method in class net.esper.event.BeanEventType
Looks up and returns a cached indexed property's descriptor.
getIndexedStream() - Method in class net.esper.eql.join.exec.TableLookupExecNode
Returns target stream for lookup.
getIndexedStream() - Method in class net.esper.eql.join.exec.TableOuterLookupExecNode
Returns target stream for lookup.
getIndexedStream() - Method in class net.esper.eql.join.plan.TableLookupPlan
Returns indexed stream.
getIndexNum(String[]) - Method in class net.esper.eql.join.plan.QueryPlanIndex
Find a matching index for the property names supplied.
getIndexNum() - Method in class net.esper.eql.join.plan.TableLookupPlan
Returns index number to use for looking up in.
getIndexProperties(int, int) - Method in class net.esper.eql.join.plan.QueryGraph
Returns index properties.
getIndexProperties(JoinedPropDesc[]) - Static method in class net.esper.eql.lookup.JoinedPropDesc
Returns the index property names given an array of descriptors.
getIndexPropName() - Method in class net.esper.eql.lookup.JoinedPropDesc
Returns the property name of the indexed field.
getIndexProps() - Method in class net.esper.eql.join.plan.QueryPlanIndex
Returns property names of all indexes.
getIndexSpecs() - Method in class net.esper.eql.join.plan.QueryPlan
Return index specs.
getIndizes() - Method in class net.esper.filter.FilterHandleSetNode
Returns list of indexes - not returning an iterator.
getInitializationValue() - Method in class net.esper.client.ConfigurationVariable
Returns the initialization value, or null if none was supplied.
getInitialReferencePoint() - Method in class net.esper.view.window.TimeBatchView
Gets the reference point to use to anchor interval start and end dates to.
getInitialReferencePoint() - Method in class net.esper.view.window.TimeBatchViewRStream
Gets the reference point to use to anchor interval start and end dates to.
getInner(int) - Method in class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Returns the set of inner streams for the given outer stream number.
getInputParameters() - Method in class net.esper.eql.db.QueryMetaData
Return the input parameters.
getInputStream() - Method in class net.esper.util.SimpleByteArrayOutputStream
Return the input stream for the output buffer.
getInsertInto() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the insert-into-clause, or null to indicate that the clause is absent.
getInsertIntoDesc() - Method in class net.esper.eql.spec.StatementSpecCompiled
Return a descriptor with the insert-into event name and optional list of columns.
getInsertIntoDesc() - Method in class net.esper.eql.spec.StatementSpecRaw
Return a descriptor with the insert-into event name and optional list of columns.
getInsertIntoDispatchLocking() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns the blocking strategy to use when multiple threads deliver results for a single statement to consuming statements of an insert-into, and the guarantee of order of delivery must be maintained.
getInsertIntoDispatchTimeout() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns the number of milliseconds that a thread may maximually be blocking to deliver statement results from a producing statement that employs insert-into to a consuming statement.
getInsertIntoLatchFactory() - Method in class net.esper.core.EPStatementHandle
Returns the factory for latches in insert-into guaranteed order of delivery.
getInternalEventRouter() - Method in class net.esper.core.EPServicesContext
Returns router for internal event processing.
getInternalTimerMsecResolution() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns the millisecond resolutuion of the internal timer thread.
getIntervalSize() - Method in class net.esper.view.ext.TimeOrderView
Returns the time interval size.
getIntValue() - Method in class net.esper.type.IntParameter
Returns int value.
getIsDescendingValues() - Method in class net.esper.view.ext.SortWindowView
Returns the flags indicating whether to sort in descending order on each property.
getIterator(Viewable) - Method in interface net.esper.eql.core.ResultSetProcessor
Returns the iterator implementing the group-by and aggregation and order-by logic specific to each case of use of these construct.
getIterator(Set<MultiKey<EventBean>>) - Method in interface net.esper.eql.core.ResultSetProcessor
Returns the iterator for iterating over a join-result.
getIterator(Viewable) - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
 
getIterator(Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
 
getIterator(Viewable) - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
 
getIterator(Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
 
getIterator(Viewable) - Method in class net.esper.eql.core.ResultSetProcessorRowForAll
 
getIterator(Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorRowForAll
 
getIterator(Viewable) - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
 
getIterator(Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
 
getIterator(Viewable) - Method in class net.esper.eql.core.ResultSetProcessorSimple
 
getIterator(Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorSimple
 
getJavaClass() - Method in enum net.esper.util.DatabaseTypeEnum
Retuns the Java class for the name.
getJavaSqlTypeBinding() - Method in class net.esper.eql.db.ColumnSettings
Returns the mapping of java.sql.Types value to Java built-in name (class or simple name).
getJavaSqlTypesMapping() - Method in class net.esper.client.ConfigurationDBRef
Returns the mapping of types that the engine must perform when receiving output columns of that sql types.
getJoinSetComposerFactory() - Method in class net.esper.core.StatementContext
Returns the statement's factory for join set processors.
getKey() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
 
getKey() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashMapIterator
 
getKey() - Method in class net.esper.collection.apachecommons.AbstractKeyValue
Gets the key from the pair.
getKey() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Gets the key from the entry.
getKey() - Method in interface net.esper.collection.apachecommons.KeyValue
Gets the key from the pair.
getKey() - Method in interface net.esper.collection.apachecommons.MapIterator
Gets the current key, which is the key returned by the last call to next().
getKey() - Method in class net.esper.event.property.MappedProperty
Returns the key value for mapped access.
GETKEY_INVALID - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
Message.
getKeyProperties() - Method in class net.esper.eql.join.plan.IndexedTableLookupPlan
Returns property names to use for lookup in index.
getKeyProperties(int, int) - Method in class net.esper.eql.join.plan.QueryGraph
Returns key properties.
getKeyProperties(Collection<JoinedPropDesc>) - Static method in class net.esper.eql.lookup.JoinedPropDesc
Returns the key property names.
getKeyProperties(JoinedPropDesc[]) - Static method in class net.esper.eql.lookup.JoinedPropDesc
Returns the key property names.
getKeyPropName() - Method in class net.esper.eql.lookup.JoinedPropDesc
Returns the property name of the key field.
getKeys() - Method in class net.esper.collection.MultiKeyUntyped
Returns keys.
getKeys(EventBean[]) - Method in class net.esper.eql.lookup.IndexedTableLookupStrategy
Get the index lookup keys.
getKeys(EventBean[]) - Method in class net.esper.eql.lookup.IndexedTableLookupStrategyCoercing
 
getKeyStreamId() - Method in class net.esper.eql.lookup.JoinedPropDesc
Returns the stream id of the key field.
getKeyStreamNums(Collection<JoinedPropDesc>) - Static method in class net.esper.eql.lookup.JoinedPropDesc
Returns the key stream numbers.
getLeft() - Method in class net.esper.client.soda.OuterJoinQualifier
Returns property value expression to join on.
getLeftNode() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns left hand identifier node.
getListedName() - Method in class net.esper.event.EventPropertyDescriptor
Returns the listed name, which is the name the property would show up as when asking an event type for the set of valid properties.
getListenerDispatchLocking() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns the blocking strategy to use when multiple threads deliver results for a single statement to listeners, and the guarantee of order of delivery must be maintained.
getListenerDispatchTimeout() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns the timeout in millisecond to wait for listener code to complete before dispatching the next result, if dispatch order is preserved
getListeners() - Method in class net.esper.core.EPStatementListenerSet
Returns the set of listeners to the statement.
getListenerSet() - Method in class net.esper.core.EPStatementImpl
Returns the set of listeners to the statement.
getListenerSet() - Method in interface net.esper.core.EPStatementSPI
Returns the current set of listeners for read-only operations.
getListOfValues() - Method in class net.esper.filter.FilterSpecParamIn
Returns the list of values we are asking to match.
getLoaderName() - Method in class net.esper.client.ConfigurationAdapterLoader
Returns the loader name.
getLogging() - Method in class net.esper.client.ConfigurationEngineDefaults
Returns logging settings applicable to the engine, other then Log4J settings.
getLong() - Method in class net.esper.type.LongValue
Returns the long value.
getLookupStrategy() - Method in class net.esper.eql.join.exec.TableLookupExecNode
Returns strategy for lookup.
getLookupStrategy() - Method in class net.esper.eql.join.exec.TableOuterLookupExecNode
Returns strategy for lookup.
getLookupStrategySpec() - Method in class net.esper.eql.join.plan.TableLookupNode
Returns lookup plan.
getLookupStrategySpec() - Method in class net.esper.eql.join.plan.TableOuterLookupNode
Returns lookup plan.
getLookupStream() - Method in class net.esper.eql.join.plan.TableLookupPlan
Returns the lookup stream.
getLow() - Method in class net.esper.type.RangeParameter
Returns start of range.
getMappedProperty(String) - Method in class net.esper.event.BeanEventType
Looks up and returns a cached mapped property's descriptor.
getMatchingEvent(String) - Method in interface net.esper.pattern.MatchedEventMap
Returns a single event instance given the tag identifier, or null if the tag could not be located.
getMatchingEvent(String) - Method in class net.esper.pattern.MatchedEventMapImpl
Returns a single event instance given the tag identifier, or null if the tag could not be located.
getMatchingEvents() - Method in interface net.esper.pattern.MatchedEventMap
Returns a map containing the events where the key is the event tag string and the value is the event instance.
getMatchingEvents() - Method in class net.esper.pattern.MatchedEventMapImpl
Returns a map containing the events where the key is the event tag string and the value is the event instance.
getMathArithTypeEnum() - Method in class net.esper.eql.expression.ExprMathNode
Returns the type of math.
getMax() - Method in class net.esper.filter.DoubleRange
Returns high endpoint.
getMax() - Method in class net.esper.filter.FilterSpecParamRange
Returns the upper endpoint.
getMaxAgeMSec() - Method in class net.esper.eql.db.DataCacheExpiringImpl
Returns the maximum age in milliseconds.
getMaxAgeSeconds() - Method in class net.esper.client.ConfigurationDBRef.ExpiryTimeCacheDesc
Returns the maximum age in seconds.
getMBeanInfo() - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
 
getMBeanInfo() - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
getMeasureField() - Method in class net.esper.view.stat.MultiDimStatsView
Returns the name of the field to extract the measure values from.
getMeasures() - Method in interface net.esper.view.stat.olap.Cube
Returns all measures.
getMeasures() - Method in class net.esper.view.stat.olap.CubeImpl
 
getMembers(int) - Method in interface net.esper.view.stat.olap.Cube
Returns the member value for each dimension that intersect to identify the cell of the given ordinal.
getMembers(int) - Method in class net.esper.view.stat.olap.CubeImpl
 
getMembers() - Method in interface net.esper.view.stat.olap.Dimension
Returns the member values for the dimension.
getMembers() - Method in class net.esper.view.stat.olap.DimensionImpl
 
getMembers(int) - Method in interface net.esper.view.stat.olap.MultidimCube
Get the members making up a dimension.
getMembers(int) - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
getMergeView() - Method in enum net.esper.view.ViewEnum
Returns the enumeration value of the view for merging the data generated by another view.
getMessage() - Method in exception net.esper.client.EPStatementException
 
getMetadataRetrievalEnum() - Method in class net.esper.client.ConfigurationDBRef
Returns an enumeration indicating how the engine retrieves metadata about the columns that a given SQL query returns.
getMetadataRetrievalEnum() - Method in class net.esper.eql.db.ColumnSettings
Returns the metadata orgin.
getMetadataSQL() - Method in class net.esper.eql.spec.DBStatementStreamSpec
Returns the optional sample metadata SQL
getMethod() - Method in class net.esper.client.soda.StaticMethodExpression
Returns the method name.
getMethod() - Method in class net.esper.event.property.DynamicPropertyDescriptor
Returns the method to invoke.
getMethodInvocationReferences() - Method in class net.esper.client.Configuration
 
getMethodInvocationReferences() - Method in interface net.esper.client.ConfigurationInformation
Returns a map of class name and cache configurations, for use in method invocations in the from-clause of methods provided by the class.
getMethodName() - Method in class net.esper.client.soda.MethodInvocationStream
Returns the name of the static method to invoke in the from-clause.
getMethodName() - Method in class net.esper.eql.expression.ExprNode.MappedPropertyParseResult
Returns the method name.
getMethodName() - Method in class net.esper.eql.expression.ExprStaticMethodNode
Returns the method name.
getMethodName() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
Returns the method name.
getMethodName() - Method in class net.esper.eql.spec.MethodStreamSpec
Returns the method name.
getMethodProperties() - Method in class net.esper.client.ConfigurationEventTypeLegacy
Returns a list of descriptors specifying explicitly configured method names and their property name.
getMethodResolutionService() - Method in class net.esper.core.StatementContext
Returns service to look up static and aggregation methods or functions.
getMillisecondsBeforeExpiry() - Method in class net.esper.view.window.ExternallyTimedWindowView
Retuns the window size in milliseconds.
getMillisecondsBeforeExpiry() - Method in class net.esper.view.window.TimeWindowView
Returns the size of the time window in millisecond.
getMillisecondsBeforeExpiry() - Method in class net.esper.view.window.TimeWindowViewFactory
Returns the number of millisecond before window contents expire.
getMin() - Method in class net.esper.filter.DoubleRange
Returns low endpoint.
getMin() - Method in class net.esper.filter.FilterSpecParamRange
Returns the lower endpoint.
getMinMaxTypeEnum() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
Returns the indicator for minimum or maximum.
getMinMaxTypeEnum() - Method in class net.esper.eql.expression.ExprMinMaxRowNode
Returns the indicator for minimum or maximum.
getModel() - Method in class net.esper.client.EPPreparedStatementImpl
Returns the statement object model for the prepared statement
getModel() - Method in class net.esper.client.soda.SubqueryExistsExpression
Returns the lookup statement object model.
getModel() - Method in class net.esper.client.soda.SubqueryExpression
Returns the lookup statement object model.
getModel() - Method in class net.esper.client.soda.SubqueryInExpression
Returns the lookup statement object model.
getMsecIntervalSize() - Method in class net.esper.eql.view.OutputConditionTime
Returns the interval size in milliseconds.
getMsecIntervalSize() - Method in class net.esper.view.window.TimeAccumView
Returns the interval size in milliseconds.
getMsecIntervalSize() - Method in class net.esper.view.window.TimeAccumViewRStream
Returns the interval size in milliseconds.
getMsecIntervalSize() - Method in class net.esper.view.window.TimeBatchView
Returns the interval size in milliseconds.
getMsecIntervalSize() - Method in class net.esper.view.window.TimeBatchViewRStream
Returns the interval size in milliseconds.
getMsecIntervalSize() - Method in class net.esper.view.window.TimeLengthBatchView
Returns the interval size in milliseconds.
getMsecTimerResolution() - Method in class net.esper.timer.TimerServiceImpl
Returns the timer resolution.
getMsecVersionRelease() - Method in class net.esper.client.ConfigurationEngineDefaults.Variables
Returns the number of milliseconds that a version of a variables is held stable for use by very long-running atomic statement execution.
getMultiKey(EventBean) - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
Determine multikey for index access.
getMultiKey(EventBean) - Method in class net.esper.eql.join.table.PropertyIndTableCoerceAdd
 
getMultiKey(EventBean, EventPropertyGetter[]) - Static method in class net.esper.event.EventBeanUtility
Returns Multikey instance for given event and getters.
getN() - Method in class net.esper.view.stat.BaseStatisticsBean
Returns the number of data points.
getName() - Method in class net.esper.client.ConfigurationEventTypeLegacy.LegacyFieldPropDesc
Returns the event property name.
getName() - Method in class net.esper.client.ConfigurationEventTypeLegacy.LegacyMethodPropDesc
Returns the event property name.
getName() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM.XPathPropertyDesc
Returns the event property name.
getName() - Method in class net.esper.client.ConfigurationPlugInAggregationFunction
Returns the aggregation function name.
getName() - Method in class net.esper.client.ConfigurationPlugInPatternObject
Returns the view name.
getName() - Method in class net.esper.client.ConfigurationPlugInView
Returns the view name.
getName() - Method in interface net.esper.client.EPStatement
Returns the statement name.
getName() - Method in class net.esper.client.soda.EPBaseNamedObject
Returns the object name.
getName() - Method in class net.esper.core.EPStatementImpl
 
getName() - Method in class net.esper.eql.variable.VersionedValueList
Returns the name of the value stored.
getName() - Method in enum net.esper.pattern.guard.GuardEnum
Returns name.
getName() - Method in enum net.esper.pattern.observer.ObserverEnum
Returns name.
getName() - Method in enum net.esper.view.ViewEnum
Returns name of the view that can be used to reference the view in a view expression.
getName() - Method in enum net.esper.view.ViewFieldEnum
Returns the field name of fields that contain data within a view's posted objects.
getNamedWindowLock(String) - Method in interface net.esper.eql.named.NamedWindowService
Returns the statement lock for the named window, to be shared with on-delete statements for the same named window.
getNamedWindowLock(String) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
getNamedWindowService() - Method in class net.esper.core.EPServicesContext
Returns the named window management service.
getNamedWindowService() - Method in class net.esper.core.StatementContext
Returns the named window management service.
getNamedWindowType() - Method in class net.esper.eql.named.NamedWindowProcessor
Returns the event type of the named window.
getNameInNamespace() - Method in class net.esper.core.EngineEnvContext
 
getNameParser(Name) - Method in class net.esper.core.EngineEnvContext
 
getNameParser(String) - Method in class net.esper.core.EngineEnvContext
 
getNamespace() - Method in class net.esper.client.ConfigurationPlugInPatternObject
Returns the namespace
getNamespace() - Method in class net.esper.client.ConfigurationPlugInView
Returns the namespace
getNamespace() - Method in class net.esper.client.soda.EPBaseNamedObject
Returns the object namespace name.
getNamespace() - Method in enum net.esper.pattern.guard.GuardEnum
Returns the namespace name.
getNamespace() - Method in enum net.esper.pattern.observer.ObserverEnum
Returns the observer namespace name.
getNamespace() - Method in enum net.esper.view.ViewEnum
Returns namespace that the object belongs to.
getNamespaceName() - Method in class net.esper.view.ViewFactoryContext
Returns the view namespace name.
getNamespacePrefixes() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns the namespace prefixes in a map of prefix as key and namespace name as value.
getNamespaceURI(String) - Method in class net.esper.event.xml.XPathNamespaceContext
 
getNavigableStreams(int) - Method in class net.esper.eql.join.plan.QueryGraph
Returns set of streams that the given stream is navigable to.
getNewData() - Method in class net.esper.eql.named.NamedWindowDeltaData
Returns the insert stream events.
getNewData(int) - Method in class net.esper.view.ext.IStreamSortedRandomAccess
 
getNewData(int) - Method in class net.esper.view.ext.IStreamTimeOrderRandomAccess
 
getNewData(int) - Method in class net.esper.view.internal.PriorEventBufferUnbound
 
getNewData(int) - Method in class net.esper.view.window.IStreamRandomAccess
 
getNewData(int) - Method in interface net.esper.view.window.RandomAccessByIndex
Returns an new data event given an index.
getNewDataBuffer() - Method in class net.esper.view.internal.BufferView
Returns the buffer for new data.
getNewEventsCount() - Method in class net.esper.eql.view.OutputConditionCount
Returns the number of new events.
getNode() - Method in class net.esper.eql.join.rep.Cursor
Returns current result node the event belong to.
getNodeNumber() - Method in class net.esper.pattern.EvalNode
Returns the evaluation node's relative node number in the evaluation node tree.
getNodeRWLock() - Method in class net.esper.filter.FilterHandleSetNode
Returns to lock to use for making changes to the filter callback or inzides collections stored by this node.
getNodesPerStream() - Method in class net.esper.eql.join.rep.RepositoryImpl
Returns a list of nodes that are the lookup results per stream.
getNumber() - Method in class net.esper.pattern.EvalNodeNumber
Returns the node number representation in an array of short.
getNumberOfEvents() - Method in class net.esper.view.window.TimeLengthBatchView
Returns the length of the batch.
getNumDimensions() - Method in interface net.esper.view.stat.olap.MultidimCube
Get the number of dimensions of the cube.
getNumDimensions() - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
getNumEventsEmitted() - Method in interface net.esper.client.EPRuntime
Number of events emitted over the lifetime of the event stream processing runtime.
getNumEventsEmitted() - Method in class net.esper.core.EPRuntimeImpl
 
getNumEventsEmitted() - Method in interface net.esper.emit.EmitService
Number of events emitted.
getNumEventsEmitted() - Method in class net.esper.emit.EmitServiceImpl
 
getNumEventsEvaluated() - Method in interface net.esper.filter.FilterService
Return a count of the number of events evaluated by this service.
getNumEventsEvaluated() - Method in class net.esper.filter.FilterServiceImpl
 
getNumEventsReceived() - Method in interface net.esper.client.EPRuntime
Number of events received over the lifetime of the event stream processing runtime.
getNumEventsReceived() - Method in class net.esper.core.EPRuntimeImpl
 
getNumSeconds() - Method in class net.esper.type.TimePeriodParameter
Returns the number of seconds.
getNumStreams() - Method in class net.esper.eql.join.ExecNodeQueryStrategy
Returns the total number of streams.
getNumStreams() - Method in class net.esper.eql.join.plan.QueryGraph
Returns the number of streams.
getObjectModel() - Method in class net.esper.eql.spec.StatementSpecUnMapResult
Returns the object model.
getObjectName() - Method in class net.esper.eql.spec.ObjectSpec
Returns the object name.
getObjectNamespace() - Method in class net.esper.eql.spec.ObjectSpec
Returns namespace for view object.
getObjectParameters() - Method in class net.esper.eql.spec.ObjectSpec
Returns the list of object parameters.
getObserverFactory() - Method in class net.esper.pattern.EvalObserverNode
Returns the observer factory.
getObserverNodes() - Method in class net.esper.pattern.EvalNodeAnalysisResult
Returns observer nodes.
getOldData() - Method in class net.esper.eql.named.NamedWindowDeltaData
Returns the remove stream events.
getOldData(int) - Method in class net.esper.view.ext.IStreamSortedRandomAccess
 
getOldData(int) - Method in class net.esper.view.ext.IStreamTimeOrderRandomAccess
 
getOldData(int) - Method in class net.esper.view.internal.PriorEventBufferUnbound
 
getOldData(int) - Method in class net.esper.view.window.IStreamRandomAccess
 
getOldData(int) - Method in interface net.esper.view.window.RandomAccessByIndex
Returns an old data event given an index.
getOlderVersions() - Method in class net.esper.eql.variable.VersionedValueList
Returns the list of old versions, for testing purposes.
getOldestTimestamp() - Method in class net.esper.collection.TimeWindow
Returns the oldest timestamp in the collection if there is at least one entry, else it returns null if the window is empty.
getOldEventsCount() - Method in class net.esper.eql.view.OutputConditionCount
Returns the number of old events.
getOnExpr() - Method in class net.esper.client.soda.EPStatementObjectModel
Returns the on-delete clause for deleting from named windows, or null if this statement does not delete from a named window
getOnTriggerDesc() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the specification for an on-delete or on-select statement.
getOnTriggerDesc() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the on-delete statement specification.
getOnTriggerType() - Method in class net.esper.eql.spec.OnTriggerDesc
Returns the type of the on-trigger statement.
getOperator() - Method in class net.esper.client.soda.ArithmaticExpression
Returns the arithmatic operator.
getOperator() - Method in class net.esper.client.soda.RelationalOpExpression
Returns the operator to use.
getOptInsertIntoStream() - Method in class net.esper.core.EPStatementDesc
Return the insert-into stream name, or null if no insert-into
getOptInsertIntoStream() - Method in class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Return the insert-into stream name, or null if no insert-into
getOptionalAliasName() - Method in class net.esper.eql.spec.SelectExprElementStreamCompiledSpec
Returns the column alias (e.g.
getOptionalAsName() - Method in class net.esper.client.soda.OnDeleteClause
Returns the as-alias for the named window.
getOptionalAsName() - Method in class net.esper.client.soda.OnSelectClause
Returns the as-alias for the named window.
getOptionalAsName() - Method in class net.esper.eql.spec.OnTriggerWindowDesc
Returns the alias, or null if none defined.
getOptionalAsName() - Method in class net.esper.eql.spec.SelectExprElementRawSpec
Returns the name of the item in the select clause.
getOptionalAsName() - Method in class net.esper.eql.spec.SelectExprElementStreamRawSpec
Returns the column alias (e.g.
getOptionalAssignment() - Method in class net.esper.client.soda.CreateVariableClause
Returns the optional assignment expression, or null to initialize to a null value
getOptionalBinding() - Method in class net.esper.eql.db.DBOutputTypeDesc
Returns the optional mapping from output column type to Java built-in.
getOptionalColumnAlias() - Method in class net.esper.client.soda.SelectClauseStreamWildcard
Returns the optional column alias name (e.g.
getOptionalHavingNode() - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
Returns the optional having expression.
getOptionalHavingNode() - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
Returns the having node.
getOptionalHavingNode() - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
Returns the optional having expression.
getOptionalMetadataSQL() - Method in class net.esper.client.soda.SQLStream
Returns the metadata SQL if any.
getOptionalPassword() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the password to connect to the database, or null if none supplied, since the password can also be supplied through properties.
getOptionalProperties() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the properties, if supplied, to use for obtaining a connection via driver manager.
getOptionalSortedRandomAccess() - Method in class net.esper.view.ext.SortWindowView
Returns the friend handling the random access, cal be null if not required.
getOptionalSortedRandomAccess() - Method in class net.esper.view.ext.TimeOrderView
Returns the friend handling the random access, cal be null if not required.
getOptionalStreamName() - Method in interface net.esper.eql.spec.StreamSpec
Returns the stream name, or null if undefined.
getOptionalStreamName() - Method in class net.esper.eql.spec.StreamSpecBase
Returns the name assigned.
getOptionalUserName() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the user name to connect to the database, or null if none supplied, since the user name can also be supplied through properties.
getOrderByClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the order-by-clause, or null to indicate that the clause is absent.
getOrderByExpressions() - Method in class net.esper.client.soda.OrderByClause
Returns a list of expressions and flags to order by.
getOrderByList() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the list of order-by expression as specified in the ORDER BY clause.
getOrderByList() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the list of order-by expression as specified in the ORDER BY clause.
getOrdinal(DimensionMember[]) - Method in interface net.esper.view.stat.olap.Cube
Given the the members of each dimension that define the intersection, returns the ordinal of a measure.
getOrdinal(int[], int[]) - Static method in class net.esper.view.stat.olap.CubeDimensionHelper
Given index values for each dimension and all dimension sizes this method returns an ordinal value.
getOrdinal(DimensionMember[]) - Method in class net.esper.view.stat.olap.CubeImpl
 
getOuter(int) - Method in class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Returns the set of outer streams for the given inner stream number.
getOuterJoinDescList() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the LEFT/RIGHT/FULL OUTER JOIN-type and property name descriptor, if applicable.
getOuterJoinDescList() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the LEFT/RIGHT/FULL OUTER JOIN-type and property name descriptor, if applicable.
getOuterJoinQualifiers() - Method in class net.esper.client.soda.FromClause
Returns the outer join descriptors, if this is an outer join, or an empty list if none of the streams are outer joined.
getOuterJoinType() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns the type of outer join (left/right/full).
getOutputConditionFactory() - Method in class net.esper.core.EPServicesContext
Returns the output condition factory
getOutputConditionFactory() - Method in class net.esper.core.StatementContext
Returns the statement's factory for output conditions.
getOutputLimitClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the output-rate-limiting-clause, or null to indicate that the clause is absent.
getOutputLimitSpec() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the output limit definition, if any.
getOutputLimitSpec() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the output limit definition, if any.
getOutputParameters() - Method in class net.esper.eql.db.QueryMetaData
Returns a map of output column name and type descriptor.
getPageField() - Method in class net.esper.view.stat.MultiDimStatsView
Returns the name of the field to extract the page values from.
getParameterExpressions() - Method in class net.esper.client.soda.MethodInvocationStream
Returns a list of expressions that are parameters to the method.
getParameters() - Method in class net.esper.client.soda.EPBaseNamedObject
Returns the object parameters.
getParameters() - Method in class net.esper.eql.db.SQLParameterDesc
Returns parameter names.
getParameters() - Method in class net.esper.filter.FilterSpecCompiled
Returns list of filter parameters.
getParameters() - Method in interface net.esper.filter.FilterValueSet
Returns list of filter parameters.
getParameters() - Method in class net.esper.filter.FilterValueSetImpl
Returns list of filter parameters.
getParameters() - Method in class net.esper.type.ListParameter
Returns list of parameters.
getParamTypes() - Method in class net.esper.eql.expression.ExprStaticMethodNode
Returns parameter descriptor.
getParamTypes() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
Returns parameter descriptor.
getParent() - Method in class net.esper.eql.join.rep.Node
Returns the parent node, or null if this is a root node.
getParent() - Method in interface net.esper.view.View
Returns the View's parent Viewable.
getParent() - Method in class net.esper.view.ViewSupport
 
getParentAssembler() - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Returns parent node.
getParentEvaluator() - Method in class net.esper.pattern.EvalStateNode
Returns the parent evaluator.
getParentEvent() - Method in class net.esper.eql.join.rep.Node
Returns lookup event.
getParentNumber() - Method in class net.esper.pattern.EvalNodeNumber
Returns the parent's node number, of null if this is the root node number.
getPatternContextFactory() - Method in class net.esper.core.StatementContext
Returns the pattern context factory for the statement.
getPatternGuardSpec() - Method in class net.esper.pattern.EvalGuardNode
Returns the guard object specification to use for instantiating the guard factory and guard.
getPatternObjectType() - Method in class net.esper.client.ConfigurationPlugInPatternObject
Returns an object type of the pattern object plug-in.
getPatternObserverSpec() - Method in class net.esper.pattern.EvalObserverNode
Returns the observer object specification to use for instantiating the observer factory and observer.
getPatternResolutionService() - Method in class net.esper.core.StatementContext
Returns the statement's resolution service for pattern objects.
getPatternStateFactory() - Method in class net.esper.pattern.PatternContext
Returns the pattern state node factory to use.
getPermutation(int, int, int[]) - Static method in class net.esper.collection.PermutationEnumeration
Returns permutation.
getPlan(EventType[], List<OuterJoinDesc>, ExprNode, String[]) - Static method in class net.esper.eql.join.plan.QueryPlanBuilder
Build query plan using the filter.
getPluggables() - Method in class net.esper.eql.spec.PluggableObjectCollection
Returns the underlying nested map of namespace keys and name-to-object maps.
getPlugInAggregationFunctions() - Method in class net.esper.client.Configuration
 
getPlugInAggregationFunctions() - Method in interface net.esper.client.ConfigurationInformation
Returns a list of configured plug-in aggregation functions.
getPlugInPatternObjects() - Method in class net.esper.client.Configuration
 
getPlugInPatternObjects() - Method in interface net.esper.client.ConfigurationInformation
Returns a list of configured plug-ins for pattern observers and guards.
getPlugInPatternObjects() - Method in class net.esper.core.EPServicesContext
Information to resolve plug-in pattern object namespace and name.
getPlugInViews() - Method in class net.esper.client.Configuration
 
getPlugInViews() - Method in interface net.esper.client.ConfigurationInformation
Returns a list of configured plug-in views.
getPlugInViews() - Method in class net.esper.core.EPServicesContext
Information to resolve plug-in view namespace and name.
getPositionInfo(RecognitionException) - Static method in exception net.esper.eql.parse.EPStatementSyntaxException
Returns the position information string for a parser exception.
getPrefix(String) - Method in class net.esper.event.xml.XPathNamespaceContext
 
getPrefixes(String) - Method in class net.esper.event.xml.XPathNamespaceContext
 
getPrimitiveClassForName(String) - Static method in class net.esper.util.JavaClassHelper
Returns the class for a Java primitive type name, ignoring case, and considering String as a primitive.
getPrimitiveType(Class) - Static method in class net.esper.util.JavaClassHelper
Returns the un-boxed class for the given class, or the class itself if already un-boxed or not a primitive type.
getPriorVersion() - Method in class net.esper.eql.variable.CurrentValue
Returns the prior version.
getProcessor(List<SelectExprElementCompiledSpec>, List<ExprNode>, List<OrderByItem>, AggregationService, EventAdapterService) - Static method in class net.esper.eql.core.OrderByProcessorFactory
Returns processor for order-by clauses.
getProcessor(SelectClauseSpec, InsertIntoDesc, List<ExprNode>, ExprNode, OutputLimitSpec, List<OrderByItem>, StreamTypeService, EventAdapterService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Static method in class net.esper.eql.core.ResultSetProcessorFactory
Returns the result set process for the given select expression, group-by clause and having clause given a set of types describing each stream in the from-clause.
getProcessor(List<SelectExprElementCompiledSpec>, List<SelectExprElementStreamCompiledSpec>, boolean, InsertIntoDesc, StreamTypeService, EventAdapterService) - Static method in class net.esper.eql.core.SelectExprProcessorFactory
Returns the processor to use for a given select-clause.
getProcessor(String) - Method in interface net.esper.eql.named.NamedWindowService
Returns the processing instance for a given named window.
getProcessor(String) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
getProperties() - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
Returns properties to use from lookup event to look up in index.
getProperties() - Method in class net.esper.eql.lookup.IndexedTableLookupStrategy
Returns properties to use from lookup event to look up in index.
getProperties() - Method in class net.esper.event.property.NestedProperty
Returns the list of property instances making up the nesting levels.
getProperties(Class) - Static method in class net.esper.event.property.PropertyHelper
Introspects the given class and returns event property descriptors for each property found in the class itself, it's superclasses and all interfaces this class and the superclasses implements.
getPropertiesLeft() - Method in class net.esper.eql.join.plan.QueryGraphValue
Returns property names for left stream.
getPropertiesRight() - Method in class net.esper.eql.join.plan.QueryGraphValue
Returns property names for right stream.
getPropertyArray(EventBean, EventPropertyGetter[]) - Static method in class net.esper.event.EventBeanUtility
Returns object array containing property values of given properties, retrieved via EventPropertyGetter instances.
getPropertyBoxedType() - Method in class net.esper.filter.FilterParamIndexPropBase
Returns boxed property type.
getPropertyName() - Method in class net.esper.client.soda.PropertyValueExpression
Returns the property name.
getPropertyName() - Method in class net.esper.eql.core.PropertyResolutionDescriptor
Returns resolved property name of the property as it exists in a stream.
getPropertyName(AST) - Static method in class net.esper.eql.parse.ASTFilterSpecHelper
Return the generated property name that is defined by the AST child node and it's siblings.
getPropertyName() - Method in class net.esper.event.EventPropertyDescriptor
Return the property name, for mapped and indexed properties this is just the property name without parantheses or brackets.
getPropertyName() - Method in class net.esper.event.property.PropertyBase
Returns the property name.
getPropertyName() - Method in class net.esper.filter.FilterParamIndexPropBase
Returns the name of the property to get the value for to match against the values contained in the index.
getPropertyName() - Method in class net.esper.filter.FilterSpecParam
Returns the property name for the filter parameter.
getPropertyName() - Method in interface net.esper.filter.FilterValueSetParam
Returns the property name for the filter parameter.
getPropertyName() - Method in class net.esper.filter.FilterValueSetParamImpl
 
getPropertyNames() - Method in class net.esper.event.BaseConfigurableEventType
 
getPropertyNames() - Method in class net.esper.event.BeanEventType
 
getPropertyNames() - Method in class net.esper.event.CompositeEventType
 
getPropertyNames() - Method in interface net.esper.event.EventType
Get all valid property names for the event type.
getPropertyNames() - Method in class net.esper.event.MapEventType
 
getPropertyNames() - Method in class net.esper.event.WrapperEventType
 
getPropertyNames() - Method in interface net.esper.view.stat.olap.Dimension
Returns the event property name or names providing the member values for the dimension.
getPropertyNames() - Method in class net.esper.view.stat.olap.DimensionImpl
 
getPropertyNames() - Method in class net.esper.view.std.AddPropertyValueView
Returns field name for which to set the merge value for.
getPropertyResolutionStyle() - Method in class net.esper.client.ConfigurationEventTypeLegacy
Returns the type's property resolution style to use.
getPropertyResolutionStyle() - Method in class net.esper.event.BeanEventType
Returns the property resolution style.
getPropertyType() - Method in class net.esper.eql.core.PropertyResolutionDescriptor
Returns the property type of the resolved property.
getPropertyType(String) - Method in class net.esper.event.BaseConfigurableEventType
 
getPropertyType(String) - Method in class net.esper.event.BeanEventType
 
getPropertyType(String) - Method in class net.esper.event.CompositeEventType
 
getPropertyType() - Method in class net.esper.event.EventPropertyDescriptor
Returns an enum indicating the type of property: simple, mapped, indexed.
getPropertyType(String) - Method in interface net.esper.event.EventType
Get the type of an event property as returned by the "getter" method for that property.
getPropertyType(String) - Method in class net.esper.event.MapEventType
 
getPropertyType(BeanEventType) - Method in class net.esper.event.property.DynamicIndexedProperty
 
getPropertyType(BeanEventType) - Method in class net.esper.event.property.DynamicMappedProperty
 
getPropertyType(BeanEventType) - Method in class net.esper.event.property.DynamicSimpleProperty
 
getPropertyType(BeanEventType) - Method in class net.esper.event.property.IndexedProperty
 
getPropertyType(BeanEventType) - Method in class net.esper.event.property.MappedProperty
 
getPropertyType(BeanEventType) - Method in class net.esper.event.property.NestedProperty
 
getPropertyType(BeanEventType) - Method in interface net.esper.event.property.Property
Returns the property type.
getPropertyType(BeanEventType) - Method in class net.esper.event.property.SimpleProperty
 
getPropertyType(String) - Method in class net.esper.event.WrapperEventType
 
getPropertyTypeMap() - Method in class net.esper.event.property.DynamicIndexedProperty
 
getPropertyTypeMap() - Method in class net.esper.event.property.DynamicMappedProperty
 
getPropertyTypeMap() - Method in class net.esper.event.property.DynamicSimpleProperty
 
getPropertyTypeMap() - Method in class net.esper.event.property.IndexedProperty
 
getPropertyTypeMap() - Method in class net.esper.event.property.MappedProperty
 
getPropertyTypeMap() - Method in class net.esper.event.property.NestedProperty
 
getPropertyTypeMap() - Method in interface net.esper.event.property.Property
Returns the property type for use with Map event representations.
getPropertyTypeMap() - Method in class net.esper.event.property.SimpleProperty
 
getPropertyValues() - Method in class net.esper.view.std.AddPropertyValueView
Returns the value to set for the field.
getPropExpr(String) - Static method in class net.esper.client.soda.Expressions
Returns an expression returning the propertyName value for the propertyName name passed in.
getPrototypeAggregator() - Method in class net.esper.eql.expression.ExprAggregateNode
Returns the aggregation state prototype for use in grouping aggregation states per group-by keys.
getProvider(String) - Static method in class net.esper.client.EPServiceProviderManager
Returns an EPServiceProvider for a given registration URI.
getProvider(String, Configuration) - Static method in class net.esper.client.EPServiceProviderManager
Returns an EPServiceProvider for a given registration URI.
getPurgeIntervalMSec() - Method in class net.esper.eql.db.DataCacheExpiringImpl
Returns the purge interval in milliseconds.
getPurgeIntervalSeconds() - Method in class net.esper.client.ConfigurationDBRef.ExpiryTimeCacheDesc
Returns the purge interval length.
getQuerySetting(String) - Method in interface net.esper.eql.db.DatabaseConfigService
Returns the column metadata settings for the database.
getQuerySetting(String) - Method in class net.esper.eql.db.DatabaseConfigServiceImpl
 
getQueryStrategies() - Method in class net.esper.eql.join.JoinSetComposerImpl
Returns query strategies.
getRate() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the rate, or null or -1 if a variable is used instead
getRateType() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the type of rate.
getRawFilterSpec() - Method in class net.esper.eql.spec.FilterStreamSpecRaw
Returns the unvalided filter spec.
getRawFilterSpec() - Method in class net.esper.pattern.EvalFilterNode
Returns the raw (unoptimized/validated) filter definition.
getReader(String) - Method in interface net.esper.eql.variable.VariableService
Returns a reader that provides access to variable values.
getReader(String) - Method in class net.esper.eql.variable.VariableServiceImpl
 
getReadMethod() - Method in class net.esper.event.EventPropertyDescriptor
Returns the read method.
getReadOnly() - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Returns a boolean indicating read-only, or null if not set and default accepted.
getReadWriteLock() - Method in interface net.esper.eql.variable.VariableService
Lock for use in atomic writes to the variable space.
getReadWriteLock() - Method in class net.esper.eql.variable.VariableServiceImpl
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexBase
Supplies the lock for protected access.
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexBooleanExpr
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexCompare
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexEquals
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexIn
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexNotEquals
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexNotIn
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexNotRange
 
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexPropBase
Supplies the lock for protected access.
getReadWriteLock() - Method in class net.esper.filter.FilterParamIndexRange
 
getRelationalOpEnum() - Method in class net.esper.eql.expression.ExprRelationalOpNode
Returns the type of relational op used.
getRelativeToEvent(EventBean, int) - Method in class net.esper.view.internal.PriorEventBufferMulti
 
getRelativeToEvent(EventBean, int) - Method in class net.esper.view.internal.PriorEventBufferSingle
 
getRelativeToEvent(EventBean, int) - Method in class net.esper.view.internal.PriorEventViewFactory.RelativeAccessImpl
 
getRelativeToEvent(EventBean, int) - Method in class net.esper.view.window.IStreamRelativeAccess
 
getRelativeToEvent(EventBean, int) - Method in interface net.esper.view.window.RelativeAccessByEventNIndex
Returns the prior event to the given event counting back the number of events as supplied by index.
getResolvedPropertyName() - Method in class net.esper.eql.expression.ExprIdentNode
Return property name as resolved by lookup in streams.
getResolvedStreamName() - Method in class net.esper.eql.expression.ExprIdentNode
Returns stream name as resolved by lookup of property in streams.
getResourceAsStream(String) - Static method in class net.esper.client.Configuration
Returns an input stream from an application resource in the classpath.
getResultClass() - Method in interface net.esper.event.TypedEventPropertyGetter
Returns type of event property.
getResultClass() - Method in class net.esper.event.xml.XPathPropertyGetter
 
getResultEventAsName() - Method in class net.esper.filter.FilterSpecParamEventProp
Returns tag for result event.
getResultEventAsName() - Method in class net.esper.filter.InSetOfValuesEventProp
Returns the tag used for the event property.
getResultEventAsName() - Method in class net.esper.filter.RangeValueEventProp
Returns the tag name or stream name to use for the event property.
getResultEventProperty() - Method in class net.esper.filter.FilterSpecParamEventProp
Returns the property of the result event.
getResultEventProperty() - Method in class net.esper.filter.InSetOfValuesEventProp
Returns the event property name.
getResultEventProperty() - Method in class net.esper.filter.RangeValueEventProp
Returns the name of the event property.
getResultEventType() - Method in interface net.esper.eql.core.ResultSetProcessor
Returns the event type of processed results.
getResultEventType() - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
 
getResultEventType() - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
 
getResultEventType() - Method in class net.esper.eql.core.ResultSetProcessorRowForAll
 
getResultEventType() - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
 
getResultEventType() - Method in class net.esper.eql.core.ResultSetProcessorSimple
 
getResultEventType() - Method in class net.esper.eql.core.SelectExprEvalProcessor
 
getResultEventType() - Method in class net.esper.eql.core.SelectExprEvalProcessorStreams
 
getResultEventType() - Method in class net.esper.eql.core.SelectExprJoinWildcardProcessor
 
getResultEventType() - Method in interface net.esper.eql.core.SelectExprProcessor
Returns the event type that represents the select-clause items.
getReturnType() - Method in class net.esper.event.EventPropertyDescriptor
Returns the type of the underlying method or field of the event property.
getReverseIndex() - Method in class net.esper.collection.TimeWindow
Returns the reverse index, for testing purposes.
getRight() - Method in class net.esper.client.soda.OuterJoinQualifier
Returns property value expression to join on.
getRightNode() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns right hand identifier node.
getRootElementName() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns the root element name.
getRootElementName() - Method in class net.esper.event.xml.BaseXMLEventType
Returns the name of the root element.
getRootElementNamespace() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns the root element namespace.
getRootView() - Method in class net.esper.eql.named.NamedWindowProcessor
Returns the root view of the named window, hooked into the view chain before the named window's data window views, right after the filter stream that filters for insert-into events.
getRootViewable(ExprSubselectNode) - Method in class net.esper.core.SubSelectStreamCollection
Returns the lookup viewable, child-most view.
getRowField() - Method in class net.esper.view.stat.MultiDimStatsView
Returns the name of the field to extract the row values from.
getRowsPerStream() - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode.ChildStreamResults
Returns rows per stream.
getScheduleBucket() - Method in class net.esper.core.StatementContext
Returns the schedule bucket for ordering schedule callbacks within this pattern.
getScheduleBucket() - Method in class net.esper.pattern.PatternContext
Returns the schedule bucket for ordering schedule callbacks within this pattern.
getScheduleBucket() - Method in class net.esper.view.ViewFactoryContext
Returns the schedule bucket for ordering schedule callbacks within this pattern.
getScheduleCallback() - Method in class net.esper.core.EPStatementHandleCallback
Returns the statement schedule callback, or null if this is a filter callback handle.
getSchedulingService() - Method in class net.esper.core.EPServiceProviderImpl
 
getSchedulingService() - Method in interface net.esper.core.EPServiceProviderSPI
Get the SchedulingService for this engine.
getSchedulingService() - Method in class net.esper.core.EPServicesContext
Returns scheduling service implementation.
getSchedulingService() - Method in class net.esper.core.StatementContext
Returns service to use for schedule evaluation.
getSchedulingService() - Method in class net.esper.pattern.PatternContext
Returns service to use for schedule evaluation.
getSchedulingService() - Method in class net.esper.view.ViewFactoryContext
Returns service to use for schedule evaluation.
getSchemaResource() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns the schema resource.
getSecond() - Method in class net.esper.collection.InterchangeablePair
Returns second value within pair.
getSecond() - Method in class net.esper.collection.Pair
Returns second value within pair.
getSecond() - Method in class net.esper.collection.UniformPair
Returns second value within pair.
getSelectClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the select-clause.
getSelectClauseSpec() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns SELECT-clause list of expressions.
getSelectClauseSpec() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns SELECT-clause list of expressions.
getSelectEventsHaving(SelectExprProcessor, OrderByProcessor, EventBean[], ExprNode, boolean, boolean, boolean) - Static method in class net.esper.eql.core.ResultSetProcessorSimple
Applies the select-clause to the given events returning the selected events.
getSelectEventsHaving(SelectExprProcessor, OrderByProcessor, Set<MultiKey<EventBean>>, ExprNode, boolean, boolean, boolean) - Static method in class net.esper.eql.core.ResultSetProcessorSimple
Applies the select-clause to the given events returning the selected events.
getSelectEventsNoHaving(SelectExprProcessor, OrderByProcessor, EventBean[], boolean, boolean, boolean) - Static method in class net.esper.eql.core.ResultSetProcessorSimple
Applies the select-clause to the given events returning the selected events.
getSelectEventsNoHaving(SelectExprProcessor, OrderByProcessor, Set<MultiKey<EventBean>>, boolean, boolean, boolean) - Static method in class net.esper.eql.core.ResultSetProcessorSimple
Applies the select-clause to the given events returning the selected events.
getSelectExpression() - Method in class net.esper.eql.spec.SelectExprElementCompiledSpec
Returns the expression node representing the item in the select clause.
getSelectExpression() - Method in class net.esper.eql.spec.SelectExprElementRawSpec
Returns the expression node representing the item in the select clause.
getSelectExprList() - Method in class net.esper.eql.spec.SelectClauseSpec
Returns the list of select expressions.
getSelectExprProcessor() - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
Returns the select expression processor
getSelectExprProcessor() - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
Returns the select expression processor
getSelectExprProcessor() - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
Returns the select expression processor
getSelectList() - Method in class net.esper.client.soda.SelectClause
Returns the list of expressions in the select clause.
getSelector() - Method in class net.esper.client.soda.OutputLimitClause
Returns the selector indicating the events to output.
getSelectStreamSelectorEnum() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the stream selector (rstream/istream).
getSelectStreamSelectorEnum() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the stream selector (rstream/istream).
getSelectStreamsList() - Method in class net.esper.eql.spec.SelectClauseSpec
Returns the list of stream wildcard selection elements.
getService(List<ExprAggregateNode>, List<ExprAggregateNode>, List<ExprAggregateNode>, boolean, MethodResolutionService) - Static method in class net.esper.eql.agg.AggregationServiceFactory
Returns an instance to handle the aggregation required by the aggregation expression nodes, depending on whether there are any group-by nodes.
getSimpleProperty(String) - Method in class net.esper.event.BeanEventType
Looks up and returns a cached simple property's descriptor.
getSize() - Method in class net.esper.client.ConfigurationDBRef.LRUCacheDesc
Returns the maximum cache size.
getSize() - Method in class net.esper.eql.db.DataCacheExpiringImpl
Returns the current cache size.
getSize() - Method in class net.esper.view.window.LengthBatchView
Returns the number of events to batch (data window size).
getSize() - Method in class net.esper.view.window.LengthBatchViewRStream
Returns the number of events to batch (data window size).
getSize() - Method in class net.esper.view.window.LengthWindowView
Returns the size of the length window.
getSize() - Method in class net.esper.view.window.LengthWindowViewRStream
Returns the size of the length window.
getSlope() - Method in class net.esper.view.stat.RegressionBean
Returns the slope.
getSlotNum() - Method in class net.esper.schedule.ScheduleSlot
Returns the slot number.
getSortFieldNames() - Method in class net.esper.view.ext.SortWindowView
Returns the field names supplying the values to sort by.
getSortKey(EventBean[], boolean) - Method in interface net.esper.eql.core.OrderByProcessor
Returns the sort key for a given row.
getSortKey(EventBean[], boolean) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
getSortKeyPerRow(EventBean[], boolean) - Method in interface net.esper.eql.core.OrderByProcessor
Returns the sort key for a each row where a row is a single event (no join, single stream).
getSortKeyPerRow(EventBean[], boolean) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
getSortWindowSize() - Method in class net.esper.view.ext.SortWindowView
Returns the number of elements kept by the sort window.
getSqlType() - Method in class net.esper.eql.db.DBOutputTypeDesc
Returns the SQL type of the output column.
getSqlWithSubsParams() - Method in class net.esper.client.soda.SQLStream
Returns the SQL with optional substitution parameters in the SQL.
getSqlWithSubsParams() - Method in class net.esper.eql.spec.DBStatementStreamSpec
Returns the SQL with substitution parameters.
getStartMethod() - Method in class net.esper.core.EPStatementDesc
Returns the start method.
getStartMethod() - Method in class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Returns the start method.
getState() - Method in interface net.esper.client.EPStatement
Returns the statement's current state.
getState() - Method in class net.esper.core.EPStatementImpl
 
getStatement(String) - Method in interface net.esper.client.EPAdministrator
Returns the statement by the given statement name.
getStatement(String) - Method in class net.esper.core.EPAdministratorImpl
 
getStatementAwareListeners() - Method in interface net.esper.client.EPListenable
Returns an iterator of statement-aware update listeners.
getStatementAwareListeners() - Method in class net.esper.core.EPStatementImpl
 
getStatementById(String) - Method in class net.esper.core.StatementLifecycleSvcImpl
Returns the statement given a statement id.
getStatementByName(String) - Method in interface net.esper.core.StatementLifecycleSvc
Returns the statement by the given name, or null if no such statement exists.
getStatementByName(String) - Method in class net.esper.core.StatementLifecycleSvcImpl
 
getStatementContextFactory() - Method in class net.esper.core.EPServicesContext
Returns the factory to use for creating a statement context.
getStatementHandle() - Method in class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Returns the statements handle.
getStatementId() - Method in class net.esper.core.EPStatementImpl
 
getStatementId() - Method in interface net.esper.core.EPStatementSPI
Returns the statement id.
getStatementId() - Method in class net.esper.core.StatementContext
Returns the statement id.
getStatementId() - Method in class net.esper.pattern.PatternContext
Returns the statement id.
getStatementId() - Method in class net.esper.view.ViewFactoryContext
Returns the statement id.
getStatementLifecycleSvc() - Method in class net.esper.core.EPServicesContext
Returns statement lifecycle svc
getStatementLock() - Method in class net.esper.core.EPStatementHandle
Returns statement resource lock.
getStatementLock(String, String) - Method in interface net.esper.core.StatementLockFactory
Create lock for statement
getStatementLock(String, String) - Method in class net.esper.core.StatementLockFactoryImpl
 
getStatementLockFactory() - Method in class net.esper.core.EPServicesContext
Factory for statement-level locks.
getStatementName() - Method in class net.esper.core.StatementContext
Returns the statement name
getStatementName() - Method in class net.esper.pattern.PatternContext
Returns the statement name.
getStatementNames() - Method in interface net.esper.client.EPAdministrator
Returns the statement names of all started and stopped statements.
getStatementNames() - Method in class net.esper.core.EPAdministratorImpl
 
getStatementNames() - Method in interface net.esper.core.StatementLifecycleSvc
Returns an array of statement names.
getStatementNames() - Method in class net.esper.core.StatementLifecycleSvcImpl
 
getStatementSpec() - Method in class net.esper.eql.parse.EQLTreeWalker
Returns statement specification.
getStatementSpecCompiled() - Method in class net.esper.eql.expression.ExprSubselectNode
Returns the compiled statement spec.
getStatementSpecRaw() - Method in class net.esper.eql.expression.ExprSubselectNode
Returns the uncompiled statement spec.
getStatementStopService() - Method in class net.esper.core.StatementContext
Returns statement stop subscription taker.
getStatementStopService() - Method in class net.esper.view.ViewFactoryContext
Returns statement stop svc.
getStateObjectId() - Method in class net.esper.pattern.EvalStateNode
Returns the state nodes object id.
getStaticMethod() - Method in class net.esper.eql.expression.ExprStaticMethodNode
Returns the static method.
getStmtAwareListeners() - Method in class net.esper.core.EPStatementListenerSet
Returns the set of statement-aware listeners.
getStopMethod() - Method in class net.esper.core.EPStatementDesc
Returns the stop method.
getStopMethod() - Method in class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Returns the stop method.
getStream() - Method in class net.esper.eql.join.rep.Cursor
Returns current stream the event belongs to.
getStream() - Method in class net.esper.eql.join.rep.Node
Returns the stream number of the stream that supplied the event results.
getStreamAliasName() - Method in class net.esper.client.soda.SelectClauseStreamWildcard
Returns the stream alias name (e.g.
getStreamAliasName() - Method in class net.esper.eql.spec.SelectExprElementStreamCompiledSpec
Returns the stream alias (e.g.
getStreamAliasName() - Method in class net.esper.eql.spec.SelectExprElementStreamRawSpec
Returns the stream alias (e.g.
getStreamEventType() - Method in class net.esper.eql.core.PropertyResolutionDescriptor
Returns event type of the stream that the property was found in.
getStreamId() - Method in class net.esper.eql.expression.ExprIdentNode
Returns stream id supplying the property value.
getStreamId() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
Returns stream id supplying the property value.
getStreamId() - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
Returns stream id supplying the property value.
getStreamName() - Method in class net.esper.client.soda.InsertIntoClause
Returns name of stream name to use for insert-into stream.
getStreamName() - Method in class net.esper.client.soda.Stream
Returns the stream name.
getStreamName() - Method in class net.esper.eql.core.PropertyResolutionDescriptor
Returns stream name.
getStreamName() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
Returns the stream name.
getStreamName() - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
Returns the stream name.
getStreamNames() - Method in interface net.esper.eql.core.StreamTypeService
Returns an array of event stream names in the order declared.
getStreamNames() - Method in class net.esper.eql.core.StreamTypeServiceImpl
 
getStreamNum() - Method in class net.esper.eql.core.PropertyResolutionDescriptor
Returns the number of the stream the property was found in.
getStreamNum() - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Returns the stream number.
getStreamNum() - Method in class net.esper.view.ViewFactoryContext
Returns the stream number.
getStreamNumber() - Method in class net.esper.core.SubSelectHolder
Returns lookup stream number.
getStreamNumber(ExprSubselectNode) - Method in class net.esper.core.SubSelectStreamCollection
Returns stream number.
getStreamNumber() - Method in class net.esper.eql.spec.SelectExprElementStreamCompiledSpec
Returns the stream number of the stream for the stream alias.
getStreamNumber() - Method in class net.esper.pattern.PatternContext
Returns the stream number.
getStreamOrPropertyName() - Method in class net.esper.eql.expression.ExprIdentNode
For unit testing, returns stream or property name candidate.
getStreams() - Method in class net.esper.client.soda.FromClause
Returns the list of streams in the from-clause.
getStreamSelector() - Method in class net.esper.client.soda.SelectClause
Returns the stream selector.
getStreamService() - Method in class net.esper.core.EPServicesContext
Returns stream service.
getStreamSpecs() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the FROM-clause stream definitions.
getStreamSpecs() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns the FROM-clause stream definitions.
getStreamWildcardSelectList() - Method in class net.esper.client.soda.SelectClause
Returns the list of stream wildcard selectors (e.g.
getSubParams() - Method in class net.esper.client.EPPreparedStatementImpl
Returns the indexed substitution parameters.
getSubSelectExpressions() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns the list of lookup expression nodes.
getSubselects() - Method in class net.esper.eql.expression.ExprNodeSubselectVisitor
Returns a list of lookup expression nodes.
getSubstreams() - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Returns an array of stream numbers that lists all child node's stream numbers.
getSumXSq() - Method in class net.esper.view.stat.BaseStatisticsBean
For use by subclasses, returns sum (X * X).
getSumXY() - Method in class net.esper.view.stat.BaseStatisticsBean
For use by subclasses, returns sum (X * Y).
getSumYSq() - Method in class net.esper.view.stat.BaseStatisticsBean
For use by subclasses, returns sum (Y * Y).
getSuper(Class, Set<Class>) - Static method in class net.esper.eql.expression.ExprInstanceofNode
Populates all interface and superclasses for the given class, recursivly.
getSuper(Class, Set<Class>) - Static method in class net.esper.event.BeanEventType
Add the given class's implemented interfaces and superclasses to the result set of classes.
getSuperTypes() - Method in class net.esper.event.BeanEventType
 
getSuperTypes() - Method in class net.esper.event.CompositeEventType
 
getSuperTypes() - Method in interface net.esper.event.EventType
Returns an array of event types that are super to this event type, from which this event type inherited event properties.
getSuperTypes() - Method in class net.esper.event.MapEventType
 
getSuperTypes() - Method in class net.esper.event.WrapperEventType
 
getSuperTypes() - Method in class net.esper.event.xml.BaseXMLEventType
 
getTables() - Method in class net.esper.eql.join.JoinSetComposerImpl
Returns tables.
getTables() - Method in class net.esper.eql.named.NamedWindowIndexRepository
Returns a list of current index tables in the repository.
getTaggedEventTypes() - Method in class net.esper.eql.spec.PatternStreamSpecCompiled
Returns event types tagged in the pattern expression.
getTaggedEventTypes() - Method in class net.esper.event.CompositeEventType
 
getTaggedEventTypes() - Method in interface net.esper.event.TaggedCompositeEventType
Returns the event types for each composing event.
getTaggedEventTypes() - Method in class net.esper.filter.FilterSpecParamExprNode
Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)
getTagName() - Method in class net.esper.client.soda.PatternFilterExpr
Returns the tag name.
getTailView() - Method in class net.esper.eql.named.NamedWindowProcessor
Returns the tail view of the named window, hooked into the view chain after the named window's data window views, as the last view.
getText() - Method in interface net.esper.client.EPStatement
Returns the underlying expression text.
getText() - Method in enum net.esper.client.soda.OutputLimitSelector
Returns the text for the selector.
getText() - Method in enum net.esper.client.soda.OutputLimitUnit
Returns the text for the unit.
getText() - Method in class net.esper.core.EPStatementImpl
 
getText() - Method in enum net.esper.type.OuterJoinType
Returns the operator as an expression text.
getThreading() - Method in class net.esper.client.ConfigurationEngineDefaults
Returns threading settings.
getTime() - Method in class net.esper.schedule.SchedulingServiceImpl
 
getTime() - Method in interface net.esper.schedule.TimeProvider
Returns the current engine time.
getTimeInMillis() - Method in class net.esper.client.time.CurrentTimeEvent
Returns the time in milliseconds.
getTimeLastStateChange() - Method in interface net.esper.client.EPStatement
Returns the system time in milliseconds of when the statement last change state.
getTimeLastStateChange() - Method in class net.esper.core.EPStatementImpl
 
getTimerService() - Method in class net.esper.core.EPServicesContext
Returns time provider service implementation.
getTimestamp() - Method in class net.esper.eql.variable.VersionedValue
Returns the time the version was taken.
getTimestampFieldName() - Method in class net.esper.view.ext.TimeOrderView
Returns the timestamp property name.
getTimestampFieldName() - Method in class net.esper.view.window.ExternallyTimedWindowView
Returns the field name to get timestamp values from.
getTotalCells(int[]) - Static method in class net.esper.view.stat.olap.CubeDimensionHelper
Returns the number of cells in a cube that has the given dimension sizes.
getTransactionIsolation() - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Returns the connection settings for transaction isolation level.
getType() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM.XPathPropertyDesc
Returns the javax.xml.xpath.XPathConstants constant representing the event property type.
getType() - Method in class net.esper.client.ConfigurationVariable
Returns the variable type.
getType() - Method in class net.esper.client.soda.OuterJoinQualifier
Returns the type of outer join.
getType() - Method in class net.esper.eql.expression.ExprAggregateNode
 
getType() - Method in class net.esper.eql.expression.ExprAndNode
 
getType() - Method in class net.esper.eql.expression.ExprArrayNode
 
getType() - Method in class net.esper.eql.expression.ExprBetweenNode
 
getType() - Method in class net.esper.eql.expression.ExprBitWiseNode
 
getType() - Method in class net.esper.eql.expression.ExprCaseNode
 
getType() - Method in class net.esper.eql.expression.ExprCastNode
 
getType() - Method in class net.esper.eql.expression.ExprCoalesceNode
 
getType() - Method in class net.esper.eql.expression.ExprConcatNode
 
getType() - Method in class net.esper.eql.expression.ExprConstantNode
 
getType() - Method in class net.esper.eql.expression.ExprEqualsNode
 
getType() - Method in class net.esper.eql.expression.ExprIdentNode
 
getType() - Method in class net.esper.eql.expression.ExprInNode
 
getType() - Method in class net.esper.eql.expression.ExprInstanceofNode
 
getType() - Method in class net.esper.eql.expression.ExprLikeNode
 
getType() - Method in class net.esper.eql.expression.ExprMathNode
 
getType() - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
getType() - Method in class net.esper.eql.expression.ExprNotNode
 
getType() - Method in class net.esper.eql.expression.ExprOrNode
 
getType() - Method in class net.esper.eql.expression.ExprPreviousNode
 
getType() - Method in class net.esper.eql.expression.ExprPriorNode
 
getType() - Method in class net.esper.eql.expression.ExprPropertyExistsNode
 
getType() - Method in class net.esper.eql.expression.ExprRegexpNode
 
getType() - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
getType() - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
getType() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
 
getType() - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
getType() - Method in class net.esper.eql.expression.ExprSubselectExistsNode
 
getType() - Method in class net.esper.eql.expression.ExprSubselectInNode
 
getType() - Method in class net.esper.eql.expression.ExprSubselectRowNode
 
getType() - Method in class net.esper.eql.expression.ExprSubstitutionNode
 
getType() - Method in class net.esper.eql.expression.ExprTimestampNode
 
getType() - Method in interface net.esper.eql.expression.ExprValidator
Returns the type that the node's evaluate method returns an instance of.
getType() - Method in class net.esper.eql.expression.ExprVariableNode
 
getType() - Method in class net.esper.eql.variable.VariableReader
Returns the type of the variable.
getType() - Method in class net.esper.type.BoolValue
 
getType() - Method in class net.esper.type.ByteValue
 
getType() - Method in class net.esper.type.DoubleValue
 
getType() - Method in class net.esper.type.FloatValue
 
getType() - Method in class net.esper.type.IntValue
 
getType() - Method in class net.esper.type.LongValue
 
getType() - Method in interface net.esper.type.PrimitiveValue
Returns the type of primitive value this instance represents.
getType() - Method in class net.esper.type.ShortValue
 
getType() - Method in class net.esper.type.StringValue
 
getType() - Method in interface net.esper.util.DatabaseTypeBinding
Returns the Java target type.
getTypeFromStream(StreamTypeService, String, String) - Static method in class net.esper.eql.expression.ExprIdentNode
Determine stream id and property type given an unresolved property name and a stream name that may also be part of the property name.
getTypeName() - Method in class net.esper.client.soda.CastExpression
Returns the name of the type to cast to.
getTypeName() - Method in enum net.esper.type.PrimitiveValueType
Returns the name of the type.
getTypeNames() - Method in class net.esper.client.soda.InstanceOfExpression
Returns the types to compare to.
getTypes() - Method in class net.esper.event.MapEventType
Returns the name-type map of map properties.
getUnassignedExpressions() - Method in class net.esper.filter.FilterParamExprMap
Returns all expression nodes for which no filter parameter exists.
getUncommitted() - Method in class net.esper.eql.variable.VariableVersionThreadEntry
Returns a map of variable number and uncommitted value, or empty map or null if none exist
getUnderlying() - Method in class net.esper.event.BeanEventBean
 
getUnderlying() - Method in class net.esper.event.CompositeEventBean
 
getUnderlying() - Method in interface net.esper.event.EventBean
Get the underlying data object to this event wrapper.
getUnderlying() - Method in class net.esper.event.MapEventBean
 
getUnderlying() - Method in class net.esper.event.WrapperEventBean
 
getUnderlying() - Method in class net.esper.event.xml.XMLEventBean
 
getUnderlyingEvent() - Method in class net.esper.event.WrapperEventBean
Returns the wrapped event.
getUnderlyingEventType() - Method in class net.esper.event.WrapperEventType
Returns the wrapped event type.
getUnderlyingMap() - Method in class net.esper.event.WrapperEventBean
Returns the underlying map storing the additional properties, if any.
getUnderlyingMapType() - Method in class net.esper.event.WrapperEventType
Returns the map type.
getUnderlyingType() - Method in class net.esper.event.BaseConfigurableEventType
 
getUnderlyingType() - Method in class net.esper.event.BeanEventType
 
getUnderlyingType() - Method in class net.esper.event.CompositeEventType
 
getUnderlyingType() - Method in interface net.esper.event.EventType
Get the class that represents the Java type of the event type.
getUnderlyingType() - Method in class net.esper.event.MapEventType
 
getUnderlyingType() - Method in class net.esper.event.WrapperEventType
 
getUniqueFieldName() - Method in class net.esper.view.std.UniqueByPropertyView
Returns the name of the field supplying the unique value to keep the most recent record for.
getUnit() - Method in class net.esper.client.soda.OutputLimitClause
Returns the unit the frequency is in.
getUnitValues() - Method in class net.esper.schedule.ScheduleSpec
Return map of ordered set of valid schedule values for minute, hour, day, month etc.
getUnresolvedPropertyName() - Method in class net.esper.eql.expression.ExprIdentNode
For unit testing, returns unresolved property name.
getUpdateListeners() - Method in interface net.esper.client.EPListenable
Returns an iterator of update listeners.
getUpdateListeners() - Method in class net.esper.core.EPStatementImpl
 
getURI() - Method in interface net.esper.client.EPServiceProvider
Returns the provider URI, or null if this is the default provider.
getURI() - Method in class net.esper.core.EPServiceProviderImpl
 
getUrl() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the database URL to use to obtains connections.
getValidatedSubtree(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprNode
Validates the expression node subtree that has this node as root.
getValue() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
 
getValue() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashMapIterator
 
getValue() - Method in class net.esper.collection.apachecommons.AbstractKeyValue
Gets the value from the pair.
getValue() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Gets the value from the entry.
getValue() - Method in interface net.esper.collection.apachecommons.KeyValue
Gets the value from the pair.
getValue() - Method in interface net.esper.collection.apachecommons.MapIterator
Gets the current value, which is the value associated with the last key returned by next().
getValue(int) - Method in class net.esper.collection.SortedDoubleVector
Returns the value at a given index.
getValue() - Method in interface net.esper.eql.agg.AggregationMethod
Returns the current value held.
getValue(int) - Method in interface net.esper.eql.agg.AggregationResultFuture
Returns current aggregation state, for use by expression node representing an aggregation function.
getValue(int) - Method in class net.esper.eql.agg.AggregationServiceGroupAllImpl
 
getValue(int) - Method in class net.esper.eql.agg.AggregationServiceGroupByImpl
 
getValue(int) - Method in class net.esper.eql.agg.AggregationServiceNull
 
getValue() - Method in class net.esper.eql.agg.AvedevAggregator
 
getValue() - Method in class net.esper.eql.agg.AvgAggregator
 
getValue() - Method in class net.esper.eql.agg.CountAggregator
 
getValue() - Method in class net.esper.eql.agg.DistinctValueAggregator
 
getValue() - Method in class net.esper.eql.agg.DoubleSumAggregator
 
getValue() - Method in class net.esper.eql.agg.FloatSumAggregator
 
getValue() - Method in class net.esper.eql.agg.IntegerSumAggregator
 
getValue() - Method in class net.esper.eql.agg.LongSumAggregator
 
getValue() - Method in class net.esper.eql.agg.MedianAggregator
 
getValue() - Method in class net.esper.eql.agg.MinMaxAggregator
 
getValue() - Method in class net.esper.eql.agg.NonNullCountAggregator
 
getValue() - Method in class net.esper.eql.agg.NumIntegerSumAggregator
 
getValue() - Method in class net.esper.eql.agg.StddevAggregator
 
getValue() - Method in class net.esper.eql.expression.ExprConstantNode
Returns the constant's value.
getValue() - Method in class net.esper.eql.variable.VariableReader
Returns the value of a variable.
getValue() - Method in class net.esper.eql.variable.VersionedValue
Returns the value.
getValue(String, Map) - Method in class net.esper.event.MapEventType
Returns the value of the given property, allowing nested property names.
getValue(ResultSet, String) - Method in interface net.esper.util.DatabaseTypeBinding
Returns the Java object for the given column.
getValue() - Method in class net.esper.util.PlaceholderParser.Fragment
Returns the string text of the fragment.
getValue() - Method in interface net.esper.view.stat.olap.Cell
Returns the value.
getValue() - Method in class net.esper.view.stat.olap.CellImpl
 
GETVALUE_INVALID - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
Message.
getValueObject() - Method in class net.esper.type.BoolValue
 
getValueObject() - Method in class net.esper.type.ByteValue
 
getValueObject() - Method in class net.esper.type.DoubleValue
 
getValueObject() - Method in class net.esper.type.FloatValue
 
getValueObject() - Method in class net.esper.type.IntValue
 
getValueObject() - Method in class net.esper.type.LongValue
 
getValueObject() - Method in interface net.esper.type.PrimitiveValue
Returns a value object.
getValueObject() - Method in class net.esper.type.ShortValue
 
getValueObject() - Method in class net.esper.type.StringValue
 
getValues() - Method in class net.esper.collection.SortedDoubleVector
Returns underlying ArrayList, for testing purposes only.
getValues() - Method in interface net.esper.view.stat.olap.DimensionMember
Returns member values.
getValues() - Method in class net.esper.view.stat.olap.DimensionMemberImpl
 
getValueSet(MatchedEventMap) - Method in class net.esper.filter.FilterSpecCompiled
Returns the values for the filter, using the supplied result events to ask filter parameters for the value to filter for.
getValuesInRange(int, int) - Method in class net.esper.type.CronParameter
 
getValuesInRange(int, int) - Method in class net.esper.type.FrequencyParameter
 
getValuesInRange(int, int) - Method in class net.esper.type.IntParameter
 
getValuesInRange(int, int) - Method in class net.esper.type.ListParameter
 
getValuesInRange(int, int) - Method in interface net.esper.type.NumberSetParameter
Return a set of int values representing the value of the parameter for the given range.
getValuesInRange(int, int) - Method in class net.esper.type.RangeParameter
 
getValuesInRange(int, int) - Method in class net.esper.type.WildcardParameter
 
getValueType() - Method in interface net.esper.eql.agg.AggregationMethod
Returns the type of the current value.
getValueType() - Method in class net.esper.eql.agg.AvedevAggregator
 
getValueType() - Method in class net.esper.eql.agg.AvgAggregator
 
getValueType() - Method in class net.esper.eql.agg.CountAggregator
 
getValueType() - Method in class net.esper.eql.agg.DistinctValueAggregator
 
getValueType() - Method in class net.esper.eql.agg.DoubleSumAggregator
 
getValueType() - Method in class net.esper.eql.agg.FloatSumAggregator
 
getValueType() - Method in class net.esper.eql.agg.IntegerSumAggregator
 
getValueType() - Method in class net.esper.eql.agg.LongSumAggregator
 
getValueType() - Method in class net.esper.eql.agg.MedianAggregator
 
getValueType() - Method in class net.esper.eql.agg.MinMaxAggregator
 
getValueType() - Method in class net.esper.eql.agg.NonNullCountAggregator
 
getValueType() - Method in class net.esper.eql.agg.NumIntegerSumAggregator
 
getValueType() - Method in class net.esper.eql.agg.StddevAggregator
 
getVariableName() - Method in class net.esper.client.soda.CreateVariableClause
Returns the variable name.
getVariableName() - Method in class net.esper.eql.expression.ExprVariableNode
Returns the name of the variable.
getVariableName() - Method in class net.esper.eql.spec.CreateVariableDesc
Returns the variable name
getVariableName() - Method in class net.esper.eql.spec.OnTriggerSetAssignment
Returns the variable name
getVariableName() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the variable name if set, or null if a fixed rate
getVariableNumber() - Method in class net.esper.eql.variable.VariableReader
Returns the variable number.
getVariables() - Method in class net.esper.client.Configuration
 
getVariables() - Method in class net.esper.client.ConfigurationEngineDefaults
Returns engine defaults applicable to variables.
getVariables() - Method in interface net.esper.client.ConfigurationInformation
Returns the variables by name as key and type plus initialization value as value
getVariableService() - Method in class net.esper.core.EPServicesContext
Returns the variable service.
getVariableService() - Method in class net.esper.core.StatementContext
Returns variable service.
getVariableService() - Method in class net.esper.eql.spec.StatementSpecMapContext
Returns the variable service.
getVariableType() - Method in class net.esper.client.soda.CreateVariableClause
Returns the variable type name.
getVariableType() - Method in class net.esper.eql.spec.CreateVariableDesc
Returns the variable type.
getVersion() - Method in class net.esper.eql.variable.VariableVersionThreadEntry
Returns the version visible for a thread.
getVersion() - Method in class net.esper.eql.variable.VersionedValue
Returns the version.
getVersion(int) - Method in class net.esper.eql.variable.VersionedValueList
Retrieve a value for the given version or older then then given version.
getViewable() - Method in class net.esper.core.SubSelectHolder
Returns the lookup child viewable.
getViewFactoryChain() - Method in class net.esper.core.SubSelectHolder
Returns the lookup view factory chain
getViewFactoryChain(ExprSubselectNode) - Method in class net.esper.core.SubSelectStreamCollection
Returns the lookup's view factory chain.
getViewFactoryChain() - Method in class net.esper.view.ViewFactoryChain
Returns the chain of view factories.
getViewName() - Method in class net.esper.view.ViewFactoryContext
Returns the view name.
getViewNum() - Method in class net.esper.view.ViewFactoryContext
Returns the view number
getViewResolutionService() - Method in class net.esper.core.StatementContext
Returns view resolution svc.
getViewResources() - Method in class net.esper.client.ConfigurationEngineDefaults
Returns view resources defaults.
getViews() - Method in class net.esper.client.soda.CreateWindowClause
Returns the views onto the named window.
getViews() - Method in class net.esper.client.soda.ProjectedStream
Returns the list of views added to the stream.
getViews() - Method in class net.esper.eql.core.MethodPollingViewable
 
getViews() - Method in class net.esper.eql.db.DatabasePollingViewable
 
getViews() - Method in interface net.esper.view.Viewable
Returns all added views.
getViews() - Method in class net.esper.view.ViewSupport
 
getViews() - Method in class net.esper.view.ZeroDepthStream
 
getViewService() - Method in class net.esper.core.EPServicesContext
Returns services for view creation, sharing and removal.
getViewSpecs() - Method in class net.esper.eql.spec.CreateWindowDesc
Returns the view specifications.
getViewSpecs() - Method in interface net.esper.eql.spec.StreamSpec
Returns views definitions onto the stream
getViewSpecs() - Method in class net.esper.eql.spec.StreamSpecBase
Returns view definitions to use to construct views to derive data on stream.
getViewUpdatedCollection() - Method in class net.esper.view.window.KeepAllView
Returns the (optional) collection handling random access to window contents for prior or previous events.
getViewUpdatedCollection() - Method in class net.esper.view.window.LengthWindowView
Returns the (optional) collection handling random access to window contents for prior or previous events.
getViewUpdatedCollection() - Method in class net.esper.view.window.TimeWindowView
Returns the (optional) collection handling random access to window contents for prior or previous events.
getWhereClause() - Method in class net.esper.client.soda.EPStatementObjectModel
Return the where-clause, or null to indicate that the clause is absent.
getWindowName() - Method in class net.esper.client.soda.CreateWindowClause
Returns the window name.
getWindowName() - Method in class net.esper.client.soda.OnDeleteClause
Returns the name of the named window to delete from.
getWindowName() - Method in class net.esper.client.soda.OnSelectClause
Returns the name of the named window to delete from.
getWindowName() - Method in class net.esper.eql.spec.CreateWindowDesc
Returns the window name.
getWindowName() - Method in class net.esper.eql.spec.NamedWindowConsumerStreamSpec
Returns the window name.
getWindowName() - Method in class net.esper.eql.spec.OnTriggerWindowDesc
Returns the window name.
getXAverage() - Method in class net.esper.view.stat.BaseStatisticsBean
Returns the average of all X data points.
getXpath() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM.XPathPropertyDesc
Returns the XPath expression.
getXPathFactory() - Method in class net.esper.event.xml.BaseXMLEventType
Returns the XPath factory used.
getXPathProperties() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns a map of property name and descriptor for XPath-expression properties.
getXStandardDeviationPop() - Method in class net.esper.view.stat.BaseStatisticsBean
Calculates standard deviation for X based on the entire population given as arguments.
getXStandardDeviationSample() - Method in class net.esper.view.stat.BaseStatisticsBean
Calculates standard deviation for X based on the sample data points supplied.
getXSum() - Method in class net.esper.view.stat.BaseStatisticsBean
Returns the sum of all X data points.
getXVariance() - Method in class net.esper.view.stat.BaseStatisticsBean
Calculates standard deviation for X based on the sample data points supplied.
getYAverage() - Method in class net.esper.view.stat.BaseStatisticsBean
Returns the average of all Y data points.
getYIntercept() - Method in class net.esper.view.stat.RegressionBean
Returns the Y intercept.
getYStandardDeviationPop() - Method in class net.esper.view.stat.BaseStatisticsBean
Calculates standard deviation for Y based on the entire population given as arguments.
getYStandardDeviationSample() - Method in class net.esper.view.stat.BaseStatisticsBean
Calculates standard deviation for Y based on the sample data points supplied.
getYSum() - Method in class net.esper.view.stat.BaseStatisticsBean
Returns the sum of all Y data points.
getYVariance() - Method in class net.esper.view.stat.BaseStatisticsBean
Calculates standard deviation for Y based on the sample data points supplied.
graphOuterJoins(int, List<OuterJoinDesc>) - Static method in class net.esper.eql.join.plan.NStreamOuterQueryPlanBuilder
Builds a graph of outer joins given the outer join information from the statement.
GROUP - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GROUP - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
GROUP_BY_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GROUP_BY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
GroupByClause - Class in net.esper.client.soda
The group-by clause consists of a list of expressions that provide the grouped-by values.
GroupByClause() - Constructor for class net.esper.client.soda.GroupByClause
Ctor - for use to create an expression tree, without child expression.
GroupByClause(String...) - Constructor for class net.esper.client.soda.GroupByClause
Ctor.
GroupByClause(Expression...) - Constructor for class net.esper.client.soda.GroupByClause
Ctor.
groupByClause(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
groupByListExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
GroupByView - Class in net.esper.view.std
The group view splits the data in a stream to multiple subviews, based on a key index.
GroupByView(StatementContext, String[]) - Constructor for class net.esper.view.std.GroupByView
Constructor.
GroupByViewFactory - Class in net.esper.view.std
Factory for GroupByView instances.
GroupByViewFactory() - Constructor for class net.esper.view.std.GroupByViewFactory
 
groupFieldNames - Variable in class net.esper.view.std.GroupByViewFactory
List of group-by field names.
gt(String, Object) - Static method in class net.esper.client.soda.Expressions
Greater-then between a property and a constant.
gt(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Greater-then between expression results.
GT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
gtProperty(String, String) - Static method in class net.esper.client.soda.Expressions
Greater-then between properties.
guard(String, String, Object[], PatternExpr) - Static method in class net.esper.client.soda.Patterns
Guard pattern expression guards a sub-expression, equivalent to the "every MyEvent where timer:within(1 sec)" syntax
Guard - Interface in net.esper.pattern.guard
Guard instances inspect a matched events and makes a determination on whether to let it pass or not.
GUARD_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GUARD_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
GuardEnum - Enum in net.esper.pattern.guard
Enum for all build-in guards.
guardExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
GuardFactory - Interface in net.esper.pattern.guard
Interface for a factory for Guard instances.
GuardFactorySupport - Class in net.esper.pattern.guard
Abstract class for applications to extend to implement pattern guard objects.
GuardFactorySupport() - Constructor for class net.esper.pattern.guard.GuardFactorySupport
 
GuardParameterException - Exception in net.esper.pattern.guard
Thrown to indicate a validation error in guard parameterization.
GuardParameterException(String) - Constructor for exception net.esper.pattern.guard.GuardParameterException
Ctor.
guardPostFix() - Method in class net.esper.eql.generated.EQLStatementParser
 
guardQuit() - Method in class net.esper.pattern.EvalGuardStateNode
 
guardQuit() - Method in interface net.esper.pattern.guard.Quitable
Indicate guard quitted.
GuardSupport - Class in net.esper.pattern.guard
Abstract class for applications to extend to implement a pattern guard.
GuardSupport() - Constructor for class net.esper.pattern.guard.GuardSupport
 

H

handleMatching(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowOnDeleteView
 
handleMatching(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowOnExprBaseView
Implemented by on-trigger views to action on the combination of trigger and matching events in the named window.
handleMatching(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowOnSelectView
 
HARD - Static variable in class net.esper.collection.apachecommons.AbstractReferenceMap
Constant indicating that hard references should be used
hasData() - Method in class net.esper.core.PatternListenerDispatch
Returns true if at least one event has been added.
hash(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the hash code for the key specified.
hashCode() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
 
hashCode() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the standard Map hashCode.
hashCode - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
The hash code of the key
hashCode() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
 
hashCode() - Method in class net.esper.collection.apachecommons.AbstractMapEntry
Gets a hashCode compatible with the equals method.
hashCode() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Gets the hashcode of the entry using temporary hard references.
hashCode() - Method in class net.esper.collection.InterchangeablePair
 
hashCode() - Method in class net.esper.collection.MultiKey
 
hashCode() - Method in class net.esper.collection.MultiKeyUntyped
 
hashCode() - Method in class net.esper.collection.Pair
 
hashCode() - Method in class net.esper.collection.UniformPair
 
hashCode() - Method in class net.esper.core.EPStatementHandle
 
hashCode() - Method in class net.esper.eql.join.plan.QueryGraphKey
 
hashCode() - Method in class net.esper.eql.lookup.JoinedPropDesc
 
hashCode() - Method in class net.esper.eql.spec.ObjectSpec
 
hashCode() - Method in class net.esper.event.CompositeEventType
 
hashCode() - Method in class net.esper.event.EventPropertyDescriptor
 
hashCode() - Method in class net.esper.event.MapEventType
 
hashCode() - Method in class net.esper.event.WrapperEventType
 
hashCode() - Method in class net.esper.event.xml.BaseXMLEventType
 
hashCode() - Method in class net.esper.filter.DoubleRange
 
hashCode() - Method in class net.esper.filter.FilterSpecCompiled
 
hashCode() - Method in class net.esper.filter.FilterSpecParam
 
hashCode() - Method in class net.esper.filter.FilterSpecParamConstant
 
hashCode() - Method in class net.esper.filter.FilterSpecParamEventProp
 
hashCode() - Method in class net.esper.filter.FilterSpecParamExprNode
 
hashCode() - Method in class net.esper.filter.FilterSpecParamIn
 
hashCode() - Method in class net.esper.filter.FilterSpecParamRange
 
hashCode() - Method in class net.esper.filter.InSetOfValuesConstant
 
hashCode() - Method in class net.esper.filter.InSetOfValuesEventProp
 
hashCode() - Method in class net.esper.filter.RangeValueDouble
 
hashCode() - Method in class net.esper.filter.RangeValueEventProp
 
hashCode() - Method in class net.esper.pattern.EvalNodeNumber
 
hashCode() - Method in class net.esper.pattern.MatchedEventMapImpl
 
hashCode() - Method in class net.esper.schedule.ScheduleSlot
 
hashCode() - Method in class net.esper.schedule.ScheduleSpec
 
hashCode() - Method in class net.esper.type.TimePeriodParameter
 
hashCode() - Method in class net.esper.util.PlaceholderParser.Fragment
 
hashEntry(Object, Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Gets the hash code for a MapEntry.
hashIndex(int, int) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the index into the data storage for the hashCode specified.
hashIndex - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
The current index into the array of buckets
hasMoreElements() - Method in class net.esper.collection.NumberSetPermutationEnumeration
 
hasMoreElements() - Method in class net.esper.collection.PermutationEnumeration
 
hasNext() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
 
hasNext() - Method in interface net.esper.collection.apachecommons.MapIterator
Checks to see if there are more entries still to be iterated.
hasNext() - Method in class net.esper.collection.ArrayEventIterator
 
hasNext() - Method in class net.esper.collection.IterablesListIterator
 
hasNext() - Method in class net.esper.collection.NullIterator
 
hasNext() - Method in class net.esper.collection.SafeIteratorImpl
 
hasNext() - Method in class net.esper.collection.SingleEventIterator
 
hasNext() - Method in class net.esper.collection.SingleObjectIterator
 
hasNext() - Method in class net.esper.collection.TimeWindowIterator
 
hasNext() - Method in class net.esper.collection.TransformEventIterator
 
hasNext() - Method in class net.esper.eql.core.ResultSetAggregateAllIterator
 
hasNext() - Method in class net.esper.eql.core.ResultSetAggregateGroupedIterator
 
hasNext() - Method in class net.esper.eql.core.ResultSetRowPerGroupIterator
 
hasNext() - Method in class net.esper.eql.join.rep.NodeCursorIterator
 
hasNext() - Method in class net.esper.eql.join.rep.SingleCursorIterator
 
hasNext() - Method in class net.esper.eql.join.table.PropertyIndexedEventTableIterator
 
hasNext() - Method in class net.esper.eql.view.FilterExprViewIterator
 
hasNext() - Method in class net.esper.util.DOMElementIterator
 
hasNext() - Method in class net.esper.view.ext.SortWindowIterator
 
hasNext() - Method in class net.esper.view.ext.TimeOrderViewIterator
 
hasRequiredStream() - Method in class net.esper.eql.join.exec.LookupInstructionExec
Returns true if there is one or more required substreams or false if no substreams are required joins.
hasViews() - Method in class net.esper.eql.core.MethodPollingViewable
 
hasViews() - Method in class net.esper.eql.db.DatabasePollingViewable
 
hasViews() - Method in interface net.esper.view.Viewable
Test is there are any views to the Viewable.
hasViews() - Method in class net.esper.view.ViewSupport
 
hasViews() - Method in class net.esper.view.ZeroDepthStream
 
HAVING - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
HAVING - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
HAVING_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
HAVING_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
havingClause(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
havingClause() - Method in class net.esper.eql.generated.EQLStatementParser
 
HEX_DIGIT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
HEX_DIGIT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
HIGH_WATERMARK_VERSIONS - Static variable in class net.esper.eql.variable.VariableServiceImpl
Applicable for each variable if more then the number of versions accumulated, check timestamps to determine if a version can be expired.
HistoricalDataQueryStrategy - Class in net.esper.eql.join
Query strategy for use with HistoricalEventViewable to perform lookup for a given stream using the poll method on a viewable.
HistoricalDataQueryStrategy(int, int, HistoricalEventViewable, boolean, ExprEqualsNode, HistoricalIndexLookupStrategy, PollResultIndexingStrategy) - Constructor for class net.esper.eql.join.HistoricalDataQueryStrategy
Ctor.
HistoricalEventViewable - Interface in net.esper.view
Interface for views that poll data based on information from other streams.
HistoricalIndexLookupStrategy - Interface in net.esper.eql.join
Strategy for use in poll-based joins to reduce a cached result set (represented by EventTable), in which the cache result set may have been indexed, to fewer rows following the join-criteria in a where clause.
HistoricalIndexLookupStrategyIndex - Class in net.esper.eql.join
Index lookup strategy into a poll-based cache result.
HistoricalIndexLookupStrategyIndex(EventType, String[]) - Constructor for class net.esper.eql.join.HistoricalIndexLookupStrategyIndex
Ctor.
HistoricalIndexLookupStrategyNoIndex - Class in net.esper.eql.join
Full table scan strategy for a poll-based cache result.
HistoricalIndexLookupStrategyNoIndex() - Constructor for class net.esper.eql.join.HistoricalIndexLookupStrategyNoIndex
 
HOUR_PART - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
HOUR_PART - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
hourPart(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
hourPart() - Method in class net.esper.eql.generated.EQLStatementParser
 

I

IDENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IDENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
imports - Variable in class net.esper.client.Configuration
The java-style class and package name imports that will be used to resolve partial class names.
in(String, Object...) - Static method in class net.esper.client.soda.Expressions
In-expression that is equivalent to the syntax of "property in (value, value, ...
in(Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
In-expression that is equivalent to the syntax of "property in (value, value, ...
IN_RANGE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IN_RANGE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
IN_SET - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IN_SET - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
IN_SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IN_SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
IN_SUBSELECT_QUERY_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IN_SUBSELECT_QUERY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
INC - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INC - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
incrIndent() - Method in class net.esper.util.IndentWriter
Increase the indentation one level.
Indent - Class in net.esper.util
Utility class around indenting and formatting text.
Indent() - Constructor for class net.esper.util.Indent
 
indent(int) - Static method in class net.esper.util.Indent
Utility method to indent a text for a number of characters.
IndentWriter - Class in net.esper.util
Writer that uses an underlying PrintWriter to indent output text for easy reading.
IndentWriter(PrintWriter, int, int) - Constructor for class net.esper.util.IndentWriter
Ctor.
index(List<EventBean>, boolean) - Method in interface net.esper.eql.join.PollResultIndexingStrategy
Build and index of a poll result.
index(List<EventBean>, boolean) - Method in class net.esper.eql.join.PollResultIndexingStrategyIndex
 
index(List<EventBean>, boolean) - Method in class net.esper.eql.join.PollResultIndexingStrategyIndexCoerce
 
index(List<EventBean>, boolean) - Method in class net.esper.eql.join.PollResultIndexingStrategyNoIndex
 
index - Variable in class net.esper.eql.lookup.IndexedTableLookupStrategy
Index to look up in.
IndexedDataCollection - Class in net.esper.collection
Collection to hold indexed data.
IndexedDataCollection() - Constructor for class net.esper.collection.IndexedDataCollection
 
IndexedProperty - Class in net.esper.event.property
Represents an indexed property or array property, ie.
IndexedProperty(String, int) - Constructor for class net.esper.event.property.IndexedProperty
Ctor.
IndexedTableLookupPlan - Class in net.esper.eql.join.plan
Plan to perform an indexed table lookup.
IndexedTableLookupPlan(int, int, int, String[]) - Constructor for class net.esper.eql.join.plan.IndexedTableLookupPlan
Ctor.
IndexedTableLookupStrategy - Class in net.esper.eql.join.exec
Lookup on an index using a set of properties as key values.
IndexedTableLookupStrategy(EventType, String[], PropertyIndexedEventTable) - Constructor for class net.esper.eql.join.exec.IndexedTableLookupStrategy
Ctor.
IndexedTableLookupStrategy - Class in net.esper.eql.lookup
Index lookup strategy for subqueries.
IndexedTableLookupStrategy(EventType[], int[], String[], PropertyIndexedEventTable) - Constructor for class net.esper.eql.lookup.IndexedTableLookupStrategy
Ctor.
IndexedTableLookupStrategyCoercing - Class in net.esper.eql.lookup
Index lookup strategy that coerces the key values before performing a lookup.
IndexedTableLookupStrategyCoercing(EventType[], int[], String[], PropertyIndexedEventTable, Class[]) - Constructor for class net.esper.eql.lookup.IndexedTableLookupStrategyCoercing
Ctor.
IndexFactory - Class in net.esper.filter
Factory for FilterParamIndexBase instances based on event property name and filter operator type.
IndexFactory() - Constructor for class net.esper.filter.IndexFactory
 
IndexHelper - Class in net.esper.filter
Utility class for matching filter parameters to indizes.
IndexHelper() - Constructor for class net.esper.filter.IndexHelper
 
IndexTreeBuilder - Class in net.esper.filter
Builder manipulates a tree structure consisting of FilterHandleSetNode and FilterParamIndexBase instances.
IndexTreeBuilder() - Constructor for class net.esper.filter.IndexTreeBuilder
Constructor.
IndexTreePath - Class in net.esper.filter
Encapsulates the information required by IndexTreeBuilder to maintain the filter parameter tree structure when filters are added and removed from the tree.
IndexTreePath() - Constructor for class net.esper.filter.IndexTreePath
Constructor.
inExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
InExpression - Class in net.esper.client.soda
In-expresson checks that a value is in (or not in) a set of values, equivalent to the syntax "color in ('red', 'blue')".
InExpression(boolean) - Constructor for class net.esper.client.soda.InExpression
Ctor - for use to create an expression tree, without child expression.
InExpression(Expression, boolean, Object...) - Constructor for class net.esper.client.soda.InExpression
Ctor - for use to create an expression tree, without child expression.
INFO - Static variable in class net.esper.util.ThreadLogUtil
Set info log level.
info(String, Object...) - Static method in class net.esper.util.ThreadLogUtil
If enabled, logs for info level the given objects and text
init(String, Properties, EPServiceProviderSPI) - Method in interface net.esper.adapter.AdapterLoader
Initializes the adapter loader.
init() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Initialise subclasses during construction, cloning or deserialization.
init() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Initialise this subclass during construction, cloning or deserialization.
init(EventAdapterService, ConfigurationInformation) - Static method in class net.esper.core.EPServicesContextFactoryDefault
Initialize event adapter service for config snapshot.
init() - Method in interface net.esper.core.ExtensionServicesContext
Invoked to initialize extension services after engine services initialization.
init() - Method in interface net.esper.core.StatementLifecycleSvc
Initialized the service before use.
init() - Method in class net.esper.core.StatementLifecycleSvcImpl
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Provides results to assembly nodes for initialization.
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.BranchOptionalAssemblyNode
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.BranchRequiredAssemblyNode
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.LeafAssemblyNode
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.RootCartProdAssemblyNode
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.RootOptionalAssemblyNode
 
init(List<Node>[]) - Method in class net.esper.eql.join.assemble.RootRequiredAssemblyNode
 
init(EventBean[][]) - Method in interface net.esper.eql.join.JoinSetComposer
Provides initialization events per stream to composer to populate join indexes, if required
init(EventBean[][]) - Method in class net.esper.eql.join.JoinSetComposerImpl
 
InitializableView - Interface in net.esper.view
Views that require initialization after view instantiation and after view hook-up with the parent view can impleeent this interface and get invoked to initialize.
initialize() - Method in interface net.esper.client.EPServiceProvider
Frees any resources associated with this runtime instance, and leaves the engine instance ready for further use.
initialize() - Method in class net.esper.core.EPServiceProviderImpl
 
initialize() - Method in class net.esper.core.EPServicesContext
Destroy services.
initialize() - Method in interface net.esper.view.InitializableView
Initializes a view.
initVariables(VariableService, Map<String, ConfigurationVariable>) - Static method in class net.esper.core.EPServicesContextFactoryDefault
Adds configured variables to the variable service.
INSERT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INSERT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
insert(EventBean) - Method in interface net.esper.view.EventStream
Insert a new event onto the stream.
insert(EventBean) - Method in class net.esper.view.ZeroDepthStream
 
INSERTINTO_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INSERTINTO_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
INSERTINTO_EXPRCOL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INSERTINTO_EXPRCOL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
INSERTINTO_STREAM_NAME - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INSERTINTO_STREAM_NAME - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
InsertIntoClause - Class in net.esper.client.soda
An insert-into clause consists of a stream name and column names and an optional stream selector.
InsertIntoClause(String) - Constructor for class net.esper.client.soda.InsertIntoClause
Ctor.
InsertIntoClause(String, String[]) - Constructor for class net.esper.client.soda.InsertIntoClause
Ctor.
InsertIntoClause(String, List<String>, boolean) - Constructor for class net.esper.client.soda.InsertIntoClause
Ctor.
insertIntoColumnList() - Method in class net.esper.eql.generated.EQLStatementParser
 
InsertIntoDesc - Class in net.esper.eql.spec
Descriptor generated by INSERT-INTO clauses specified in expressions to insert the results of statement as a stream to further statements.
InsertIntoDesc(boolean, String) - Constructor for class net.esper.eql.spec.InsertIntoDesc
Ctor.
insertIntoExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
insertIntoExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
insertIntoExprCol(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
InsertIntoLatchFactory - Class in net.esper.core
Class to hold a current latch per statement that uses an insert-into stream (per statement and insert-into stream relationship).
InsertIntoLatchFactory(String, long, ConfigurationEngineDefaults.Threading.Locking) - Constructor for class net.esper.core.InsertIntoLatchFactory
Ctor.
InsertIntoLatchSpin - Class in net.esper.core
A spin-locking implementation of a latch for use in guaranteeing delivery between a single event produced by a single statement and consumable by another statement.
InsertIntoLatchSpin(InsertIntoLatchSpin, long, Object) - Constructor for class net.esper.core.InsertIntoLatchSpin
Ctor.
InsertIntoLatchSpin() - Constructor for class net.esper.core.InsertIntoLatchSpin
Ctor - use for the first and unused latch to indicate completion.
InsertIntoLatchWait - Class in net.esper.core
A suspend-and-notify implementation of a latch for use in guaranteeing delivery between a single event produced by a single statement and consumable by another statement.
InsertIntoLatchWait(InsertIntoLatchWait, long, Object) - Constructor for class net.esper.core.InsertIntoLatchWait
Ctor.
InsertIntoLatchWait() - Constructor for class net.esper.core.InsertIntoLatchWait
Ctor - use for the first and unused latch to indicate completion.
InSetOfValuesConstant - Class in net.esper.filter
Constant value in a list of values following an in-keyword.
InSetOfValuesConstant(Object) - Constructor for class net.esper.filter.InSetOfValuesConstant
Ctor.
InSetOfValuesEventProp - Class in net.esper.filter
Event property value in a list of values following an in-keyword.
InSetOfValuesEventProp(String, String, boolean, Class) - Constructor for class net.esper.filter.InSetOfValuesEventProp
Ctor.
inspect(int, List<ViewFactory>, StatementContext) - Method in class net.esper.eql.named.NotADataWindowViewCapability
 
inspect(int, List<ViewFactory>, StatementContext) - Method in class net.esper.eql.named.RemoveStreamViewCapability
 
inspect(MatchedEventMap) - Method in interface net.esper.pattern.guard.Guard
Returns true if inspection shows that the match events can pass, or false to not pass.
inspect(MatchedEventMap) - Method in class net.esper.pattern.guard.TimerWithinGuard
 
inspect(int, List<ViewFactory>, StatementContext) - Method in interface net.esper.view.ViewCapability
Inspect view factories returning false to indicate that view factories do not meet view resource requirements, or true to indicate view capability and view factories can be compatible.
inspect(int, List<ViewFactory>, StatementContext) - Method in class net.esper.view.ViewCapDataWindowAccess
 
inspect(int, List<ViewFactory>, StatementContext) - Method in class net.esper.view.ViewCapPriorEventAccess
 
INSTANCE - Static variable in class net.esper.collection.apachecommons.EmptyIterator
Singleton instance of the iterator.
INSTANCE - Static variable in class net.esper.collection.apachecommons.EmptyMapIterator
Singleton instance of the iterator.
instanceOf(Expression, String, String...) - Static method in class net.esper.client.soda.Expressions
Instance-of function, tests if the type of the return value of an expression is in a list of types.
instanceOf(String, String, String...) - Static method in class net.esper.client.soda.Expressions
Instance-of function, tests if the type of the return value of a property is in a list of types.
INSTANCEOF - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INSTANCEOF - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
InstanceOfExpression - Class in net.esper.client.soda
Instance-of expression checks if an expression returns a certain type.
InstanceOfExpression(String[]) - Constructor for class net.esper.client.soda.InstanceOfExpression
Ctor - for use to create an expression tree, without child expression.
InstanceOfExpression(Expression, String, String...) - Constructor for class net.esper.client.soda.InstanceOfExpression
Ctor.
instantiateChain(Viewable, List<ViewFactory>, StatementContext) - Static method in class net.esper.view.ViewServiceHelper
Instantiate a chain of views.
instantiateFactories(int, List<ViewSpec>, StatementContext) - Static method in class net.esper.view.ViewServiceHelper
Given a list of view specifications obtained from by parsing this method instantiates a list of view factories.
inSubSelectQuery() - Method in class net.esper.eql.generated.EQLStatementParser
 
INT_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INT_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
IntegerSumAggregator - Class in net.esper.eql.agg
Sum for integer values.
IntegerSumAggregator() - Constructor for class net.esper.eql.agg.IntegerSumAggregator
 
InterchangeablePair<First,Second> - Class in net.esper.collection
General-purpose pair of values of any type.
InterchangeablePair(First, Second) - Constructor for class net.esper.collection.InterchangeablePair
Construct pair of values.
internalDispatch() - Method in class net.esper.core.EPStatementHandle
Invoked by EPRuntime to indicate that a statements's filer and schedule processing is done, and now it's time to process join results.
InternalEventRouter - Interface in net.esper.core
Interface for a service that routes events within the engine for further processing.
InternalRouteView - Class in net.esper.eql.view
View for internally routing events which is commenly the last step in execution of a statement in which an insert-into clause has been specified.
InternalRouteView(boolean, InternalEventRouter, EPStatementHandle) - Constructor for class net.esper.eql.view.InternalRouteView
Ctor.
intervalSize - Variable in class net.esper.view.ext.TimeOrderViewFactory
The interval to wait for newer events to arrive.
INTO - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INTO - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
IntParameter - Class in net.esper.type
Parameter supplying a single int value is a set of numbers.
IntParameter(int) - Constructor for class net.esper.type.IntParameter
Ctor.
introspect(Class) - Static method in class net.esper.event.property.PropertyHelper
Using the Java Introspector class the method returns the property descriptors obtained through introspection.
IntValue - Class in net.esper.type
Placeholder for an integer value in an event expression.
IntValue() - Constructor for class net.esper.type.IntValue
Constructor.
IntValue(Integer) - Constructor for class net.esper.type.IntValue
Constructor.
invoke(String, Object[], String[]) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
 
invoke(String, Object[], String[]) - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
invokeConstructor(Class, Object[]) - Static method in class net.esper.util.ConstructorHelper
Find and invoke constructor matching the argument number and types returning an instance of given class.
invokeParseRule(EQLStatementParser) - Method in interface net.esper.eql.parse.ParseRuleSelector
Implementations can invoke a parse rule of their choice on the parser.
invokeWalkRule(EQLBaseWalker, AST) - Method in interface net.esper.eql.parse.WalkRuleSelector
Implementations can invoke a walk rule of their choice on the walker and AST passed in.
IS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
isActive() - Method in interface net.esper.eql.db.DataCache
Returns true if the cache is active and currently caching, or false if the cache is inactive and not currently caching
isActive() - Method in class net.esper.eql.db.DataCacheExpiringImpl
 
isActive() - Method in class net.esper.eql.db.DataCacheLRUImpl
 
isActive() - Method in class net.esper.eql.db.DataCacheNullImpl
 
isAssignmentCompatible(Class, Class) - Static method in class net.esper.util.JavaClassHelper
Returns true if 2 classes are assignment compatible.
isBoolean(Class) - Static method in class net.esper.util.JavaClassHelper
Determines if the class passed in is a boolean boxed or unboxed type.
isCanSelfJoin() - Method in class net.esper.core.EPStatementHandle
Returns true if the statement potentially self-joins amojng the events it processes.
isCase2() - Method in class net.esper.eql.expression.ExprCaseNode
Returns true if this is a switch-type case.
isComparisonOperator() - Method in enum net.esper.filter.FilterOperator
Returns true for relational comparison operators which excludes the = equals operator, else returns false.
isCompatibleWrapper(EventType, EventType, Map<String, Class>) - Static method in class net.esper.event.EventAdapterServiceImpl
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.
isCompleted() - Method in class net.esper.core.InsertIntoLatchSpin
Returns true if the dispatch completed for this future.
isCompleted() - Method in class net.esper.core.InsertIntoLatchWait
Returns true if the dispatch completed for this future.
isCompleted() - Method in class net.esper.core.UpdateDispatchFutureSpin
Returns true if the dispatch completed for this future.
isCompleted() - Method in class net.esper.core.UpdateDispatchFutureWait
Returns true if the dispatch completed for this future.
isConstantResult() - Method in class net.esper.eql.expression.ExprAggregateNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprAndNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprArrayNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprBetweenNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprBitWiseNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprCaseNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprCastNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprCoalesceNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprConcatNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprConstantNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprEqualsNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprIdentNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprInNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprInstanceofNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprLikeNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprMathNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprNode
Returns true if the expression node's evaluation value doesn't depend on any events data, as must be determined at validation time, which is bottom-up and therefore reliably allows each node to determine constant value.
isConstantResult() - Method in class net.esper.eql.expression.ExprNotNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprOrNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprPreviousNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprPriorNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprPropertyExistsNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprRegexpNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprSubselectNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprSubstitutionNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprTimestampNode
 
isConstantResult() - Method in class net.esper.eql.expression.ExprVariableNode
 
isDebugEnabled - Static variable in class net.esper.util.ExecutionPathDebugLog
Public access.
isDescending() - Method in class net.esper.client.soda.OrderByElement
Returns true for descending sorts for this column, false for ascending sort.
isDescending() - Method in class net.esper.eql.spec.OrderByItem
Returns true for ascending, false for descending.
isDescendingValues - Variable in class net.esper.view.ext.SortWindowViewFactory
The flags defining the ascending or descending sort order.
isDestroyed() - Method in interface net.esper.client.EPServiceProvider
Returns true if the service is in destroyed state, or false if not.
isDestroyed() - Method in interface net.esper.client.EPStatement
Returns true if the statement state is destroyed.
isDestroyed() - Method in class net.esper.core.EPServiceProviderImpl
 
isDestroyed() - Method in class net.esper.core.EPStatementImpl
 
isDispatchWaiting - Variable in class net.esper.core.UpdateDispatchViewBase
Flag to indicate we have registered a dispatch.
isDistinct() - Method in class net.esper.client.soda.AvedevProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.AvgProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.CountProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.MaxProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.MedianProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.MinProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.PlugInProjectionExpression
Returns true for distinct.
isDistinct() - Method in class net.esper.client.soda.StddevProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct() - Method in class net.esper.client.soda.SumProjectionExpression
Returns true if the projection considers distinct values only.
isDistinct - Variable in class net.esper.eql.expression.ExprAggregateNode
Indicator for whether the aggregation is distinct - i.e.
isDistinct() - Method in class net.esper.eql.expression.ExprAggregateNode
Returns true if the aggregation node is only aggregatig distinct values, or false if aggregating all values.
isEmpty() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Checks whether the map is currently empty.
isEmpty() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Checks whether the map is currently empty.
isEmpty() - Method in class net.esper.collection.ArrayBackedCollection
 
isEmpty() - Method in class net.esper.collection.OneEventLinkedList
Returns true if the collection is empty.
isEmpty() - Static method in class net.esper.collection.ThreadWorkQueue
Returns an indicator whether the queue is empty.
isEmpty() - Method in class net.esper.collection.TimeWindow
Returns true if the window is currently empty.
isEmpty() - Method in interface net.esper.eql.join.table.EventTable
Returns true if the index is empty, or false if not
isEmpty() - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
 
isEmpty() - Method in class net.esper.eql.join.table.UnindexedEventTable
 
isEmpty() - Method in class net.esper.eql.join.table.UnindexedEventTableList
 
isEmpty() - Method in class net.esper.filter.FilterHandleSetNode
Returns an indication of whether there are any callbacks or index nodes at all in this set.
isEmpty() - Method in class net.esper.view.ext.SortWindowView
True to indicate the sort window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.ext.TimeOrderView
True to indicate the sort window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.ExternallyTimedWindowView
Returns true to indicate the window is empty, or false if the view is not empty.
isEmpty() - Method in class net.esper.view.window.KeepAllView
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.LengthBatchView
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.LengthBatchViewRStream
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.LengthWindowView
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.LengthWindowViewRStream
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.TimeAccumView
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.TimeAccumViewRStream
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.TimeBatchView
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.TimeBatchViewRStream
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.TimeLengthBatchView
Returns true if the window is empty, or false if not empty.
isEmpty() - Method in class net.esper.view.window.TimeWindowView
Returns true if the window is empty, or false if not empty.
isEnableExecutionDebug() - Method in class net.esper.client.ConfigurationEngineDefaults.Logging
Returns true if execution path debug logging is enabled.
isEqualKey(Object, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Compares two keys, in internal converted form, to see if they are equal.
isEqualKey(Object, Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Compares two keys, in internal converted form, to see if they are equal.
isEqualsProperties(Map<String, Class>, Map<String, Class>) - Static method in class net.esper.event.MapEventType
Compares two sets of properties and determines if they are the same, allowing for boxed/unboxed types.
isEqualValue(Object, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Compares two values, in external form, to see if they are equal.
isExistsProperty(EventBean) - Method in class net.esper.event.CGLibPropertyGetter
 
isExistsProperty(EventBean) - Method in interface net.esper.event.EventPropertyGetter
Returns true if the property exists, or false if the type does not have such a property.
isExistsProperty(EventBean) - Method in class net.esper.event.property.ArrayFastPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.ArrayFieldPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.ArrayMethodPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.DynamicPropertyGetterBase
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.KeyedFastPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.KeyedMethodPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.MapIndexedPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.MapMappedPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.MapNestedPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.MapPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.property.NestedPropertyGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.ReflectionPropFieldGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.ReflectionPropMethodGetter
 
isExistsProperty(EventBean) - Method in class net.esper.event.xml.XPathPropertyGetter
 
isExistsSubstitutionParameters() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns true if there are one or more substitution parameters in the statement of contained-within lookup statements
isFloatingPointClass(Class) - Static method in class net.esper.util.JavaClassHelper
Returns true if the supplied type is a floating point number.
isFloatingPointNumber(Number) - Static method in class net.esper.util.JavaClassHelper
Returns true if the Number instance is a floating point number.
isForceOutput() - Method in class net.esper.view.window.TimeLengthBatchView
True for force-output.
isForceUpdate - Variable in class net.esper.view.window.TimeLengthBatchViewFactory
Indicate whether to output only if there is data, or to keep outputing empty batches.
isHasParameters() - Method in class net.esper.event.property.DynamicPropertyDescriptor
Returns true if the method takes parameters.
isHasVariables() - Method in class net.esper.core.EPStatementHandle
Returns true if the statement uses variables, false if not.
isHasVariables() - Method in class net.esper.eql.expression.ExprNodeVariableVisitor
Returns true if the visitor finds a variable value.
isHasVariables() - Method in class net.esper.eql.spec.StatementSpecCompiled
Returns true to indicate the statement has vaiables.
isHasVariables() - Method in class net.esper.eql.spec.StatementSpecMapContext
Returns true if a statement has variables.
isHasVariables() - Method in class net.esper.eql.spec.StatementSpecRaw
Returns true if a statement (or subquery sub-statements) use variables.
isHeldByCurrentThread() - Method in interface net.esper.util.ManagedLock
Returns true if the current thread holds the lock, or false if not.
isHeldByCurrentThread() - Method in class net.esper.util.ManagedLockImpl
 
isHighEndpointIncluded() - Method in class net.esper.client.soda.BetweenExpression
True if the high endpoint is included.
isHighEndpointIncluded() - Method in class net.esper.eql.expression.ExprBetweenNode
Returns true if the high endpoint is included, false if not
isImplementsInterface(Class, Class) - Static method in class net.esper.util.JavaClassHelper
Method to check if a given class, and its superclasses and interfaces (deep), implement a given interface.
isInner(int, int) - Method in class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Returns true if the outer stream has an optional relationship to the inner stream.
isInsertIntoDispatchPreserveOrder() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns true to indicate preserve order for inter-statement insert-into, or false to indicate not to preserve order
isInternalTimerEnabled() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns true if internal timer is enabled (the default), or false for internal timer disabled.
isInvertedRangeOperator() - Method in enum net.esper.filter.FilterOperator
Returns true for inverted range operators, false if not an inverted range operator.
isIStream() - Method in class net.esper.client.soda.InsertIntoClause
Returns true if insert (new data) events are fed, or false for remove (old data) events are fed.
isIStream() - Method in class net.esper.eql.spec.InsertIntoDesc
Returns true if insert (new data) events are fed, or false for remove (old data) events are fed.
isJavaBuiltinDataType(Class) - Static method in class net.esper.util.JavaClassHelper
Returns true if the class passed in is a Java built-in data type (primitive or wrapper) including String.
isListenerDispatchPreserveOrder() - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Returns true to indicate preserve order for dispatch to listeners, or false to indicate not to preserve order
isLowEndpointIncluded() - Method in class net.esper.client.soda.BetweenExpression
True if the low endpoint is included.
isLowEndpointIncluded() - Method in class net.esper.eql.expression.ExprBetweenNode
Returns true if the low endpoint is included, false if not
isMustCoerce() - Method in class net.esper.filter.FilterSpecParamEventProp
Returns true if numeric coercion is required, or false if not
isNamedWindow(String) - Method in interface net.esper.eql.named.NamedWindowService
Returns true to indicate that the name is a named window.
isNamedWindow(String) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
isNavigable(int, int) - Method in class net.esper.eql.join.plan.QueryGraph
Returns true if there is a relationship between streams via equal properties.
isNotBetween() - Method in class net.esper.client.soda.BetweenExpression
Returns true for not-between, or false for between range.
isNotBetween() - Method in class net.esper.eql.expression.ExprBetweenNode
Returns true for inverted range, or false for regular (openn/close/half-open/half-closed) ranges.
isNotEquals() - Method in class net.esper.eql.expression.ExprEqualsNode
Returns true if this is a NOT EQUALS node, false if this is a EQUALS node.
isNotIn() - Method in class net.esper.client.soda.InExpression
Returns true for the not-in expression, or false for an in-expression.
isNotIn() - Method in class net.esper.client.soda.SubqueryInExpression
Returns true for not-in, or false for in-lookup.
isNotIn() - Method in class net.esper.eql.expression.ExprInNode
Returns true for not-in, false for regular in
isNotIn() - Method in class net.esper.eql.expression.ExprSubselectInNode
Returns true for not-in, or false for in.
isNotNull(String) - Static method in class net.esper.client.soda.Expressions
Not-null test.
isNotNull(Expression) - Static method in class net.esper.client.soda.Expressions
Not-null test.
isNumeric(Class) - Static method in class net.esper.util.JavaClassHelper
Determines if the class passed in is one of the numeric classes.
isNumericNonFP(Class) - Static method in class net.esper.util.JavaClassHelper
Determines if the class passed in is one of the numeric classes and not a floating point.
isOuter(int, int) - Method in class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Returns true if the inner stream has a relationship to the outer stream.
isParameter() - Method in class net.esper.util.PlaceholderParser.Fragment
Returns true to indicate this is a parameter and not a text fragment.
isParameter() - Method in class net.esper.util.PlaceholderParser.ParameterFragment
 
isParameter() - Method in class net.esper.util.PlaceholderParser.TextFragment
 
isProperty(String) - Method in class net.esper.event.BaseConfigurableEventType
 
isProperty(String) - Method in class net.esper.event.BeanEventType
 
isProperty(String) - Method in class net.esper.event.CompositeEventType
 
isProperty(String) - Method in interface net.esper.event.EventType
Check that the given property name is valid for this event type, ie.
isProperty(String) - Method in class net.esper.event.MapEventType
 
isProperty(String) - Method in class net.esper.event.WrapperEventType
 
isRangeOperator() - Method in enum net.esper.filter.FilterOperator
Returns true for all range operators, false if not a range operator.
isRemoveStreamHandling - Variable in class net.esper.view.ext.TimeOrderViewFactory
Indicates if the view must handle the remove stream of parent views.
isRemoveStreamHandling - Variable in class net.esper.view.window.ExternallyTimedWindowViewFactory
Flag to indicate that the view must handle the removed events from a parent view.
isRemoveStreamHandling - Variable in class net.esper.view.window.LengthBatchViewFactory
Flag to indicate that the view must handle the removed events from a parent view.
isRemoveStreamHandling - Variable in class net.esper.view.window.LengthWindowViewFactory
Flag to indicate that the view must handle the removed events from a parent view.
isRemoveStreamHandling - Variable in class net.esper.view.window.TimeAccumViewFactory
Indicators that we need to handle the remove stream posted by parent views.
isRemoveStreamHandling - Variable in class net.esper.view.window.TimeBatchViewFactory
Flag to indicate that the view must handle the removed events from a parent view.
isRemoveStreamHandling - Variable in class net.esper.view.window.TimeWindowViewFactory
Flag to indicate that the view must handle the removed events from a parent view.
isResolvePropertiesAbsolute() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Indicates whether properties are compiled into absolute or deep XPath expressions (see setter method for more detail).
isRoot() - Method in class net.esper.pattern.EvalNodeNumber
Returns true for a root node, false for child nodes.
isSatisfied() - Method in class net.esper.eql.spec.SubstitutionParameterExpression
Returns true if the parameter is satisfied, or false if not.
isShareViews() - Method in class net.esper.client.ConfigurationEngineDefaults.ViewResources
Returns true to indicate the engine shares view resources between statements, or false to indicate the engine does not share view resources between statements.
isStartEager() - Method in class net.esper.view.window.TimeLengthBatchView
True for start-eager.
isStartEager - Variable in class net.esper.view.window.TimeLengthBatchViewFactory
Indicate whether to output only if there is data, or to keep outputing empty batches.
isStarted() - Method in interface net.esper.client.EPStatement
Returns true if the statement state is started.
isStarted() - Method in class net.esper.core.EPStatementImpl
 
isStopped() - Method in interface net.esper.client.EPStatement
Returns true if the statement state is stopped.
isStopped() - Method in class net.esper.core.EPStatementImpl
 
isTaggedEvent() - Method in class net.esper.eql.spec.SelectExprElementStreamCompiledSpec
Returns true to indicate that we are meaning to select a tagged event in a pattern, or false if selecting an event from a stream.
ISTREAM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ISTREAM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
IStreamRandomAccess - Class in net.esper.view.window
For use with length and time window views that must provide random access into data window contents provided for the "previous" expression if used.
IStreamRandomAccess(RandomAccessByIndexObserver) - Constructor for class net.esper.view.window.IStreamRandomAccess
Ctor.
IStreamRelativeAccess - Class in net.esper.view.window
Provides relative access to insert stream events for certain window.
IStreamRelativeAccess(IStreamRelativeAccess.IStreamRelativeAccessUpdateObserver) - Constructor for class net.esper.view.window.IStreamRelativeAccess
Ctor.
IStreamRelativeAccess.IStreamRelativeAccessUpdateObserver - Interface in net.esper.view.window
For indicating that the collection has been updated.
IStreamRStreamSelectorView - Class in net.esper.eql.view
View for applying a final "rstream" or "istream" selection on the result event rows before publishing to listeners.
IStreamRStreamSelectorView(SelectClauseStreamSelectorEnum) - Constructor for class net.esper.eql.view.IStreamRStreamSelectorView
Ctor.
IStreamSortedRandomAccess - Class in net.esper.view.ext
Provides random access into a sorted-window's data.
IStreamSortedRandomAccess(RandomAccessByIndexObserver) - Constructor for class net.esper.view.ext.IStreamSortedRandomAccess
Ctor.
IStreamTimeOrderRandomAccess - Class in net.esper.view.ext
Provides random access into a time-ordered-window's data.
IStreamTimeOrderRandomAccess(RandomAccessByIndexObserver) - Constructor for class net.esper.view.ext.IStreamTimeOrderRandomAccess
Ctor.
isUnbound - Variable in class net.esper.view.internal.PriorEventViewFactory
unbound to indicate the we are not receiving remove stream events (unbound stream, stream without child views) therefore must use a different buffer.
isUsingWildcard() - Method in class net.esper.eql.spec.SelectClauseSpec
Returns true if a wildcard was found in the select clause, or false if not
isVisit(ExprNode) - Method in class net.esper.eql.expression.ExprNodeIdentifierVisitor
 
isVisit(ExprNode) - Method in class net.esper.eql.expression.ExprNodeSubselectVisitor
 
isVisit(ExprNode) - Method in class net.esper.eql.expression.ExprNodeVariableVisitor
 
isVisit(ExprNode) - Method in interface net.esper.eql.expression.ExprNodeVisitor
Allows visitor to indicate whether to visit a given node.
isWildcard() - Method in class net.esper.client.soda.SelectClause
Returns true is a wildcard is part of the select clause, or false if not.
isWildcard(int, int) - Method in class net.esper.type.CronParameter
 
isWildcard(int, int) - Method in class net.esper.type.FrequencyParameter
 
isWildcard(int, int) - Method in class net.esper.type.IntParameter
 
isWildcard(int, int) - Method in class net.esper.type.ListParameter
 
isWildcard(int, int) - Method in interface net.esper.type.NumberSetParameter
Returns true if all values between and including min and max are supplied by the parameter.
isWildcard(int, int) - Method in class net.esper.type.RangeParameter
 
isWildcard(int, int) - Method in class net.esper.type.WildcardParameter
 
IterableMap - Interface in net.esper.collection.apachecommons
Defines a map that can be iterated directly without needing to create an entry set.
IterablesListIterator - Class in net.esper.collection
An iterator over a list of iterables.
IterablesListIterator(List<Iterable<EventBean>>) - Constructor for class net.esper.collection.IterablesListIterator
Constructor - takes a list of Iterable that supply the iterators to iterate over.
iterator() - Method in interface net.esper.client.EPIterable
Returns a concurrency-unsafe iterator over events representing statement results (pull API).
iterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
 
iterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
 
iterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.Values
 
iterator() - Method in class net.esper.collection.ArrayBackedCollection
 
iterator() - Method in class net.esper.collection.TimeWindow
Returns event iterator.
iterator() - Method in class net.esper.core.EPStatementImpl
 
iterator() - Method in class net.esper.core.UpdateDispatchViewBase
 
iterator() - Method in class net.esper.eql.core.MethodPollingViewable
 
iterator() - Method in class net.esper.eql.db.DatabasePollingViewable
 
iterator() - Method in interface net.esper.eql.join.table.EventTable
Returns an iterator over events in the table.
iterator() - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
 
iterator() - Method in class net.esper.eql.join.table.UnindexedEventTable
 
iterator() - Method in class net.esper.eql.join.table.UnindexedEventTableList
 
iterator() - Method in class net.esper.eql.named.NamedWindowConsumerView
 
iterator() - Method in class net.esper.eql.named.NamedWindowOnDeleteView
 
iterator() - Method in class net.esper.eql.named.NamedWindowOnSelectView
 
iterator() - Method in class net.esper.eql.named.NamedWindowRootView
 
iterator() - Method in class net.esper.eql.named.NamedWindowTailView
 
iterator() - Method in class net.esper.eql.variable.CreateVariableView
 
iterator() - Method in class net.esper.eql.variable.OnSetVariableView
 
iterator() - Method in class net.esper.eql.view.FilterExprView
 
iterator() - Method in class net.esper.eql.view.InternalRouteView
 
iterator() - Method in class net.esper.eql.view.IStreamRStreamSelectorView
 
iterator() - Method in class net.esper.eql.view.OutputProcessView
 
iterator() - Method in interface net.esper.view.EventCollection
Allows iteration through all elements in this event collection.
iterator() - Method in class net.esper.view.ext.SortWindowView
 
iterator() - Method in class net.esper.view.ext.TimeOrderView
 
iterator() - Method in class net.esper.view.internal.BufferView
 
iterator() - Method in class net.esper.view.internal.PriorEventView
 
iterator() - Method in class net.esper.view.stat.BaseBivariateStatisticsView
 
iterator() - Method in class net.esper.view.stat.MultiDimStatsView
 
iterator() - Method in class net.esper.view.stat.UnivariateStatisticsView
 
iterator() - Method in class net.esper.view.stat.WeightedAverageView
 
iterator() - Method in class net.esper.view.std.AddPropertyValueView
 
iterator() - Method in class net.esper.view.std.GroupByView
 
iterator() - Method in class net.esper.view.std.LastElementView
 
iterator() - Method in class net.esper.view.std.MergeView
 
iterator() - Method in class net.esper.view.std.SizeView
 
iterator() - Method in class net.esper.view.std.UniqueByPropertyView
 
iterator() - Method in class net.esper.view.window.ExternallyTimedWindowView
 
iterator() - Method in class net.esper.view.window.KeepAllView
 
iterator() - Method in class net.esper.view.window.LengthBatchView
 
iterator() - Method in class net.esper.view.window.LengthBatchViewRStream
 
iterator() - Method in class net.esper.view.window.LengthWindowView
 
iterator() - Method in class net.esper.view.window.LengthWindowViewRStream
 
iterator() - Method in class net.esper.view.window.TimeAccumView
 
iterator() - Method in class net.esper.view.window.TimeAccumViewRStream
 
iterator() - Method in class net.esper.view.window.TimeBatchView
 
iterator() - Method in class net.esper.view.window.TimeBatchViewRStream
 
iterator() - Method in class net.esper.view.window.TimeLengthBatchView
 
iterator() - Method in class net.esper.view.window.TimeWindowView
 
iterator() - Method in class net.esper.view.ZeroDepthStream
 

J

JavaClassHelper - Class in net.esper.util
Helper for questions about Java classes such as
JavaClassHelper() - Constructor for class net.esper.util.JavaClassHelper
 
JMXLastCubeElementDynamicMBean - Class in net.esper.indicator.jmx
JMX dynamic MBean that displays tabular data and/or cells that represent a rendered Cube.
JMXLastCubeElementDynamicMBean() - Constructor for class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
Constructor.
JMXLastElementDynamicMBean - Class in net.esper.indicator.jmx
JMX DynamicMBean that exposes all properties of an element as attributes for querying.
JMXLastElementDynamicMBean(EventType) - Constructor for class net.esper.indicator.jmx.JMXLastElementDynamicMBean
Constructor.
JMXLastElementObserver - Interface in net.esper.indicator.jmx
DynamicMBean interface extension to set the last element to render in a JMX view.
JMXLastEventIndicator - Class in net.esper.indicator.jmx
This listeners can be used to indicate events received through a JMX console.
JMXLastEventIndicator(EventType, String, String) - Constructor for class net.esper.indicator.jmx.JMXLastEventIndicator
Constructor.
JOIN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
JOIN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
join(EventBean[][], EventBean[][]) - Method in interface net.esper.eql.join.JoinExecutionStrategy
Execute join.
join(EventBean[][], EventBean[][]) - Method in class net.esper.eql.join.JoinExecutionStrategyImpl
 
join(EventBean[][], EventBean[][]) - Method in interface net.esper.eql.join.JoinSetComposer
Return join tuple result set from new data and old data for each stream.
join(EventBean[][], EventBean[][]) - Method in class net.esper.eql.join.JoinSetComposerImpl
 
JoinedPropDesc - Class in net.esper.eql.lookup
Holds property information for joined properties in a lookup.
JoinedPropDesc(String, Class, String, Integer) - Constructor for class net.esper.eql.lookup.JoinedPropDesc
Ctor.
JoinExecStrategyDispatchable - Class in net.esper.eql.join
This class reacts to any new data buffered by registring with the dispatch service.
JoinExecStrategyDispatchable(JoinExecutionStrategy, int) - Constructor for class net.esper.eql.join.JoinExecStrategyDispatchable
CTor.
JoinExecutionStrategy - Interface in net.esper.eql.join
Strategy for executing a join.
JoinExecutionStrategyImpl - Class in net.esper.eql.join
Join execution strategy based on a 3-step getSelectListEvents of composing a join set, filtering the join set and indicating.
JoinExecutionStrategyImpl(JoinSetComposer, JoinSetProcessor, JoinSetProcessor) - Constructor for class net.esper.eql.join.JoinExecutionStrategyImpl
Ctor.
JoinPreloadMethod - Interface in net.esper.eql.join
Method for preloading events for a given stream onto the stream's indexes, from a buffer already associated with a stream.
JoinPreloadMethodImpl - Class in net.esper.eql.join
Implements a method for pre-loading (initializing) join indexes from a filled buffer.
JoinPreloadMethodImpl(int, JoinSetComposer) - Constructor for class net.esper.eql.join.JoinPreloadMethodImpl
Ctor.
JoinSetComposer - Interface in net.esper.eql.join
Interface for populating a join tuple result set from new data and old data for each stream.
JoinSetComposerFactory - Interface in net.esper.eql.join
Factory for building a JoinSetComposer implementations from analyzing filter nodes, for fast join tuple result set composition.
JoinSetComposerFactoryImpl - Class in net.esper.eql.join
Factory for building a JoinSetComposer from analyzing filter nodes, for fast join tuple result set composition.
JoinSetComposerFactoryImpl() - Constructor for class net.esper.eql.join.JoinSetComposerFactoryImpl
 
JoinSetComposerImpl - Class in net.esper.eql.join
Implements the function to determine a join result set using tables/indexes and query strategy instances for each stream.
JoinSetComposerImpl(EventTable[][], QueryStrategy[], SelectClauseStreamSelectorEnum) - Constructor for class net.esper.eql.join.JoinSetComposerImpl
Ctor.
JoinSetFilter - Class in net.esper.eql.join
Processes join tuple set by filtering out tuples.
JoinSetFilter(ExprNode) - Constructor for class net.esper.eql.join.JoinSetFilter
Ctor.
JoinSetIndicator - Interface in net.esper.eql.join
Marker interface for indicators to join set processors.
JoinSetProcessor - Interface in net.esper.eql.join
Processes a join result set constisting of sets of tuples of events.
Junction - Class in net.esper.client.soda
Base junction for conjunction (and) and disjunction (or).
Junction() - Constructor for class net.esper.client.soda.Junction
 

K

KeepAllView - Class in net.esper.view.window
This view is a keep-all data window that simply keeps all events added.
KeepAllView(KeepAllViewFactory, ViewUpdatedCollection) - Constructor for class net.esper.view.window.KeepAllView
Ctor.
KeepAllViewFactory - Class in net.esper.view.window
Factory for KeepAllView.
KeepAllViewFactory() - Constructor for class net.esper.view.window.KeepAllViewFactory
 
key - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
The key
key - Variable in class net.esper.collection.apachecommons.AbstractKeyValue
The key
KeyedFastPropertyGetter - Class in net.esper.event.property
Getter for a key property identified by a given key value, using the CGLIB fast method.
KeyedFastPropertyGetter(FastMethod, Object) - Constructor for class net.esper.event.property.KeyedFastPropertyGetter
Constructor.
KeyedMethodPropertyGetter - Class in net.esper.event.property
Getter for a key property identified by a given key value, using vanilla reflection.
KeyedMethodPropertyGetter(Method, Object) - Constructor for class net.esper.event.property.KeyedMethodPropertyGetter
Constructor.
keySet - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Key set
keySet() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the keySet view of the map.
keySet() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Returns a set view of this map's keys.
keyType - Variable in class net.esper.collection.apachecommons.AbstractReferenceMap
The reference type for keys.
KeyValue - Interface in net.esper.collection.apachecommons
Defines a simple key value pair.

L

LAND - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LAND - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
last - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
The last returned entry
LAST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LAST - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LAST_OPERATOR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LAST_OPERATOR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LastElementView - Class in net.esper.view.std
This view is a very simple view presenting the last event posted by the parent view to any subviews.
LastElementView() - Constructor for class net.esper.view.std.LastElementView
 
LastElementViewFactory - Class in net.esper.view.std
Factory for LastElementView instances.
LastElementViewFactory() - Constructor for class net.esper.view.std.LastElementViewFactory
 
lastEvent - Variable in class net.esper.view.std.LastElementView
The last new element posted from a parent view.
lastIterableEvent - Variable in class net.esper.core.UpdateDispatchViewBase
For iteration with patterns.
lastNewEvents - Variable in class net.esper.core.UpdateDispatchViewBase
Buffer for holding dispatchable events.
lastOldEvents - Variable in class net.esper.core.UpdateDispatchViewBase
Buffer for holding dispatchable events.
lastOperator(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
lastOperator() - Method in class net.esper.eql.generated.EQLStatementParser
 
LBRACK - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LBRACK - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LCURLY - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LCURLY - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
le(String, Object) - Static method in class net.esper.client.soda.Expressions
Less-or-equals between a property and a constant.
le(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Less-or-equal between expression results.
LE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LeafAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a leaf with a no child nodes below it.
LeafAssemblyNode(int, int) - Constructor for class net.esper.eql.join.assemble.LeafAssemblyNode
Ctor.
leave(Object) - Method in interface net.esper.eql.agg.AggregationMethod
Apply the value as leaving aggregation (leaving window).
leave(Object) - Method in class net.esper.eql.agg.AvedevAggregator
 
leave(Object) - Method in class net.esper.eql.agg.AvgAggregator
 
leave(Object) - Method in class net.esper.eql.agg.CountAggregator
 
leave(Object) - Method in class net.esper.eql.agg.DistinctValueAggregator
 
leave(Object) - Method in class net.esper.eql.agg.DoubleSumAggregator
 
leave(Object) - Method in class net.esper.eql.agg.FloatSumAggregator
 
leave(Object) - Method in class net.esper.eql.agg.IntegerSumAggregator
 
leave(Object) - Method in class net.esper.eql.agg.LongSumAggregator
 
leave(Object) - Method in class net.esper.eql.agg.MedianAggregator
 
leave(Object) - Method in class net.esper.eql.agg.MinMaxAggregator
 
leave(Object) - Method in class net.esper.eql.agg.NonNullCountAggregator
 
leave(Object) - Method in class net.esper.eql.agg.NumIntegerSumAggregator
 
leave(Object) - Method in class net.esper.eql.agg.StddevAggregator
 
leaveNode(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
leaveNode(AST) - Method in class net.esper.eql.parse.EQLTreeWalker
Leave AST node and process it's type and child nodes.
LEFT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LEFT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LEFT_OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LEFT_OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LengthBatchView - Class in net.esper.view.window
A data view that aggregates events in a stream and releases them in one batch when a maximum number of events has been collected.
LengthBatchView(LengthBatchViewFactory, int, ViewUpdatedCollection) - Constructor for class net.esper.view.window.LengthBatchView
Constructor.
LengthBatchViewFactory - Class in net.esper.view.window
Factory for TimeBatchView.
LengthBatchViewFactory() - Constructor for class net.esper.view.window.LengthBatchViewFactory
 
LengthBatchViewRStream - Class in net.esper.view.window
Same as the LengthBatchView, this view also supports fast-remove from the batch for remove stream events.
LengthBatchViewRStream(LengthBatchViewFactory, int) - Constructor for class net.esper.view.window.LengthBatchViewRStream
Constructor.
LengthWindowView - Class in net.esper.view.window
This view is a moving window extending the specified number of elements into the past.
LengthWindowView(LengthWindowViewFactory, int, ViewUpdatedCollection) - Constructor for class net.esper.view.window.LengthWindowView
Constructor creates a moving window extending the specified number of elements into the past.
LengthWindowViewFactory - Class in net.esper.view.window
Factory for LengthWindowView.
LengthWindowViewFactory() - Constructor for class net.esper.view.window.LengthWindowViewFactory
 
LengthWindowViewRStream - Class in net.esper.view.window
This view is a moving window extending the specified number of elements into the past, allowing in addition to remove events efficiently for remove-stream events received by the view.
LengthWindowViewRStream(LengthWindowViewFactory, int) - Constructor for class net.esper.view.window.LengthWindowViewRStream
Constructor creates a moving window extending the specified number of elements into the past.
leProperty(String, String) - Static method in class net.esper.client.soda.Expressions
Less-or-equal between properties.
lexSampleSQL(String) - Static method in class net.esper.eql.db.DatabasePollingViewableFactory
Lexes the sample SQL and inserts a "where 1=0" where-clause.
LIB_FUNCTION - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LIB_FUNCTION - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
libFunc(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
libFunction() - Method in class net.esper.eql.generated.EQLStatementParser
 
libFunctionArgs() - Method in class net.esper.eql.generated.EQLStatementParser
 
like(String, String) - Static method in class net.esper.client.soda.Expressions
SQL-Like.
like(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
SQL-Like.
like(String, Object, String) - Static method in class net.esper.client.soda.Expressions
SQL-Like.
like(Expression, Expression, Expression) - Static method in class net.esper.client.soda.Expressions
SQL-Like.
LIKE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LIKE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
likeExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
LikeExpression - Class in net.esper.client.soda
SQL-Like expression for matching '%' and '_' wildcard strings following SQL standards.
LikeExpression() - Constructor for class net.esper.client.soda.LikeExpression
Ctor - for use to create an expression tree, without child expression.
LikeExpression(Expression, Expression) - Constructor for class net.esper.client.soda.LikeExpression
Ctor.
LikeExpression(Expression, Expression, Expression) - Constructor for class net.esper.client.soda.LikeExpression
Ctor.
LikeUtil - Class in net.esper.util
Utility for performing a SQL Like comparsion.
LikeUtil(String, Character, boolean) - Constructor for class net.esper.util.LikeUtil
Ctor.
list(Name) - Method in class net.esper.core.EngineEnvContext
 
list(String) - Method in class net.esper.core.EngineEnvContext
 
listBindings(Name) - Method in class net.esper.core.EngineEnvContext
 
listBindings(String) - Method in class net.esper.core.EngineEnvContext
 
ListParameter - Class in net.esper.type
Represents a list of values in a set of numeric parameters.
ListParameter() - Constructor for class net.esper.type.ListParameter
Ctor.
LITERAL_day - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_day - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_days - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_days - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_false - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_false - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_hour - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_hour - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_hours - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_hours - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_millisecond - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_millisecond - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_milliseconds - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_milliseconds - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_minute - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_minute - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_msec - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_msec - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_null - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_null - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_sec - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_sec - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_second - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_second - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LITERAL_true - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LITERAL_true - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LNOT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LNOT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
loadFactor - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Load factor, normally 0.75
LONG_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LONG_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LongSumAggregator - Class in net.esper.eql.agg
Sum for long values.
LongSumAggregator() - Constructor for class net.esper.eql.agg.LongSumAggregator
 
LongValue - Class in net.esper.type
Placeholder for a long-typed value in an event expression.
LongValue() - Constructor for class net.esper.type.LongValue
 
lookup(Name) - Method in class net.esper.core.EngineEnvContext
 
lookup(String) - Method in class net.esper.core.EngineEnvContext
 
lookup(EventBean) - Method in class net.esper.eql.join.exec.FullTableScanLookupStrategy
 
lookup(EventBean) - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
 
lookup(EventBean) - Method in interface net.esper.eql.join.exec.TableLookupStrategy
Returns matched events for a event to look up for.
lookup(EventBean[], Set<MultiKey<EventBean>>) - Method in class net.esper.eql.join.ExecNodeQueryStrategy
 
lookup(EventBean[], Set<MultiKey<EventBean>>) - Method in class net.esper.eql.join.HistoricalDataQueryStrategy
 
lookup(EventBean, EventTable) - Method in interface net.esper.eql.join.HistoricalIndexLookupStrategy
Look up into the index, potentially using some of the properties in the lookup event, returning a partial or full result in respect to the index.
lookup(EventBean, EventTable) - Method in class net.esper.eql.join.HistoricalIndexLookupStrategyIndex
 
lookup(EventBean, EventTable) - Method in class net.esper.eql.join.HistoricalIndexLookupStrategyNoIndex
 
lookup(EventBean[], Set<MultiKey<EventBean>>) - Method in interface net.esper.eql.join.QueryStrategy
Look up events returning tuples of joined events.
lookup(Object[]) - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
Returns the set of events that have the same property value as the given event.
lookup(Object[]) - Method in class net.esper.eql.join.table.PropertyIndTableCoerceAll
Returns the set of events that have the same property value as the given event.
lookup(EventBean[]) - Method in class net.esper.eql.lookup.FullTableScanLookupStrategy
 
lookup(EventBean[]) - Method in class net.esper.eql.lookup.IndexedTableLookupStrategy
 
lookup(EventBean[]) - Method in interface net.esper.eql.lookup.TableLookupStrategy
Returns matched events for a set of events to look up for.
lookup(EventBean[]) - Method in interface net.esper.eql.named.LookupStrategy
Determines the events to be deleted from a named window.
lookup(EventBean[]) - Method in class net.esper.eql.named.LookupStrategyAllRows
 
lookup(EventBean[]) - Method in class net.esper.eql.named.LookupStrategyIndexed
 
lookup(EventBean[]) - Method in class net.esper.eql.named.LookupStrategyTableScan
 
LookupInstructionExec - Class in net.esper.eql.join.exec
Execution for a lookup instruction to look up in one or more event streams with a supplied event and using a given set of lookup strategies, and adding any lookup results to a lighweight repository object for later result assembly.
LookupInstructionExec(int, String, int[], TableLookupStrategy[], boolean[]) - Constructor for class net.esper.eql.join.exec.LookupInstructionExec
Ctor.
LookupInstructionExecNode - Class in net.esper.eql.join.exec
Execution for a set of lookup instructions and for a set of result assemble instructions to perform joins and construct a complex result.
LookupInstructionExecNode(int, String, int, LookupInstructionExec[], boolean[], BaseAssemblyNode[]) - Constructor for class net.esper.eql.join.exec.LookupInstructionExecNode
Ctor.
LookupInstructionExecNode.MyResultAssembler - Class in net.esper.eql.join.exec
Receives result rows posted by result set assembly nodes.
LookupInstructionExecNode.MyResultAssembler(int) - Constructor for class net.esper.eql.join.exec.LookupInstructionExecNode.MyResultAssembler
Ctor.
LookupInstructionPlan - Class in net.esper.eql.join.plan
Plan for lookup using a from-stream event looking up one or more to-streams using a specified lookup plan for each to-stream.
LookupInstructionPlan(int, String, int[], TableLookupPlan[], boolean[]) - Constructor for class net.esper.eql.join.plan.LookupInstructionPlan
Ctor.
LookupInstructionQueryPlanNode - Class in net.esper.eql.join.plan
Query plan for executing a set of lookup instructions and assembling an end result via a set of assembly instructions.
LookupInstructionQueryPlanNode(int, String, int, boolean[], List<LookupInstructionPlan>, List<BaseAssemblyNode>) - Constructor for class net.esper.eql.join.plan.LookupInstructionQueryPlanNode
Ctor.
lookupLink(Name) - Method in class net.esper.core.EngineEnvContext
 
lookupLink(String) - Method in class net.esper.core.EngineEnvContext
 
LookupStrategy - Interface in net.esper.eql.named
A deletion strategy is for use with named window in on-delete statements and encapsulates the strategy for resolving one or more events arriving in the on-clause of an on-delete statement to one or more events to be deleted from the named window.
LookupStrategyAllRows - Class in net.esper.eql.named
Deletes from a named window all events simply using the named window's data window iterator.
LookupStrategyAllRows(Iterable<EventBean>) - Constructor for class net.esper.eql.named.LookupStrategyAllRows
Ctor.
LookupStrategyIndexed - Class in net.esper.eql.named
Uses an index to determine event to be deleted or selected from a named window.
LookupStrategyIndexed(ExprNode, TableLookupStrategy) - Constructor for class net.esper.eql.named.LookupStrategyIndexed
Ctor.
LookupStrategyTableScan - Class in net.esper.eql.named
Determine events to be deleted from a named window using the where-clause and full table scan.
LookupStrategyTableScan(ExprNode, Iterable<EventBean>) - Constructor for class net.esper.eql.named.LookupStrategyTableScan
Ctor.
LOR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LOR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LPAREN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LPAREN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
lt(String, Object) - Static method in class net.esper.client.soda.Expressions
Less-then between a property and a constant.
lt(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Less-then between expression results.
LT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ltProperty(String, String) - Static method in class net.esper.client.soda.Expressions
Less-then between properties.
LW - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LW - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 

M

makeAndStateNode(Evaluator, EvalAndNode, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a followed-by state node.
makeAndStateNode(Evaluator, EvalAndNode, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeAvedevAggregator() - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new avedev-aggregator.
makeAvedevAggregator() - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeAvgAggregator() - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new avg-aggregator.
makeAvgAggregator() - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeComposer(List<OuterJoinDesc>, ExprNode, EventType[], String[], Viewable[], SelectClauseStreamSelectorEnum) - Method in interface net.esper.eql.join.JoinSetComposerFactory
Builds join tuple composer.
makeComposer(List<OuterJoinDesc>, ExprNode, EventType[], String[], Viewable[], SelectClauseStreamSelectorEnum) - Method in class net.esper.eql.join.JoinSetComposerFactoryImpl
Builds join tuple composer.
makeContext(String, String, String, boolean, EPServicesContext, Map<String, Object>, OnTriggerDesc, CreateWindowDesc) - Method in interface net.esper.core.StatementContextFactory
Create a new statement context consisting of statement-level services.
makeContext(String, String, String, boolean, EPServicesContext, Map<String, Object>, OnTriggerDesc, CreateWindowDesc) - Method in class net.esper.core.StatementContextFactoryDefault
 
makeCountAggregator(boolean) - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new count-aggregator.
makeCountAggregator(boolean) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeDatabaseRefService(ConfigurationInformation, SchedulingService) - Static method in class net.esper.core.EPServicesContextFactoryDefault
Creates the database config service.
makeDistinctAggregator(AggregationMethod, Class) - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new distinct-value-aggregator.
makeDistinctAggregator(AggregationMethod, Class) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeEngineImportService(ConfigurationInformation) - Static method in class net.esper.core.EPServicesContextFactoryDefault
Constructs the auto import service.
makeEveryStateNode(Evaluator, EvalEveryNode, MatchedEventMap, PatternContext, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a every-state node.
makeEveryStateNode(Evaluator, EvalEveryNode, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeExec(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.LookupInstructionPlan
Constructs the executable from the plan.
makeExec(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.LookupInstructionQueryPlanNode
 
makeExec(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.NestedIterationNode
 
makeExec(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.QueryPlanNode
Make execution node from this specification.
makeExec(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.TableLookupNode
 
makeExec(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.TableOuterLookupNode
 
makeFieldDesc(Field, String) - Static method in class net.esper.event.property.PropertyListBuilderExplicit
Makes a simple-type event property descriptor based on a reflected field.
makeFilterParam(ExprNode) - Static method in class net.esper.filter.FilterSpecCompiler
For a given expression determine if this is optimizable and create the filter parameter representing the expression, or null if not optimizable.
makeFilterSpec(EventType, List<ExprNode>, LinkedHashMap<String, EventType>, StreamTypeService, MethodResolutionService, TimeProvider, VariableService) - Static method in class net.esper.filter.FilterSpecCompiler
Factory method for compiling filter expressions into a filter specification for use with filter service.
makeFilterStateNode(Evaluator, EvalFilterNode, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a followed-by state node.
makeFilterStateNode(Evaluator, EvalFilterNode, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeFollowedByState(Evaluator, EvalFollowedByNode, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a followed-by state node.
makeFollowedByState(Evaluator, EvalFollowedByNode, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeGuard(PatternContext, Quitable, Object, Object) - Method in interface net.esper.pattern.guard.GuardFactory
Constructs a guard instance.
makeGuard(PatternContext, Quitable, Object, Object) - Method in class net.esper.pattern.guard.TimerWithinGuardFactory
 
makeGuardState(Evaluator, EvalGuardNode, MatchedEventMap, PatternContext, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a guard state node.
makeGuardState(Evaluator, EvalGuardNode, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeMedianAggregator() - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new median-aggregator.
makeMedianAggregator() - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeMethodDesc(Method, String) - Static method in class net.esper.event.property.PropertyListBuilderExplicit
Makes an event property descriptor based on a reflected method, considering the methods parameters to determine if this is an indexed or mapped event property.
makeMinMaxAggregator(MinMaxTypeEnum, Class) - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new min-max-aggregator.
makeMinMaxAggregator(MinMaxTypeEnum, Class) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeNew() - Method in class net.esper.eql.db.ConnectionCache
Make a new pair of resources.
makeNotNode(Evaluator, EvalNotNode, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a followed-by state node.
makeNotNode(Evaluator, EvalNotNode, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeObserver(PatternContext, MatchedEventMap, ObserverEventEvaluator, Object, Object) - Method in interface net.esper.pattern.observer.ObserverFactory
Make an observer instance.
makeObserver(PatternContext, MatchedEventMap, ObserverEventEvaluator, Object, Object) - Method in class net.esper.pattern.observer.TimerAtObserverFactory
 
makeObserver(PatternContext, MatchedEventMap, ObserverEventEvaluator, Object, Object) - Method in class net.esper.pattern.observer.TimerIntervalObserverFactory
 
makeObserverNode(Evaluator, EvalObserverNode, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a followed-by state node.
makeObserverNode(Evaluator, EvalObserverNode, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeOrState(Evaluator, EvalOrNode, MatchedEventMap, PatternContext, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes an or-state node.
makeOrState(Evaluator, EvalOrNode, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeParameter(AST) - Static method in class net.esper.eql.parse.ASTParameterHelper
Returns the parse Object for the parameter/constant AST node whose text to parse.
makeParentStateNode(EvalNode, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes a parent state node for the child state node.
makeParentStateNode(EvalNode, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makePlugInAggregator(String) - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new plug-in aggregation instance by name.
makePlugInAggregator(String) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeRootNode(EvalNode, MatchedEventMap) - Method in interface net.esper.pattern.PatternStateFactory
Makes a root state node.
makeRootNode(EvalNode, MatchedEventMap) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeStateNode(EvalNodeNumber, MatchedEventMap, Object) - Method in interface net.esper.pattern.PatternStateFactory
Makes any new state node.
makeStateNode(EvalNodeNumber, MatchedEventMap, Object) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
makeStddevAggregator() - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new stddev-aggregator.
makeStddevAggregator() - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeStrategy(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.FullTableScanLookupPlan
 
makeStrategy(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.IndexedTableLookupPlan
 
makeStrategy(EventTable[][], EventType[]) - Method in class net.esper.eql.join.plan.TableLookupPlan
Instantiates the lookup plan into a execution strategy for the lookup.
makeSubViews(GroupByView, Object[], StatementContext) - Static method in class net.esper.view.std.GroupByView
Instantiate subviews for the given group view and the given key value to group-by.
makeSumAggregator(Class) - Method in interface net.esper.eql.core.MethodResolutionService
Makes a new sum-aggregator.
makeSumAggregator(Class) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
makeView(ResultSetProcessor, int, OutputLimitSpec, StatementContext) - Static method in class net.esper.eql.view.OutputProcessViewFactory
Creates an output processor view depending on the presence of output limiting requirements.
makeView(StatementContext) - Method in class net.esper.view.ext.SortWindowViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.ext.TimeOrderViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.internal.PriorEventViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.stat.CorrelationViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.std.GroupByViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.std.LastElementViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.std.MergeViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.std.SizeViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
makeView(StatementContext) - Method in interface net.esper.view.ViewFactory
Create a new view.
makeView(StatementContext) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.KeepAllViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.LengthBatchViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.LengthWindowViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.TimeAccumViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.TimeBatchViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
makeView(StatementContext) - Method in class net.esper.view.window.TimeWindowViewFactory
 
ManagedLock - Interface in net.esper.util
Interface for a lock for use to perform statement-level locking.
ManagedLockImpl - Class in net.esper.util
Simple lock based on ReentrantLock that associates a name with the lock and traces locking and unlocking.
ManagedLockImpl(String) - Constructor for class net.esper.util.ManagedLockImpl
Ctor.
ManagedReadWriteLock - Class in net.esper.util
Simple read-write lock based on ReentrantReadWriteLock that associates a name with the lock and traces read/write locking and unlocking.
ManagedReadWriteLock(String, boolean) - Constructor for class net.esper.util.ManagedReadWriteLock
Ctor.
map(EPStatementObjectModel, EngineImportService, VariableService) - Static method in class net.esper.eql.spec.StatementSpecMapper
Maps the SODA object model to a statement specification.
mapAliases - Variable in class net.esper.client.Configuration
The type aliases for events that result when maps are sent into the engine.
MapEventBean - Class in net.esper.event
Wrapper for events represented by a Map of key-value pairs that are the event properties.
MapEventBean(Map<String, Object>, EventType) - Constructor for class net.esper.event.MapEventBean
Constructor for initialization with existing values.
MapEventBean(EventType, Map<String, EventBean>) - Constructor for class net.esper.event.MapEventBean
Constructor for initialization with existing values.
MapEventBean(EventType) - Constructor for class net.esper.event.MapEventBean
Constructor for the mutable functions, e.g.
MapEventType - Class in net.esper.event
Implementation of the EventType interface for handling plain Maps containing name value pairs.
MapEventType(String, Map<String, Class>, EventAdapterService) - Constructor for class net.esper.event.MapEventType
Constructor takes a type name, map of property names and types.
mapFromSODA(StreamSelector) - Static method in enum net.esper.eql.spec.SelectClauseStreamSelectorEnum
Maps the SODA-selector to the internal representation
mapFromSODA(SelectClauseStreamSelectorEnum) - Static method in enum net.esper.eql.spec.SelectClauseStreamSelectorEnum
Maps the internal stream selector to the SODA-representation
MapIndexedPropertyGetter - Class in net.esper.event.property
Getter for a dynamic indexed property for maps.
MapIndexedPropertyGetter(String, int) - Constructor for class net.esper.event.property.MapIndexedPropertyGetter
Ctor.
mapIterator() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets an iterator over the map.
mapIterator() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Gets a MapIterator over the reference map.
mapIterator() - Method in interface net.esper.collection.apachecommons.IterableMap
Obtains a MapIterator over the map.
MapIterator - Interface in net.esper.collection.apachecommons
Defines an iterator that operates over a Map.
MapMappedPropertyGetter - Class in net.esper.event.property
Getter for a dynamic mappeds property for maps.
MapMappedPropertyGetter(String, String) - Constructor for class net.esper.event.property.MapMappedPropertyGetter
Ctor.
MapNestedPropertyGetter - Class in net.esper.event.property
Getter for one or more levels deep nested properties of maps.
MapNestedPropertyGetter(List<EventPropertyGetter>) - Constructor for class net.esper.event.property.MapNestedPropertyGetter
Ctor.
MappedProperty - Class in net.esper.event.property
Represents a mapped property or array property, ie.
MappedProperty(String, String) - Constructor for class net.esper.event.property.MappedProperty
Ctor.
MapPropertyGetter - Class in net.esper.event.property
A getter that interrogates a given property in a map which may itself contain nested maps or indexed entries.
MapPropertyGetter(String, EventPropertyGetter) - Constructor for class net.esper.event.property.MapPropertyGetter
Ctor.
MatchedEventMap - Interface in net.esper.pattern
Collection for internal use similar to the MatchedEventMap class in the client package that holds the one or more events that could match any defined event expressions.
MatchedEventMapImpl - Class in net.esper.pattern
Collection for internal use similar to the MatchedEventMap class in the client package that holds the one or more events that could match any defined event expressions.
MatchedEventMapImpl() - Constructor for class net.esper.pattern.MatchedEventMapImpl
Constructor creates an empty collection of events.
MatchedEventMapImpl(Map<String, EventBean>) - Constructor for class net.esper.pattern.MatchedEventMapImpl
Ctor.
matchEvent(EventBean, Collection<FilterHandle>) - Method in interface net.esper.filter.EventEvaluator
Perform the matching of an event based on the event property values, adding any callbacks for matches found to the matches list.
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.EventTypeIndex
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterHandleSetNode
Evaluate an event by asking each index to match the event.
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexBooleanExpr
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexCompare
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexEquals
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexIn
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexNotEquals
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexNotIn
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexNotRange
 
matchEvent(EventBean, Collection<FilterHandle>) - Method in class net.esper.filter.FilterParamIndexRange
 
matchExistingViews(Viewable, List<ViewFactory>) - Static method in class net.esper.view.ViewServiceHelper
Match the views under the stream to the list of view specications passed in.
matchFound(EventBean) - Method in interface net.esper.filter.FilterHandleCallback
Indicate that an event was evaluated by the FilterService which matches the filter specification FilterSpecCompiled associated with this callback.
matchFound(EventBean) - Method in class net.esper.pattern.EvalFilterStateNode
 
matchFound(Map<String, EventBean>) - Method in interface net.esper.pattern.PatternMatchCallback
Indicate matching events.
MathArithTypeEnum - Enum in net.esper.type
Enumeration for the type of arithmatic to use.
MathArithTypeEnum.AddDouble - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.AddDouble() - Constructor for class net.esper.type.MathArithTypeEnum.AddDouble
 
MathArithTypeEnum.AddFloat - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.AddFloat() - Constructor for class net.esper.type.MathArithTypeEnum.AddFloat
 
MathArithTypeEnum.AddInt - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.AddInt() - Constructor for class net.esper.type.MathArithTypeEnum.AddInt
 
MathArithTypeEnum.AddLong - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.AddLong() - Constructor for class net.esper.type.MathArithTypeEnum.AddLong
 
MathArithTypeEnum.Computer - Interface in net.esper.type
Interface for number cruncher.
MathArithTypeEnum.DivideDouble - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.DivideDouble() - Constructor for class net.esper.type.MathArithTypeEnum.DivideDouble
 
MathArithTypeEnum.DivideFloat - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.DivideFloat() - Constructor for class net.esper.type.MathArithTypeEnum.DivideFloat
 
MathArithTypeEnum.DivideInt - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.DivideInt() - Constructor for class net.esper.type.MathArithTypeEnum.DivideInt
 
MathArithTypeEnum.DivideLong - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.DivideLong() - Constructor for class net.esper.type.MathArithTypeEnum.DivideLong
 
MathArithTypeEnum.ModuloDouble - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.ModuloDouble() - Constructor for class net.esper.type.MathArithTypeEnum.ModuloDouble
 
MathArithTypeEnum.ModuloFloat - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.ModuloFloat() - Constructor for class net.esper.type.MathArithTypeEnum.ModuloFloat
 
MathArithTypeEnum.ModuloInt - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.ModuloInt() - Constructor for class net.esper.type.MathArithTypeEnum.ModuloInt
 
MathArithTypeEnum.ModuloLong - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.ModuloLong() - Constructor for class net.esper.type.MathArithTypeEnum.ModuloLong
 
MathArithTypeEnum.MultiplyDouble - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.MultiplyDouble() - Constructor for class net.esper.type.MathArithTypeEnum.MultiplyDouble
 
MathArithTypeEnum.MultiplyFloat - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.MultiplyFloat() - Constructor for class net.esper.type.MathArithTypeEnum.MultiplyFloat
 
MathArithTypeEnum.MultiplyInt - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.MultiplyInt() - Constructor for class net.esper.type.MathArithTypeEnum.MultiplyInt
 
MathArithTypeEnum.MultiplyLong - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.MultiplyLong() - Constructor for class net.esper.type.MathArithTypeEnum.MultiplyLong
 
MathArithTypeEnum.SubtractDouble - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.SubtractDouble() - Constructor for class net.esper.type.MathArithTypeEnum.SubtractDouble
 
MathArithTypeEnum.SubtractFloat - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.SubtractFloat() - Constructor for class net.esper.type.MathArithTypeEnum.SubtractFloat
 
MathArithTypeEnum.SubtractInt - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.SubtractInt() - Constructor for class net.esper.type.MathArithTypeEnum.SubtractInt
 
MathArithTypeEnum.SubtractLong - Class in net.esper.type
Computer for type-specific arith.
MathArithTypeEnum.SubtractLong() - Constructor for class net.esper.type.MathArithTypeEnum.SubtractLong
 
max(String, String, String...) - Static method in class net.esper.client.soda.Expressions
Maximum value per-row function (not aggregating).
max(Expression, Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
Maximum value per-row function (not aggregating).
max(String) - Static method in class net.esper.client.soda.Expressions
Maximum aggregation function.
max(Expression) - Static method in class net.esper.client.soda.Expressions
Maximum aggregation function.
MAX - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MAX - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
max() - Method in enum net.esper.type.ScheduleUnit
Returns minimum valid value for the unit.
maxDistinct(String) - Static method in class net.esper.client.soda.Expressions
Maximum aggregation function considering distinct values only.
maxDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Maximum aggregation function considering distinct values only.
maxFunc() - Method in class net.esper.eql.generated.EQLStatementParser
 
MAXIMUM_CAPACITY - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
The maximum capacity allowed
MaxProjectionExpression - Class in net.esper.client.soda
Maximum of the (distinct) values returned by an expression.
MaxProjectionExpression(boolean) - Constructor for class net.esper.client.soda.MaxProjectionExpression
Ctor - for use to create an expression tree, without inner expression
MaxProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.MaxProjectionExpression
Ctor - adds the expression to project.
MaxRowExpression - Class in net.esper.client.soda
Maximum-value per-row expression (not aggregating) determines the maximum value among a set of values.
MaxRowExpression() - Constructor for class net.esper.client.soda.MaxRowExpression
Ctor - for use to create an expression tree, without child expression.
MaxRowExpression(String, String, String[]) - Constructor for class net.esper.client.soda.MaxRowExpression
Ctor.
MaxRowExpression(Expression, Expression, Expression...) - Constructor for class net.esper.client.soda.MaxRowExpression
Ctor.
maxValue() - Method in class net.esper.collection.SortedRefCountedSet
Returns the largest key value, or null if the collection is empty.
mBAND(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBAND_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBNOT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBOR(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBOR_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBSR(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBSR_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBXOR(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mBXOR_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mCOLON(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mCOMMA(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mDEC(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mDIV(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mDIV_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
measureField - Variable in class net.esper.view.stat.MultiDimStatsViewFactory
Property name supplying measures.
median(String) - Static method in class net.esper.client.soda.Expressions
Median aggregation function.
median(Expression) - Static method in class net.esper.client.soda.Expressions
Median aggregation function.
MEDIAN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MEDIAN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
MedianAggregator - Class in net.esper.eql.agg
Median aggregation.
MedianAggregator() - Constructor for class net.esper.eql.agg.MedianAggregator
Ctor.
medianDistinct(String) - Static method in class net.esper.client.soda.Expressions
Median aggregation function considering distinct values only.
medianDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Median aggregation function considering distinct values only.
MedianProjectionExpression - Class in net.esper.client.soda
Median projection (aggregation) in the distinct and regular form.
MedianProjectionExpression(boolean) - Constructor for class net.esper.client.soda.MedianProjectionExpression
Ctor - for use to create an expression tree, without inner expression
MedianProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.MedianProjectionExpression
Ctor - adds the expression to project.
mEQUAL(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mEQUALS(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
merge(MatchedEventMap) - Method in interface net.esper.pattern.MatchedEventMap
Merge the state of an other match event structure into this one by adding all entries within the MatchedEventMap to this match event.
merge(MatchedEventMap) - Method in class net.esper.pattern.MatchedEventMapImpl
Merge the state of an other match event structure into this one by adding all entries within the MatchedEventMap to this match event.
MergeView - Class in net.esper.view.std
The merge view works together with a group view that splits the data in a stream to multiple subviews, based on a key index.
MergeView(StatementContext, String[], EventType) - Constructor for class net.esper.view.std.MergeView
Constructor.
MergeViewFactory - Class in net.esper.view.std
Factory for MergeView instances.
MergeViewFactory() - Constructor for class net.esper.view.std.MergeViewFactory
 
mESC(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
METADATASQL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
METADATASQL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
MetaDefItem - Interface in net.esper.util
Marker interface for use with statement and engine-level specifications.
METHOD_JOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
METHOD_JOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
methodInvocationReferences - Variable in class net.esper.client.Configuration
Map of class name and configuration for method invocations on that class.
MethodInvocationStream - Class in net.esper.client.soda
An stream that polls from a method.
MethodInvocationStream(String, String, String) - Constructor for class net.esper.client.soda.MethodInvocationStream
Ctor.
methodJoinExpression(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
methodJoinExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
MethodPollingExecStrategy - Class in net.esper.eql.core
Viewable providing historical data from a database.
MethodPollingExecStrategy(EventAdapterService, FastMethod) - Constructor for class net.esper.eql.core.MethodPollingExecStrategy
Ctor.
MethodPollingViewable - Class in net.esper.eql.core
Polling-data provider that calls a static method on a class and passed parameters, and wraps the results as POJO events.
MethodPollingViewable(MethodStreamSpec, int, List<ExprNode>, PollExecStrategy, DataCache, EventType) - Constructor for class net.esper.eql.core.MethodPollingViewable
Ctor.
MethodPollingViewableFactory - Class in net.esper.eql.core
Factory for method-invocation data provider streams.
MethodPollingViewableFactory() - Constructor for class net.esper.eql.core.MethodPollingViewableFactory
 
MethodResolutionService - Interface in net.esper.eql.core
Service for resolving methods and aggregation functions, and for creating managing aggregation instances.
MethodResolutionServiceImpl - Class in net.esper.eql.core
Implements method resolution.
MethodResolutionServiceImpl(EngineImportService) - Constructor for class net.esper.eql.core.MethodResolutionServiceImpl
Ctor.
MethodResolver - Class in net.esper.util
Used for retrieving static and instance method objects.
MethodResolver() - Constructor for class net.esper.util.MethodResolver
 
MethodStreamSpec - Class in net.esper.eql.spec
Specification object for historical data poll via database SQL statement.
MethodStreamSpec(String, List<ViewSpec>, String, String, String, List<ExprNode>) - Constructor for class net.esper.eql.spec.MethodStreamSpec
Ctor.
mEXPONENT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mFLOAT_SUFFIX(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mFOLLOWED_BY(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mGE(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mGT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mHEX_DIGIT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mIDENT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
MILLISECOND_PART - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MILLISECOND_PART - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
millisecondPart(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
millisecondPart() - Method in class net.esper.eql.generated.EQLStatementParser
 
milliseconds - Variable in class net.esper.pattern.guard.TimerWithinGuardFactory
Number of milliseconds.
milliseconds - Variable in class net.esper.pattern.observer.TimerIntervalObserverFactory
Number of milliseconds after which the interval should fire.
millisecondsBeforeExpiry - Variable in class net.esper.view.window.ExternallyTimedWindowViewFactory
The number of msec to expire.
millisecondsBeforeExpiry - Variable in class net.esper.view.window.TimeBatchViewFactory
Number of msec before expiry.
millisecondsBeforeExpiry - Variable in class net.esper.view.window.TimeLengthBatchViewFactory
Number of msec before batch fires (either interval or number of events).
millisecondsBeforeExpiry - Variable in class net.esper.view.window.TimeWindowViewFactory
Number of msec before expiry.
millisecondsQuietTime - Variable in class net.esper.view.window.TimeAccumViewFactory
Number of msec of quiet time before results are flushed.
min(String, String, String...) - Static method in class net.esper.client.soda.Expressions
Minimum value per-row function (not aggregating).
min(Expression, Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
Minimum value per-row function (not aggregating).
min(String) - Static method in class net.esper.client.soda.Expressions
Minimum aggregation function.
min(Expression) - Static method in class net.esper.client.soda.Expressions
Minimum aggregation function.
MIN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MIN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
min() - Method in enum net.esper.type.ScheduleUnit
Returns minimum valid value for the unit.
MIN_LIMIT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MIN_LIMIT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
mINC(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
minDistinct(String) - Static method in class net.esper.client.soda.Expressions
Minimum aggregation function considering distinct values only.
minDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Minimum aggregation function considering distinct values only.
MinMaxAggregator - Class in net.esper.eql.agg
Min/max aggregator for all values.
MinMaxAggregator(MinMaxTypeEnum, Class) - Constructor for class net.esper.eql.agg.MinMaxAggregator
Ctor.
MinMaxTypeEnum - Enum in net.esper.type
Enumeration for the type of arithmatic to use.
MinProjectionExpression - Class in net.esper.client.soda
Minimum of the (distinct) values returned by an expression.
MinProjectionExpression(boolean) - Constructor for class net.esper.client.soda.MinProjectionExpression
Ctor - for use to create an expression tree, without inner expression
MinProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.MinProjectionExpression
Ctor - adds the expression to project.
MinRowExpression - Class in net.esper.client.soda
Minimum-value per-row expression (not aggregating) determines the minimum value among a set of values.
MinRowExpression() - Constructor for class net.esper.client.soda.MinRowExpression
Ctor - for use to create an expression tree, without child expression.
MinRowExpression(String, String, String[]) - Constructor for class net.esper.client.soda.MinRowExpression
Ctor.
MinRowExpression(Expression, Expression, Expression...) - Constructor for class net.esper.client.soda.MinRowExpression
Ctor.
minus(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Subtraction.
minus(String, String) - Static method in class net.esper.client.soda.Expressions
Subtraction.
MINUS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MINUS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
MINUS_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MINUS_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
MINUTE_PART - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MINUTE_PART - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
minutePart(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
minutePart() - Method in class net.esper.eql.generated.EQLStatementParser
 
MINUTES - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MINUTES - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
minValue() - Method in class net.esper.collection.SortedRefCountedSet
Returns the smallest key value, or null if the collection is empty.
ML_COMMENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ML_COMMENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
mLAND(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLBRACK(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLCURLY(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLE(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLNOT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLOR(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLPAREN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mLT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mMINUS(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mMINUS_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mML_COMMENT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mMOD(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mMOD_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mNOT_EQUAL(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mNUM_INT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
MOD - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MOD - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
MOD_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MOD_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
modCount - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Modification count for iterators
modulo(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Modulo.
modulo(String, String) - Static method in class net.esper.client.soda.Expressions
Modulo.
mPLUS(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mPLUS_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mQUESTION(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mQUOTED_STRING_LITERAL(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mRBRACK(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mRCURLY(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mRPAREN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSEMI(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSL(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSL_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSL_COMMENT(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSQL_NE(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSR(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSR_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSTAR(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSTAR_ASSIGN(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mSTRING_LITERAL(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
MULTIDIM_OLAP__MEASURES - Static variable in enum net.esper.view.ViewFieldEnum
Measures in an OLAP cube.
MultidimCube<V> - Interface in net.esper.view.stat.olap
Interface for storage and access to multi-dimensional data.
MultidimCubeCellFactory<V> - Interface in net.esper.view.stat.olap
Implementations provide a factory for cells to use by MultidimCubeImpl.
MultidimCubeImpl<V> - Class in net.esper.view.stat.olap
Implementation for a multidimensional cube that can be configured with the type of cell to store.
MultidimCubeImpl(String[], MultidimCubeCellFactory<V>) - Constructor for class net.esper.view.stat.olap.MultidimCubeImpl
Constructor.
MultiDimStatsView - Class in net.esper.view.stat
This view compiles OLAP cubes for the specified fields.
MultiDimStatsView(StatementContext, String[], String, String, String, String) - Constructor for class net.esper.view.stat.MultiDimStatsView
Constructor.
MultiDimStatsViewFactory - Class in net.esper.view.stat
Factory for MultiDimStatsView instances.
MultiDimStatsViewFactory() - Constructor for class net.esper.view.stat.MultiDimStatsViewFactory
 
MultiKey<T> - Class in net.esper.collection
Functions as a key value for Maps where keys need to be composite values.
MultiKey(T[]) - Constructor for class net.esper.collection.MultiKey
Constructor for multiple keys supplied in an object array.
MultiKeyComparator - Class in net.esper.util
A comparator on multikeys.
MultiKeyComparator(Boolean[]) - Constructor for class net.esper.util.MultiKeyComparator
Ctor.
MultiKeyUntyped - Class in net.esper.collection
Functions as a key value for Maps where keys need to be composite values.
MultiKeyUntyped(Object[]) - Constructor for class net.esper.collection.MultiKeyUntyped
Constructor for multiple keys supplied in an object array.
MultiKeyUntyped(Object) - Constructor for class net.esper.collection.MultiKeyUntyped
Constructor for a single key object.
MultiKeyUntyped(Object, Object) - Constructor for class net.esper.collection.MultiKeyUntyped
Constructor for a pair of key objects.
MultiKeyUntyped(Object, Object, Object) - Constructor for class net.esper.collection.MultiKeyUntyped
Constructor for three key objects.
MultiKeyUntyped(Object, Object, Object, Object) - Constructor for class net.esper.collection.MultiKeyUntyped
Constructor for four key objects.
multiply(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Multiplication.
multiply(String, String) - Static method in class net.esper.client.soda.Expressions
Multiplication.
multiplyExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
mWS(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 

N

NamedWindowConsumerDispatchUnit - Class in net.esper.eql.named
Holds a unit of dispatch that is a result of a named window processing incoming or timer events.
NamedWindowConsumerDispatchUnit(NamedWindowDeltaData, Map<EPStatementHandle, List<NamedWindowConsumerView>>) - Constructor for class net.esper.eql.named.NamedWindowConsumerDispatchUnit
Ctor.
NamedWindowConsumerStreamSpec - Class in net.esper.eql.spec
Specification for use of an existing named window.
NamedWindowConsumerStreamSpec(String, String, List<ViewSpec>, List<ExprNode>) - Constructor for class net.esper.eql.spec.NamedWindowConsumerStreamSpec
Ctor.
NamedWindowConsumerView - Class in net.esper.eql.named
Represents a consumer of a named window that selects from a named window via a from-clause.
NamedWindowConsumerView(List<ExprNode>, EventType, StatementStopService, NamedWindowTailView) - Constructor for class net.esper.eql.named.NamedWindowConsumerView
Ctor.
NamedWindowDeltaData - Class in net.esper.eql.named
A holder for events posted by a named window as an insert and remove stream.
NamedWindowDeltaData(EventBean[], EventBean[]) - Constructor for class net.esper.eql.named.NamedWindowDeltaData
Ctor.
NamedWindowDeltaData(NamedWindowDeltaData, NamedWindowDeltaData) - Constructor for class net.esper.eql.named.NamedWindowDeltaData
Ctor aggregates two deltas into a single delta.
namedWindowEventType - Variable in class net.esper.eql.named.NamedWindowOnExprBaseView
The event type of the events hosted in the named window.
NamedWindowIndexRepository - Class in net.esper.eql.named
A repository of index tables for use with a single named window and all it's deleting statements that may use the indexes to correlate triggering events with indexed events of the named window.
NamedWindowIndexRepository() - Constructor for class net.esper.eql.named.NamedWindowIndexRepository
Ctor.
NamedWindowOnDeleteView - Class in net.esper.eql.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnDeleteView(StatementStopService, LookupStrategy, NamedWindowRootView) - Constructor for class net.esper.eql.named.NamedWindowOnDeleteView
Ctor.
NamedWindowOnExprBaseView - Class in net.esper.eql.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnExprBaseView(StatementStopService, LookupStrategy, NamedWindowRootView) - Constructor for class net.esper.eql.named.NamedWindowOnExprBaseView
Ctor.
NamedWindowOnSelectView - Class in net.esper.eql.named
View for the on-select statement that handles selecting events from a named window.
NamedWindowOnSelectView(StatementStopService, LookupStrategy, NamedWindowRootView, InternalEventRouter, ResultSetProcessor, EPStatementHandle) - Constructor for class net.esper.eql.named.NamedWindowOnSelectView
Ctor.
NamedWindowProcessor - Class in net.esper.eql.named
An instance of this class is associated with a specific named window.
NamedWindowProcessor(NamedWindowService, String, EventType) - Constructor for class net.esper.eql.named.NamedWindowProcessor
Ctor.
NamedWindowRootView - Class in net.esper.eql.named
The root window in a named window plays multiple roles: It holds the indexes for deleting rows, if any on-delete statement requires such indexes.
NamedWindowRootView() - Constructor for class net.esper.eql.named.NamedWindowRootView
Ctor.
NamedWindowService - Interface in net.esper.eql.named
Service to manage named window dispatches, locks and processors on an engine level.
NamedWindowServiceImpl - Class in net.esper.eql.named
This service hold for each named window a dedicated processor and a lock to the named window.
NamedWindowServiceImpl(StatementLockFactory, VariableService) - Constructor for class net.esper.eql.named.NamedWindowServiceImpl
Ctor.
NamedWindowTailView - Class in net.esper.eql.named
This view is hooked into a named window's view chain as the last view and handles dispatching of named window insert and remove stream results via NamedWindowService to consuming statements.
NamedWindowTailView(EventType, NamedWindowService, NamedWindowRootView) - Constructor for class net.esper.eql.named.NamedWindowTailView
Ctor.
namespaceContext - Variable in class net.esper.event.xml.BaseXMLEventType
XPath namespace context.
negatedExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
NestedIterationExecNode - Class in net.esper.eql.join.exec
Execution node that performs a nested iteration over all child nodes.
NestedIterationExecNode(int[]) - Constructor for class net.esper.eql.join.exec.NestedIterationExecNode
Ctor.
NestedIterationNode - Class in net.esper.eql.join.plan
Plan to perform a nested iteration over child nodes.
NestedIterationNode(int[]) - Constructor for class net.esper.eql.join.plan.NestedIterationNode
Ctor.
NestedProperty - Class in net.esper.event.property
This class represents a nested property, each nesting level made up of a property instance that can be of type indexed, mapped or simple itself.
NestedProperty(List<Property>, BeanEventTypeFactory) - Constructor for class net.esper.event.property.NestedProperty
Ctor.
NestedPropertyGetter - Class in net.esper.event.property
Getter for one or more levels deep nested properties.
NestedPropertyGetter(List<EventPropertyGetter>, BeanEventTypeFactory) - Constructor for class net.esper.event.property.NestedPropertyGetter
Ctor.
net.esper.adapter - package net.esper.adapter
Adapter framework classes are in this package as they may provide service APIs to the engine.
net.esper.client - package net.esper.client
This package defines the central Esper Client APIs.
net.esper.client.soda - package net.esper.client.soda
This package defines the Esper statement object model.
net.esper.client.time - package net.esper.client.time
This package defines the Esper Client timer control events.
net.esper.collection - package net.esper.collection
Internal collection classes
net.esper.collection.apachecommons - package net.esper.collection.apachecommons
Apache commons collection classes such as for soft-reference map implementation
net.esper.core - package net.esper.core
Implementation of client package interfaces, glue code
net.esper.dispatch - package net.esper.dispatch
Dispatching makes results available to joins and handles internal event routing
net.esper.emit - package net.esper.emit
Package for emitting events
net.esper.eql.agg - package net.esper.eql.agg
Contains aggregation service and aggregators
net.esper.eql.core - package 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 - package net.esper.eql.db
Database SQL polling views and caches
net.esper.eql.expression - package 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.generated - package net.esper.eql.generated
ANTLR-generated classes for parsing and AST tree-walking
net.esper.eql.join - package net.esper.eql.join
Join process interfaces and glue code
net.esper.eql.join.assemble - package net.esper.eql.join.assemble
Outer join result set assembly code
net.esper.eql.join.exec - package net.esper.eql.join.exec
Inner join execution
net.esper.eql.join.plan - package net.esper.eql.join.plan
Inner join and outer join query planning
net.esper.eql.join.rep - package net.esper.eql.join.rep
Outer join result set handling
net.esper.eql.join.table - package net.esper.eql.join.table
Indexes for views
net.esper.eql.lookup - package net.esper.eql.lookup
Subquery execution strategies and lookup indexes
net.esper.eql.named - package net.esper.eql.named
Named window classes are in this package
net.esper.eql.parse - package net.esper.eql.parse
Parsers and AST tree walkers and helper classes transforming AST into business objects
net.esper.eql.spec - 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 - package net.esper.eql.variable
Variable service and variable collections
net.esper.eql.view - package net.esper.eql.view
Internal processing views for output rate limiting, filtering and internal event routing
net.esper.event - package net.esper.event
This package defines the Esper Client event API.
net.esper.event.property - package net.esper.event.property
Parsers and business objects to handle nested, indexed, mapped or generally complex properties for use in JavaBean access
net.esper.event.xml - package net.esper.event.xml
XML event wrappers
net.esper.filter - package net.esper.filter
Main switchboard filtering and routing of incoming events to interested statements is performed in this package.
net.esper.indicator.jmx - package net.esper.indicator.jmx
Classes for indicating events through a JMX console
net.esper.indicator.pretty - package net.esper.indicator.pretty
Classes for pretty-printing OLAP cubes
net.esper.pattern - package net.esper.pattern
Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active pattern instance
net.esper.pattern.guard - package net.esper.pattern.guard
Pattern guards that can define the lifetime of a pattern
net.esper.pattern.observer - package net.esper.pattern.observer
Pattern observer classes the observe timer events
net.esper.schedule - package net.esper.schedule
Package for timer callback scheduling
net.esper.timer - package net.esper.timer
Supplies internal clocking triggering execution of schedule callbacks in a scheduling service
net.esper.type - package net.esper.type
Internal primitive, enum and other type representations
net.esper.util - package net.esper.util
Utility classes that center around Java type handling, printing, reflection, debugging
net.esper.view - package net.esper.view
View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering.
net.esper.view.ext - package net.esper.view.ext
Extension views that providing services such as sorting, which don't fit much into other categories.
net.esper.view.internal - package net.esper.view.internal
Internal management views for buffering view results and providing these to joins.
net.esper.view.stat - package net.esper.view.stat
Views computing statistical values.
net.esper.view.stat.olap - package net.esper.view.stat.olap
Views computing OLAP cubes.
net.esper.view.std - package net.esper.view.std
Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc.
net.esper.view.stream - package net.esper.view.stream
View to event stream relationship service
net.esper.view.window - package net.esper.view.window
Window views are in this package
newAggregator(MethodResolutionService) - Method in interface net.esper.eql.agg.AggregationMethod
Make a new, initalized aggregation state.
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.AggregationSupport
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.AvedevAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.AvgAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.CountAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.DistinctValueAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.DoubleSumAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.FloatSumAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.IntegerSumAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.LongSumAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.MedianAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.MinMaxAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.NonNullCountAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.NumIntegerSumAggregator
 
newAggregator(MethodResolutionService) - Method in class net.esper.eql.agg.StddevAggregator
 
newAggregators(AggregationMethod[], MultiKeyUntyped) - Method in interface net.esper.eql.core.MethodResolutionService
Returns a new set of aggregators given an existing prototype-set of aggregators for a given group key.
newAggregators(AggregationMethod[], MultiKeyUntyped) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
newCell() - Method in interface net.esper.view.stat.olap.MultidimCubeCellFactory
Supplies an instance of the object representing a cell.
newCells(int) - Method in interface net.esper.view.stat.olap.MultidimCubeCellFactory
Supplies an array of the type of object representing a cell.
newChildNumber() - Method in class net.esper.pattern.EvalNodeNumber
Returns a new child node number.
newData(int, FlushedEventBuffer, FlushedEventBuffer) - Method in class net.esper.eql.join.JoinExecStrategyDispatchable
 
newData(int, FlushedEventBuffer, FlushedEventBuffer) - Method in interface net.esper.view.internal.BufferObserver
Receive new and old events from a stream.
newLatch(Object) - Method in class net.esper.core.InsertIntoLatchFactory
Returns a new latch.
newService() - Static method in class net.esper.dispatch.DispatchServiceProvider
Returns new service.
newService() - Static method in class net.esper.emit.EmitServiceProvider
Creates an implementation of the EmitService interface.
newService() - Static method in class net.esper.filter.FilterServiceProvider
Creates an implementation of the FilterEvaluationService interface.
newService() - Static method in class net.esper.schedule.SchedulingServiceProvider
Creates an implementation of the SchedulingService interface.
newService(boolean) - Static method in class net.esper.view.stream.StreamFactoryServiceProvider
Creates an implementation of the StreamFactoryService interface.
newService() - Static method in class net.esper.view.ViewServiceProvider
Creates an implementation of the ViewService interface.
newSiblingNumber() - Method in class net.esper.pattern.EvalNodeNumber
Returns a new sibling node number based on the current node.
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalAndNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalEveryNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalFilterNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalFollowedByNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalGuardNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalNode
Create the evaluation state node containing the truth value state for each operator in an event expression.
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalNotNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalObserverNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalOrNode
 
newState(Evaluator, MatchedEventMap, PatternContext, Object) - Method in class net.esper.pattern.EvalRootNode
 
next() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySetIterator
 
next - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
The next entry in the hash chain
next - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
The next entry
next() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashMapIterator
 
next() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.KeySetIterator
 
next() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.ValuesIterator
 
next() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Gets the next entry in the bucket.
next() - Method in interface net.esper.collection.apachecommons.MapIterator
Gets the next key from the Map.
next() - Method in class net.esper.collection.ArrayEventIterator
 
next() - Method in class net.esper.collection.IterablesListIterator
 
next() - Method in class net.esper.collection.NullIterator
 
next() - Method in class net.esper.collection.SafeIteratorImpl
 
next() - Method in class net.esper.collection.SingleEventIterator
 
next() - Method in class net.esper.collection.SingleObjectIterator
 
next() - Static method in class net.esper.collection.ThreadWorkQueue
Returns the next event to getSelectListEvents, or null if there are no more events.
next() - Method in class net.esper.collection.TimeWindowIterator
 
next() - Method in class net.esper.collection.TransformEventIterator
 
next() - Method in class net.esper.eql.core.ResultSetAggregateAllIterator
 
next() - Method in class net.esper.eql.core.ResultSetAggregateGroupedIterator
 
next() - Method in class net.esper.eql.core.ResultSetRowPerGroupIterator
 
next() - Method in class net.esper.eql.join.rep.NodeCursorIterator
 
next() - Method in class net.esper.eql.join.rep.SingleCursorIterator
 
next() - Method in class net.esper.eql.join.table.PropertyIndexedEventTableIterator
 
next() - Method in class net.esper.eql.view.FilterExprViewIterator
 
next() - Method in class net.esper.util.DOMElementIterator
 
next() - Method in class net.esper.view.ext.SortWindowIterator
 
next() - Method in class net.esper.view.ext.TimeOrderViewIterator
 
nextElement() - Method in class net.esper.collection.NumberSetPermutationEnumeration
 
nextElement() - Method in class net.esper.collection.PermutationEnumeration
 
nextEntry() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
Next entry.
nextIndize(int[], int[]) - Static method in class net.esper.view.stat.olap.CubeDimensionHelper
Increments the index values in the dimensionIndizes array given each dimension's size.
nextToken() - Method in class net.esper.eql.generated.EQLStatementLexer
 
NO_NEXT_ENTRY - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
Message.
NO_PREVIOUS_ENTRY - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
Message.
Node - Class in net.esper.eql.join.rep
Node is the structure to hold results of event lookups in joined streams.
Node(int) - Constructor for class net.esper.eql.join.rep.Node
Ctor.
NodeCursorIterator - Class in net.esper.eql.join.rep
Iterator over a set of nodes supplying node and event-within-node position information in a Cursor.
NodeCursorIterator(int, Iterator<Node>) - Constructor for class net.esper.eql.join.rep.NodeCursorIterator
Ctor.
NonNullCountAggregator - Class in net.esper.eql.agg
Count all non-null values.
NonNullCountAggregator() - Constructor for class net.esper.eql.agg.NonNullCountAggregator
 
not(Expression) - Static method in class net.esper.client.soda.Expressions
Not expression negates the sub-expression to the not which is expected to return boolean-typed values.
not(PatternExpr) - Static method in class net.esper.client.soda.Patterns
Not-keyword pattern expression flips the truth-value of the pattern sub-expression.
NOT_BETWEEN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_BETWEEN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_EQUAL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_EQUAL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_IN_RANGE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_IN_RANGE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_IN_SET - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_IN_SET - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_IN_SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_IN_SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_LIKE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_LIKE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NOT_REGEXP - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_REGEXP - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NotADataWindowViewCapability - Class in net.esper.eql.named
Expresses the requirement that all views are derived-value views and now data window views, with the exception of group-by and merge views.
NotADataWindowViewCapability() - Constructor for class net.esper.eql.named.NotADataWindowViewCapability
 
NotExpression - Class in net.esper.client.soda
Negates the contained-within subexpression.
NotExpression(Expression) - Constructor for class net.esper.client.soda.NotExpression
Ctor.
NotExpression() - Constructor for class net.esper.client.soda.NotExpression
Ctor - for use to create an expression tree, without child expression.
notFilter(String) - Static method in class net.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not MyEvent" syntax.
notFilter(String, String) - Static method in class net.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not tag=MyEvent" syntax.
notFilter(Filter) - Static method in class net.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not MyEvent(vol > 100)" syntax.
notFilter(Filter, String) - Static method in class net.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not tag=MyEvent(vol > 100)" syntax.
notIn(String, Object...) - Static method in class net.esper.client.soda.Expressions
Not-In-expression that is equivalent to the syntax of "property not in (value, value, ...
notIn(Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
Not-In-expression that is equivalent to the syntax of "property not in (value, value, ...
NStreamOuterQueryPlanBuilder - Class in net.esper.eql.join.plan
Builds a query plan for 3 or more streams in a outer join.
NStreamOuterQueryPlanBuilder() - Constructor for class net.esper.eql.join.plan.NStreamOuterQueryPlanBuilder
 
NStreamQueryPlanBuilder - Class in net.esper.eql.join.plan
Builds a query plan for 3 or more streams in a join.
NStreamQueryPlanBuilder() - Constructor for class net.esper.eql.join.plan.NStreamQueryPlanBuilder
 
NStreamQueryPlanBuilder.BestChainResult - Class in net.esper.eql.join.plan
Encapsulates the chain information.
NStreamQueryPlanBuilder.BestChainResult(int, int[]) - Constructor for class net.esper.eql.join.plan.NStreamQueryPlanBuilder.BestChainResult
Ctor.
NULL - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
An object for masking null
NULL_TREE_LOOKAHEAD - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NULL_TREE_LOOKAHEAD - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NULL_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NULL_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NullIterator<T> - Class in net.esper.collection
Iterator that never returns an elements.
NullIterator() - Constructor for class net.esper.collection.NullIterator
 
NUM_DOUBLE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUM_DOUBLE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NUM_FLOAT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUM_FLOAT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NUM_INT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUM_INT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NUM_LONG - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUM_LONG - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
number(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
number() - Method in class net.esper.eql.generated.EQLStatementParser
 
numberOfEvents - Variable in class net.esper.view.window.TimeLengthBatchViewFactory
Number of events to collect before batch fires.
NumberSetParameter - Interface in net.esper.type
Interface to generate a set of integers from parameters that include ranges, lists and frequencies.
NumberSetPermutationEnumeration - Class in net.esper.collection
Based on the PermutationEnumeration this enumeration provides, among a set of supplied integer values, all permutations of order these values can come in, ie.
NumberSetPermutationEnumeration(int[]) - Constructor for class net.esper.collection.NumberSetPermutationEnumeration
Ctor.
NUMERIC_PARAM_FREQUENCE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUMERIC_PARAM_FREQUENCY - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUMERIC_PARAM_FREQUENCY - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NUMERIC_PARAM_LIST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUMERIC_PARAM_LIST - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
NUMERIC_PARAM_RANGE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NUMERIC_PARAM_RANGE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
numericListParameter() - Method in class net.esper.eql.generated.EQLStatementParser
 
numericParameterList(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
numericParameterList() - Method in class net.esper.eql.generated.EQLStatementParser
 
NumIntegerSumAggregator - Class in net.esper.eql.agg
Sum for any number value.
NumIntegerSumAggregator() - Constructor for class net.esper.eql.agg.NumIntegerSumAggregator
 
numStreams - Variable in class net.esper.eql.join.assemble.BaseAssemblyNode
Number of streams in statement.

O

ObjectSpec - Class in net.esper.eql.spec
Encapsulates the information required to specify an object identification and construction.
ObjectSpec(String, String, List<Object>) - Constructor for class net.esper.eql.spec.ObjectSpec
Constructor.
observer(String, String, Object[]) - Static method in class net.esper.client.soda.Patterns
Observer pattern expression, equivalent to the "every timer:interval(1 sec)" syntax
OBSERVER_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
OBSERVER_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ObserverEnum - Enum in net.esper.pattern.observer
Enum for all build-in observers.
observerEvaluateFalse() - Method in class net.esper.pattern.EvalObserverStateNode
 
observerEvaluateFalse() - Method in interface net.esper.pattern.observer.ObserverEventEvaluator
Indicate that the observer turned permanently false.
observerEvaluateTrue(MatchedEventMap) - Method in class net.esper.pattern.EvalObserverStateNode
 
observerEvaluateTrue(MatchedEventMap) - Method in interface net.esper.pattern.observer.ObserverEventEvaluator
Indicate an event for evaluation (sub-expression the observer represents has turned true).
ObserverEventEvaluator - Interface in net.esper.pattern.observer
For use by EventObserver instances to place an event for processing/evaluation.
observerExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
ObserverFactory - Interface in net.esper.pattern.observer
Interface for factories for making observer instances.
ObserverFactorySupport - Class in net.esper.pattern.observer
Abstract class for applications to extend to implement a pattern observer factory.
ObserverFactorySupport() - Constructor for class net.esper.pattern.observer.ObserverFactorySupport
 
ObserverParameterException - Exception in net.esper.pattern.observer
Thrown to indicate a validation error in guard parameterization.
ObserverParameterException(String) - Constructor for exception net.esper.pattern.observer.ObserverParameterException
Ctor.
ON - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ON_DELETE_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON_DELETE_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ON_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ON_EXPR_FROM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON_EXPR_FROM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ON_SELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON_SELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ON_SET_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON_SET_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
OnClause - Class in net.esper.client.soda
A clause to delete from a named window based on a triggering event arriving and correlated to the named window events to be deleted.
OnClause() - Constructor for class net.esper.client.soda.OnClause
 
OnDeleteClause - Class in net.esper.client.soda
A clause to delete from a named window based on a triggering event arriving and correlated to the named window events to be deleted.
OnDeleteClause(String, String) - Constructor for class net.esper.client.soda.OnDeleteClause
Ctor.
onDeleteExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
onDeleteExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
OneEventLinkedList - Class in net.esper.collection
Simple collection that exposes a limited add-and-get interface and that is optimized towards holding a single event, but can hold multiple events.
OneEventLinkedList() - Constructor for class net.esper.collection.OneEventLinkedList
 
onExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
onExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
onExprFrom(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
onExprFrom() - Method in class net.esper.eql.generated.EQLStatementParser
 
OnSelectClause - Class in net.esper.client.soda
A clause to delete from a named window based on a triggering event arriving and correlated to the named window events to be deleted.
OnSelectClause(String, String) - Constructor for class net.esper.client.soda.OnSelectClause
Ctor.
onSelectExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
onSelectExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
onSetAssignment(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
onSetAssignment() - Method in class net.esper.eql.generated.EQLStatementParser
 
OnSetClause - Class in net.esper.client.soda
A clause to assign new values to variables based on a triggering event arriving.
OnSetClause() - Constructor for class net.esper.client.soda.OnSetClause
Ctor.
onSetExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
onSetExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
OnSetVariableView - Class in net.esper.eql.variable
A view that handles the setting of variables upon receipt of a triggering event.
OnSetVariableView(OnTriggerSetDesc, EventAdapterService, VariableService) - Constructor for class net.esper.eql.variable.OnSetVariableView
Ctor.
OnTriggerDesc - Class in net.esper.eql.spec
Specification for on-trigger statements.
OnTriggerDesc(OnTriggerType) - Constructor for class net.esper.eql.spec.OnTriggerDesc
Ctor.
OnTriggerSetAssignment - Class in net.esper.eql.spec
Descriptor for an on-set assignment.
OnTriggerSetAssignment(String, ExprNode) - Constructor for class net.esper.eql.spec.OnTriggerSetAssignment
Ctor.
OnTriggerSetDesc - Class in net.esper.eql.spec
Specification for the on-set statement.
OnTriggerSetDesc() - Constructor for class net.esper.eql.spec.OnTriggerSetDesc
Ctor.
OnTriggerType - Enum in net.esper.eql.spec
Enum for the type of on-trigger statement.
OnTriggerWindowDesc - Class in net.esper.eql.spec
Specification for the on-delete statement.
OnTriggerWindowDesc(String, String, boolean) - Constructor for class net.esper.eql.spec.OnTriggerWindowDesc
Ctor.
optionalReferencePoint - Variable in class net.esper.view.window.TimeBatchViewFactory
The reference point, or null if none supplied.
or() - Static method in class net.esper.client.soda.Expressions
Logical OR disjunction.
or(Expression, Expression, Expression...) - Static method in class net.esper.client.soda.Expressions
Logical OR disjunction.
or(PatternExpr, PatternExpr, PatternExpr...) - Static method in class net.esper.client.soda.Patterns
Pattern-OR expression, allows adding sub-expressions that are connected by a logical OR.
or() - Static method in class net.esper.client.soda.Patterns
Pattern-OR expression, allows adding sub-expressions that are connected by a logical OR.
OR_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
OR_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ORDER - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ORDER - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ORDER_BY_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ORDER_BY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ORDER_ELEMENT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ORDER_ELEMENT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
OrderByClause - Class in net.esper.client.soda
An order-by clause consists of expressions and flags indicating if ascending or descending.
OrderByClause() - Constructor for class net.esper.client.soda.OrderByClause
Ctor.
OrderByClause(String...) - Constructor for class net.esper.client.soda.OrderByClause
Ctor.
OrderByClause(Expression...) - Constructor for class net.esper.client.soda.OrderByClause
Ctor.
orderByClause(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
OrderByElement - Class in net.esper.client.soda
A single entry in an order-by clause consisting of an expression and order ascending or descending flag.
OrderByElement(Expression, boolean) - Constructor for class net.esper.client.soda.OrderByElement
Ctor.
orderByElement(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
OrderByItem - Class in net.esper.eql.spec
Specification object to an element in the order-by expression.
OrderByItem(ExprNode, boolean) - Constructor for class net.esper.eql.spec.OrderByItem
Ctor.
orderByListElement() - Method in class net.esper.eql.generated.EQLStatementParser
 
orderByListExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
OrderByProcessor - Interface in net.esper.eql.core
A processor for ordering output events according to the order specified in the order-by clause.
OrderByProcessorFactory - Class in net.esper.eql.core
Factory for OrderByProcessor processors.
OrderByProcessorFactory() - Constructor for class net.esper.eql.core.OrderByProcessorFactory
 
OrderByProcessorSimple - Class in net.esper.eql.core
An order-by processor that sorts events according to the expressions in the order_by clause.
OrderByProcessorSimple(List<OrderByItem>, List<ExprNode>, boolean, AggregationService) - Constructor for class net.esper.eql.core.OrderByProcessorSimple
Ctor.
orExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
OUTER - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
OUTER - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
OuterInnerDirectionalGraph - Class in net.esper.eql.join.plan
This class represents outer-join relationships between outer and inner tables.
OuterInnerDirectionalGraph(int) - Constructor for class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Ctor.
outerJoin(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
outerJoin() - Method in class net.esper.eql.generated.EQLStatementParser
 
OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
OuterJoinAnalyzer - Class in net.esper.eql.join.plan
Analyzes an outer join descriptor list and builds a query graph model from it.
OuterJoinAnalyzer() - Constructor for class net.esper.eql.join.plan.OuterJoinAnalyzer
 
OuterJoinDesc - Class in net.esper.eql.spec
Contains the ON-clause criteria in an outer join.
OuterJoinDesc(OuterJoinType, ExprIdentNode, ExprIdentNode, ExprIdentNode[], ExprIdentNode[]) - Constructor for class net.esper.eql.spec.OuterJoinDesc
Ctor.
outerJoinIdent(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
outerJoinIdent() - Method in class net.esper.eql.generated.EQLStatementParser
 
outerJoinIdentPair() - Method in class net.esper.eql.generated.EQLStatementParser
 
outerJoinList() - Method in class net.esper.eql.generated.EQLStatementParser
 
OuterJoinQualifier - Class in net.esper.client.soda
Qualifies a join by providing the outer join type (full/left/right) and joined-on properties.
OuterJoinQualifier(OuterJoinType, PropertyValueExpression, PropertyValueExpression) - Constructor for class net.esper.client.soda.OuterJoinQualifier
Ctor.
OuterJoinQualifier(OuterJoinType, PropertyValueExpression, PropertyValueExpression, ArrayList<Pair<PropertyValueExpression, PropertyValueExpression>>) - Constructor for class net.esper.client.soda.OuterJoinQualifier
Ctor.
OuterJoinType - Enum in net.esper.type
Enum for the type of outer join.
OUTPUT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
OUTPUT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
OutputCallback - Interface in net.esper.eql.view
A wrapper for the callback from the output limit condition to the output handler.
OutputCondition - Interface in net.esper.eql.view
A condition that must be satisfied before output processing is allowed to continue.
OutputConditionCount - Class in net.esper.eql.view
Output limit condition that is satisfied when either the total number of new events arrived or the total number of old events arrived is greater than a preset value.
OutputConditionCount(int, VariableReader, OutputCallback) - Constructor for class net.esper.eql.view.OutputConditionCount
Constructor.
OutputConditionFactory - Interface in net.esper.eql.view
Factory for output condition instances.
OutputConditionFactoryDefault - Class in net.esper.eql.view
Factory for output condition instances.
OutputConditionFactoryDefault() - Constructor for class net.esper.eql.view.OutputConditionFactoryDefault
 
OutputConditionFirst - Class in net.esper.eql.view
An output condition that is satisfied at the first event of either a time-based or count-based batch.
OutputConditionFirst(OutputLimitSpec, StatementContext, OutputCallback) - Constructor for class net.esper.eql.view.OutputConditionFirst
Ctor.
OutputConditionNull - Class in net.esper.eql.view
An empty output condition that is always satisfied.
OutputConditionNull(OutputCallback) - Constructor for class net.esper.eql.view.OutputConditionNull
Ctor.
OutputConditionTime - Class in net.esper.eql.view
Output condition that is satisfied at the end of every time interval of a given length.
OutputConditionTime(Double, boolean, VariableReader, StatementContext, OutputCallback) - Constructor for class net.esper.eql.view.OutputConditionTime
Constructor.
outputLimit() - Method in class net.esper.eql.generated.EQLStatementParser
 
OutputLimitClause - Class in net.esper.client.soda
An output limit clause defines how to limit output of statements and consists of a selector specifiying which events to select to output, a frequency and a unit.
OutputLimitClause(OutputLimitSelector, Double, OutputLimitUnit) - Constructor for class net.esper.client.soda.OutputLimitClause
Ctor.
OutputLimitClause(OutputLimitSelector, String, OutputLimitUnit) - Constructor for class net.esper.client.soda.OutputLimitClause
Ctor.
OutputLimitClause(OutputLimitSelector, Double, String, OutputLimitUnit) - Constructor for class net.esper.client.soda.OutputLimitClause
Ctor.
outputLimitExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
OutputLimitLimitType - Enum in net.esper.eql.spec
Enum for describing the type of output limit within an interval.
OutputLimitRateType - Enum in net.esper.eql.spec
Enum for the type of rate for output-rate limiting.
OutputLimitSelector - Enum in net.esper.client.soda
Selector for use in output rate limiting.
OutputLimitSpec - Class in net.esper.eql.spec
Spec for defining an output rate
OutputLimitSpec(Double, String, OutputLimitRateType, OutputLimitLimitType) - Constructor for class net.esper.eql.spec.OutputLimitSpec
Ctor.
OutputLimitUnit - Enum in net.esper.client.soda
Unit for output rate limiting.
OutputProcessView - Class in net.esper.eql.view
Base output processing view that has the responsibility to serve up event type and statement iterator.
OutputProcessView(ResultSetProcessor) - Constructor for class net.esper.eql.view.OutputProcessView
Ctor.
OutputProcessViewDirect - Class in net.esper.eql.view
Output process view that does not enforce any output policies and may simply hand over events to child views.
OutputProcessViewDirect(ResultSetProcessor) - Constructor for class net.esper.eql.view.OutputProcessViewDirect
Ctor.
OutputProcessViewFactory - Class in net.esper.eql.view
Factory for output processing views.
OutputProcessViewFactory() - Constructor for class net.esper.eql.view.OutputProcessViewFactory
 
OutputProcessViewPolicy - Class in net.esper.eql.view
A view that prepares output events, batching incoming events and invoking the result set processor as necessary.
OutputProcessViewPolicy(ResultSetProcessor, int, OutputLimitSpec, StatementContext) - Constructor for class net.esper.eql.view.OutputProcessViewPolicy
Ctor.

P

pageField - Variable in class net.esper.view.stat.MultiDimStatsViewFactory
Property name supplying pages.
Pair<First,Second> - Class in net.esper.collection
General-purpose pair of values of any type.
Pair(First, Second) - Constructor for class net.esper.collection.Pair
Construct pair of values.
parameter(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
parameter() - Method in class net.esper.eql.generated.EQLStatementParser
 
parameterSet() - Method in class net.esper.eql.generated.EQLStatementParser
 
parent - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
The parent map
parent - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
The parent map
parent - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
The parent map
parent - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.Values
The parent map
parent - Variable in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
The parent map
parent - Variable in class net.esper.view.ViewSupport
Parent viewable to this view - directly accessible by subclasses.
parentNode - Variable in class net.esper.eql.join.assemble.BaseAssemblyNode
Parent node.
parse(AST) - Static method in class net.esper.eql.parse.ASTConstantHelper
Parse the AST constant node and return Object value.
parse(String, ParseRuleSelector) - Static method in class net.esper.eql.parse.ParseHelper
Parse expression using the rule the ParseRuleSelector instance supplies.
parse(String, BeanEventTypeFactory) - Static method in class net.esper.event.property.PropertyParser
Parse the given property name returning a Property instance for the property.
parse(String, XPathFactory, String, String, XSModel) - Static method in class net.esper.event.xml.SchemaXMLPropertyParser
Return the xPath corresponding to the given property.
parse(String, String, String, boolean) - Static method in class net.esper.event.xml.SimpleXMLPropertyParser
Return the xPath corresponding to the given property.
parse(String) - Static method in class net.esper.event.xml.SimpleXMLPropertyParser
Parses a given property name returning an AST.
parse(String) - Method in class net.esper.type.BoolValue
 
parse(String) - Method in class net.esper.type.ByteValue
 
parse(String) - Method in class net.esper.type.DoubleValue
 
parse(String) - Method in class net.esper.type.FloatValue
 
parse(String) - Method in class net.esper.type.IntValue
 
parse(String) - Method in class net.esper.type.LongValue
 
parse(String) - Method in interface net.esper.type.PrimitiveValue
Parse the string literal value into the specific data type.
parse(String[]) - Method in interface net.esper.type.PrimitiveValue
Parse the string literal values supplied in the array into the specific data type.
parse(String[]) - Method in class net.esper.type.PrimitiveValueBase
 
parse(String) - Static method in enum net.esper.type.RelationalOpEnum
Parses the operator and returns an enum for the operator.
parse(String) - Method in class net.esper.type.ShortValue
 
parse(String) - Method in class net.esper.type.StringValue
 
parse(Class, String) - Static method in class net.esper.util.JavaClassHelper
Parse the String using the given Java built-in class for parsing.
parseComparisonOperator(String) - Static method in enum net.esper.filter.FilterOperator
Parse the comparison operator returning null if not a valid operator.
ParseHelper - Class in net.esper.eql.parse
Helper class for parsing an expression and walking a parse tree.
ParseHelper() - Constructor for class net.esper.eql.parse.ParseHelper
 
parseMappedProperty(String) - Static method in class net.esper.eql.expression.ExprNode
Parse the mapped property into classname, method and string argument.
parseOperator(String) - Static method in enum net.esper.type.MathArithTypeEnum
Returns the math operator for the string.
parsePlaceholder(String) - Static method in class net.esper.util.PlaceholderParser
Parses a string to find placeholders of format ${placeholder}.
parseRangeOperator(boolean, boolean, boolean) - Static method in enum net.esper.filter.FilterOperator
Parse the range operator from booleans describing whether the start or end values are exclusive.
ParseRuleSelector - Interface in net.esper.eql.parse
For selection of the parse rule to use.
parseString(String) - Static method in class net.esper.type.BoolValue
Parse the boolean string.
parseString(String[]) - Static method in class net.esper.type.BoolValue
Parse the string array returning a boolean array.
parseString(String) - Static method in class net.esper.type.ByteValue
Parses a string value as a byte.
parseString(String) - Static method in class net.esper.type.DoubleValue
Parse string value returning a double.
parseString(String[]) - Static method in class net.esper.type.DoubleValue
Parse the string array returning a double array.
parseString(String) - Static method in class net.esper.type.FloatValue
Parse string value returning a float.
parseString(String[]) - Static method in class net.esper.type.FloatValue
Parse the string array returning a float array.
parseString(String[]) - Static method in class net.esper.type.IntValue
Parse the string array returning a int array.
parseString(String) - Static method in class net.esper.type.IntValue
Parse string value returning a int.
parseString(String) - Static method in class net.esper.type.LongValue
Parse the string containing a long value.
parseString(String[]) - Static method in class net.esper.type.LongValue
Parse the string array returning a long array.
parseString(String) - Static method in class net.esper.type.ShortValue
Parses a string value as a short.
parseString(String[]) - Static method in class net.esper.type.StringValue
Parse the string array returning a string array.
parseString(String) - Static method in class net.esper.type.StringValue
Parse the string literal consisting of text between double-quotes or single-quotes.
PATTERN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PATTERN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
PATTERN_INCL_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PATTERN_INCL_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
PatternAndExpr - Class in net.esper.client.soda
Logical AND for use in pattern expressions.
PatternAndExpr() - Constructor for class net.esper.client.soda.PatternAndExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternAndExpr(PatternExpr, PatternExpr, PatternExpr...) - Constructor for class net.esper.client.soda.PatternAndExpr
Ctor.
PatternContext - Class in net.esper.pattern
Contains handles to implementations of services needed by evaluation nodes.
PatternContext(StatementContext, int, PatternStateFactory) - Constructor for class net.esper.pattern.PatternContext
Constructor.
PatternContextFactory - Interface in net.esper.pattern
Factory for pattern context instances, creating context objects for each distinct pattern based on the patterns root node and stream id.
PatternContextFactoryDefault - Class in net.esper.pattern
Default pattern context factory.
PatternContextFactoryDefault() - Constructor for class net.esper.pattern.PatternContextFactoryDefault
 
PatternEveryExpr - Class in net.esper.client.soda
Pattern 'every' expression that controls the lifecycle of pattern sub-expressions.
PatternEveryExpr() - Constructor for class net.esper.client.soda.PatternEveryExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternEveryExpr(PatternExpr) - Constructor for class net.esper.client.soda.PatternEveryExpr
Ctor.
PatternExpr - Interface in net.esper.client.soda
Interface representing a pattern expression.
PatternExprBase - Class in net.esper.client.soda
Abstract base class for all pattern expressions.
PatternExprBase() - Constructor for class net.esper.client.soda.PatternExprBase
Ctor.
patternExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
PatternFilterExpr - Class in net.esper.client.soda
Filter for use in pattern expressions.
PatternFilterExpr(Filter) - Constructor for class net.esper.client.soda.PatternFilterExpr
Ctor.
PatternFilterExpr(Filter, String) - Constructor for class net.esper.client.soda.PatternFilterExpr
Ctor.
PatternFollowedByExpr - Class in net.esper.client.soda
Followed-by for use in pattern expressions.
PatternFollowedByExpr() - Constructor for class net.esper.client.soda.PatternFollowedByExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternFollowedByExpr(PatternExpr, PatternExpr, PatternExpr...) - Constructor for class net.esper.client.soda.PatternFollowedByExpr
Ctor.
PatternGuardExpr - Class in net.esper.client.soda
Guard is the where timer-within pattern object for use in pattern expressions.
PatternGuardExpr(String, String, List<Object>) - Constructor for class net.esper.client.soda.PatternGuardExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternGuardExpr(String, String, Object[], PatternExpr) - Constructor for class net.esper.client.soda.PatternGuardExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternGuardExpr(String, String, List<Object>, PatternExpr) - Constructor for class net.esper.client.soda.PatternGuardExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternGuardSpec - Class in net.esper.eql.spec
Specification for a pattern guard object consists of a namespace, name and guard object parameters.
PatternGuardSpec(String, String, List<Object>) - Constructor for class net.esper.eql.spec.PatternGuardSpec
Constructor.
patternInclusionExpression(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
patternInclusionExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
PatternListenerDispatch - Class in net.esper.core
Dispatchable for dispatching events to update listeners.
PatternListenerDispatch(Set<UpdateListener>) - Constructor for class net.esper.core.PatternListenerDispatch
Constructor.
PatternMatchCallback - Interface in net.esper.pattern
Callback interface for anything that requires to be informed of matching events which would be stored in the MatchedEventMap structure passed to the implementation.
PatternNotExpr - Class in net.esper.client.soda
Not-expression for negating a pattern sub-expression for use in pattern expressions.
PatternNotExpr() - Constructor for class net.esper.client.soda.PatternNotExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternNotExpr(PatternExpr) - Constructor for class net.esper.client.soda.PatternNotExpr
Ctor.
PatternObjectException - Exception in net.esper.pattern
This exception is thrown to indicate a problem with a view expression.
PatternObjectException(String) - Constructor for exception net.esper.pattern.PatternObjectException
Constructor.
PatternObjectException(String, Throwable) - Constructor for exception net.esper.pattern.PatternObjectException
Constructor for an inner exception and message.
PatternObjectException(Throwable) - Constructor for exception net.esper.pattern.PatternObjectException
Constructor.
PatternObjectHelper - Class in net.esper.pattern
Helper producing a repository of built-in pattern objects.
PatternObjectHelper() - Constructor for class net.esper.pattern.PatternObjectHelper
 
PatternObjectResolutionService - Interface in net.esper.pattern
Factory service for resolving pattern objects such as guards and observers.
PatternObjectResolutionServiceImpl - Class in net.esper.pattern
Resolves pattern object namespace and name to guard or observer factory class, using configuration.
PatternObjectResolutionServiceImpl(PluggableObjectCollection) - Constructor for class net.esper.pattern.PatternObjectResolutionServiceImpl
Ctor.
PatternObserverExpr - Class in net.esper.client.soda
Pattern observer expression observes occurances such as timer-at (crontab) and timer-interval.
PatternObserverExpr(String, String, Object[]) - Constructor for class net.esper.client.soda.PatternObserverExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternObserverExpr(String, String, List<Object>) - Constructor for class net.esper.client.soda.PatternObserverExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternObserverSpec - Class in net.esper.eql.spec
Specification for a pattern observer object consists of a namespace, name and object parameters.
PatternObserverSpec(String, String, List<Object>) - Constructor for class net.esper.eql.spec.PatternObserverSpec
Constructor.
patternOp(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
PatternOrExpr - Class in net.esper.client.soda
Logical OR for use in pattern expressions.
PatternOrExpr() - Constructor for class net.esper.client.soda.PatternOrExpr
Ctor - for use to create a pattern expression tree, without pattern child expression.
PatternOrExpr(PatternExpr, PatternExpr, PatternExpr...) - Constructor for class net.esper.client.soda.PatternOrExpr
Ctor.
Patterns - Class in net.esper.client.soda
Convenience factory for creating PatternExpr instances, which represent pattern expression trees.
Patterns() - Constructor for class net.esper.client.soda.Patterns
 
PatternStarter - Interface in net.esper.pattern
Interface for observing when an event expression needs to start (by adding the first listener).
PatternStateFactory - Interface in net.esper.pattern
Factory for pattern state object implementations.
PatternStateFactoryImpl - Class in net.esper.pattern
Default pattern state factory.
PatternStateFactoryImpl() - Constructor for class net.esper.pattern.PatternStateFactoryImpl
 
PatternStopCallback - Interface in net.esper.pattern
Interface for executing a stop on an active event expression.
PatternStream - Class in net.esper.client.soda
A stream of events that is generated by pattern matches.
PatternStream(PatternExpr) - Constructor for class net.esper.client.soda.PatternStream
Ctor.
PatternStream(PatternExpr, String) - Constructor for class net.esper.client.soda.PatternStream
Ctor.
PatternStreamSpecCompiled - Class in net.esper.eql.spec
Specification for building an event stream out of a pattern statement and views staggered onto the pattern statement.
PatternStreamSpecCompiled(EvalNode, Map<String, EventType>, List<ViewSpec>, String) - Constructor for class net.esper.eql.spec.PatternStreamSpecCompiled
Ctor.
PatternStreamSpecRaw - Class in net.esper.eql.spec
Pattern specification in unvalidated, unoptimized form.
PatternStreamSpecRaw(EvalNode, List<ViewSpec>, String) - Constructor for class net.esper.eql.spec.PatternStreamSpecRaw
Ctor.
PermutationEnumeration - Class in net.esper.collection
Provides a N! (n-faculty) number of permutations for N elements.
PermutationEnumeration(int) - Constructor for class net.esper.collection.PermutationEnumeration
Ctor.
PlaceholderParseException - Exception in net.esper.util
Exception to indicate a parse error in parsing placeholders.
PlaceholderParseException(String) - Constructor for exception net.esper.util.PlaceholderParseException
Ctor.
PlaceholderParser - Class in net.esper.util
Parser for strings with substitution parameters of the form ${parameter}.
PlaceholderParser() - Constructor for class net.esper.util.PlaceholderParser
 
PlaceholderParser.Fragment - Class in net.esper.util
Fragment is a parse result, a parse results in an ordered list of fragments.
PlaceholderParser.Fragment(String) - Constructor for class net.esper.util.PlaceholderParser.Fragment
Ctor.
PlaceholderParser.ParameterFragment - Class in net.esper.util
Represents a parameter in a parsed string of texts and parameters.
PlaceholderParser.ParameterFragment(String) - Constructor for class net.esper.util.PlaceholderParser.ParameterFragment
Ctor.
PlaceholderParser.TextFragment - Class in net.esper.util
Represents a piece of text in a parse string with placeholder values.
PlaceholderParser.TextFragment(String) - Constructor for class net.esper.util.PlaceholderParser.TextFragment
Ctor.
PluggableObjectCollection - Class in net.esper.eql.spec
Repository for pluggable objects of different types that follow a "namespace:name" notation.
PluggableObjectCollection() - Constructor for class net.esper.eql.spec.PluggableObjectCollection
Ctor.
PluggableObjectType - Enum in net.esper.eql.spec
Enumeration for types of plug-in objects.
plugInAggregation(String, Expression) - Static method in class net.esper.client.soda.Expressions
Plug-in aggregation function.
plugInAggregationFunctions - Variable in class net.esper.client.Configuration
List of configured plug-in aggregation functions.
plugInPatternObjects - Variable in class net.esper.client.Configuration
List of configured plug-in pattern objects.
PlugInProjectionExpression - Class in net.esper.client.soda
Represents a plug-in aggregation function.
PlugInProjectionExpression(String, boolean) - Constructor for class net.esper.client.soda.PlugInProjectionExpression
Ctor.
PlugInProjectionExpression(String, boolean, Expression) - Constructor for class net.esper.client.soda.PlugInProjectionExpression
Ctor.
plugInViews - Variable in class net.esper.client.Configuration
List of configured plug-in views.
plus(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Addition.
plus(String, String) - Static method in class net.esper.client.soda.Expressions
Addition.
PLUS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PLUS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
PLUS_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PLUS_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
poll(Object[]) - Method in class net.esper.eql.core.MethodPollingExecStrategy
 
poll(EventBean[][], PollResultIndexingStrategy) - Method in class net.esper.eql.core.MethodPollingViewable
 
poll(EventBean[][], PollResultIndexingStrategy) - Method in class net.esper.eql.db.DatabasePollingViewable
 
poll(Object[]) - Method in interface net.esper.eql.db.PollExecStrategy
Poll events using the keys provided.
poll(Object[]) - Method in class net.esper.eql.db.PollExecStrategyDBQuery
 
poll(EventBean[][], PollResultIndexingStrategy) - Method in interface net.esper.view.HistoricalEventViewable
Poll for stored historical or reference data using events per stream and returing for each event-per-stream row a separate list with events representing the poll result.
PollExecStrategy - Interface in net.esper.eql.db
Interface for polling data from a data source such as a relational database.
PollExecStrategyDBQuery - Class in net.esper.eql.db
Viewable providing historical data from a database.
PollExecStrategyDBQuery(EventAdapterService, EventType, ConnectionCache, String, Map<String, DBOutputTypeDesc>) - Constructor for class net.esper.eql.db.PollExecStrategyDBQuery
Ctor.
PollResultIndexingStrategy - Interface in net.esper.eql.join
A strategy for converting a poll-result into a potentially indexed table.
PollResultIndexingStrategyIndex - Class in net.esper.eql.join
Strategy for building an index out of poll-results knowing the properties to base the index on.
PollResultIndexingStrategyIndex(int, EventType, String[]) - Constructor for class net.esper.eql.join.PollResultIndexingStrategyIndex
Ctor.
PollResultIndexingStrategyIndexCoerce - Class in net.esper.eql.join
Strategy for building an index out of poll-results knowing the properties to base the index on, and their coercion types.
PollResultIndexingStrategyIndexCoerce(int, EventType, String[], Class[]) - Constructor for class net.esper.eql.join.PollResultIndexingStrategyIndexCoerce
Ctor.
PollResultIndexingStrategyNoIndex - Class in net.esper.eql.join
Strategy of indexing that simply builds an unindexed table of poll results.
PollResultIndexingStrategyNoIndex() - Constructor for class net.esper.eql.join.PollResultIndexingStrategyNoIndex
 
preloadFromBuffer(int) - Method in interface net.esper.eql.join.JoinPreloadMethod
Initialize a stream from the stream buffers data.
preloadFromBuffer(int) - Method in class net.esper.eql.join.JoinPreloadMethodImpl
 
prepareEQL(String) - Method in interface net.esper.client.EPAdministrator
Prepares a statement for the given EQL, which can include substitution parameters marked via question mark '?'.
prepareEQL(String) - Method in class net.esper.core.EPAdministratorImpl
 
preparePattern(String) - Method in interface net.esper.client.EPAdministrator
Prepares a statement for the given pattern, which can include substitution parameters marked via question mark '?'.
preparePattern(String) - Method in class net.esper.core.EPAdministratorImpl
 
previous(Expression, String) - Static method in class net.esper.client.soda.Expressions
Previous function.
previous(int, String) - Static method in class net.esper.client.soda.Expressions
Previous function.
PREVIOUS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PREVIOUS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
PreviousExpression - Class in net.esper.client.soda
Previous function for obtaining property values of previous events.
PreviousExpression() - Constructor for class net.esper.client.soda.PreviousExpression
Ctor.
PreviousExpression(Expression, String) - Constructor for class net.esper.client.soda.PreviousExpression
Ctor.
PreviousExpression(int, String) - Constructor for class net.esper.client.soda.PreviousExpression
Ctor.
PrimitiveValue - Interface in net.esper.type
Classes implementing this interface are responsible for parsing, setting and getting the value of the different basic Java data types that occur in an event expression.
PrimitiveValueBase - Class in net.esper.type
Abstract class for literal values supplied in an event expression string and prepared expression values supplied by set methods.
PrimitiveValueBase() - Constructor for class net.esper.type.PrimitiveValueBase
 
PrimitiveValueFactory - Class in net.esper.type
Factory class for PrimitiveValue for all fundamental Java types.
PrimitiveValueFactory() - Constructor for class net.esper.type.PrimitiveValueFactory
 
PrimitiveValueType - Enum in net.esper.type
Enumeration of types of primitive values.
print(IndentWriter) - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Output this node using writer, not outputting child nodes.
print(IndentWriter) - Method in class net.esper.eql.join.assemble.BranchOptionalAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.assemble.BranchRequiredAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.assemble.LeafAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.assemble.RootCartProdAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.assemble.RootOptionalAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.assemble.RootRequiredAssemblyNode
 
print(IndentWriter) - Method in class net.esper.eql.join.exec.ExecNode
Output the execution strategy.
print(ExecNode) - Static method in class net.esper.eql.join.exec.ExecNode
Print in readable format the execution strategy.
print(IndentWriter) - Method in class net.esper.eql.join.exec.LookupInstructionExec
Output the instruction.
print(IndentWriter) - Method in class net.esper.eql.join.exec.LookupInstructionExecNode
 
print(IndentWriter) - Method in class net.esper.eql.join.exec.NestedIterationExecNode
 
print(IndentWriter) - Method in class net.esper.eql.join.exec.TableLookupExecNode
 
print(IndentWriter) - Method in class net.esper.eql.join.exec.TableOuterLookupExecNode
 
print(IndentWriter) - Method in class net.esper.eql.join.plan.LookupInstructionPlan
Output the planned instruction.
print(IndentWriter) - Method in class net.esper.eql.join.plan.LookupInstructionQueryPlanNode
 
print(IndentWriter) - Method in class net.esper.eql.join.plan.NestedIterationNode
 
print(Map<Integer, int[]>) - Static method in class net.esper.eql.join.plan.NStreamOuterQueryPlanBuilder
Returns textual presentation of stream-substream relationships.
print() - Method in class net.esper.eql.join.plan.OuterInnerDirectionalGraph
Prints out collection.
print(QueryPlanIndex[]) - Static method in class net.esper.eql.join.plan.QueryPlanIndex
Print index specifications in readable format.
print(IndentWriter) - Method in class net.esper.eql.join.plan.QueryPlanNode
Print a long readable format of the query node to the supplied PrintWriter.
print(QueryPlanNode[]) - Static method in class net.esper.eql.join.plan.QueryPlanNode
Print in readable format the execution plan spec.
print(IndentWriter) - Method in class net.esper.eql.join.plan.TableLookupNode
 
print(IndentWriter) - Method in class net.esper.eql.join.plan.TableOuterLookupNode
 
printDescendends(IndentWriter) - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Output this node and all descendent nodes using writer, outputting child nodes.
printEvent(EventBean) - Static method in class net.esper.event.EventBeanUtility
Format the event and return a string representation.
println(String) - Method in class net.esper.util.IndentWriter
Print text to the underlying writer.
prior(int, String) - Static method in class net.esper.client.soda.Expressions
Prior function.
PRIOR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PRIOR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
PriorEventBufferMulti - Class in net.esper.view.internal
Buffers view-posted insert stream (new data) and remove stream (old data) events for use with determining prior results in these streams, for multiple different prior events.
PriorEventBufferMulti(int[]) - Constructor for class net.esper.view.internal.PriorEventBufferMulti
Ctor.
PriorEventBufferSingle - Class in net.esper.view.internal
Buffers view-posted insert stream (new data) and remove stream (old data) events for use with serving prior results in these streams, for a single prior event.
PriorEventBufferSingle(int) - Constructor for class net.esper.view.internal.PriorEventBufferSingle
Ctor.
PriorEventBufferUnbound - Class in net.esper.view.internal
Buffer class for insert stream events only for use with unbound streams that inserts data only, to serve up one or more prior events in the insert stream based on an index.
PriorEventBufferUnbound(int) - Constructor for class net.esper.view.internal.PriorEventBufferUnbound
Ctor.
PriorEventView - Class in net.esper.view.internal
View that provides access to prior events posted by the parent view for use by 'prior' expression nodes.
PriorEventView(ViewUpdatedCollection) - Constructor for class net.esper.view.internal.PriorEventView
Ctor.
PriorEventViewFactory - Class in net.esper.view.internal
Factory for making PriorEventView instances.
PriorEventViewFactory() - Constructor for class net.esper.view.internal.PriorEventViewFactory
 
PriorEventViewFactory.RelativeAccessImpl - Class in net.esper.view.internal
Adapter to provide access given an index.
PriorEventViewFactory.RelativeAccessImpl(RelativeAccessByEventNIndex, int) - Constructor for class net.esper.view.internal.PriorEventViewFactory.RelativeAccessImpl
Ctor.
PriorExpression - Class in net.esper.client.soda
Expression representing the prior function.
PriorExpression() - Constructor for class net.esper.client.soda.PriorExpression
Ctor - for use to create an expression tree, without child expression.
PriorExpression(int, String) - Constructor for class net.esper.client.soda.PriorExpression
Ctor.
process(EventBean[], boolean) - Method in class net.esper.eql.core.SelectExprEvalProcessor
 
process(EventBean[], boolean) - Method in class net.esper.eql.core.SelectExprEvalProcessorStreams
 
process(EventBean[], boolean) - Method in class net.esper.eql.core.SelectExprJoinWildcardProcessor
 
process(EventBean[], boolean) - Method in interface net.esper.eql.core.SelectExprProcessor
Computes the select-clause results and returns an event of the result event type that contains, in it's properties, the selected items.
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Process results.
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.BranchOptionalAssemblyNode
 
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.BranchRequiredAssemblyNode
 
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode
 
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.LeafAssemblyNode
 
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.RootCartProdAssemblyNode
 
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.RootOptionalAssemblyNode
 
process(List<Node>[]) - Method in class net.esper.eql.join.assemble.RootRequiredAssemblyNode
 
process(EventBean, EventBean[], List<EventBean[]>) - Method in class net.esper.eql.join.exec.ExecNode
Process single event using the prefill events to compile lookup results.
process(Repository) - Method in class net.esper.eql.join.exec.LookupInstructionExec
Execute the instruction adding results to the repository and obtaining events for lookup from the repository.
process(EventBean, EventBean[], List<EventBean[]>) - Method in class net.esper.eql.join.exec.LookupInstructionExecNode
 
process(EventBean, EventBean[], List<EventBean[]>) - Method in class net.esper.eql.join.exec.NestedIterationExecNode
 
process(EventBean, EventBean[], List<EventBean[]>) - Method in class net.esper.eql.join.exec.TableLookupExecNode
 
process(EventBean, EventBean[], List<EventBean[]>) - Method in class net.esper.eql.join.exec.TableOuterLookupExecNode
 
process(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.join.JoinSetFilter
 
process(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in interface net.esper.eql.join.JoinSetProcessor
Process join result set.
process(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.view.OutputProcessViewDirect
This process (update) method is for participation in a join.
process(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.view.OutputProcessViewPolicy
This process (update) method is for participation in a join.
processJoinResult(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in interface net.esper.eql.core.ResultSetProcessor
For use by joins posting their result, process the event rows that are entered and removed (new and old events).
processJoinResult(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
 
processJoinResult(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
 
processJoinResult(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorRowForAll
 
processJoinResult(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
 
processJoinResult(Set<MultiKey<EventBean>>, Set<MultiKey<EventBean>>) - Method in class net.esper.eql.core.ResultSetProcessorSimple
 
processViewResult(EventBean[], EventBean[]) - Method in interface net.esper.eql.core.ResultSetProcessor
For use by views posting their result, process the event rows that are entered and removed (new and old events).
processViewResult(EventBean[], EventBean[]) - Method in class net.esper.eql.core.ResultSetProcessorAggregateAll
 
processViewResult(EventBean[], EventBean[]) - Method in class net.esper.eql.core.ResultSetProcessorAggregateGrouped
 
processViewResult(EventBean[], EventBean[]) - Method in class net.esper.eql.core.ResultSetProcessorRowForAll
 
processViewResult(EventBean[], EventBean[]) - Method in class net.esper.eql.core.ResultSetProcessorRowPerGroup
 
processViewResult(EventBean[], EventBean[]) - Method in class net.esper.eql.core.ResultSetProcessorSimple
 
ProjectedStream - Class in net.esper.client.soda
Abstract base class for streams that can be projected via views providing data window, uniqueness or other projections or deriving further information from streams.
ProjectedStream(List<View>, String) - Constructor for class net.esper.client.soda.ProjectedStream
Ctor.
property(String) - Static method in class net.esper.client.soda.Expressions
Property value.
Property - Interface in net.esper.event.property
Interface for a property of an event of type BeanEventType (JavaBean event).
PROPERTY_NAME_BOOLEAN_EXPRESSION - Static variable in class net.esper.filter.FilterSpecCompiler
Assigned for filter parameters that are based on boolean expression and not on any particular property name.
PropertyAccessException - Exception in net.esper.event
This exception is thrown to indicate a problem with a accessing a property of an EventBean.
PropertyAccessException(String) - Constructor for exception net.esper.event.PropertyAccessException
Constructor.
PropertyAccessException(String, Throwable) - Constructor for exception net.esper.event.PropertyAccessException
Constructor for an inner exception and message.
PropertyAccessException(Throwable) - Constructor for exception net.esper.event.PropertyAccessException
Constructor.
PropertyBase - Class in net.esper.event.property
All properties have a property name and this is the abstract base class that serves up the property name.
PropertyBase(String) - Constructor for class net.esper.event.property.PropertyBase
Ctor.
PropertyCheckHelper - Class in net.esper.view
Utility class for checking in a schema if fields exist and/or have an expected type.
PropertyCheckHelper() - Constructor for class net.esper.view.PropertyCheckHelper
 
PropertyExistsExpression - Class in net.esper.client.soda
Property-exists checks if a dynamic property exists.
PropertyExistsExpression() - Constructor for class net.esper.client.soda.PropertyExistsExpression
Ctor - for use to create an expression tree, without child expression.
PropertyExistsExpression(String) - Constructor for class net.esper.client.soda.PropertyExistsExpression
Ctor.
propertyGetters - Variable in class net.esper.eql.join.table.PropertyIndexedEventTable
Getters for properties.
propertyGetters - Variable in class net.esper.eql.lookup.IndexedTableLookupStrategy
Getters to use to get key values.
PropertyHelper - Class in net.esper.event.property
This class offers utililty methods around introspection and CGLIB interaction.
PropertyHelper() - Constructor for class net.esper.event.property.PropertyHelper
 
propertyIndex - Variable in class net.esper.eql.join.table.PropertyIndexedEventTable
Index table.
PropertyIndexedEventTable - Class in net.esper.eql.join.table
Index that organizes events by the event property values into hash buckets.
PropertyIndexedEventTable(int, EventType, String[]) - Constructor for class net.esper.eql.join.table.PropertyIndexedEventTable
Ctor.
PropertyIndexedEventTableIterator - Class in net.esper.eql.join.table
Iterator for use by PropertyIndexedEventTable.
PropertyIndexedEventTableIterator(Map<MultiKeyUntyped, Set<EventBean>>) - Constructor for class net.esper.eql.join.table.PropertyIndexedEventTableIterator
Ctor.
PropertyIndTableCoerceAdd - Class in net.esper.eql.join.table
Index that organizes events by the event property values into hash buckets.
PropertyIndTableCoerceAdd(int, EventType, String[], Class[]) - Constructor for class net.esper.eql.join.table.PropertyIndTableCoerceAdd
Ctor.
PropertyIndTableCoerceAll - Class in net.esper.eql.join.table
Index that organizes events by the event property values into hash buckets.
PropertyIndTableCoerceAll(int, EventType, String[], Class[]) - Constructor for class net.esper.eql.join.table.PropertyIndTableCoerceAll
Ctor.
PropertyListBuilder - Interface in net.esper.event.property
Interface for an introspector that generates a list of event property descriptors given a clazz.
PropertyListBuilderExplicit - Class in net.esper.event.property
Introspector that considers explicitly configured event properties only.
PropertyListBuilderExplicit(ConfigurationEventTypeLegacy) - Constructor for class net.esper.event.property.PropertyListBuilderExplicit
Ctor.
PropertyListBuilderFactory - Class in net.esper.event.property
Factory for creates a builder/introspector for determining event property descriptors based on a given class.
PropertyListBuilderFactory() - Constructor for class net.esper.event.property.PropertyListBuilderFactory
 
PropertyListBuilderJavaBean - Class in net.esper.event.property
Implementation for a property list builder that considers JavaBean-style methods as the exposed event properties, plus any explicitly configured props.
PropertyListBuilderJavaBean(ConfigurationEventTypeLegacy) - Constructor for class net.esper.event.property.PropertyListBuilderJavaBean
Ctor.
PropertyListBuilderPublic - Class in net.esper.event.property
Implementation for a property list builder that considers any public method and public field as the exposed event properties, plus any explicitly configured props.
PropertyListBuilderPublic(ConfigurationEventTypeLegacy) - Constructor for class net.esper.event.property.PropertyListBuilderPublic
Ctor.
propertyName - Variable in class net.esper.event.property.PropertyBase
Property name.
propertyName - Variable in class net.esper.filter.FilterSpecParam
The property name of the filter parameter.
propertyName - Variable in class net.esper.view.std.UniqueByPropertyViewFactory
Property name to evaluate unique values.
PropertyNotFoundException - Exception in net.esper.eql.core
Exception to indicate that a property name used in a filter doesn't resolve.
PropertyNotFoundException(String) - Constructor for exception net.esper.eql.core.PropertyNotFoundException
Ctor.
PropertyParser - Class in net.esper.event.property
Parser for property names that can be simple, nested, mapped or a combination of these.
PropertyParser() - Constructor for class net.esper.event.property.PropertyParser
 
PropertyResolutionDescriptor - Class in net.esper.eql.core
Encapsulates the result of resolving a property and optional stream name against a supplied list of streams StreamTypeService.
PropertyResolutionDescriptor(String, EventType, String, int, Class) - Constructor for class net.esper.eql.core.PropertyResolutionDescriptor
Ctor.
PropertyValueExpression - Class in net.esper.client.soda
Expression returning a property value.
PropertyValueExpression(String) - Constructor for class net.esper.client.soda.PropertyValueExpression
Ctor.
purge() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Purges stale mappings from this map.
purge(Reference) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Purges the specified reference.
purgeBeforeRead() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Purges stale mappings from this map before read operations.
purgeBeforeWrite() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Purges stale mappings from this map before write operations.
purgeValues - Variable in class net.esper.collection.apachecommons.AbstractReferenceMap
Should the value be automatically purged when the associated key has been collected?
pushStmtContext() - Method in class net.esper.eql.generated.EQLBaseWalker
 
pushStmtContext() - Method in class net.esper.eql.parse.EQLTreeWalker
Pushes a statement into the stack, creating a new empty statement to fill in.
put(Object, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Puts a key-value mapping into this map.
put(Object, Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Puts a key-value mapping into this map.
put(K, V) - Method in class net.esper.collection.RefCountedMap
Add and key and value with a reference count as one.
put(Object[], EventTable) - Method in interface net.esper.eql.db.DataCache
Puts into the cache a key and a list of rows, or an empty list if zero rows.
put(Object[], EventTable) - Method in class net.esper.eql.db.DataCacheExpiringImpl
 
put(Object[], EventTable) - Method in class net.esper.eql.db.DataCacheLRUImpl
Adds an entry to this cache.
put(Object[], EventTable) - Method in class net.esper.eql.db.DataCacheNullImpl
 
put(ExprNode, FilterSpecParam) - Method in class net.esper.filter.FilterParamExprMap
Add a node and filter param.
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexBase
Store the event evaluation instance for the given constant.
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexBooleanExpr
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexCompare
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexEquals
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexIn
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexNotEquals
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexNotIn
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexNotRange
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexPropBase
Store the event evaluation instance for the given constant.
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndexRange
 
putAll(Map) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Puts all the values from the specified map into this map.

Q

qualifyExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
QueryGraph - Class in net.esper.eql.join.plan
Model of relationships between streams based on properties in both streams that are specified as equal in a filter expression.
QueryGraph(int) - Constructor for class net.esper.eql.join.plan.QueryGraph
Ctor.
QueryGraphKey - Class in net.esper.eql.join.plan
Key consisting of 2 integer stream numbers, for use by QueryGraph.
QueryGraphKey(int, int) - Constructor for class net.esper.eql.join.plan.QueryGraphKey
Ctor.
QueryGraphValue - Class in net.esper.eql.join.plan
Property lists stored as a value for each stream-to-stream relationship, for use by QueryGraph.
QueryGraphValue() - Constructor for class net.esper.eql.join.plan.QueryGraphValue
Ctor.
QueryMetaData - Class in net.esper.eql.db
Holder for query meta data information obtained from interrogating statements.
QueryMetaData(List<String>, Map<String, DBOutputTypeDesc>) - Constructor for class net.esper.eql.db.QueryMetaData
Ctor.
QueryPlan - Class in net.esper.eql.join.plan
Contains the query plan for all streams.
QueryPlan(QueryPlanIndex[], QueryPlanNode[]) - Constructor for class net.esper.eql.join.plan.QueryPlan
Ctor.
QueryPlanBuilder - Class in net.esper.eql.join.plan
Build a query plan based on filtering information.
QueryPlanBuilder() - Constructor for class net.esper.eql.join.plan.QueryPlanBuilder
 
QueryPlanIndex - Class in net.esper.eql.join.plan
Specifies an index to build as part of an overall query plan.
QueryPlanIndex(String[][], Class[][]) - Constructor for class net.esper.eql.join.plan.QueryPlanIndex
Ctor.
QueryPlanIndexBuilder - Class in net.esper.eql.join.plan
Build query index plans.
QueryPlanIndexBuilder() - Constructor for class net.esper.eql.join.plan.QueryPlanIndexBuilder
 
QueryPlanNode - Class in net.esper.eql.join.plan
Specification node for a query execution plan to be extended by specific execution specification nodes.
QueryPlanNode() - Constructor for class net.esper.eql.join.plan.QueryPlanNode
 
QueryStrategy - Interface in net.esper.eql.join
Encapsulates the strategy use to resolve the events for a stream into a tuples of events in a join.
QUESTION - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
QUESTION - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
quit() - Method in class net.esper.pattern.EvalAndStateNode
 
quit() - Method in class net.esper.pattern.EvalEveryStateNode
 
quit() - Method in class net.esper.pattern.EvalFilterStateNode
 
quit() - Method in class net.esper.pattern.EvalFollowedByStateNode
 
quit() - Method in class net.esper.pattern.EvalGuardStateNode
 
quit() - Method in class net.esper.pattern.EvalNotStateNode
 
quit() - Method in class net.esper.pattern.EvalObserverStateNode
 
quit() - Method in class net.esper.pattern.EvalOrStateNode
 
quit() - Method in class net.esper.pattern.EvalRootStateNode
 
quit() - Method in class net.esper.pattern.EvalStateNode
Stops the event expression or an instance of it.
Quitable - Interface in net.esper.pattern.guard
Receiver for quit events for use by guards.
QUOTED_STRING_LITERAL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
QUOTED_STRING_LITERAL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 

R

RandomAccessByIndex - Interface in net.esper.view.window
Random access interface to insert stream and remove stream data based on an index.
RandomAccessByIndexGetter - Class in net.esper.view.window
Getter that provides an index at runtime.
RandomAccessByIndexGetter() - Constructor for class net.esper.view.window.RandomAccessByIndexGetter
 
RandomAccessByIndexObserver - Interface in net.esper.view.window
For indicating that the collection has been updated.
randomAccessGetterImpl - Variable in class net.esper.view.ext.SortWindowViewFactory
The access into the collection for use with 'previous'.
randomAccessGetterImpl - Variable in class net.esper.view.ext.TimeOrderViewFactory
The access into the collection for use with 'previous'.
randomAccessGetterImpl - Variable in class net.esper.view.window.ExternallyTimedWindowViewFactory
The getter for direct access into the window.
randomAccessGetterImpl - Variable in class net.esper.view.window.KeepAllViewFactory
The access into the data window.
randomAccessGetterImpl - Variable in class net.esper.view.window.LengthWindowViewFactory
The access into the data window.
randomAccessGetterImpl - Variable in class net.esper.view.window.TimeAccumViewFactory
Access into the data window.
randomAccessGetterImpl - Variable in class net.esper.view.window.TimeWindowViewFactory
Access into the data window.
range(Expression, Expression, Expression, boolean, boolean) - Static method in class net.esper.client.soda.Expressions
Between (or range).
rangeOperand() - Method in class net.esper.eql.generated.EQLStatementParser
 
RangeParameter - Class in net.esper.type
Represents a range of numbers as a parameter.
RangeParameter(int, int) - Constructor for class net.esper.type.RangeParameter
Ctor.
RangeValueDouble - Class in net.esper.filter
A Double-typed value as a filter parameter representing a range.
RangeValueDouble(double) - Constructor for class net.esper.filter.RangeValueDouble
Ctor.
RangeValueEventProp - Class in net.esper.filter
An event property as a filter parameter representing a range.
RangeValueEventProp(String, String) - Constructor for class net.esper.filter.RangeValueEventProp
Ctor.
rawEventType - Variable in class net.esper.eql.expression.ExprSubselectNode
The event type generated for wildcard selects.
RBRACK - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
RBRACK - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
RCURLY - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
RCURLY - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
read() - Method in class net.esper.util.SimpleByteArrayInputStream
 
read(byte[], int, int) - Method in class net.esper.util.SimpleByteArrayInputStream
 
rebind(Name, Object) - Method in class net.esper.core.EngineEnvContext
 
rebind(String, Object) - Method in class net.esper.core.EngineEnvContext
 
recursiveAnalyzeChildNodes(EvalNode) - Static method in class net.esper.pattern.EvalNode
Searched recursivly for pattern evaluation filter nodes.
recursiveBuild(int, QueryGraph, OuterInnerDirectionalGraph, Set<Integer>, LinkedHashMap<Integer, int[]>, boolean[]) - Static method in class net.esper.eql.join.plan.NStreamOuterQueryPlanBuilder
Recusivly builds a substream-per-stream ordered tree graph using the join information supplied for outer joins and from the query graph (where clause).
recursiveNestedJoin(EventBean, int, EventBean[], List<EventBean[]>) - Method in class net.esper.eql.join.exec.NestedIterationExecNode
Recursive method to run through all child nodes and, for each result set tuple returned by a child node, execute the inner child of the child node until there are no inner child nodes.
RefCountedMap<K,V> - Class in net.esper.collection
Reference-counting map based on a HashMap implementation that stores as a value a pair of value and reference counter.
RefCountedMap() - Constructor for class net.esper.collection.RefCountedMap
Constructor.
RefCountedSet<K> - Class in net.esper.collection
reference-counting set based on a HashMap implementation that stores keys and a reference counter for each unique key value.
RefCountedSet() - Constructor for class net.esper.collection.RefCountedSet
Constructor.
reference(K) - Method in class net.esper.collection.RefCountedMap
Increase the reference count for a given key by one.
ReferenceMap - Class in net.esper.collection.apachecommons
A Map implementation that allows mappings to be removed by the garbage collector.
ReferenceMap() - Constructor for class net.esper.collection.apachecommons.ReferenceMap
Constructs a new ReferenceMap that will use hard references to keys and soft references to values.
ReferenceMap(int, int) - Constructor for class net.esper.collection.apachecommons.ReferenceMap
Constructs a new ReferenceMap that will use the specified types of references.
ReferenceMap(int, int, boolean) - Constructor for class net.esper.collection.apachecommons.ReferenceMap
Constructs a new ReferenceMap that will use the specified types of references.
ReferenceMap(int, int, int, float) - Constructor for class net.esper.collection.apachecommons.ReferenceMap
Constructs a new ReferenceMap with the specified reference types, load factor and initial capacity.
ReferenceMap(int, int, int, float, boolean) - Constructor for class net.esper.collection.apachecommons.ReferenceMap
Constructs a new ReferenceMap with the specified reference types, load factor and initial capacity.
ReflectionPropFieldGetter - Class in net.esper.event
Property getter for fields using Java's vanilla reflection.
ReflectionPropFieldGetter(Field) - Constructor for class net.esper.event.ReflectionPropFieldGetter
Constructor.
ReflectionPropMethodGetter - Class in net.esper.event
Property getter for methods using Java's vanilla reflection.
ReflectionPropMethodGetter(Method) - Constructor for class net.esper.event.ReflectionPropMethodGetter
Constructor.
refresh(TreeMap<MultiKeyUntyped, LinkedList<EventBean>>, int, int) - Method in class net.esper.view.ext.IStreamSortedRandomAccess
Refreshes the random access data with the updated information.
refresh(TreeMap<Long, ArrayList<EventBean>>, int) - Method in class net.esper.view.ext.IStreamTimeOrderRandomAccess
Refreshes the random access data with the updated information.
regexp(Expression, Expression) - Static method in class net.esper.client.soda.Expressions
Regular expression.
regexp(Expression, Expression, String) - Static method in class net.esper.client.soda.Expressions
Regular expression.
regexp(String, String) - Static method in class net.esper.client.soda.Expressions
Regular expression.
regexp(String, String, String) - Static method in class net.esper.client.soda.Expressions
Regular expression.
REGEXP - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
REGEXP - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
regExpExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
RegExpExpression - Class in net.esper.client.soda
Regular expression evaluates a "regexp" regular expression.
RegExpExpression() - Constructor for class net.esper.client.soda.RegExpExpression
Ctor - for use to create an expression tree, without child expression.
RegExpExpression(Expression, Expression) - Constructor for class net.esper.client.soda.RegExpExpression
Ctor.
RegExpExpression(Expression, Expression, Expression) - Constructor for class net.esper.client.soda.RegExpExpression
Ctor.
registerCallback(int, VariableChangeCallback) - Method in interface net.esper.eql.variable.VariableService
Registers a callback invoked when the variable is written with a new value.
registerCallback(int, VariableChangeCallback) - Method in class net.esper.eql.variable.VariableServiceImpl
 
RegressionBean - Class in net.esper.view.stat
Bean for calculating the regression slope and y intercept (same to Microsoft Excel LINEST function).
RegressionBean() - Constructor for class net.esper.view.stat.RegressionBean
 
RegressionLinestView - Class in net.esper.view.stat
A view that calculates regression on two fields.
RegressionLinestView(StatementContext, String, String) - Constructor for class net.esper.view.stat.RegressionLinestView
Constructor.
RegressionLinestViewFactory - Class in net.esper.view.stat
Factory for RegressionLinestView instances.
RegressionLinestViewFactory() - Constructor for class net.esper.view.stat.RegressionLinestViewFactory
 
regularJoin() - Method in class net.esper.eql.generated.EQLStatementParser
 
relationalExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
RelationalOpEnum - Enum in net.esper.type
Enum representing relational types of operation.
RelationalOpEnum.Computer - Interface in net.esper.type
Computer for relational op.
RelationalOpEnum.GEDoubleComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.GEDoubleComputer() - Constructor for class net.esper.type.RelationalOpEnum.GEDoubleComputer
 
RelationalOpEnum.GELongComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.GELongComputer() - Constructor for class net.esper.type.RelationalOpEnum.GELongComputer
 
RelationalOpEnum.GEStringComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.GEStringComputer() - Constructor for class net.esper.type.RelationalOpEnum.GEStringComputer
 
RelationalOpEnum.GTDoubleComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.GTDoubleComputer() - Constructor for class net.esper.type.RelationalOpEnum.GTDoubleComputer
 
RelationalOpEnum.GTLongComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.GTLongComputer() - Constructor for class net.esper.type.RelationalOpEnum.GTLongComputer
 
RelationalOpEnum.GTStringComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.GTStringComputer() - Constructor for class net.esper.type.RelationalOpEnum.GTStringComputer
 
RelationalOpEnum.LEDoubleComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.LEDoubleComputer() - Constructor for class net.esper.type.RelationalOpEnum.LEDoubleComputer
 
RelationalOpEnum.LELongComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.LELongComputer() - Constructor for class net.esper.type.RelationalOpEnum.LELongComputer
 
RelationalOpEnum.LEStringComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.LEStringComputer() - Constructor for class net.esper.type.RelationalOpEnum.LEStringComputer
 
RelationalOpEnum.LTDoubleComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.LTDoubleComputer() - Constructor for class net.esper.type.RelationalOpEnum.LTDoubleComputer
 
RelationalOpEnum.LTLongComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.LTLongComputer() - Constructor for class net.esper.type.RelationalOpEnum.LTLongComputer
 
RelationalOpEnum.LTStringComputer - Class in net.esper.type
Computer for relational op compare.
RelationalOpEnum.LTStringComputer() - Constructor for class net.esper.type.RelationalOpEnum.LTStringComputer
 
RelationalOpExpression - Class in net.esper.client.soda
Comparison using one of the relational operators (=, !=, <, <=, >, >=).
RelationalOpExpression(String) - Constructor for class net.esper.client.soda.RelationalOpExpression
Ctor.
RelationalOpExpression(Expression, String, Expression) - Constructor for class net.esper.client.soda.RelationalOpExpression
Ctor.
RelativeAccessByEventNIndex - Interface in net.esper.view.window
Provides access to prior events given an event from which to count back, and an index to look at.
RelativeAccessByEventNIndexGetter - Class in net.esper.view.window
Provides random-access into window contents by event and index as a combination.
RelativeAccessByEventNIndexGetter() - Constructor for class net.esper.view.window.RelativeAccessByEventNIndexGetter
 
relativeAccessGetterImpl - Variable in class net.esper.view.window.LengthBatchViewFactory
The access into the window.
relativeAccessGetterImpl - Variable in class net.esper.view.window.TimeBatchViewFactory
The access into the data window.
relativeAccessGetterImpl - Variable in class net.esper.view.window.TimeLengthBatchViewFactory
The access into the data window.
RELEASE_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
Release text.
RELEASED_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
Released text.
releaseLock(StatementLockFactory) - Method in interface net.esper.util.ManagedLock
Release a lock.
releaseLock(StatementLockFactory) - Method in class net.esper.util.ManagedLockImpl
Unlock.
releaseReadLock() - Method in class net.esper.util.ManagedReadWriteLock
Unlock read lock.
releaseWriteLock() - Method in class net.esper.util.ManagedReadWriteLock
Unlock write lock.
remove(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
 
remove() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
 
remove(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
 
remove(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Removes the specified mapping from this map.
remove(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Removes the specified mapping from this map.
remove() - Method in interface net.esper.collection.apachecommons.MapIterator
Removes the last returned key from the underlying Map (optional operation).
remove(Object) - Method in class net.esper.collection.ArrayBackedCollection
 
remove() - Method in class net.esper.collection.ArrayEventIterator
 
remove(Object, Object) - Method in class net.esper.collection.IndexedDataCollection
Removes a value object from the index, returning a boolean value to indicate if the value object was found.
remove() - Method in class net.esper.collection.IterablesListIterator
 
remove() - Method in class net.esper.collection.NullIterator
 
remove(K) - Method in class net.esper.collection.RefCountedSet
Removed a key to the set.
remove() - Method in class net.esper.collection.SafeIteratorImpl
 
remove() - Method in class net.esper.collection.SingleEventIterator
 
remove() - Method in class net.esper.collection.SingleObjectIterator
 
remove(double) - Method in class net.esper.collection.SortedDoubleVector
Remove a value from the collection.
remove(K) - Method in class net.esper.collection.SortedRefCountedSet
Remove a key from the set.
remove(EventBean) - Method in class net.esper.collection.TimeWindow
Removes the event from the window, if remove stream handling is enabled.
remove() - Method in class net.esper.collection.TimeWindowIterator
 
remove() - Method in class net.esper.collection.TransformEventIterator
 
remove() - Method in class net.esper.eql.core.ResultSetAggregateAllIterator
 
remove() - Method in class net.esper.eql.core.ResultSetAggregateGroupedIterator
 
remove() - Method in class net.esper.eql.core.ResultSetRowPerGroupIterator
 
remove() - Method in class net.esper.eql.join.rep.NodeCursorIterator
 
remove() - Method in class net.esper.eql.join.rep.SingleCursorIterator
 
remove(EventBean[]) - Method in interface net.esper.eql.join.table.EventTable
Remove events from table.
remove(EventBean[]) - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
Remove events.
remove() - Method in class net.esper.eql.join.table.PropertyIndexedEventTableIterator
 
remove(EventBean[]) - Method in class net.esper.eql.join.table.UnindexedEventTable
 
remove(EventBean[]) - Method in class net.esper.eql.join.table.UnindexedEventTableList
 
remove() - Method in class net.esper.eql.view.FilterExprViewIterator
 
remove(FilterHandle) - Method in class net.esper.filter.EventTypeIndexBuilder
Remove a filter callback from the given index node.
remove(FilterParamIndexBase) - Method in class net.esper.filter.FilterHandleSetNode
Remove an index, returning true if it was found and removed or false if not in collection.
remove(FilterHandle) - Method in class net.esper.filter.FilterHandleSetNode
Remove a filter callback, returning true if it was found and removed or false if not in collection.
remove(Object) - Method in class net.esper.filter.FilterParamIndexBase
Remove the event evaluation instance for the given constant.
remove(Object) - Method in class net.esper.filter.FilterParamIndexBooleanExpr
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexCompare
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexEquals
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexIn
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexNotEquals
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexNotIn
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexNotRange
 
remove(Object) - Method in class net.esper.filter.FilterParamIndexPropBase
Remove the event evaluation instance for the given constant.
remove(Object) - Method in class net.esper.filter.FilterParamIndexRange
 
remove(FilterHandle) - Method in interface net.esper.filter.FilterService
Remove a filter callback.
remove(FilterHandle) - Method in class net.esper.filter.FilterServiceImpl
 
remove(FilterHandle, IndexTreePath, FilterHandleSetNode) - Method in class net.esper.filter.IndexTreeBuilder
Remove an filterCallback from the given top node.
remove(ScheduleHandle, ScheduleSlot) - Method in interface net.esper.schedule.SchedulingService
Remove a handle.
remove(ScheduleHandle, ScheduleSlot) - Method in class net.esper.schedule.SchedulingServiceImpl
 
remove() - Method in class net.esper.util.DOMElementIterator
 
remove() - Method in class net.esper.view.ext.SortWindowIterator
 
remove() - Method in class net.esper.view.ext.TimeOrderViewIterator
 
remove(EventStream, Viewable) - Method in interface net.esper.view.ViewService
Removes a view discoupling the view and any of it's parent views up the tree to the last shared parent view.
remove(EventStream, Viewable) - Method in class net.esper.view.ViewServiceImpl
 
REMOVE_INVALID - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
Message.
removeAll(Collection) - Method in class net.esper.collection.ArrayBackedCollection
 
removeAllListeners() - Method in interface net.esper.client.EPListenable
Remove all listeners.
removeAllListeners() - Method in class net.esper.core.EPStatementImpl
Remove all listeners to a statement.
removeAllListeners() - Method in class net.esper.core.EPStatementListenerSet
Remove all listeners to a statement.
removeChainLeafView(Viewable, Viewable) - Static method in class net.esper.view.ViewServiceHelper
Removes a view from a parent view returning the orphaned parent views in a list.
removeConsumer(NamedWindowConsumerView) - Method in class net.esper.eql.named.NamedWindowTailView
Called by the consumer view to indicate it was stopped or destroyed, such that the consumer can be deregistered and further dispatches disregard this consumer.
removeDuplicateProperties(List<EventPropertyDescriptor>) - Static method in class net.esper.event.property.PropertyHelper
Removed duplicate properties using the property name to find unique properties.
removeEntry(AbstractHashedMap.HashEntry, int, AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Removes an entry from the chain stored in a particular index.
removeEntry(FilterSpecParam) - Method in class net.esper.filter.FilterParamExprMap
Removes a filter parameter and it's associated expression node
removeFirst() - Method in class net.esper.filter.IndexTreePath
Remove and return first index.
removeFromEnvironment(String) - Method in class net.esper.core.EngineEnvContext
 
removeJavaProperties(List<EventPropertyDescriptor>) - Static method in class net.esper.event.property.PropertyHelper
Remove Java language specific properties from the given list of property descriptors.
removeListener(UpdateListener) - Method in interface net.esper.client.EPListenable
Remove a listener that observes events.
removeListener(StatementAwareUpdateListener) - Method in interface net.esper.client.EPListenable
Remove a statement-aware listener that observes events.
removeListener(UpdateListener) - Method in class net.esper.core.EPStatementImpl
Remove a listeners to a statement.
removeListener(StatementAwareUpdateListener) - Method in class net.esper.core.EPStatementImpl
 
removeListener(UpdateListener) - Method in class net.esper.core.EPStatementListenerSet
Remove a listeners to a statement.
removeListener(StatementAwareUpdateListener) - Method in class net.esper.core.EPStatementListenerSet
Remove a listeners to a statement.
removeMapping(AbstractHashedMap.HashEntry, int, AbstractHashedMap.HashEntry) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Removes a mapping from the map.
removeOldData(EventBean[]) - Method in class net.esper.eql.named.NamedWindowRootView
Called by tail view to indicate that the data window view exired events that must be removed from index tables.
removeOnExpr(LookupStrategy) - Method in class net.esper.eql.named.NamedWindowRootView
Unregister an on-delete statement view, using the strategy as a key to remove a reference to the index table used by the strategy.
removePoint(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Remove a X data point only.
removePoint(double, double) - Method in class net.esper.view.stat.BaseStatisticsBean
Remove a data point.
removeProcessor(String) - Method in interface net.esper.eql.named.NamedWindowService
Upon destroy of the named window creation statement, the named window processor must be removed.
removeProcessor(String) - Method in class net.esper.eql.named.NamedWindowServiceImpl
 
RemoveStreamViewCapability - Class in net.esper.eql.named
View capability requirement that asks views to handle the remove stream posted by parent views, for use with named windows since these allow on-delete removal of events from a window.
RemoveStreamViewCapability() - Constructor for class net.esper.eql.named.RemoveStreamViewCapability
 
removeTableReference(EventTable) - Method in class net.esper.eql.named.NamedWindowIndexRepository
Remove a reference to an index table, decreasing its reference count.
removeValue(FilterSpecParam) - Method in class net.esper.filter.FilterParamExprMap
Remove a filter parameter leaving the expression node in place.
removeView(View) - Method in class net.esper.eql.core.MethodPollingViewable
 
removeView(View) - Method in class net.esper.eql.db.DatabasePollingViewable
 
removeView(View) - Method in interface net.esper.view.Viewable
Remove a view.
removeView(View) - Method in class net.esper.view.ViewSupport
 
removeView(View) - Method in class net.esper.view.ZeroDepthStream
 
rename(Name, Name) - Method in class net.esper.core.EngineEnvContext
 
rename(String, String) - Method in class net.esper.core.EngineEnvContext
 
renderCube(Cube) - Static method in class net.esper.indicator.pretty.CubeCellStringRenderer
Render a multidimensional table (see Cube) as flatted out structure.
renderCube(Cube) - Static method in class net.esper.indicator.pretty.CubeTabularDataRenderer
Render the Cube as a collection of OpenMBean TabularData tables, each table carries a string key that contains the page dimension member, if present, else just the string TABLE_NAME.
renderEQL(StringWriter, Object) - Static method in class net.esper.core.EPStatementObjectModelHelper
Renders a constant as an EQL.
renderMember(DimensionMember) - Static method in class net.esper.indicator.pretty.DimensionMemberRenderHelper
Renders dimension members as a String.
Repository - Interface in net.esper.eql.join.rep
An interface for a repository of events in a lookup/join scheme that supplies events for event stream table lookups and receives results of lookups.
RepositoryImpl - Class in net.esper.eql.join.rep
Implements a repository for join events and lookup results.
RepositoryImpl(int, EventBean, int) - Constructor for class net.esper.eql.join.rep.RepositoryImpl
Ctor.
requestCapability(int, ViewCapability, ViewResourceCallback) - Method in interface net.esper.eql.core.ViewResourceDelegate
Request a view resource.
requestCapability(int, ViewCapability, ViewResourceCallback) - Method in class net.esper.eql.core.ViewResourceDelegateImpl
 
requiresChildViews() - Method in class net.esper.eql.named.NotADataWindowViewCapability
 
requiresChildViews() - Method in class net.esper.eql.named.RemoveStreamViewCapability
 
requiresChildViews() - Method in interface net.esper.view.ViewCapability
Returns true to indicate that the capability requirs one or more child views, or can work without child views.
requiresChildViews() - Method in class net.esper.view.ViewCapDataWindowAccess
 
requiresChildViews() - Method in class net.esper.view.ViewCapPriorEventAccess
 
reset() - Method in class net.esper.client.Configuration
Reset to an empty configuration.
reset() - Method in interface net.esper.collection.apachecommons.ResettableIterator
Resets the iterator back to the position at which the iterator was created.
resetPattern(String) - Method in class net.esper.util.LikeUtil
Resets the search pattern.
RESETTABLE_INSTANCE - Static variable in class net.esper.collection.apachecommons.EmptyIterator
Singleton instance of the iterator.
ResettableIterator - Interface in net.esper.collection.apachecommons
Defines an iterator that can be reset back to an initial state.
resolveAggregation(String) - Method in interface net.esper.eql.core.EngineImportService
Used at statement compile-time to try and resolve a given function name into an aggregation method.
resolveAggregation(String) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
resolveAggregation(String) - Method in interface net.esper.eql.core.MethodResolutionService
Returns a plug-in aggregation method for a given configured aggregation function name.
resolveAggregation(String) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
resolveByPropertyName(String) - Method in interface net.esper.eql.core.StreamTypeService
Returns the offset of the stream and the type of the property for the given property name, by looking through the types offered and matching up.
resolveByPropertyName(String) - Method in class net.esper.eql.core.StreamTypeServiceImpl
 
resolveByStreamAndPropName(String, String) - Method in interface net.esper.eql.core.StreamTypeService
Returns the offset of the stream and the type of the property for the given property name, by using the specified stream name to resolve the property.
resolveByStreamAndPropName(String) - Method in interface net.esper.eql.core.StreamTypeService
Returns the offset of the stream and the type of the property for the given property name, by looking through the types offered and matching up.
resolveByStreamAndPropName(String, String) - Method in class net.esper.eql.core.StreamTypeServiceImpl
 
resolveByStreamAndPropName(String) - Method in class net.esper.eql.core.StreamTypeServiceImpl
 
resolveClass(String) - Method in interface net.esper.eql.core.EngineImportService
Resolves a given class name, either fully qualified and simple and imported to a class.
resolveClass(String) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
resolveClass(String) - Method in interface net.esper.eql.core.MethodResolutionService
Resolves a given class name, either fully qualified and simple and imported to a class.
resolveClass(String) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
resolveClassInternal(String) - Method in class net.esper.eql.core.EngineImportServiceImpl
Finds a class by class name using the auto-import information provided.
resolveClassPathOrURLResource(String, String) - Static method in class net.esper.util.ResourceLoader
Resolve a resource into a URL using the URL string or classpath-relative filename and using a name for any exceptions thrown.
resolveMethod(String, String, Class[]) - Method in interface net.esper.eql.core.EngineImportService
Resolves a given class, method and list of parameter types to a static method.
resolveMethod(String, String) - Method in interface net.esper.eql.core.EngineImportService
Resolves a given class and method name to a static method, expecting the method to exist exactly once and not be overloaded, with any parameters.
resolveMethod(Class, String, Class[]) - Method in interface net.esper.eql.core.EngineImportService
Resolves a given method name and list of parameter types to an instance or static method exposed by the given class.
resolveMethod(String, String, Class[]) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
resolveMethod(String, String) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
resolveMethod(Class, String, Class[]) - Method in class net.esper.eql.core.EngineImportServiceImpl
 
resolveMethod(Class, String, Class[]) - Method in interface net.esper.eql.core.MethodResolutionService
Resolves a given method name and list of parameter types to an instance or static method exposed by the given class.
resolveMethod(String, String, Class[]) - Method in interface net.esper.eql.core.MethodResolutionService
Resolves a given class, method and list of parameter types to a static method.
resolveMethod(String, String) - Method in interface net.esper.eql.core.MethodResolutionService
Resolves a given class and method name to a static method, not allowing overloaded methods and expecting the method to be found exactly once with zero or more parameters.
resolveMethod(String, String, Class[]) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
resolveMethod(String, String) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
resolveMethod(Class, String, Class[]) - Method in class net.esper.eql.core.MethodResolutionServiceImpl
 
resolveMethod(Class, String, Class[], boolean) - Static method in class net.esper.util.MethodResolver
Attempts to find the static or instance method described by the parameters, or a method of the same name that will accept the same type of parameters.
resolveType(String, EventAdapterService) - Static method in class net.esper.eql.spec.FilterStreamSpecRaw
Resolves a given event alias to an event type.
ResourceLoader - Class in net.esper.util
Utility class for loading or resolving external resources via URL and class path.
ResourceLoader() - Constructor for class net.esper.util.ResourceLoader
 
restart() - Method in class net.esper.schedule.ScheduleBucket
Restart bucket slot numbering wuch as when a statement is restarted and new slots are allocated.
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.BranchOptionalAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.BranchRequiredAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.CartesianProdAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.LeafAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in interface net.esper.eql.join.assemble.ResultAssembler
Publish a result row.
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.RootCartProdAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.RootOptionalAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.assemble.RootRequiredAssemblyNode
 
result(EventBean[], int, EventBean, Node) - Method in class net.esper.eql.join.exec.LookupInstructionExecNode.MyResultAssembler
 
ResultAssembler - Interface in net.esper.eql.join.assemble
Interface for indicating a result in the form of a single row of multiple events, which could represent either a full result over all streams or a partial result over a subset of streams.
ResultSetAggregateAllIterator - Class in net.esper.eql.core
Iterator for aggregation results that aggregate all rows.
ResultSetAggregateAllIterator(Iterator<EventBean>, ResultSetProcessorAggregateAll) - Constructor for class net.esper.eql.core.ResultSetAggregateAllIterator
Ctor.
ResultSetAggregateGroupedIterator - Class in net.esper.eql.core
Iterator for group-by with aggregation.
ResultSetAggregateGroupedIterator(Iterator<EventBean>, ResultSetProcessorAggregateGrouped, AggregationService) - Constructor for class net.esper.eql.core.ResultSetAggregateGroupedIterator
Ctor.
ResultSetProcessor - Interface in net.esper.eql.core
Processor for result sets coming from 2 sources.
resultSetProcessor - Variable in class net.esper.eql.view.OutputProcessView
Processes the parent views result set generating events for pushing out to child view.
ResultSetProcessorAggregateAll - Class in net.esper.eql.core
Result set processor for the case: aggregation functions used in the select clause, and no group-by, and not all of the properties in the select clause are under an aggregation function.
ResultSetProcessorAggregateAll(SelectExprProcessor, OrderByProcessor, AggregationService, ExprNode, boolean, boolean) - Constructor for class net.esper.eql.core.ResultSetProcessorAggregateAll
Ctor.
ResultSetProcessorAggregateGrouped - Class in net.esper.eql.core
Result-set processor for the aggregate-grouped case: there is a group-by and one or more non-aggregation event properties in the select clause are not listed in the group by, and there are aggregation functions.
ResultSetProcessorAggregateGrouped(SelectExprProcessor, OrderByProcessor, AggregationService, List<ExprNode>, ExprNode, boolean, boolean) - Constructor for class net.esper.eql.core.ResultSetProcessorAggregateGrouped
Ctor.
ResultSetProcessorFactory - Class in net.esper.eql.core
Factory for output processors.
ResultSetProcessorFactory() - Constructor for class net.esper.eql.core.ResultSetProcessorFactory
 
ResultSetProcessorRowForAll - Class in net.esper.eql.core
Result set processor for the case: aggregation functions used in the select clause, and no group-by, and all properties in the select clause are under an aggregation function.
ResultSetProcessorRowForAll(SelectExprProcessor, AggregationService, ExprNode) - Constructor for class net.esper.eql.core.ResultSetProcessorRowForAll
Ctor.
ResultSetProcessorRowPerGroup - Class in net.esper.eql.core
Result set processor for the fully-grouped case: there is a group-by and all non-aggregation event properties in the select clause are listed in the group by, and there are aggregation functions.
ResultSetProcessorRowPerGroup(SelectExprProcessor, OrderByProcessor, AggregationService, List<ExprNode>, ExprNode, boolean, boolean) - Constructor for class net.esper.eql.core.ResultSetProcessorRowPerGroup
Ctor.
ResultSetProcessorSimple - Class in net.esper.eql.core
Result set processor for the simplest case: no aggregation functions used in the select clause, and no group-by.
ResultSetProcessorSimple(SelectExprProcessor, OrderByProcessor, ExprNode, boolean, boolean) - Constructor for class net.esper.eql.core.ResultSetProcessorSimple
Ctor.
ResultSetProcessorSimple.ResultSetSimpleTransform - Class in net.esper.eql.core
Method to transform an event based on the select expression.
ResultSetProcessorSimple.ResultSetSimpleTransform(ResultSetProcessorSimple) - Constructor for class net.esper.eql.core.ResultSetProcessorSimple.ResultSetSimpleTransform
Ctor.
ResultSetRowPerGroupIterator - Class in net.esper.eql.core
Iterator for the group-by case with a row per group.
ResultSetRowPerGroupIterator(Iterator<EventBean>, ResultSetProcessorRowPerGroup, AggregationService) - Constructor for class net.esper.eql.core.ResultSetRowPerGroupIterator
Ctor.
retainAll(Collection) - Method in class net.esper.collection.ArrayBackedCollection
 
reuseEntry(AbstractHashedMap.HashEntry, int, int, Object, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Reuses an existing key-value mapping, storing completely new data.
RIGHT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
RIGHT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
RIGHT_OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
RIGHT_OUTERJOIN_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
rollback() - Method in interface net.esper.eql.variable.VariableService
Rolls back the variable outstanding changes.
rollback() - Method in class net.esper.eql.variable.VariableServiceImpl
 
RollingEventBuffer - Class in net.esper.collection
Event buffer of a given size provides a random access API into the most current event to prior events up to the given size.
RollingEventBuffer(int) - Constructor for class net.esper.collection.RollingEventBuffer
Ctor.
ROLLOVER_READER_BOUNDARY - Static variable in class net.esper.eql.variable.VariableServiceImpl
Sets the boundary above which a reader considers the high-version list of variable values.
ROLLOVER_WRITER_BOUNDARY - Static variable in class net.esper.eql.variable.VariableServiceImpl
Sets the boundary above which a write transaction rolls over all variable's version lists.
RootCartProdAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a root with a two or more child nodes below it.
RootCartProdAssemblyNode(int, int, boolean) - Constructor for class net.esper.eql.join.assemble.RootCartProdAssemblyNode
Ctor.
RootOptionalAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a root with a one optional child node below it.
RootOptionalAssemblyNode(int, int) - Constructor for class net.esper.eql.join.assemble.RootOptionalAssemblyNode
Ctor.
RootRequiredAssemblyNode - Class in net.esper.eql.join.assemble
Assembly node for an event stream that is a root with a one required child node below it.
RootRequiredAssemblyNode(int, int) - Constructor for class net.esper.eql.join.assemble.RootRequiredAssemblyNode
Ctor.
rootView - Variable in class net.esper.eql.named.NamedWindowOnExprBaseView
The root view accepting removals (old data).
route(Object) - Method in interface net.esper.client.EPRuntime
Route the event object back to the event stream processing runtime for internal dispatching.
route(Object) - Method in class net.esper.core.EPRuntimeImpl
 
route(EventBean[], EPStatementHandle) - Method in class net.esper.core.EPRuntimeImpl
 
route(EventBean[], EPStatementHandle) - Method in interface net.esper.core.InternalEventRouter
Route the event such that the event is processed as required.
rowField - Variable in class net.esper.view.stat.MultiDimStatsViewFactory
Property name supplying rows.
RPAREN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
RPAREN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
RSTREAM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
RSTREAM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 

S

safeIterator() - Method in interface net.esper.client.EPIterable
Returns a concurrency-safe iterator that iterates over events representing statement results (pull API) in the face of concurrent event processing by further threads.
SafeIterator<E> - Interface in net.esper.client
A concurrency-safe iterator that iterates over events representing statement results (pull API) in the face of concurrent event processing by further threads.
safeIterator() - Method in class net.esper.core.EPStatementImpl
 
SafeIteratorImpl<E> - Class in net.esper.collection
Implements the safe iterator.
SafeIteratorImpl(ManagedLock, Iterator<E>) - Constructor for class net.esper.collection.SafeIteratorImpl
Ctor.
ScheduleBucket - Class in net.esper.schedule
This class acts as a buckets for sorting schedule service callbacks that are scheduled to occur at the same time.
ScheduleBucket(int) - Constructor for class net.esper.schedule.ScheduleBucket
Ctor.
ScheduleCalendar - Class in net.esper.schedule
Calendar class for use in scheduling, specifically for use in computing the next invocation time.
ScheduleComputeHelper - Class in net.esper.schedule
For a crontab-like schedule, this class computes the next occurance given a start time and a specification of what the schedule looks like.
ScheduleComputeHelper() - Constructor for class net.esper.schedule.ScheduleComputeHelper
 
scheduledTrigger(ExtensionServicesContext) - Method in class net.esper.eql.db.DataCacheExpiringImpl
 
scheduledTrigger(ExtensionServicesContext) - Method in class net.esper.pattern.guard.TimerWithinGuard
 
scheduledTrigger(ExtensionServicesContext) - Method in class net.esper.pattern.observer.TimerAtObserver
 
scheduledTrigger(ExtensionServicesContext) - Method in class net.esper.pattern.observer.TimerIntervalObserver
 
scheduledTrigger(ExtensionServicesContext) - Method in interface net.esper.schedule.ScheduleHandleCallback
Callback that is invoked as indicated by a schedule added to the scheduling service.
ScheduleHandle - Interface in net.esper.schedule
Marker interface for use with SchedulingService.
ScheduleHandleCallback - Interface in net.esper.schedule
Interface for scheduled callbacks.
ScheduleHandleExistsException - Exception in net.esper.schedule
This exception is thrown to indicate trying to add a scheduling callback that already existed.
ScheduleHandleExistsException(String) - Constructor for exception net.esper.schedule.ScheduleHandleExistsException
Constructor.
ScheduleHandleExistsException(String, Throwable) - Constructor for exception net.esper.schedule.ScheduleHandleExistsException
Constructor for an inner exception and message.
ScheduleHandleExistsException(Throwable) - Constructor for exception net.esper.schedule.ScheduleHandleExistsException
Constructor.
ScheduleServiceException - Exception in net.esper.schedule
This exception is thrown to indicate a problem with scheduling.
ScheduleServiceException(String) - Constructor for exception net.esper.schedule.ScheduleServiceException
Constructor.
ScheduleServiceException(String, Throwable) - Constructor for exception net.esper.schedule.ScheduleServiceException
Constructor for an inner exception and message.
ScheduleServiceException(Throwable) - Constructor for exception net.esper.schedule.ScheduleServiceException
Constructor.
ScheduleSlot - Class in net.esper.schedule
This class is a slot in a ScheduleBucket for sorting schedule service callbacks.
ScheduleSlot(int, int) - Constructor for class net.esper.schedule.ScheduleSlot
Ctor.
ScheduleSpec - Class in net.esper.schedule
Holds a schedule specification which consists of a set of integer values or a null value for each schedule unit to indicate a wildcard.
ScheduleSpec(EnumMap<ScheduleUnit, SortedSet<Integer>>) - Constructor for class net.esper.schedule.ScheduleSpec
Constructor - validates that all mandatory schedule.
ScheduleSpec() - Constructor for class net.esper.schedule.ScheduleSpec
Constructor - for unit testing, initialize to all wildcards but leave seconds empty.
ScheduleUnit - Enum in net.esper.type
Enumeration of units in a specification of schedule, which contains elements for each of the following units: minute, hour, day of month, month, day of week and seconds.
SchedulingService - Interface in net.esper.schedule
Interface for a service that allows to add and remove handles (typically storing callbacks) for a certain time which are returned when the evaluate method is invoked and the current time is on or after the handle's registered time.
SchedulingServiceImpl - Class in net.esper.schedule
Implements the schedule service by simply keeping a sorted set of long millisecond values and a set of handles for each.
SchedulingServiceImpl() - Constructor for class net.esper.schedule.SchedulingServiceImpl
Constructor.
SchedulingServiceProvider - Class in net.esper.schedule
Static factory for implementations of the SchedulingService interface.
SchedulingServiceProvider() - Constructor for class net.esper.schedule.SchedulingServiceProvider
 
SchemaUtil - Class in net.esper.event.xml
Utility class for querying schema information via Xerces implementation classes.
SchemaUtil() - Constructor for class net.esper.event.xml.SchemaUtil
 
SchemaXMLEventType - Class in net.esper.event.xml
EventType for xml events that have a Schema.
SchemaXMLEventType(ConfigurationEventTypeXMLDOM) - Constructor for class net.esper.event.xml.SchemaXMLEventType
Ctor.
SchemaXMLPropertyParser - Class in net.esper.event.xml
Parses event property names and transforms to XPath expressions using the schema information supplied.
SchemaXMLPropertyParser() - Constructor for class net.esper.event.xml.SchemaXMLPropertyParser
 
SEC_LIMIT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SEC_LIMIT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SECOND_PART - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SECOND_PART - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
secondPart(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
secondPart() - Method in class net.esper.eql.generated.EQLStatementParser
 
SECONDS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SECONDS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SELECT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SELECT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SelectClause - Class in net.esper.client.soda
A select-clause consists of selection expressions and optionally an indicator that a wildcard is selected and an optional stream selector.
SelectClause(StreamSelector, boolean) - Constructor for class net.esper.client.soda.SelectClause
Ctor.
SelectClause(StreamSelector, String...) - Constructor for class net.esper.client.soda.SelectClause
Ctor.
selectClause - Variable in class net.esper.eql.expression.ExprSubselectNode
The validated select clause.
selectClause(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
selectClause() - Method in class net.esper.eql.generated.EQLStatementParser
 
SelectClauseElement - Class in net.esper.client.soda
Part of a select-clause to describe individual select-clause expressions.
SelectClauseElement(Expression) - Constructor for class net.esper.client.soda.SelectClauseElement
Ctor.
SelectClauseElement(Expression, String) - Constructor for class net.esper.client.soda.SelectClauseElement
Ctor.
SelectClauseSpec - Class in net.esper.eql.spec
Encapsulates the parsed select expressions in a select-clause in an EQL statement.
SelectClauseSpec() - Constructor for class net.esper.eql.spec.SelectClauseSpec
Ctor.
SelectClauseSpec(List<SelectExprElementRawSpec>) - Constructor for class net.esper.eql.spec.SelectClauseSpec
Ctor.
SelectClauseStreamSelectorEnum - Enum in net.esper.eql.spec
Enumeration for representing select-clause selection of the remove stream or the insert stream, or both.
SelectClauseStreamWildcard - Class in net.esper.client.soda
For use in a select clause, this element in a select clause defines that for a given stream we want to select the underlying type.
SelectClauseStreamWildcard(String, String) - Constructor for class net.esper.client.soda.SelectClauseStreamWildcard
Ctor.
selectExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
selectExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
SelectExprElementCompiledSpec - Class in net.esper.eql.spec
Represents a single item in a SELECT-clause, with a name assigned either by the engine or by the user specifying an "as" tag name.
SelectExprElementCompiledSpec(ExprNode, String) - Constructor for class net.esper.eql.spec.SelectExprElementCompiledSpec
Ctor.
SelectExprElementRawSpec - Class in net.esper.eql.spec
Represents a single item in a SELECT-clause, potentially unnamed as no "as" tag may have been supplied in the syntax.
SelectExprElementRawSpec(ExprNode, String) - Constructor for class net.esper.eql.spec.SelectExprElementRawSpec
Ctor.
SelectExprElementStreamCompiledSpec - Class in net.esper.eql.spec
Mirror class to SelectExprElementStreamRawSpec but added the stream number for the alias.
SelectExprElementStreamCompiledSpec(String, String, int, boolean) - Constructor for class net.esper.eql.spec.SelectExprElementStreamCompiledSpec
Ctor.
SelectExprElementStreamRawSpec - Class in net.esper.eql.spec
For use in select clauses for specifying a selected stream: select a.* from MyEvent as a, MyOther as b
SelectExprElementStreamRawSpec(String, String) - Constructor for class net.esper.eql.spec.SelectExprElementStreamRawSpec
Ctor.
SelectExprEvalProcessor - Class in net.esper.eql.core
Processor for select-clause expressions that handles a list of selection items represented by expression nodes.
SelectExprEvalProcessor(List<SelectExprElementCompiledSpec>, InsertIntoDesc, boolean, StreamTypeService, EventAdapterService) - Constructor for class net.esper.eql.core.SelectExprEvalProcessor
Ctor.
SelectExprEvalProcessorStreams - Class in net.esper.eql.core
Processor for select-clause expressions that handles a list of selection items represented by expression nodes.
SelectExprEvalProcessorStreams(List<SelectExprElementCompiledSpec>, List<SelectExprElementStreamCompiledSpec>, InsertIntoDesc, boolean, StreamTypeService, EventAdapterService) - Constructor for class net.esper.eql.core.SelectExprEvalProcessorStreams
Ctor.
SelectExprJoinWildcardProcessor - Class in net.esper.eql.core
Processor for select-clause expressions that handles wildcards.
SelectExprJoinWildcardProcessor(String[], EventType[], EventAdapterService, InsertIntoDesc) - Constructor for class net.esper.eql.core.SelectExprJoinWildcardProcessor
Ctor.
SelectExprProcessor - Interface in net.esper.eql.core
Interface for processors of select-clause items, implementors are computing results based on matching events.
SelectExprProcessorFactory - Class in net.esper.eql.core
Factory for select expression processors.
SelectExprProcessorFactory() - Constructor for class net.esper.eql.core.SelectExprProcessorFactory
 
SELECTION_ELEMENT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SELECTION_ELEMENT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SELECTION_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SELECTION_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SELECTION_STREAM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SELECTION_STREAM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
selectionList(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
selectionList() - Method in class net.esper.eql.generated.EQLStatementParser
 
selectionListElement(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
selectionListElement() - Method in class net.esper.eql.generated.EQLStatementParser
 
SEMI - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SEMI - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
sendBatch() - Method in class net.esper.view.window.LengthBatchView
This method updates child views and clears the batch of events.
sendBatch() - Method in class net.esper.view.window.LengthBatchViewRStream
This method updates child views and clears the batch of events.
sendBatch() - Method in class net.esper.view.window.TimeBatchView
This method updates child views and clears the batch of events.
sendBatch() - Method in class net.esper.view.window.TimeBatchViewRStream
This method updates child views and clears the batch of events.
sendBatch(boolean) - Method in class net.esper.view.window.TimeLengthBatchView
This method updates child views and clears the batch of events.
sendEvent(Object) - Method in interface net.esper.client.EPRuntime
Send an event represented by a plain Java object to the event stream processing runtime.
sendEvent(Map, String) - Method in interface net.esper.client.EPRuntime
Send a map containing event property values to the event stream processing runtime.
sendEvent(Node) - Method in interface net.esper.client.EPRuntime
Send an event represented by a DOM node to the event stream processing runtime.
sendEvent(Object) - Method in class net.esper.core.EPRuntimeImpl
 
sendEvent(Node) - Method in class net.esper.core.EPRuntimeImpl
 
sendEvent(Map, String) - Method in class net.esper.core.EPRuntimeImpl
 
sendRemoveStream() - Method in class net.esper.view.window.TimeAccumView
This method sends the remove stream for all accumulated events.
sendRemoveStream() - Method in class net.esper.view.window.TimeAccumViewRStream
This method sends the remove stream for all accumulated events.
SerializableObjectCopier - Class in net.esper.util
Utility class for copying serializable objects via object input and output streams.
SerializableObjectCopier() - Constructor for class net.esper.util.SerializableObjectCopier
 
services - Variable in class net.esper.core.StatementLifecycleSvcImpl
Services context for statement lifecycle management.
SET - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SET - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
setAccessorStyle(ConfigurationEventTypeLegacy.AccessorStyle) - Method in class net.esper.client.ConfigurationEventTypeLegacy
Sets the accessor style.
setAggregationResultFuture(AggregationResultFuture, int) - Method in class net.esper.eql.expression.ExprAggregateNode
Assigns to the node the future which can be queried for the current aggregation state at evaluation time.
setAsName(String) - Method in class net.esper.client.soda.SelectClauseElement
Sets the optional "as"-name of the expression, or null if not defined
setAssignments(List<Pair<String, Expression>>) - Method in class net.esper.client.soda.OnSetClause
Sets a list of variable assignments.
setAttribute(Attribute) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
 
setAttribute(Attribute) - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
setAttributes(AttributeList) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
 
setAttributes(AttributeList) - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
setAutoCommit(Boolean) - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Indicates whether to set any new connections for this database to auto-commit.
setBinaryOp(BitWiseOpEnum) - Method in class net.esper.client.soda.BitwiseOpExpression
Sets the binary operator.
setBoolean(boolean) - Method in class net.esper.type.BoolValue
 
setBoolean(boolean) - Method in interface net.esper.type.PrimitiveValue
Set a boolean value.
setBoolean(boolean) - Method in class net.esper.type.PrimitiveValueBase
 
setBuffer(BufferView, int) - Method in class net.esper.eql.join.JoinPreloadMethodImpl
Sets the buffer for a stream to preload events from.
setByte(byte) - Method in class net.esper.type.ByteValue
 
setByte(byte) - Method in interface net.esper.type.PrimitiveValue
Set a byte value.
setByte(byte) - Method in class net.esper.type.PrimitiveValueBase
 
setCallback(PatternMatchCallback) - Method in interface net.esper.pattern.EvalRootState
Accept callback to indicate pattern results.
setCallback(PatternMatchCallback) - Method in class net.esper.pattern.EvalRootStateNode
Hands the callback to use to indicate matching events.
setCallback(TimerCallback) - Method in interface net.esper.timer.TimerService
Set the callback method to invoke for clock ticks.
setCallback(TimerCallback) - Method in class net.esper.timer.TimerServiceImpl
 
setCanSelfJoin(boolean) - Method in class net.esper.core.EPStatementHandle
Set the statement's self-join flag to indicate the the statement may join to itself, that is a single event may dispatch into multiple streams or patterns for the same statement, requiring internal dispatch logic to not shortcut evaluation of all filters for the statement within one lock, requiring the callback handle to be sorted.
setCatalog(String) - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Sets the name of the catalog on new database connections.
setClassLegacyConfigs(Map<String, ConfigurationEventTypeLegacy>) - Method in interface net.esper.event.EventAdapterService
Sets the configured legacy Java class information.
setClassLegacyConfigs(Map<String, ConfigurationEventTypeLegacy>) - Method in class net.esper.event.EventAdapterServiceImpl
Set the legacy Java class type information.
setClassName(String) - Method in class net.esper.client.ConfigurationAdapterLoader
Sets the loader classname.
setClassName(String) - Method in class net.esper.client.soda.MethodInvocationStream
Sets the name of the class providing the method.
setClassName(String) - Method in class net.esper.client.soda.StaticMethodExpression
Sets the class name.
setClassPropertyResolutionStyle(Configuration.PropertyResolutionStyle) - Method in class net.esper.client.ConfigurationEngineDefaults.EventMeta
Sets the property resolution style to use for resolving property names of Java classes.
setClassToLegacyConfigs(Map<String, ConfigurationEventTypeLegacy>) - Method in class net.esper.event.BeanEventAdapter
Set the additional mappings for legacy classes.
setCodeGeneration(ConfigurationEventTypeLegacy.CodeGeneration) - Method in class net.esper.client.ConfigurationEventTypeLegacy
Sets the code generation flags.
setCoercionTypes(String[], Class[]) - Method in class net.esper.eql.join.plan.QueryPlanIndex
Sets the coercion types for a given index.
setColumnChangeCase(ConfigurationDBRef.ColumnChangeCaseEnum) - Method in class net.esper.client.ConfigurationDBRef
Sets enum value determining how the engine should change case on output column names returned from statement or statement result set metadata.
setConfigProperties(Properties) - Method in class net.esper.client.ConfigurationAdapterLoader
Sets the loader configuration.
setConfiguration(Configuration) - Method in class net.esper.core.EPServiceProviderImpl
Sets engine configuration information for use in the next initialize.
setConnectionAutoCommit(boolean) - Method in class net.esper.client.ConfigurationDBRef
Sets the auto-commit connection settings for new connections to this database.
setConnectionCatalog(String) - Method in class net.esper.client.ConfigurationDBRef
Sets the catalog name for new connections created for this database.
setConnectionLifecycleEnum(ConfigurationDBRef.ConnectionLifecycleEnum) - Method in class net.esper.client.ConfigurationDBRef
Controls whether a new connection is obtained for each lookup, or connections are retained between lookups.
setConnectionOptions(Connection, ConfigurationDBRef.ConnectionSettings) - Static method in class net.esper.eql.db.DatabaseDMConnFactory
Method to set connection-level configuration settings.
setConnectionReadOnly(boolean) - Method in class net.esper.client.ConfigurationDBRef
Sets the read-only flag on new connections created for this database.
setConnectionTransactionIsolation(int) - Method in class net.esper.client.ConfigurationDBRef
Sets the transaction isolation level on new connections created for this database.
setConstant(Object) - Method in class net.esper.client.soda.ConstantExpression
Sets the constant value that the expression represents.
setConstant(Object) - Method in class net.esper.eql.spec.SubstitutionParameterExpression
Sets the constant value that the expression represents.
setContext(PatternContext) - Method in interface net.esper.pattern.PatternStateFactory
Sets the services for pattern state objects.
setContext(PatternContext) - Method in class net.esper.pattern.PatternStateFactoryImpl
 
setCreateVariable(CreateVariableClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Sets the create-variable clause if this is a statement creating a variable, or null if not.
setCreateVariableDesc(CreateVariableDesc) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the descriptor for create-variable statements, if this is one.
setCreateWindow(CreateWindowClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Sets the create-window clause for creating named windows, or null if this statement does not create a named window.
setCreateWindowDesc(CreateWindowDesc) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the create-window specification.
setCube(Cube) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
Set the cube to display.
setCurrentRow(MultiKeyUntyped) - Method in interface net.esper.eql.agg.AggregationService
Set the current aggregation state row - for use when evaluation nodes are asked to evaluate.
setCurrentRow(MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceGroupAllImpl
 
setCurrentRow(MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceGroupByImpl
 
setCurrentRow(MultiKeyUntyped) - Method in class net.esper.eql.agg.AggregationServiceNull
 
setCurrentState(EPStatementState, long) - Method in class net.esper.core.EPStatementImpl
 
setCurrentState(EPStatementState, long) - Method in interface net.esper.core.EPStatementSPI
Set statement state.
setDatabaseName(String) - Method in class net.esper.client.soda.SQLStream
Sets the database name.
setDataPoints(long) - Method in class net.esper.view.stat.BaseStatisticsBean
Sets the number of datapoints
setDataSourceConnection(String, Properties) - Method in class net.esper.client.ConfigurationDBRef
Sets the connection factory to use DataSource to obtain a connection.
setDataWindowContents(Iterable<EventBean>) - Method in class net.esper.eql.named.NamedWindowRootView
Sets the iterator to use to obtain current named window data window contents.
setDebugEnabled(Boolean) - Static method in class net.esper.util.ExecutionPathDebugLog
Sets execution path debug logging.
setDefaultNamespace(String) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Sets the default namespace.
setDefaultNamespace(String) - Method in class net.esper.event.xml.XPathNamespaceContext
Sets the default namespace.
setDefaultPropertyResolutionStyle(Configuration.PropertyResolutionStyle) - Method in class net.esper.event.BeanEventAdapter
Sets the default property resolution style for Java class properties.
setDefaultPropertyResolutionStyle(Configuration.PropertyResolutionStyle) - Method in interface net.esper.event.EventAdapterService
Sets the resolution style for case-sentitivity.
setDefaultPropertyResolutionStyle(Configuration.PropertyResolutionStyle) - Method in class net.esper.event.EventAdapterServiceImpl
Sets the default property resolution style.
setDescending(boolean) - Method in class net.esper.client.soda.OrderByElement
Set to true for descending sorts for this column, false for ascending sort.
setDimension(Dimension) - Method in class net.esper.view.stat.olap.DimensionMemberImpl
Set the dimension this member belongs to.
setDistinct(boolean) - Method in class net.esper.client.soda.AvedevProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.AvgProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.CountProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.MaxProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.MedianProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.MinProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.PlugInProjectionExpression
Set to true for distinct.
setDistinct(boolean) - Method in class net.esper.client.soda.StddevProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDistinct(boolean) - Method in class net.esper.client.soda.SumProjectionExpression
Set the distinct flag indicating the projection considers distinct values only.
setDouble(double) - Method in class net.esper.type.DoubleValue
 
setDouble(double) - Method in interface net.esper.type.PrimitiveValue
Set a double value.
setDouble(double) - Method in class net.esper.type.PrimitiveValueBase
 
setDriverManagerConnection(String, String, Properties) - Method in class net.esper.client.ConfigurationDBRef
Sets the connection factory to use DriverManager to obtain a connection.
setDriverManagerConnection(String, String, String, String) - Method in class net.esper.client.ConfigurationDBRef
Sets the connection factory to use DriverManager to obtain a connection.
setDriverManagerConnection(String, String, String, String, Properties) - Method in class net.esper.client.ConfigurationDBRef
Sets the connection factory to use DriverManager to obtain a connection.
setElse(Expression) - Method in class net.esper.client.soda.CaseSwitchExpression
Sets the else-part of the case-switch.
setElse(Expression) - Method in class net.esper.client.soda.CaseWhenThenExpression
Sets the expression to provide a value when no when-condition matches.
setEnableExecutionDebug(boolean) - Method in class net.esper.client.ConfigurationEngineDefaults.Logging
Set the debug flag for debugging the execution path, in which case the engine logs to Log4j in debug-level during execution.
setEPServicesContextFactoryClassName(String) - Method in class net.esper.client.Configuration
Sets the class name of the services context factory class to use.
setEvents(Set<EventBean>) - Method in class net.esper.eql.join.rep.Node
Store lookup results.
setEventTypeAlias(String) - Method in class net.esper.client.soda.Filter
Sets the name of the event type to filter for.
setExistsSubstitutionParameters(boolean) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the substitution parameters.
setExpiryTimeCache(double, double) - Method in class net.esper.client.ConfigurationDBRef
Configures an expiry-time cache of the given maximum age in seconds and purge interval in seconds.
setExpiryTimeCache(double, double, ConfigurationDBRef.CacheReferenceType) - Method in class net.esper.client.ConfigurationDBRef
Configures an expiry-time cache of the given maximum age in seconds and purge interval in seconds.
setExpiryTimeCache(double, double) - Method in class net.esper.client.ConfigurationMethodRef
Configures an expiry-time cache of the given maximum age in seconds and purge interval in seconds.
setExpiryTimeCache(double, double, ConfigurationDBRef.CacheReferenceType) - Method in class net.esper.client.ConfigurationMethodRef
Configures an expiry-time cache of the given maximum age in seconds and purge interval in seconds.
setExplicitProperties(Map<String, TypedEventPropertyGetter>) - Method in class net.esper.event.BaseConfigurableEventType
Sets explicit properties using a map of event property name and getter instance for each property.
setExplicitProperties(Collection<ConfigurationEventTypeXMLDOM.XPathPropertyDesc>) - Method in class net.esper.event.xml.BaseXMLEventType
Set the preconfigured event properties resolved by XPath expression.
setExpression(String) - Method in exception net.esper.client.EPStatementException
Sets expression text for statement.
setExpression(Expression) - Method in class net.esper.client.soda.OrderByElement
Sets the order-by value expression.
setExpression(PatternExpr) - Method in class net.esper.client.soda.PatternStream
Sets the pattern expression providing events to the stream.
setExpression(Expression) - Method in class net.esper.client.soda.SelectClauseElement
Sets the selection expression.
setExpression(ExprNode) - Method in class net.esper.eql.spec.OnTriggerSetAssignment
Sets the expression providing the new variable value
setFactoryClassName(String) - Method in class net.esper.client.ConfigurationPlugInPatternObject
Sets the view factory class name.
setFactoryClassName(String) - Method in class net.esper.client.ConfigurationPlugInView
Sets the view factory class name.
setFilter(Expression) - Method in class net.esper.client.soda.Filter
Sets the optional filter expression that tests the event, or null if no filter expression is needed.
setFilter(Filter) - Method in class net.esper.client.soda.FilterStream
Sets the filter to use.
setFilter(Filter) - Method in class net.esper.client.soda.PatternFilterExpr
Sets the filter specification.
setFilterExpr(ExprNode) - Method in class net.esper.eql.expression.ExprSubselectNode
Sets the validated filter expression, or null if there is none.
setFilterExprRootNode(ExprNode) - Method in class net.esper.eql.spec.StatementSpecCompiled
Set the where clause filter node.
setFilterExprRootNode(ExprNode) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the where clause or null if none
setFilterRootNode(ExprNode) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the where clause filter expression node.
setFilterSpec(FilterSpecCompiled) - Method in class net.esper.eql.spec.FilterStreamSpecCompiled
Sets a filter specification.
setFilterSpec(FilterSpecCompiled) - Method in class net.esper.pattern.EvalFilterNode
Sets a validated and optimized filter specification
setFirst(First) - Method in class net.esper.collection.InterchangeablePair
Set the first value of the pair to a new value.
setFirst(First) - Method in class net.esper.collection.Pair
Set the first value of the pair to a new value.
setFirst(T) - Method in class net.esper.collection.UniformPair
Set the first value of the pair to a new value.
setFloat(float) - Method in class net.esper.type.FloatValue
 
setFloat(float) - Method in interface net.esper.type.PrimitiveValue
Set a float value.
setFloat(float) - Method in class net.esper.type.PrimitiveValueBase
 
setFrequency(double) - Method in class net.esper.client.soda.OutputLimitClause
Sets output frequency.
setFrequencyVariable(String) - Method in class net.esper.client.soda.OutputLimitClause
Sets the variable name of the variable providing output rate frequency values, or null if the frequency is a fixed value.
setFromClause(FromClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify a from-clause.
setFunctionClassName(String) - Method in class net.esper.client.ConfigurationPlugInAggregationFunction
Sets the aggregation function's implementation class name.
setFunctionName(String) - Method in class net.esper.client.soda.PlugInProjectionExpression
Sets the function name.
setFunctionName(String) - Method in class net.esper.eql.agg.AggregationSupport
Sets the aggregation function name.
setGroupByClause(GroupByClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify a group-by-clause.
setGroupByExpressions(List<Expression>) - Method in class net.esper.client.soda.GroupByClause
Sets the expressions providing the grouped-by values.
setGuardFactory(GuardFactory) - Method in class net.esper.pattern.EvalGuardNode
Supplies the guard factory to the node.
setGuardParameters(List<Object>) - Method in interface net.esper.pattern.guard.GuardFactory
Sets the guard object parameters.
setGuardParameters(List<Object>) - Method in class net.esper.pattern.guard.TimerWithinGuardFactory
 
setHasVariables(boolean) - Method in class net.esper.eql.spec.StatementSpecMapContext
Set to true to indicate that a statement has variables.
setHasVariables(boolean) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the flag indicating the statement uses variables.
setHavingClause(Expression) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify a having-clause.
setHavingExprRootNode(ExprNode) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the having-clause filter expression node.
setHighEndpointIncluded(boolean) - Method in class net.esper.client.soda.BetweenExpression
Set to true to indicate that the high endpoint is included (the default).
setInitializationValue(Object) - Method in class net.esper.client.ConfigurationVariable
Sets the variable type.
setInsertInto(InsertIntoClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify an insert-into-clause.
setInsertIntoDesc(InsertIntoDesc) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the definition for any insert-into clause.
setInsertIntoDispatchLocking(ConfigurationEngineDefaults.Threading.Locking) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Sets the blocking strategy to use when multiple threads deliver results for a single statement to consuming statements of an insert-into, and the guarantee of order of delivery must be maintained.
setInsertIntoDispatchPreserveOrder(boolean) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
In multithreaded environments, this setting controls whether insert-into streams preserve the order of events inserted into them by one or more statements such that statements that consume other statement's events behave deterministic
setInsertIntoDispatchTimeout(long) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Sets the number of milliseconds that a thread may maximually be blocking to deliver statement results from a producing statement that employs insert-into to a consuming statement.
setInsertIntoLatchFactory(InsertIntoLatchFactory) - Method in class net.esper.core.EPStatementHandle
Sets the factory for latches in insert-into guaranteed order of delivery.
setInt(int) - Method in class net.esper.type.IntValue
 
setInt(int) - Method in interface net.esper.type.PrimitiveValue
Set an int value.
setInt(int) - Method in class net.esper.type.PrimitiveValueBase
 
setInternalEventRouter(InternalEventRouter) - Method in class net.esper.core.EPServicesContext
Set the router for internal event processing.
setInternalTimerEnabled(boolean) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Sets the use of internal timer.
setInternalTimerMsecResolution(long) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Sets the length of the interval (resolution) of the timer thread.
setIsPatternWalk(boolean) - Method in class net.esper.eql.generated.EQLBaseWalker
 
setIsPatternWalk(boolean) - Method in class net.esper.eql.parse.EQLTreeWalker
Set to indicate that we are walking a pattern.
setIsUsingWildcard(boolean) - Method in class net.esper.eql.spec.SelectClauseSpec
To indicate that a wildcard is one of the values in the list of expressions.
setJoinExecutionStrategy(JoinExecutionStrategy) - Method in class net.esper.eql.view.OutputProcessView
For joins, supplies the join execution strategy that provides iteration over statement results.
setLastValue(EventBean) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
Set last element containing the cube information to render.
setLastValue(EventBean) - Method in class net.esper.indicator.jmx.JMXLastElementDynamicMBean
 
setLastValue(EventBean) - Method in interface net.esper.indicator.jmx.JMXLastElementObserver
Update JMX last element view with a new value.
setLater(InsertIntoLatchWait) - Method in class net.esper.core.InsertIntoLatchWait
Hand a later latch to use for indicating completion via notify.
setLater(UpdateDispatchFutureWait) - Method in class net.esper.core.UpdateDispatchFutureWait
Hand a later future to the dispatch to use for indicating completion via notify.
setLeft(PropertyValueExpression) - Method in class net.esper.client.soda.OuterJoinQualifier
Sets the property value expression to join on.
setListenerDispatchLocking(ConfigurationEngineDefaults.Threading.Locking) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
Sets the blocking strategy to use when multiple threads deliver results for a single statement to listeners, and the guarantee of order of delivery must be maintained.
setListenerDispatchPreserveOrder(boolean) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
In multithreaded environments, this setting controls whether dispatches to listeners preserve the ordering in which the statement processes events.
setListenerDispatchTimeout(long) - Method in class net.esper.client.ConfigurationEngineDefaults.Threading
In multithreaded environments, this setting controls when dispatches to listeners preserve the ordering the timeout to complete any outstanding dispatches.
setListeners(EPStatementListenerSet) - Method in class net.esper.core.EPStatementImpl
 
setListeners(EPStatementListenerSet) - Method in class net.esper.core.EPStatementListenerSet
Set the update listener set to use.
setListeners(EPStatementListenerSet) - Method in interface net.esper.core.EPStatementSPI
Sets the statement listeners.
setLoaderName(String) - Method in class net.esper.client.ConfigurationAdapterLoader
Sets the loader name.
setLocalVersion() - Method in interface net.esper.eql.variable.VariableService
Sets the variable version that subsequent reads consider.
setLocalVersion() - Method in class net.esper.eql.variable.VariableServiceImpl
 
setLong(long) - Method in class net.esper.type.LongValue
 
setLong(long) - Method in interface net.esper.type.PrimitiveValue
Set a long value.
setLong(long) - Method in class net.esper.type.PrimitiveValueBase
 
setLowEndpointIncluded(boolean) - Method in class net.esper.client.soda.BetweenExpression
Set to true to indicate that the low endpoint is included (the default).
setLRUCache(int) - Method in class net.esper.client.ConfigurationDBRef
Configures a LRU cache of the given size for the database.
setLRUCache(int) - Method in class net.esper.client.ConfigurationMethodRef
Configures a LRU cache of the given size for the method invocation.
setMembers(int, Class) - Method in interface net.esper.view.stat.olap.MultidimCube
Set dimension members from the enumeration Class.
setMembers(int, List<Object>) - Method in interface net.esper.view.stat.olap.MultidimCube
Set dimension members from the list of value objects.
setMembers(int, Class) - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
setMembers(int, List<Object>) - Method in class net.esper.view.stat.olap.MultidimCubeImpl
 
setMetadataOrigin(ConfigurationDBRef.MetadataOriginEnum) - Method in class net.esper.client.ConfigurationDBRef
Sets and indicator how the engine should retrieve metadata about the columns that a given SQL query returns.
setMethod(String) - Method in class net.esper.client.soda.StaticMethodExpression
Sets the method name.
setMethodName(String) - Method in class net.esper.client.soda.MethodInvocationStream
Sets the name of the static method to invoke in the from-clause.
setModel(EPStatementObjectModel) - Method in class net.esper.client.soda.SubqueryExistsExpression
Sets the lookup statement object model.
setModel(EPStatementObjectModel) - Method in class net.esper.client.soda.SubqueryExpression
Sets the lookup statement object model.
setModel(EPStatementObjectModel) - Method in class net.esper.client.soda.SubqueryInExpression
Sets the lookup statement object model.
setMonth(int) - Method in class net.esper.type.CronParameter
Sets the month value.
setMsecVersionRelease(long) - Method in class net.esper.client.ConfigurationEngineDefaults.Variables
Sets the number of milliseconds that a version of a variables is held stable for use by very long-running atomic statement execution.
setName(String) - Method in class net.esper.client.ConfigurationPlugInAggregationFunction
Sets the aggregation function name.
setName(String) - Method in class net.esper.client.ConfigurationPlugInPatternObject
Sets the view name.
setName(String) - Method in class net.esper.client.ConfigurationPlugInView
Sets the view name.
setName(String) - Method in class net.esper.client.soda.EPBaseNamedObject
Sets the object name.
setNamespace(String) - Method in class net.esper.client.ConfigurationPlugInPatternObject
Sets the view namespace.
setNamespace(String) - Method in class net.esper.client.ConfigurationPlugInView
Sets the view namespace.
setNamespace(String) - Method in class net.esper.client.soda.EPBaseNamedObject
Sets the object namespace name
setNamespaceContext(XPathNamespaceContext) - Method in class net.esper.event.xml.BaseXMLEventType
Sets the namespace context for use in XPath expression resolution.
setNodeNumber(EvalNodeNumber) - Method in class net.esper.pattern.EvalNode
Sets the evaluation node's relative node number.
setNotBetween(boolean) - Method in class net.esper.client.soda.BetweenExpression
Set to true for not-between, or false for between range.
setNotIn(boolean) - Method in class net.esper.client.soda.InExpression
Set to true to indicate this is a not-in expression.
setNotIn(boolean) - Method in class net.esper.client.soda.SubqueryInExpression
Set to true for not-in, or false for in-lookup.
setNotIn(boolean) - Method in class net.esper.eql.expression.ExprSubselectInNode
Indicate that this is a not-in lookup.
setObject(int, Object) - Method in interface net.esper.client.EPPreparedStatement
Sets the value of the designated parameter using the given object.
setObject(int, Object) - Method in class net.esper.client.EPPreparedStatementImpl
 
setObserver(BufferObserver) - Method in class net.esper.view.internal.BufferView
Set the observer for indicating new and old data.
setObserverFactory(ObserverFactory) - Method in class net.esper.pattern.EvalObserverNode
Supplies the observer factory to the node.
setObserverParameters(List<Object>) - Method in interface net.esper.pattern.observer.ObserverFactory
Sets the observer object parameters.
setObserverParameters(List<Object>) - Method in class net.esper.pattern.observer.TimerAtObserverFactory
 
setObserverParameters(List<Object>) - Method in class net.esper.pattern.observer.TimerIntervalObserverFactory
 
setOnExpr(OnClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Sets the on-delete or on-select clause for selecting or deleting from named windows, or null if this statement does not on-select or on-delete from a named window
setOnTriggerDesc(OnTriggerDesc) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the on-delete statement specification.
setOperator(String) - Method in class net.esper.client.soda.RelationalOpExpression
Sets the operator to use.
setOptionalAsName(String) - Method in class net.esper.client.soda.OnDeleteClause
Sets the as-alias for the named window.
setOptionalAsName(String) - Method in class net.esper.client.soda.OnSelectClause
Sets the as-alias for the named window.
setOptionalAssignment(Expression) - Method in class net.esper.client.soda.CreateVariableClause
Sets the optional assignment expression, or null to initialize to a null value
setOptionalDispatchable(EPStatementDispatch) - Method in class net.esper.core.EPStatementHandle
Provides a callback for use when statement processing for filters and schedules is done, for use by join statements that require an explicit indicator that all joined streams results have been processed.
setOptionalMetadataSQL(String) - Method in class net.esper.client.soda.SQLStream
Sets metadata SQL.
setOrderByClause(OrderByClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify an order-by-clause.
setOrderByExpressions(List<OrderByElement>) - Method in class net.esper.client.soda.OrderByClause
Sets a list of expressions and flags to order by.
setOutputLimitClause(OutputLimitClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify an output-rate-limiting-clause.
setOutputLimitSpec(OutputLimitSpec) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the output limiting definition.
setParameterExpressions(List<Expression>) - Method in class net.esper.client.soda.MethodInvocationStream
Sets a list of expressions that are parameters to the method.
setParameters(List<Object>) - Method in class net.esper.client.soda.EPBaseNamedObject
Sets the parameters for the object.
setParent(Node) - Method in class net.esper.eql.join.rep.Node
Sets the parent node.
setParent(Viewable) - Method in class net.esper.eql.named.NamedWindowRootView
 
setParent(Viewable) - Method in class net.esper.view.ext.SortWindowView
 
setParent(Viewable) - Method in class net.esper.view.ext.TimeOrderView
 
setParent(Viewable) - Method in class net.esper.view.internal.PriorEventView
 
setParent(Viewable) - Method in class net.esper.view.stat.BaseBivariateStatisticsView
 
setParent(Viewable) - Method in class net.esper.view.stat.MultiDimStatsView
 
setParent(Viewable) - Method in class net.esper.view.stat.UnivariateStatisticsView
 
setParent(Viewable) - Method in class net.esper.view.stat.WeightedAverageView
 
setParent(Viewable) - Method in class net.esper.view.std.AddPropertyValueView
 
setParent(Viewable) - Method in class net.esper.view.std.GroupByView
 
setParent(Viewable) - Method in class net.esper.view.std.UniqueByPropertyView
 
setParent(Viewable) - Method in interface net.esper.view.View
Called when the View is added to a Viewable object.
setParent(Viewable) - Method in class net.esper.view.ViewSupport
 
setParent(Viewable) - Method in class net.esper.view.window.ExternallyTimedWindowView
 
setParentAssembler(ResultAssembler) - Method in class net.esper.eql.join.assemble.BaseAssemblyNode
Set parent node.
setParentEvaluator(Evaluator) - Method in class net.esper.pattern.EvalStateNode
Sets the parent evaluator.
setParentEvent(EventBean) - Method in class net.esper.eql.join.rep.Node
Set the parent lookup (from stream) event whose results (to stream) are stored.
setParentView(Viewable) - Method in class net.esper.core.EPStatementImpl
 
setParentView(Viewable) - Method in interface net.esper.core.EPStatementSPI
Sets the parent view.
setPatternObjectType(ConfigurationPlugInPatternObject.PatternObjectType) - Method in class net.esper.client.ConfigurationPlugInPatternObject
Set the type of pattern object for plug-in.
setPropertyName(String) - Method in class net.esper.client.soda.PropertyValueExpression
Sets the property name.
setPropertyResolutionStyle(Configuration.PropertyResolutionStyle) - Method in class net.esper.client.ConfigurationEventTypeLegacy
Sets the type's property resolution style to use.
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.ext.SortWindowViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.ext.TimeOrderViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.internal.PriorEventViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.stat.CorrelationViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.std.GroupByViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.std.LastElementViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.std.MergeViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.std.SizeViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in interface net.esper.view.ViewFactory
Indicates to the view factory to provide the view resource indicated.
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.ViewFactorySupport
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.KeepAllViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.LengthBatchViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.LengthWindowViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.TimeAccumViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.TimeBatchViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.TimeWindowViewFactory
 
setRawEventType(EventType) - Method in class net.esper.eql.expression.ExprSubselectNode
Sets the event type generated for wildcard selects.
setReadOnly(Boolean) - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Indicates whether to set any new connections for this database to read-only.
setResolvePropertiesAbsolute(boolean) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
When set to true (the default), indicates that when properties are compiled to XPath expressions that the compilation should generate an absolute XPath expression such as "/getQuote/request" for the simple request property, or "/getQuote/request/symbol" for a "request.symbol" nested property, wherein the root element node is "getQuote".
setResult(List<EventBean[]>, EventBean) - Method in class net.esper.eql.join.exec.LookupInstructionExecNode.MyResultAssembler
Supplies the result list to which to add result rows.
setRight(PropertyValueExpression) - Method in class net.esper.client.soda.OuterJoinQualifier
Sets the property value expression to join on.
setRootElementName(String) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Sets the root element name.
setRootElementNamespace(String) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Sets the root element namespace.
setSchemaResource(String) - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Sets the schema resource.
setSecond(Second) - Method in class net.esper.collection.InterchangeablePair
Set the second value of the pair to a new value.
setSecond(Second) - Method in class net.esper.collection.Pair
Set the second value of the pair to a new value.
setSecond(T) - Method in class net.esper.collection.UniformPair
Set the second value of the pair to a new value.
setSelectAsName(String) - Method in class net.esper.eql.expression.ExprSubselectNode
Supplies the name of the select expression as-tag
setSelectClause(SelectClause) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify a select-clause.
setSelectClause(ExprNode) - Method in class net.esper.eql.expression.ExprSubselectNode
Sets the validate select clause
setSelectClauseSpec(SelectClauseSpec) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the select clause.
setSelectList(List<SelectClauseElement>) - Method in class net.esper.client.soda.SelectClause
Sets the list of expressions in the select clause.
setSelector(OutputLimitSelector) - Method in class net.esper.client.soda.OutputLimitClause
Sets the selector indicating the events to output.
setSelectStreamDirEnum(SelectClauseStreamSelectorEnum) - Method in class net.esper.eql.spec.StatementSpecRaw
Sets the stream selector (rstream/istream/both etc).
setShareViews(boolean) - Method in class net.esper.client.ConfigurationEngineDefaults.ViewResources
Set the flag to instruct the engine whether to share view resources between statements for not
setShort(short) - Method in interface net.esper.type.PrimitiveValue
Set a short value.
setShort(short) - Method in class net.esper.type.PrimitiveValueBase
 
setShort(short) - Method in class net.esper.type.ShortValue
 
setSqlWithSubsParams(String) - Method in class net.esper.client.soda.SQLStream
Sets the SQL with optional substitution parameters in the SQL.
setState(String, int, Object) - Method in interface net.esper.eql.variable.VariableStateHandler
Sets the new variable value
setStatementLifecycleSvc(StatementLifecycleSvc) - Method in class net.esper.core.EPServicesContext
Sets the service dealing with starting and stopping statements.
setStatementLock(ManagedLock) - Method in class net.esper.core.EPStatementHandle
Sets the lock to use for the statement.
setStatementSpecCompiled(StatementSpecCompiled) - Method in class net.esper.eql.expression.ExprSubselectNode
Supplies a compiled statement spec.
setStopMethod(EPStatementStopMethod) - Method in class net.esper.core.EPStatementDesc
Sets the stop method.
setStopMethod(EPStatementStopMethod) - Method in class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Sets the stop method.
setStrategy(TableLookupStrategy) - Method in class net.esper.eql.expression.ExprSubselectNode
Sets the strategy for boiling down the table of lookup events into a subset against which to run the filter.
setStreamName(String) - Method in class net.esper.client.soda.Stream
Sets the stream name.
setStreamSelector(StreamSelector) - Method in class net.esper.client.soda.SelectClause
Sets the stream selector.
setString(String) - Method in interface net.esper.type.PrimitiveValue
Set a string value.
setString(String) - Method in class net.esper.type.PrimitiveValueBase
 
setString(String) - Method in class net.esper.type.StringValue
 
setSumX(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Sets the sum X.
setSumXSq(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Sets the sum X square.
setSumXY(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Sets the sum of x times y.
setSumY(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Sets the sum Y.
setSumYSq(double) - Method in class net.esper.view.stat.BaseStatisticsBean
Sets the sum Y square.
setTagName(String) - Method in class net.esper.client.soda.PatternFilterExpr
Sets the tag name.
setTime(long) - Method in interface net.esper.schedule.SchedulingService
Set the time based upon which the evaluation of events invokes callbacks.
setTime(long) - Method in class net.esper.schedule.SchedulingServiceImpl
 
setTransactionIsolation(int) - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Sets the transaction isolation level for new database connections, can be null to accept the default.
setType(Class) - Method in class net.esper.client.ConfigurationVariable
Sets the variable type.
setType(OuterJoinType) - Method in class net.esper.client.soda.OuterJoinQualifier
Sets the type of outer join.
setTypeName(String) - Method in class net.esper.client.soda.CastExpression
Sets the name of the type to cast to.
setTypeNames(String[]) - Method in class net.esper.client.soda.InstanceOfExpression
Sets the types to compare to.
setUncommitted(Map<Integer, Object>) - Method in class net.esper.eql.variable.VariableVersionThreadEntry
Sets a map of variable number and uncommitted value, or empty map or null if none exist
setUnit(OutputLimitUnit) - Method in class net.esper.client.soda.OutputLimitClause
Sets the unit the frequency is in.
setUnmatchedListener(UnmatchedListener) - Method in interface net.esper.client.EPRuntime
Sets a listener to receive events that are unmatched by any statement.
setUnmatchedListener(UnmatchedListener) - Method in class net.esper.core.EPRuntimeImpl
 
setUpdateListeners(EPStatementListenerSet) - Method in class net.esper.core.UpdateDispatchViewBase
Set new update listeners.
setValue(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
 
setValue(Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashMapIterator
 
setValue(Object) - Method in class net.esper.collection.apachecommons.AbstractMapEntry
Sets the value stored in this Map.Entry.
setValue(Object) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Sets the value of the entry.
setValue(Object) - Method in interface net.esper.collection.apachecommons.MapIterator
Sets the value associated with the current key (optional operation).
setValue(Object) - Method in class net.esper.eql.expression.ExprConstantNode
Sets the value of the constant.
SETVALUE_INVALID - Static variable in class net.esper.collection.apachecommons.AbstractHashedMap
Message.
setVariableName(String) - Method in class net.esper.client.soda.CreateVariableClause
Sets the variable name
setVariableType(String) - Method in class net.esper.client.soda.CreateVariableClause
Sets the variable type name.
setVersion(Integer) - Method in class net.esper.eql.variable.VariableVersionThreadEntry
Sets the version visible for a thread.
setVersionsHigh(VersionedValueList<Object>) - Method in class net.esper.eql.variable.VariableReader
For roll-over (overflow) in version numbers, sets a new collection of versioned-values for the variable to use when requests over the version rollover boundary are made.
setVersionsLow(VersionedValueList<Object>) - Method in class net.esper.eql.variable.VariableReader
Sets a new list of versioned-values to inquire against, for use when version numbers roll-over.
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.ext.SortWindowViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.ext.TimeOrderViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.internal.PriorEventViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.stat.CorrelationViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.std.GroupByViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.std.LastElementViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.std.MergeViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.std.SizeViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in interface net.esper.view.ViewFactory
Indicates user EQL query view parameters to the view factory.
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.KeepAllViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.LengthBatchViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.LengthWindowViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.TimeAccumViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.TimeBatchViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.TimeLengthBatchViewFactory
 
setViewParameters(ViewFactoryContext, List<Object>) - Method in class net.esper.view.window.TimeWindowViewFactory
 
setViewResource(Object) - Method in interface net.esper.eql.core.ViewResourceCallback
Supplies view resource.
setViewResource(Object) - Method in class net.esper.eql.expression.ExprPreviousNode
 
setViewResource(Object) - Method in class net.esper.eql.expression.ExprPriorNode
 
setViews(List<View>) - Method in class net.esper.client.soda.CreateWindowClause
Sets the views onto the named window.
setViews(List<View>) - Method in class net.esper.client.soda.ProjectedStream
Sets the list of views onto the stream.
setWhereClause(Expression) - Method in class net.esper.client.soda.EPStatementObjectModel
Specify a where-clause.
setWildcard(boolean) - Method in class net.esper.client.soda.SelectClause
Set to true if a wildcard is part of the select clause, or false if not.
setWindowName(String) - Method in class net.esper.client.soda.CreateWindowClause
Sets the window name.
setWindowName(String) - Method in class net.esper.client.soda.OnDeleteClause
Sets the name of the named window.
setWindowName(String) - Method in class net.esper.client.soda.OnSelectClause
Sets the name of the named window.
shallowCopy() - Method in interface net.esper.pattern.MatchedEventMap
Make a shallow copy of this collection.
shallowCopy() - Method in class net.esper.pattern.MatchedEventMapImpl
Make a shallow copy of this collection.
ShortValue - Class in net.esper.type
Placeholder for a short-typed value in an event expression.
ShortValue() - Constructor for class net.esper.type.ShortValue
 
SimpleByteArrayInputStream - Class in net.esper.util
Input stream that relies on a simple byte array, unchecked.
SimpleByteArrayInputStream(byte[], int) - Constructor for class net.esper.util.SimpleByteArrayInputStream
Ctor.
SimpleByteArrayOutputStream - Class in net.esper.util
Output stream that relies on a simple byte array, unchecked.
SimpleByteArrayOutputStream() - Constructor for class net.esper.util.SimpleByteArrayOutputStream
Ctor.
SimpleByteArrayOutputStream(int) - Constructor for class net.esper.util.SimpleByteArrayOutputStream
Ctor.
SimpleProperty - Class in net.esper.event.property
Represents a simple property of a given name.
SimpleProperty(String) - Constructor for class net.esper.event.property.SimpleProperty
Ctor.
simpleTypeToQName(XSSimpleTypeDecl) - Static method in class net.esper.event.xml.SchemaUtil
Returns the XPathConstants type for a given Xerces type definition.
SimpleXMLEventType - Class in net.esper.event.xml
Optimistic try to resolve the property string into an appropiate xPath, and use it as getter.
SimpleXMLEventType(ConfigurationEventTypeXMLDOM) - Constructor for class net.esper.event.xml.SimpleXMLEventType
Ctor.
SimpleXMLPropertyParser - Class in net.esper.event.xml
Parses event property names and transforms to XPath expressions.
SimpleXMLPropertyParser() - Constructor for class net.esper.event.xml.SimpleXMLPropertyParser
 
SingleCursorIterator - Class in net.esper.eql.join.rep
A utility class for an iterator that has one element.
SingleCursorIterator(Cursor) - Constructor for class net.esper.eql.join.rep.SingleCursorIterator
Ctor.
SingleEventIterator - Class in net.esper.collection
A utility class for an iterator that has one element.
SingleEventIterator(EventBean) - Constructor for class net.esper.collection.SingleEventIterator
Constructor, takes the single event to iterate over as a parameter.
SingleObjectIterator<T> - Class in net.esper.collection
A utility class for an iterator that has zero or one element and can be reset with a new value.
SingleObjectIterator(T) - Constructor for class net.esper.collection.SingleObjectIterator
Constructor, takes the single object to iterate over as a parameter.
SingleObjectIterator() - Constructor for class net.esper.collection.SingleObjectIterator
Ctor for an iterator starting out empty.
singleParameter(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
singleParameter() - Method in class net.esper.eql.generated.EQLStatementParser
 
size() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.EntrySet
 
size() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.KeySet
 
size - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
The size of the map
size() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the size of the map.
size() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.Values
 
size() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Gets the size of the map.
size() - Method in class net.esper.collection.ArrayBackedCollection
 
size() - Method in class net.esper.collection.MultiKey
Returns the number of key objects.
size() - Method in class net.esper.collection.MultiKeyUntyped
Returns the number of key objects.
size() - Method in class net.esper.collection.RefCountedSet
Returns the number of values in the collection.
size() - Method in class net.esper.collection.SortedDoubleVector
Returns the number of items in the collection.
size() - Method in class net.esper.filter.EventTypeIndex
Returns the current size of the known event types.
size() - Method in class net.esper.filter.FilterParamIndexBase
Return the number of distinct filter parameter constants stored.
size() - Method in class net.esper.filter.FilterParamIndexBooleanExpr
 
size() - Method in class net.esper.filter.FilterParamIndexCompare
 
size() - Method in class net.esper.filter.FilterParamIndexEquals
 
size() - Method in class net.esper.filter.FilterParamIndexIn
 
size() - Method in class net.esper.filter.FilterParamIndexNotEquals
 
size() - Method in class net.esper.filter.FilterParamIndexNotIn
 
size() - Method in class net.esper.filter.FilterParamIndexNotRange
 
size() - Method in class net.esper.filter.FilterParamIndexPropBase
Return the number of distinct filter parameter constants stored.
size() - Method in class net.esper.filter.FilterParamIndexRange
 
size - Variable in class net.esper.view.window.LengthBatchViewFactory
The length window size.
size - Variable in class net.esper.view.window.LengthWindowViewFactory
Size of length window.
SizeView - Class in net.esper.view.std
This view is a very simple view presenting the number of elements in a stream or view.
SizeView(StatementContext) - Constructor for class net.esper.view.std.SizeView
Ctor.
SizeViewFactory - Class in net.esper.view.std
Factory for SizeView instances.
SizeViewFactory() - Constructor for class net.esper.view.std.SizeViewFactory
 
skip(long) - Method in class net.esper.util.SimpleByteArrayInputStream
 
SL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SL_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SL_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SL_COMMENT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SL_COMMENT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SNAPSHOT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SNAPSHOT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SOFT - Static variable in class net.esper.collection.apachecommons.AbstractReferenceMap
Constant indicating that soft references should be used
sort(EventBean[], EventBean[][], boolean) - Method in interface net.esper.eql.core.OrderByProcessor
Sort the output events.
sort(EventBean[], EventBean[][], MultiKeyUntyped[], boolean) - Method in interface net.esper.eql.core.OrderByProcessor
Sort the output events, using the provided group-by keys for evaluating grouped aggregation functions, and avoiding the cost of recomputing the keys.
sort(EventBean[], MultiKeyUntyped[]) - Method in interface net.esper.eql.core.OrderByProcessor
Sort a given array of outgoing events using the sort keys returning a sorted outgoing event array.
sort(EventBean[], EventBean[][], boolean) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
sort(EventBean[], EventBean[][], MultiKeyUntyped[], boolean) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
sort(EventBean[], MultiKeyUntyped[]) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
SortedDoubleVector - Class in net.esper.collection
Sorted, reference-counting set based on an ArrayList implementation that it being kept sorted.
SortedDoubleVector() - Constructor for class net.esper.collection.SortedDoubleVector
Constructor.
SortedRefCountedSet<K> - Class in net.esper.collection
Sorted, reference-counting set based on a TreeMap implementation that stores keys and a reference counter for each unique key value.
SortedRefCountedSet() - Constructor for class net.esper.collection.SortedRefCountedSet
Constructor.
sortFieldNames - Variable in class net.esper.view.ext.SortWindowViewFactory
The sort-by field names.
SortWindowIterator - Class in net.esper.view.ext
Iterator for use by SortWindowView.
SortWindowIterator(SortedMap<MultiKeyUntyped, LinkedList<EventBean>>) - Constructor for class net.esper.view.ext.SortWindowIterator
Ctor.
sortWindowSize - Variable in class net.esper.view.ext.SortWindowViewFactory
The sort window size.
SortWindowView - Class in net.esper.view.ext
Window sorting by values in the specified field extending a specified number of elements from the lowest value up or the highest value down.
SortWindowView(SortWindowViewFactory, String[], Boolean[], int, IStreamSortedRandomAccess) - Constructor for class net.esper.view.ext.SortWindowView
Ctor.
SortWindowViewFactory - Class in net.esper.view.ext
Factory for sort window views.
SortWindowViewFactory() - Constructor for class net.esper.view.ext.SortWindowViewFactory
 
spec - Variable in class net.esper.pattern.observer.TimerAtObserverFactory
The schedule specification for the timer-at.
SQL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SQL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SQL_NE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SQL_NE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SQLParameterDesc - Class in net.esper.eql.db
Hold a raw SQL-statements parameter information that were specified in the form ${name}.
SQLParameterDesc(String[], String[]) - Constructor for class net.esper.eql.db.SQLParameterDesc
Ctor.
SQLStream - Class in net.esper.client.soda
An SQL stream that polls via SQL for events via join.
SQLStream(String, String, String, String) - Constructor for class net.esper.client.soda.SQLStream
Ctor.
SQLTypeMapUtil - Class in net.esper.util
Utility for mapping SQL types of Types to Java classes.
SQLTypeMapUtil() - Constructor for class net.esper.util.SQLTypeMapUtil
 
sqlTypeToClass(int, String) - Static method in class net.esper.util.SQLTypeMapUtil
Mapping as defined by JDBC 3 Spec , page B-177, table B-1 JBDC Types mapped to Java Types.
SR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
STAR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STAR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
STAR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STAR_ASSIGN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
start() - Method in interface net.esper.client.EPStatement
Start the statement.
start() - Method in class net.esper.core.EPStatementImpl
 
start(boolean) - Method in class net.esper.core.EPStatementStartMethod
Starts the EQL statement.
start(String) - Method in interface net.esper.core.StatementLifecycleSvc
Start statement by statement id.
start(String) - Method in class net.esper.core.StatementLifecycleSvcImpl
 
start(String, StatementLifecycleSvcImpl.EPStatementDesc, boolean) - Method in class net.esper.core.StatementLifecycleSvcImpl
Start the given statement.
start() - Method in class net.esper.eql.core.MethodPollingExecStrategy
 
start() - Method in interface net.esper.eql.db.PollExecStrategy
Start the poll, called before any poll operation.
start() - Method in class net.esper.eql.db.PollExecStrategyDBQuery
 
start() - Method in class net.esper.pattern.EvalAndStateNode
 
start() - Method in class net.esper.pattern.EvalEveryStateNode
 
start() - Method in class net.esper.pattern.EvalFilterStateNode
 
start() - Method in class net.esper.pattern.EvalFollowedByStateNode
 
start() - Method in class net.esper.pattern.EvalGuardStateNode
 
start() - Method in class net.esper.pattern.EvalNotStateNode
 
start() - Method in class net.esper.pattern.EvalObserverStateNode
 
start() - Method in class net.esper.pattern.EvalOrStateNode
 
start(PatternMatchCallback, PatternContext) - Method in class net.esper.pattern.EvalRootNode
 
start() - Method in class net.esper.pattern.EvalRootStateNode
 
start() - Method in class net.esper.pattern.EvalStateNode
Starts the event expression or an instance of it.
start(PatternMatchCallback, PatternContext) - Method in interface net.esper.pattern.PatternStarter
An event expression was started and supplies the callback to use when matching events appear.
startAllStatements() - Method in interface net.esper.client.EPAdministrator
Starts all statements that are in stopped state.
startAllStatements() - Method in class net.esper.core.EPAdministratorImpl
 
startAllStatements() - Method in interface net.esper.core.StatementLifecycleSvc
Starts all stopped statements.
startAllStatements() - Method in class net.esper.core.StatementLifecycleSvcImpl
 
startEQLExpressionRule(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
startEQLExpressionRule() - Method in class net.esper.eql.generated.EQLStatementParser
 
startEventPropertyRule() - Method in class net.esper.eql.generated.EQLStatementParser
 
startGuard() - Method in interface net.esper.pattern.guard.Guard
Start the guard operation.
startGuard() - Method in class net.esper.pattern.guard.TimerWithinGuard
 
startInternalClock() - Method in interface net.esper.timer.TimerService
Start clock expecting callbacks at regular intervals and a fixed rate.
startInternalClock() - Method in class net.esper.timer.TimerServiceImpl
 
startObserve() - Method in interface net.esper.pattern.observer.EventObserver
Start observing.
startObserve() - Method in class net.esper.pattern.observer.TimerAtObserver
 
startObserve() - Method in class net.esper.pattern.observer.TimerIntervalObserver
 
startPatternExpressionRule(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
startPatternExpressionRule() - Method in class net.esper.eql.generated.EQLStatementParser
 
StatementAwareUpdateListener - Interface in net.esper.client
Defines an interface to notify of new and old events.
StatementContext - Class in net.esper.core
Contains handles to the implementation of the the scheduling service for use in view evaluation.
StatementContext(String, String, String, String, String, SchedulingService, ScheduleBucket, EventAdapterService, EPStatementHandle, ViewResolutionService, PatternObjectResolutionService, StatementExtensionSvcContext, StatementStopService, MethodResolutionService, PatternContextFactory, FilterService, JoinSetComposerFactory, OutputConditionFactory, NamedWindowService, VariableService) - Constructor for class net.esper.core.StatementContext
Constructor.
statementContext - Variable in class net.esper.view.stat.BaseBivariateStatisticsView
Services required by implementing classes.
StatementContextFactory - Interface in net.esper.core
Interface for a factory class that makes statement context specific to a statement.
StatementContextFactoryDefault - Class in net.esper.core
Default implementation for making a statement-specific context class.
StatementContextFactoryDefault(PluggableObjectCollection, PluggableObjectCollection) - Constructor for class net.esper.core.StatementContextFactoryDefault
Ctor.
StatementExtensionSvcContext - Interface in net.esper.core
Statement-level extension services.
StatementLifecycleSvc - Interface in net.esper.core
Handles statement management.
StatementLifecycleSvcImpl - Class in net.esper.core
Provides statement lifecycle services.
StatementLifecycleSvcImpl(EPServiceProvider, EPServicesContext) - Constructor for class net.esper.core.StatementLifecycleSvcImpl
Ctor.
StatementLifecycleSvcImpl.EPStatementDesc - Class in net.esper.core
Statement information.
StatementLifecycleSvcImpl.EPStatementDesc(EPStatementSPI, EPStatementStartMethod, EPStatementStopMethod, String, EPStatementHandle) - Constructor for class net.esper.core.StatementLifecycleSvcImpl.EPStatementDesc
Ctor.
StatementLockFactory - Interface in net.esper.core
Factory for the managed lock that provides statement resource protection.
StatementLockFactoryImpl - Class in net.esper.core
Provides statement-level locks.
StatementLockFactoryImpl() - Constructor for class net.esper.core.StatementLockFactoryImpl
 
StatementSpecCompiled - Class in net.esper.eql.spec
Specification object representing a complete EQL statement including all EQL constructs.
StatementSpecCompiled(OnTriggerDesc, CreateWindowDesc, CreateVariableDesc, InsertIntoDesc, SelectClauseStreamSelectorEnum, SelectClauseSpec, List<StreamSpecCompiled>, List<OuterJoinDesc>, ExprNode, List<ExprNode>, ExprNode, OutputLimitSpec, List<OrderByItem>, List<ExprSubselectNode>, boolean) - Constructor for class net.esper.eql.spec.StatementSpecCompiled
Ctor.
StatementSpecMapContext - Class in net.esper.eql.spec
Context for mapping a SODA statement to a statement specification, or multiple for subqueries, and obtaining certain optimization information from a statement.
StatementSpecMapContext(EngineImportService, VariableService) - Constructor for class net.esper.eql.spec.StatementSpecMapContext
Ctor.
StatementSpecMapper - Class in net.esper.eql.spec
Helper for mapping internal representations of a statement to the SODA object model for statements.
StatementSpecMapper() - Constructor for class net.esper.eql.spec.StatementSpecMapper
 
StatementSpecRaw - Class in net.esper.eql.spec
Specification object representing a complete EQL statement including all EQL constructs.
StatementSpecRaw() - Constructor for class net.esper.eql.spec.StatementSpecRaw
 
StatementSpecUnMapContext - Class in net.esper.eql.spec
Un-mapping context for mapping from an internal specifications to an SODA object model.
StatementSpecUnMapContext() - Constructor for class net.esper.eql.spec.StatementSpecUnMapContext
Ctor.
StatementSpecUnMapResult - Class in net.esper.eql.spec
Return result for unmap operators unmapping an intermal statement representation to the SODA object model.
StatementSpecUnMapResult(EPStatementObjectModel, Map<Integer, SubstitutionParameterExpression>) - Constructor for class net.esper.eql.spec.StatementSpecUnMapResult
Ctor.
StatementStopCallback - Interface in net.esper.view
Callback to indicate that a statement has stopped.
statementStopped() - Method in class net.esper.eql.named.NamedWindowConsumerView
 
statementStopped() - Method in class net.esper.eql.named.NamedWindowOnExprBaseView
 
statementStopped() - Method in interface net.esper.view.StatementStopCallback
Indicates statement stopped.
StatementStopService - Interface in net.esper.view
Provides statement resources with the means to register a callback and be informed when a statement stopped and resources for the statement must be release.
StatementStopServiceImpl - Class in net.esper.view
Provides subscription list for statement stop callbacks.
StatementStopServiceImpl() - Constructor for class net.esper.view.StatementStopServiceImpl
ctor.
staticJoin() - Method in interface net.esper.eql.join.JoinExecutionStrategy
A static join is for use with iterating over join statements.
staticJoin() - Method in class net.esper.eql.join.JoinExecutionStrategyImpl
 
staticJoin() - Method in interface net.esper.eql.join.JoinSetComposer
For use in iteration over join statements, this must build a join tuple result set from all events in indexes, executing query strategies for each.
staticJoin() - Method in class net.esper.eql.join.JoinSetComposerImpl
 
staticMethod(String, String, Object...) - Static method in class net.esper.client.soda.Expressions
Static method invocation.
staticMethod(String, String, Expression...) - Static method in class net.esper.client.soda.Expressions
Static method invocation.
StaticMethodExpression - Class in net.esper.client.soda
Static method call consists of a class name and method name.
StaticMethodExpression(String, String, Object[]) - Constructor for class net.esper.client.soda.StaticMethodExpression
Ctor.
StaticMethodExpression(String, String) - Constructor for class net.esper.client.soda.StaticMethodExpression
Ctor.
statisticsBean - Variable in class net.esper.view.stat.BaseBivariateStatisticsView
This bean can be overridden by subclasses providing extra values such as correlation, regression.
stddev(String) - Static method in class net.esper.client.soda.Expressions
Standard deviation aggregation function.
stddev(Expression) - Static method in class net.esper.client.soda.Expressions
Standard deviation aggregation function.
STDDEV - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STDDEV - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
StddevAggregator - Class in net.esper.eql.agg
Standard deviation always generates double-typed numbers.
StddevAggregator() - Constructor for class net.esper.eql.agg.StddevAggregator
 
stddevDistinct(String) - Static method in class net.esper.client.soda.Expressions
Standard deviation function considering distinct values only.
stddevDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Standard deviation function considering distinct values only.
StddevProjectionExpression - Class in net.esper.client.soda
Standard deviation of the (distinct) values returned by an expression.
StddevProjectionExpression(boolean) - Constructor for class net.esper.client.soda.StddevProjectionExpression
Ctor - for use to create an expression tree, without inner expression
StddevProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.StddevProjectionExpression
Ctor - adds the expression to project.
stmtIdToDescMap - Variable in class net.esper.core.StatementLifecycleSvcImpl
Maps of statement id to descriptor.
stmtNameToStmtMap - Variable in class net.esper.core.StatementLifecycleSvcImpl
Map of statement name to statement.
stop() - Method in interface net.esper.client.EPStatement
Stop the statement.
stop() - Method in class net.esper.core.EPStatementImpl
 
stop() - Method in interface net.esper.core.EPStatementStopMethod
Stops a statement.
stop(String) - Method in interface net.esper.core.StatementLifecycleSvc
Stop statement by statement id.
stop(String) - Method in class net.esper.core.StatementLifecycleSvcImpl
 
stop() - Method in class net.esper.eql.core.MethodPollingViewable
 
stop() - Method in class net.esper.eql.db.DatabasePollingViewable
 
stop() - Method in class net.esper.pattern.EvalRootStateNode
 
stop() - Method in interface net.esper.util.StopCallback
Stops the underlying resources.
stopAllStatements() - Method in interface net.esper.client.EPAdministrator
Stops all statements that are in started state.
stopAllStatements() - Method in class net.esper.core.EPAdministratorImpl
 
stopAllStatements() - Method in interface net.esper.core.StatementLifecycleSvc
Stops all started statements.
stopAllStatements() - Method in class net.esper.core.StatementLifecycleSvcImpl
 
StopCallback - Interface in net.esper.util
General pupose callback to stop a resource and free it's underlying resources.
stopGuard() - Method in interface net.esper.pattern.guard.Guard
Called when sub-expression quits, or when the pattern stopped.
stopGuard() - Method in class net.esper.pattern.guard.TimerWithinGuard
 
stopInternalClock(boolean) - Method in interface net.esper.timer.TimerService
Stop internal clock.
stopInternalClock(boolean) - Method in class net.esper.timer.TimerServiceImpl
 
stopObserve() - Method in interface net.esper.pattern.observer.EventObserver
Stop observing.
stopObserve() - Method in class net.esper.pattern.observer.TimerAtObserver
 
stopObserve() - Method in class net.esper.pattern.observer.TimerIntervalObserver
 
Stream - Class in net.esper.client.soda
An abstract base class for a named or unnamed stream.
Stream(String) - Constructor for class net.esper.client.soda.Stream
Ctor.
STREAM_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STREAM_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
streamExpression(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
streamExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
StreamFactoryService - Interface in net.esper.view.stream
Service on top of the filter service for reuseing filter callbacks and their associated EventStream instances.
StreamFactoryServiceProvider - Class in net.esper.view.stream
Static factory for implementations of the StreamFactoryService interface.
StreamFactoryServiceProvider() - Constructor for class net.esper.view.stream.StreamFactoryServiceProvider
 
StreamFactorySvcImpl - Class in net.esper.view.stream
Service implementation to reuse or not reuse event streams and existing filters depending on the type of statement.
StreamFactorySvcImpl(boolean) - Constructor for class net.esper.view.stream.StreamFactorySvcImpl
Ctor.
StreamNotFoundException - Exception in net.esper.eql.core
Exception to indicate that a stream name could not be resolved.
StreamNotFoundException(String) - Constructor for exception net.esper.eql.core.StreamNotFoundException
Ctor.
streamNum - Variable in class net.esper.eql.join.assemble.BaseAssemblyNode
Stream number.
streamNumbers - Variable in class net.esper.eql.lookup.IndexedTableLookupStrategy
Stream numbers to get key values from.
StreamSelector - Enum in net.esper.client.soda
Enumeration for representing selection of the remove stream or the insert stream, or both.
streamSelector() - Method in class net.esper.eql.generated.EQLStatementParser
 
StreamSpec - Interface in net.esper.eql.spec
Specification for a stream, consists simply of an optional stream name and a list of views on to of the stream.
StreamSpecBase - Class in net.esper.eql.spec
Abstract base specification for a stream, consists simply of an optional stream name and a list of views on to of the stream.
StreamSpecBase(String, List<ViewSpec>) - Constructor for class net.esper.eql.spec.StreamSpecBase
Ctor.
StreamSpecBase() - Constructor for class net.esper.eql.spec.StreamSpecBase
Default ctor.
StreamSpecCompiled - Interface in net.esper.eql.spec
Validated stream specifications generally have expression nodes that are valid and event types exist.
StreamSpecRaw - Interface in net.esper.eql.spec
An uncompiled, unoptimize for of stream specification created by a parser.
StreamTypeService - Interface in net.esper.eql.core
Service supplying stream number and property type information.
StreamTypeServiceImpl - Class in net.esper.eql.core
Implementation that provides stream number and property type information.
StreamTypeServiceImpl(EventType[], String[]) - Constructor for class net.esper.eql.core.StreamTypeServiceImpl
Ctor.
StreamTypeServiceImpl(LinkedHashMap<String, EventType>, boolean, boolean) - Constructor for class net.esper.eql.core.StreamTypeServiceImpl
Ctor.
StreamTypesException - Exception in net.esper.eql.core
Base class for stream and property name resolution errors.
StreamTypesException(String) - Constructor for exception net.esper.eql.core.StreamTypesException
Ctor.
STRING_LITERAL - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STRING_LITERAL - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
STRING_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STRING_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
stringconstant() - Method in class net.esper.eql.generated.EQLStatementParser
 
StringValue - Class in net.esper.type
Placeholder for a String value in an event expression.
StringValue(String) - Constructor for class net.esper.type.StringValue
Constructor.
StringValue() - Constructor for class net.esper.type.StringValue
Constructor.
subquery(EPStatementObjectModel) - Static method in class net.esper.client.soda.Expressions
Subquery.
subqueryExists(EPStatementObjectModel) - Static method in class net.esper.client.soda.Expressions
Subquery with exists-clause, represents the syntax of "select * from ...
SubqueryExistsExpression - Class in net.esper.client.soda
Exists-expression for a set of values returned by a lookup.
SubqueryExistsExpression(EPStatementObjectModel) - Constructor for class net.esper.client.soda.SubqueryExistsExpression
Ctor - for use to create an expression tree, without child expression.
subQueryExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
subQueryExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
SubqueryExpression - Class in net.esper.client.soda
Subquery-expression returns values returned by a lookup modelled by a further EPStatementObjectModel.
SubqueryExpression(EPStatementObjectModel) - Constructor for class net.esper.client.soda.SubqueryExpression
Ctor - for use to create an expression tree, without child expression.
subqueryIn(String, EPStatementObjectModel) - Static method in class net.esper.client.soda.Expressions
Subquery with in-clause, represents the syntax of "value in (select ...
subqueryIn(Expression, EPStatementObjectModel) - Static method in class net.esper.client.soda.Expressions
Subquery with in-clause, represents the syntax of "value in (select ...
SubqueryInExpression - Class in net.esper.client.soda
In-expression for a set of values returned by a lookup.
SubqueryInExpression(EPStatementObjectModel, boolean) - Constructor for class net.esper.client.soda.SubqueryInExpression
Ctor - for use to create an expression tree, without child expression.
SubqueryInExpression(Expression, EPStatementObjectModel, boolean) - Constructor for class net.esper.client.soda.SubqueryInExpression
Ctor - for use to create an expression tree, without child expression.
subqueryNotIn(String, EPStatementObjectModel) - Static method in class net.esper.client.soda.Expressions
Subquery with not-in-clause, represents the syntax of "value not in (select ...
subqueryNotIn(Expression, EPStatementObjectModel) - Static method in class net.esper.client.soda.Expressions
Subquery with not-in-clause, represents the syntax of "value not in (select ...
SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SUBSELECT_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
subSelectExistsExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
subSelectExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
subSelectFilterExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
subSelectFilterExpr() - Method in class net.esper.eql.generated.EQLStatementParser
 
SubSelectHolder - Class in net.esper.core
Entry holding lookup resource references for use by SubSelectStreamCollection.
SubSelectHolder(int, Viewable, ViewFactoryChain) - Constructor for class net.esper.core.SubSelectHolder
Ctor.
subSelectInExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
subSelectInQueryExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
subSelectRowExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
SubSelectStreamCollection - Class in net.esper.core
Holds stream information for subqueries.
SubSelectStreamCollection() - Constructor for class net.esper.core.SubSelectStreamCollection
Ctor.
substitution(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
SUBSTITUTION - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
substitution() - Method in class net.esper.eql.generated.EQLStatementParser
 
SUBSTITUTION - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
SubstitutionParameterExpression - Class in net.esper.eql.spec
Substitution parameter that represents a node in an expression tree for which to supply a parameter value before statement creation time.
SubstitutionParameterExpression(int) - Constructor for class net.esper.eql.spec.SubstitutionParameterExpression
Ctor.
sum(String) - Static method in class net.esper.client.soda.Expressions
Sum aggregation function.
sum(Expression) - Static method in class net.esper.client.soda.Expressions
Sum aggregation function.
SUM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SUM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
sumDistinct(String) - Static method in class net.esper.client.soda.Expressions
Sum aggregation function considering distinct values only.
sumDistinct(Expression) - Static method in class net.esper.client.soda.Expressions
Sum aggregation function considering distinct values only.
SumProjectionExpression - Class in net.esper.client.soda
Sum of the (distinct) values returned by an expression.
SumProjectionExpression(boolean) - Constructor for class net.esper.client.soda.SumProjectionExpression
Ctor - for use to create an expression tree, without inner expression
SumProjectionExpression(Expression, boolean) - Constructor for class net.esper.client.soda.SumProjectionExpression
Ctor - adds the expression to project.
swap(ExprNode, String, ExprNode) - Static method in class net.esper.eql.core.AliasNodeSwapper
Replace all instances of the node representing the alias with the full expression.

T

TableLookupExecNode - Class in net.esper.eql.join.exec
Execution node for lookup in a table.
TableLookupExecNode(int, TableLookupStrategy) - Constructor for class net.esper.eql.join.exec.TableLookupExecNode
Ctor.
TableLookupNode - Class in net.esper.eql.join.plan
Specifies exection of a table lookup using the supplied plan for performing the lookup.
TableLookupNode(TableLookupPlan) - Constructor for class net.esper.eql.join.plan.TableLookupNode
Ctor.
TableLookupPlan - Class in net.esper.eql.join.plan
Abstract specification on how to perform a table lookup.
TableLookupPlan(int, int, int) - Constructor for class net.esper.eql.join.plan.TableLookupPlan
Ctor.
TableLookupStrategy - Interface in net.esper.eql.join.exec
Strategy for looking up, in some sort of table or index, an event, potentially based on the events properties, and returning a set of matched events.
TableLookupStrategy - Interface in net.esper.eql.lookup
Strategy for looking up, in some sort of table or index, or a set of events, potentially based on the events properties, and returning a set of matched events.
TableOuterLookupExecNode - Class in net.esper.eql.join.exec
Execution node for lookup in a table for outer joins.
TableOuterLookupExecNode(int, TableLookupStrategy) - Constructor for class net.esper.eql.join.exec.TableOuterLookupExecNode
Ctor.
TableOuterLookupNode - Class in net.esper.eql.join.plan
Specifies exection of a table lookup with outer join using the a specified lookup plan.
TableOuterLookupNode(TableLookupPlan) - Constructor for class net.esper.eql.join.plan.TableOuterLookupNode
Ctor.
TaggedCompositeEventBean - Interface in net.esper.event
Interface for composite events in which a property is itself an event.
TaggedCompositeEventType - Interface in net.esper.event
Interface for composite event type in which each property is itself an event.
taggedEventTypes - Variable in class net.esper.event.CompositeEventType
Map of tag name and event type.
THEN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
THEN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
ThreadLogUtil - Class in net.esper.util
Utility class for logging threading-related messages.
ThreadLogUtil() - Constructor for class net.esper.util.ThreadLogUtil
 
ThreadWorkQueue - Class in net.esper.collection
Simple queue implementation based on a Linked List per thread.
ThreadWorkQueue() - Constructor for class net.esper.collection.ThreadWorkQueue
 
threshold - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Size at which to rehash
time_period(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
TIME_PERIOD - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
time_period() - Method in class net.esper.eql.generated.EQLStatementParser
 
TIME_PERIOD - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
TimeAccumView - Class in net.esper.view.window
A data window view that holds events in a stream and only removes events from a stream (rstream) if no more events arrive for a given time interval.
TimeAccumView(TimeAccumViewFactory, StatementContext, long, ViewUpdatedCollection) - Constructor for class net.esper.view.window.TimeAccumView
Constructor.
TimeAccumViewFactory - Class in net.esper.view.window
Factory for TimeAccumView.
TimeAccumViewFactory() - Constructor for class net.esper.view.window.TimeAccumViewFactory
 
TimeAccumViewRStream - Class in net.esper.view.window
A data window view that holds events in a stream and only removes events from a stream (rstream) if no more events arrive for a given time interval, also handling the remove stream by keeping set-like semantics.
TimeAccumViewRStream(TimeAccumViewFactory, StatementContext, long) - Constructor for class net.esper.view.window.TimeAccumViewRStream
Constructor.
TimeBatchView - Class in net.esper.view.window
A data view that aggregates events in a stream and releases them in one batch at every specified time interval.
TimeBatchView(TimeBatchViewFactory, StatementContext, long, Long, ViewUpdatedCollection) - Constructor for class net.esper.view.window.TimeBatchView
Constructor.
TimeBatchViewFactory - Class in net.esper.view.window
Factory for TimeBatchView.
TimeBatchViewFactory() - Constructor for class net.esper.view.window.TimeBatchViewFactory
 
TimeBatchViewRStream - Class in net.esper.view.window
Same as the TimeBatchView, this view also supports fast-remove from the batch for remove stream events.
TimeBatchViewRStream(TimeBatchViewFactory, StatementContext, long, Long) - Constructor for class net.esper.view.window.TimeBatchViewRStream
Constructor.
TimeLengthBatchView - Class in net.esper.view.window
A data view that aggregates events in a stream and releases them in one batch if either one of these conditions is reached, whichever comes first: One, a time interval passes.
TimeLengthBatchView(TimeLengthBatchViewFactory, StatementContext, long, long, boolean, boolean, ViewUpdatedCollection) - Constructor for class net.esper.view.window.TimeLengthBatchView
Constructor.
TimeLengthBatchViewFactory - Class in net.esper.view.window
Factory for TimeLengthBatchView.
TimeLengthBatchViewFactory() - Constructor for class net.esper.view.window.TimeLengthBatchViewFactory
 
TimeOrderView - Class in net.esper.view.ext
Window retaining timestamped events up to a given number of seconds such that older events that arrive later are sorted into the window and released in timestamp order.
TimeOrderView(StatementContext, TimeOrderViewFactory, String, long, IStreamTimeOrderRandomAccess, boolean) - Constructor for class net.esper.view.ext.TimeOrderView
Ctor.
TimeOrderViewFactory - Class in net.esper.view.ext
Factory for views for time-ordering events.
TimeOrderViewFactory() - Constructor for class net.esper.view.ext.TimeOrderViewFactory
 
TimeOrderViewIterator - Class in net.esper.view.ext
Iterator for use by TimeOrderView.
TimeOrderViewIterator(SortedMap<Long, ArrayList<EventBean>>) - Constructor for class net.esper.view.ext.TimeOrderViewIterator
Ctor.
timePeriodDef(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
TimePeriodParameter - Class in net.esper.type
Parameter for views that accept time period information such as "5 sec 100 msec".
TimePeriodParameter(double) - Constructor for class net.esper.type.TimePeriodParameter
Ctor.
TimeProvider - Interface in net.esper.schedule
Provider of internal system time.
timerAt(Integer, Integer, Integer, Integer, Integer, Integer) - Static method in class net.esper.client.soda.Patterns
Timer-at observer
TimerAtObserver - Class in net.esper.pattern.observer
Observer implementation for indicating that a certain time arrived, similar to "crontab".
TimerAtObserver(ScheduleSpec, PatternContext, MatchedEventMap, ObserverEventEvaluator) - Constructor for class net.esper.pattern.observer.TimerAtObserver
Ctor.
TimerAtObserverFactory - Class in net.esper.pattern.observer
Factory for 'crontab' observers that indicate truth when a time point was reached.
TimerAtObserverFactory() - Constructor for class net.esper.pattern.observer.TimerAtObserverFactory
 
timerCallback() - Method in class net.esper.core.EPRuntimeImpl
 
TimerCallback - Interface in net.esper.timer
Callback interface for a time provider that triggers at scheduled intervals.
timerCallback() - Method in interface net.esper.timer.TimerCallback
Invoked by the internal clocking service at regular intervals.
TimerControlEvent - Class in net.esper.client.time
Event for controlling clocking, i.e.
TimerControlEvent(TimerControlEvent.ClockType) - Constructor for class net.esper.client.time.TimerControlEvent
Constructor takes a clocking type as parameter.
TimerControlEvent.ClockType - Enum in net.esper.client.time
Constants controlling the clocking.
TimerEvent - Class in net.esper.client.time
Abstract base class marker for events that control time keeping by an event stream processor instance.
TimerEvent() - Constructor for class net.esper.client.time.TimerEvent
 
timerInterval(double) - Static method in class net.esper.client.soda.Patterns
Timer-interval observer expression.
TimerIntervalObserver - Class in net.esper.pattern.observer
Observer that will wait a certain interval before indicating true (raising an event).
TimerIntervalObserver(long, PatternContext, MatchedEventMap, ObserverEventEvaluator) - Constructor for class net.esper.pattern.observer.TimerIntervalObserver
Ctor.
TimerIntervalObserverFactory - Class in net.esper.pattern.observer
Factory for making observer instances.
TimerIntervalObserverFactory() - Constructor for class net.esper.pattern.observer.TimerIntervalObserverFactory
 
TimerService - Interface in net.esper.timer
Service interface for repeated callbacks at regular intervals.
TimerServiceImpl - Class in net.esper.timer
Implementation of the internal clocking service interface.
TimerServiceImpl(long) - Constructor for class net.esper.timer.TimerServiceImpl
Constructor.
timerWithin(double, PatternExpr) - Static method in class net.esper.client.soda.Patterns
Timer-within guard expression.
TimerWithinGuard - Class in net.esper.pattern.guard
Guard implementation that keeps a timer instance and quits when the timer expired, letting all MatchedEventMap instances pass until then.
TimerWithinGuard(long, PatternContext, Quitable) - Constructor for class net.esper.pattern.guard.TimerWithinGuard
Ctor.
TimerWithinGuardFactory - Class in net.esper.pattern.guard
Factory for TimerWithinGuard instances.
TimerWithinGuardFactory() - Constructor for class net.esper.pattern.guard.TimerWithinGuardFactory
 
timestampFieldName - Variable in class net.esper.view.ext.TimeOrderViewFactory
The timestamp field name.
timestampFieldName - Variable in class net.esper.view.window.ExternallyTimedWindowViewFactory
The timestamp property name.
TimeWindow - Class in net.esper.collection
Container for events per time slot.
TimeWindow(boolean) - Constructor for class net.esper.collection.TimeWindow
Ctor.
TimeWindowIterator - Class in net.esper.collection
Iterator for TimeWindow to iterate over a timestamp slots that hold events.
TimeWindowIterator(LinkedList<Pair<Long, LinkedList<EventBean>>>) - Constructor for class net.esper.collection.TimeWindowIterator
Ctor.
TimeWindowView - Class in net.esper.view.window
This view is a moving timeWindow extending the specified amount of milliseconds into the past.
TimeWindowView(StatementContext, TimeWindowViewFactory, long, ViewUpdatedCollection, boolean) - Constructor for class net.esper.view.window.TimeWindowView
Constructor.
TimeWindowViewFactory - Class in net.esper.view.window
Factory for TimeWindowView.
TimeWindowViewFactory() - Constructor for class net.esper.view.window.TimeWindowViewFactory
 
toArray() - Method in class net.esper.collection.ArrayBackedCollection
 
toArray(T[]) - Method in class net.esper.collection.ArrayBackedCollection
 
toArray() - Method in class net.esper.collection.OneEventLinkedList
Returns an array holding the collected events.
toArray(List<EventBean>) - Static method in class net.esper.event.EventBeanUtility
Convert list of events to array, returning null for empty or null lists.
toEQL(StringWriter) - Method in class net.esper.client.soda.ArithmaticExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.ArrayExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.AvedevProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.AvgProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.BetweenExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.BitwiseOpExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.CaseSwitchExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.CaseWhenThenExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.CastExpression
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.CoalesceExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.ConcatExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.Conjunction
 
toEQL(StringWriter) - Method in class net.esper.client.soda.ConstantExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.CountProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.CountStarProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.CreateVariableClause
Render as EQL.
toEQL(StringWriter) - Method in class net.esper.client.soda.CreateWindowClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.CurrentTimestampExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.Disjunction
 
toEQL(StringWriter) - Method in class net.esper.client.soda.EPBaseNamedObject
Writes the object in EQL-syntax in the format "namespace:name(parameter, parameter, ..., parameter)"
toEQL() - Method in class net.esper.client.soda.EPStatementObjectModel
Renders the object model in it's EQL syntax textual representation.
toEQL(StringWriter) - Method in interface net.esper.client.soda.Expression
Renders the expressions and all it's child expression, in full tree depth, as a string in language syntax.
toEQL(StringWriter) - Method in class net.esper.client.soda.Filter
Returns a textual representation of the filter.
toEQL(StringWriter) - Method in class net.esper.client.soda.FromClause
Renders the from-clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.GroupByClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.InExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.InsertIntoClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.InstanceOfExpression
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.LikeExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.MaxProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.MaxRowExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.MedianProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.MinProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.MinRowExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.NotExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.OnDeleteClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.OnSelectClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.OnSetClause
Renders the clause in EQL.
toEQL(StringWriter) - Method in class net.esper.client.soda.OrderByClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.OrderByElement
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.OutputLimitClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternAndExpr
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternEveryExpr
 
toEQL(StringWriter) - Method in interface net.esper.client.soda.PatternExpr
Renders the pattern expression and all it's child expressions, in full tree depth, as a string in language syntax.
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternFilterExpr
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternFollowedByExpr
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternGuardExpr
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternNotExpr
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PatternOrExpr
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PlugInProjectionExpression
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.PreviousExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PriorExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.PropertyExistsExpression
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.PropertyValueExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.RegExpExpression
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.RelationalOpExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.SelectClause
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.SelectClauseElement
Renders the element in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.SelectClauseStreamWildcard
Renders the element in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.StaticMethodExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.StddevProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.Stream
Renders the clause in textual representation.
toEQL(StringWriter) - Method in class net.esper.client.soda.SubqueryExistsExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.SubqueryExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.SubqueryInExpression
 
toEQL(StringWriter) - Method in class net.esper.client.soda.SumProjectionExpression
 
toEQL(StringWriter) - Method in class net.esper.eql.spec.SubstitutionParameterExpression
 
toEQL(StringWriter) - Method in class net.esper.type.CronParameter
 
toEQL(StringWriter) - Method in interface net.esper.type.EQLParameterType
Returns the EQL representation of the parameter.
toEQL(StringWriter) - Method in class net.esper.type.FrequencyParameter
 
toEQL(StringWriter) - Method in class net.esper.type.IntParameter
 
toEQL(StringWriter) - Method in class net.esper.type.ListParameter
 
toEQL(StringWriter) - Method in interface net.esper.type.NumberSetParameter
 
toEQL(StringWriter) - Method in class net.esper.type.RangeParameter
 
toEQL(StringWriter) - Method in class net.esper.type.TimePeriodParameter
 
toEQL(StringWriter) - Method in class net.esper.type.WildcardParameter
 
toEQLProjectedStream(StringWriter) - Method in class net.esper.client.soda.FilterStream
 
toEQLProjectedStream(StringWriter) - Method in class net.esper.client.soda.PatternStream
 
toEQLProjectedStream(StringWriter) - Method in class net.esper.client.soda.ProjectedStream
Represent as textual.
toEQLStream(StringWriter) - Method in class net.esper.client.soda.MethodInvocationStream
 
toEQLStream(StringWriter) - Method in class net.esper.client.soda.ProjectedStream
Renders the clause in textual representation.
toEQLStream(StringWriter) - Method in class net.esper.client.soda.SQLStream
 
toEQLStream(StringWriter) - Method in class net.esper.client.soda.Stream
Renders the stream in textual representation.
toEQLViews(StringWriter, List<View>) - Static method in class net.esper.client.soda.ProjectedStream
Renders the views onto the projected stream.
toExpressionString() - Method in class net.esper.eql.expression.ExprAggregateNode
Renders the aggregation function expression.
toExpressionString() - Method in class net.esper.eql.expression.ExprAndNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprArrayNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprBetweenNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprBitWiseNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprCaseNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprCastNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprCoalesceNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprConcatNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprConstantNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprEqualsNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprIdentNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprInNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprInstanceofNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprLikeNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprMathNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprNode
Returns the expression node rendered as a string.
toExpressionString() - Method in class net.esper.eql.expression.ExprNotNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprOrNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprPreviousNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprPriorNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprPropertyExistsNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprRegexpNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprSubselectNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprSubstitutionNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprTimestampNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprVariableNode
 
toPropertyExpressions(String...) - Static method in class net.esper.client.soda.Expressions
Returns a list of expressions returning property values for the property names passed in.
toReference(int, Object, int) - Method in class net.esper.collection.apachecommons.AbstractReferenceMap.ReferenceEntry
Constructs a reference of the given type to the given referent.
toString() - Method in class net.esper.client.ConfigurationDBRef.ExpiryTimeCacheDesc
 
toString() - Method in class net.esper.client.ConfigurationDBRef.LRUCacheDesc
 
toString() - Method in class net.esper.client.time.CurrentTimeEvent
 
toString() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
 
toString() - Method in class net.esper.collection.apachecommons.AbstractHashedMap.HashIterator
 
toString() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the map as a String.
toString() - Method in class net.esper.collection.apachecommons.AbstractKeyValue
Gets a debugging String view of the pair.
toString() - Method in class net.esper.collection.InterchangeablePair
 
toString() - Method in class net.esper.collection.MultiKey
 
toString() - Method in class net.esper.collection.MultiKeyUntyped
 
toString() - Method in class net.esper.collection.Pair
 
toString() - Method in class net.esper.collection.UniformPair
 
toString() - Method in class net.esper.core.StatementContext
 
toString() - Method in class net.esper.eql.db.DBOutputTypeDesc
 
toString() - Method in class net.esper.eql.db.SQLParameterDesc
 
toString() - Method in class net.esper.eql.expression.ExprIdentNode
 
toString() - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
toString() - Method in class net.esper.eql.expression.ExprVariableNode
 
toString() - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
 
toString() - Method in class net.esper.eql.join.plan.FullTableScanLookupPlan
 
toString() - Method in class net.esper.eql.join.plan.IndexedTableLookupPlan
 
toString() - Method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder.BestChainResult
 
toString() - Method in class net.esper.eql.join.plan.QueryGraph
 
toString() - Method in class net.esper.eql.join.plan.QueryGraphKey
 
toString() - Method in class net.esper.eql.join.plan.QueryGraphValue
 
toString() - Method in class net.esper.eql.join.plan.QueryPlan
 
toString() - Method in class net.esper.eql.join.plan.QueryPlanIndex
 
toString() - Method in class net.esper.eql.join.plan.TableLookupPlan
 
toString() - Method in class net.esper.eql.join.table.PropertyIndexedEventTable
 
toString() - Method in class net.esper.eql.join.table.UnindexedEventTable
 
toString() - Method in class net.esper.eql.join.table.UnindexedEventTableList
 
toString() - Method in class net.esper.eql.lookup.IndexedTableLookupStrategy
 
toString() - Method in class net.esper.eql.spec.ObjectSpec
 
toString() - Method in class net.esper.eql.variable.VariableServiceImpl
 
toString() - Method in class net.esper.eql.variable.VersionedValue
 
toString() - Method in class net.esper.eql.variable.VersionedValueList
 
toString() - Method in class net.esper.eql.view.OutputConditionCount
 
toString() - Method in class net.esper.eql.view.OutputConditionTime
 
toString() - Method in class net.esper.event.BeanEventBean
 
toString() - Method in class net.esper.event.BeanEventType
 
toString() - Method in class net.esper.event.CGLibPropertyGetter
 
toString() - Method in class net.esper.event.EventPropertyDescriptor
 
toString() - Method in class net.esper.event.MapEventBean
 
toString() - Method in class net.esper.event.MapEventType
 
toString() - Method in class net.esper.event.property.ArrayFastPropertyGetter
 
toString() - Method in class net.esper.event.property.ArrayFieldPropertyGetter
 
toString() - Method in class net.esper.event.property.ArrayMethodPropertyGetter
 
toString() - Method in class net.esper.event.property.KeyedFastPropertyGetter
 
toString() - Method in class net.esper.event.property.KeyedMethodPropertyGetter
 
toString() - Method in class net.esper.event.ReflectionPropFieldGetter
 
toString() - Method in class net.esper.event.ReflectionPropMethodGetter
 
toString() - Method in class net.esper.event.WrapperEventBean
 
toString() - Method in class net.esper.event.WrapperEventType
 
toString() - Method in class net.esper.filter.DoubleRange
 
toString() - Method in class net.esper.filter.FilterParamIndexBase
 
toString() - Method in class net.esper.filter.FilterParamIndexPropBase
 
toString() - Method in class net.esper.filter.FilterSpecCompiled
 
toString() - Method in class net.esper.filter.FilterSpecParam
 
toString() - Method in class net.esper.filter.FilterSpecParamConstant
 
toString() - Method in class net.esper.filter.FilterSpecParamEventProp
 
toString() - Method in class net.esper.filter.FilterSpecParamExprNode
 
toString() - Method in class net.esper.filter.FilterSpecParamIn
 
toString() - Method in class net.esper.filter.FilterSpecParamRange
 
toString() - Method in class net.esper.filter.IndexTreePath
 
toString() - Method in class net.esper.filter.InSetOfValuesEventProp
 
toString() - Method in class net.esper.filter.RangeValueDouble
 
toString() - Method in class net.esper.filter.RangeValueEventProp
 
toString() - Method in class net.esper.pattern.EvalAndNode
 
toString() - Method in class net.esper.pattern.EvalAndStateNode
 
toString() - Method in class net.esper.pattern.EvalEveryNode
 
toString() - Method in class net.esper.pattern.EvalEveryStateNode
 
toString() - Method in class net.esper.pattern.EvalFilterNode
 
toString() - Method in class net.esper.pattern.EvalFilterStateNode
 
toString() - Method in class net.esper.pattern.EvalFollowedByNode
 
toString() - Method in class net.esper.pattern.EvalFollowedByStateNode
 
toString() - Method in class net.esper.pattern.EvalGuardNode
 
toString() - Method in class net.esper.pattern.EvalGuardStateNode
 
toString() - Method in class net.esper.pattern.EvalNodeNumber
 
toString() - Method in class net.esper.pattern.EvalNotNode
 
toString() - Method in class net.esper.pattern.EvalNotStateNode
 
toString() - Method in class net.esper.pattern.EvalObserverNode
 
toString() - Method in class net.esper.pattern.EvalObserverStateNode
 
toString() - Method in class net.esper.pattern.EvalOrNode
 
toString() - Method in class net.esper.pattern.EvalOrStateNode
 
toString() - Method in class net.esper.pattern.EvalRootNode
 
toString() - Method in class net.esper.pattern.EvalRootStateNode
 
toString() - Method in class net.esper.pattern.MatchedEventMapImpl
 
toString() - Method in class net.esper.schedule.ScheduleSlot
 
toString() - Method in class net.esper.schedule.ScheduleSpec
 
toString() - Method in class net.esper.type.BoolValue
 
toString() - Method in class net.esper.type.ByteValue
 
toString() - Method in class net.esper.type.DoubleValue
 
toString() - Method in class net.esper.type.FloatValue
 
toString() - Method in class net.esper.type.IntValue
 
toString() - Method in class net.esper.type.LongValue
 
toString() - Method in enum net.esper.type.PrimitiveValueType
 
toString() - Method in class net.esper.type.ShortValue
 
toString() - Method in class net.esper.type.StringValue
 
toString() - Method in class net.esper.util.ManagedLockImpl
 
toString() - Method in class net.esper.util.PlaceholderParser.ParameterFragment
 
toString() - Method in class net.esper.util.PlaceholderParser.TextFragment
 
toString() - Method in class net.esper.view.ext.SortWindowView
 
toString() - Method in class net.esper.view.ext.TimeOrderView
 
toString() - Method in class net.esper.view.stat.BaseStatisticsBean
 
toString() - Method in class net.esper.view.stat.CorrelationView
 
toString() - Method in class net.esper.view.stat.RegressionLinestView
 
toString() - Method in class net.esper.view.stat.UnivariateStatisticsView
 
toString() - Method in class net.esper.view.stat.WeightedAverageView
 
toString() - Method in class net.esper.view.std.AddPropertyValueView
 
toString() - Method in class net.esper.view.std.GroupByView
 
toString() - Method in class net.esper.view.std.LastElementView
 
toString() - Method in class net.esper.view.std.MergeView
 
toString() - Method in class net.esper.view.std.SizeView
 
toString() - Method in class net.esper.view.std.UniqueByPropertyView
 
toString() - Method in class net.esper.view.ViewFactoryContext
 
toString() - Method in class net.esper.view.window.ExternallyTimedWindowView
 
toString() - Method in class net.esper.view.window.LengthBatchView
 
toString() - Method in class net.esper.view.window.LengthBatchViewRStream
 
toString() - Method in class net.esper.view.window.LengthWindowView
 
toString() - Method in class net.esper.view.window.LengthWindowViewRStream
 
toString() - Method in class net.esper.view.window.TimeAccumView
 
toString() - Method in class net.esper.view.window.TimeAccumViewRStream
 
toString() - Method in class net.esper.view.window.TimeBatchView
 
toString() - Method in class net.esper.view.window.TimeBatchViewRStream
 
toString() - Method in class net.esper.view.window.TimeLengthBatchView
 
toString() - Method in class net.esper.view.window.TimeWindowView
 
TRACE - Static variable in class net.esper.util.ThreadLogUtil
Set trace log level.
trace(String, Object...) - Static method in class net.esper.util.ThreadLogUtil
If enabled, logs for trace level the given objects and text
traceLock(String, ReentrantLock) - Static method in class net.esper.util.ThreadLogUtil
Logs the lock and action.
traceLock(String, ReentrantReadWriteLock) - Static method in class net.esper.util.ThreadLogUtil
Logs the lock and action.
transform(EventBean) - Method in interface net.esper.collection.TransformEventMethod
Transform event returning the transformed event.
transform(EventBean) - Method in class net.esper.eql.core.ResultSetProcessorSimple.ResultSetSimpleTransform
 
TransformEventIterator - Class in net.esper.collection
Iterator for reading and transforming a source event iterator.
TransformEventIterator(Iterator<EventBean>, TransformEventMethod) - Constructor for class net.esper.collection.TransformEventIterator
Ctor.
TransformEventMethod - Interface in net.esper.collection
Interface that transforms one event into another event, for use with TransformEventIterator.
TRY_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
Acquired text.
tryWriteLock(long) - Method in class net.esper.util.ManagedReadWriteLock
Try write lock with timeout, returning an indicator whether the lock was acquired or not.
TwoStreamQueryPlanBuilder - Class in net.esper.eql.join.plan
Builds a query plan for the simple 2-stream scenario.
TwoStreamQueryPlanBuilder() - Constructor for class net.esper.eql.join.plan.TwoStreamQueryPlanBuilder
 
TypedEventPropertyGetter - Interface in net.esper.event
Interface for property getters also returning type information for the property.

U

UNARY_MINUS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
UNARY_MINUS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
unaryExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
unbind(Name) - Method in class net.esper.core.EngineEnvContext
 
unbind(String) - Method in class net.esper.core.EngineEnvContext
 
underlyingEventType - Variable in class net.esper.event.WrapperEventType
The underlying wrapped event type.
underlyingMapType - Variable in class net.esper.event.WrapperEventType
The map event type that provides the additional properties.
UniformPair<T> - Class in net.esper.collection
General-purpose pair of values of any type.
UniformPair(T, T) - Constructor for class net.esper.collection.UniformPair
Construct pair of values.
UnindexedEventTable - Class in net.esper.eql.join.table
Simple table of events without an index.
UnindexedEventTable(int) - Constructor for class net.esper.eql.join.table.UnindexedEventTable
Ctor.
UnindexedEventTableList - Class in net.esper.eql.join.table
Simple table of events without an index, based on a List implementation rather then a set since we know there cannot be duplicates (such as a poll returning individual rows).
UnindexedEventTableList(List<EventBean>) - Constructor for class net.esper.eql.join.table.UnindexedEventTableList
Ctor.
UniqueByPropertyView - Class in net.esper.view.std
This view includes only the most recent among events having the same value for the specified field.
UniqueByPropertyView(String) - Constructor for class net.esper.view.std.UniqueByPropertyView
Constructor.
UniqueByPropertyViewFactory - Class in net.esper.view.std
Factory for UniqueByPropertyView instances.
UniqueByPropertyViewFactory() - Constructor for class net.esper.view.std.UniqueByPropertyViewFactory
 
UnivariateStatisticsView - Class in net.esper.view.stat
View for computing statistics, which the view exposes via fields representing the sum, count, standard deviation for sample and for population and variance.
UnivariateStatisticsView(StatementContext, String) - Constructor for class net.esper.view.stat.UnivariateStatisticsView
Constructor requires the name of the field to use in the parent view to compute the statistics.
UnivariateStatisticsViewFactory - Class in net.esper.view.stat
Factory for UnivariateStatisticsView instances.
UnivariateStatisticsViewFactory() - Constructor for class net.esper.view.stat.UnivariateStatisticsViewFactory
 
unmap(StatementSpecRaw) - Static method in class net.esper.eql.spec.StatementSpecMapper
Maps the internal representation of a statement to the SODA object model.
UnmatchedListener - Interface in net.esper.client
Interface to receive notification from an engine that an event that has been sent into the engine or that has been generated via insert-into has not been matched to any statement, considering all started statement's event stream filter criteria (not considering where-clause and having-clauses).
update(EventBean[], EventBean[], EPStatement, EPServiceProvider) - Method in interface net.esper.client.StatementAwareUpdateListener
Notify that new events are available or old events are removed.
update(EventBean) - Method in interface net.esper.client.UnmatchedListener
Called upon the engine encountering an event not matched to any of the event stream filters of any active statement.
update(EventBean[], EventBean[]) - Method in interface net.esper.client.UpdateListener
Notify that new events are available or old events are removed.
update(EventBean[], EventBean[]) - Method in interface net.esper.collection.ViewUpdatedCollection
Accepts view insert and remove stream.
update(EventBean[], EventBean[]) - Method in class net.esper.core.UpdateDispatchViewBlockingSpin
 
update(EventBean[], EventBean[]) - Method in class net.esper.core.UpdateDispatchViewBlockingWait
 
update(EventBean[], EventBean[]) - Method in class net.esper.core.UpdateDispatchViewNonBlocking
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowConsumerView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowOnExprBaseView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowRootView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.named.NamedWindowTailView
 
update(Object, Object) - Method in class net.esper.eql.variable.CreateVariableView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.variable.CreateVariableView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.variable.OnSetVariableView
 
update(Object, Object) - Method in interface net.esper.eql.variable.VariableChangeCallback
Indicate a change in variable value.
update(EventBean[], EventBean[]) - Method in class net.esper.eql.view.FilterExprView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.view.InternalRouteView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.view.IStreamRStreamSelectorView
 
update(EventBean[], EventBean[]) - Method in class net.esper.eql.view.OutputProcessViewDirect
The update method is called if the view does not participate in a join.
update(EventBean[], EventBean[]) - Method in class net.esper.eql.view.OutputProcessViewPolicy
The update method is called if the view does not participate in a join.
update(EventBean[], EventBean[]) - Method in class net.esper.indicator.jmx.JMXLastEventIndicator
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.ext.SortWindowView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.ext.TimeOrderView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.internal.BufferView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.internal.PriorEventBufferMulti
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.internal.PriorEventBufferSingle
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.internal.PriorEventBufferUnbound
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.internal.PriorEventView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.stat.BaseBivariateStatisticsView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.stat.MultiDimStatsView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.stat.UnivariateStatisticsView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.stat.WeightedAverageView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.std.AddPropertyValueView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.std.GroupByView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.std.LastElementView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.std.MergeView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.std.SizeView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.std.UniqueByPropertyView
 
update(EventBean[], EventBean[]) - Method in interface net.esper.view.View
Notify that data has been added or removed from the Viewable parent.
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.ExternallyTimedWindowView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.IStreamRandomAccess
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.IStreamRelativeAccess
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.KeepAllView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.LengthBatchView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.LengthBatchViewRStream
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.LengthWindowView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.LengthWindowViewRStream
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeAccumView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeAccumViewRStream
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeBatchView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeBatchViewRStream
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeLengthBatchView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeWindowView
 
updateChildren(EventBean[], EventBean[]) - Method in class net.esper.view.ViewSupport
Updates all the children with new data.
updateChildren(List<View>, EventBean[], EventBean[]) - Static method in class net.esper.view.ViewSupport
Updates all the children with new data.
updated(IStreamRelativeAccess, EventBean[]) - Method in interface net.esper.view.window.IStreamRelativeAccess.IStreamRelativeAccessUpdateObserver
Callback to indicate an update.
updated(RandomAccessByIndex) - Method in class net.esper.view.window.RandomAccessByIndexGetter
 
updated(RandomAccessByIndex) - Method in interface net.esper.view.window.RandomAccessByIndexObserver
Callback to indicate an update
updated(IStreamRelativeAccess, EventBean[]) - Method in class net.esper.view.window.RelativeAccessByEventNIndexGetter
 
UpdateDispatchFutureSpin - Class in net.esper.core
UpdateDispatchFutureSpin can be added to a dispatch queue that is thread-local.
UpdateDispatchFutureSpin(UpdateDispatchViewBlockingSpin, UpdateDispatchFutureSpin, long) - Constructor for class net.esper.core.UpdateDispatchFutureSpin
Ctor.
UpdateDispatchFutureSpin() - Constructor for class net.esper.core.UpdateDispatchFutureSpin
Ctor - use for the first future to indicate completion.
UpdateDispatchFutureWait - Class in net.esper.core
UpdateDispatchFutureWait can be added to a dispatch queue that is thread-local.
UpdateDispatchFutureWait(UpdateDispatchViewBlockingWait, UpdateDispatchFutureWait, long) - Constructor for class net.esper.core.UpdateDispatchFutureWait
Ctor.
UpdateDispatchFutureWait() - Constructor for class net.esper.core.UpdateDispatchFutureWait
Ctor - use for the first future to indicate completion.
UpdateDispatchViewBase - Class in net.esper.core
Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
UpdateDispatchViewBase(EPServiceProvider, EPStatement, EPStatementListenerSet, DispatchService) - Constructor for class net.esper.core.UpdateDispatchViewBase
Ctor.
UpdateDispatchViewBlockingSpin - Class in net.esper.core
Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
UpdateDispatchViewBlockingSpin(EPServiceProvider, EPStatement, EPStatementListenerSet, DispatchService, long) - Constructor for class net.esper.core.UpdateDispatchViewBlockingSpin
Ctor.
UpdateDispatchViewBlockingWait - Class in net.esper.core
Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
UpdateDispatchViewBlockingWait(EPServiceProvider, EPStatement, EPStatementListenerSet, DispatchService, long) - Constructor for class net.esper.core.UpdateDispatchViewBlockingWait
Ctor.
UpdateDispatchViewNonBlocking - Class in net.esper.core
Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
UpdateDispatchViewNonBlocking(EPServiceProvider, EPStatement, EPStatementListenerSet, DispatchService) - Constructor for class net.esper.core.UpdateDispatchViewNonBlocking
Ctor.
updatedListeners(String, String, EPStatementListenerSet) - Method in interface net.esper.core.StatementLifecycleSvc
Statements indicate that listeners have been added through this method.
updatedListeners(String, String, EPStatementListenerSet) - Method in class net.esper.core.StatementLifecycleSvcImpl
 
updateEntry(AbstractHashedMap.HashEntry, Object) - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Updates an existing key-value mapping to change the value.
UpdateListener - Interface in net.esper.client
Defines an interface to notify of new and old events.
updateOutputCondition(int, int) - Method in interface net.esper.eql.view.OutputCondition
Update the output condition.
updateOutputCondition(int, int) - Method in class net.esper.eql.view.OutputConditionCount
 
updateOutputCondition(int, int) - Method in class net.esper.eql.view.OutputConditionFirst
 
updateOutputCondition(int, int) - Method in class net.esper.eql.view.OutputConditionNull
 
updateOutputCondition(int, int) - Method in class net.esper.eql.view.OutputConditionTime
 
UuidGenerator - Class in net.esper.util
Generates a UUID.

V

validate(Class) - Method in class net.esper.eql.agg.AggregationSupport
Implemented by plug-in aggregation functions to allow such functions to validate the type of value passed to the function at statement compile time.
validate(StreamTypeService, MethodResolutionService, TimeProvider, VariableService) - Method in class net.esper.eql.core.MethodPollingViewable
 
validate(StreamTypeService, MethodResolutionService, TimeProvider, VariableService) - Method in class net.esper.eql.db.DatabasePollingViewable
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprAggregateNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprAndNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprArrayNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprBetweenNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprBitWiseNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprCaseNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprCastNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprCoalesceNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprConcatNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprConstantNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprEqualsNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprIdentNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprInNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprInstanceofNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprLikeNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprMathNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprNotNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprOrNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprPreviousNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprPriorNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprPropertyExistsNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprRegexpNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprStreamInstanceMethodNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprStreamUnderlyingNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprSubselectExistsNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprSubselectInNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprSubselectRowNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprSubstitutionNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprTimestampNode
 
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in interface net.esper.eql.expression.ExprValidator
Validate node.
validate(StreamTypeService, MethodResolutionService, ViewResourceDelegate, TimeProvider, VariableService) - Method in class net.esper.eql.expression.ExprVariableNode
 
validate(Map<ScheduleUnit, SortedSet<Integer>>) - Static method in class net.esper.schedule.ScheduleSpec
Validate units and their value sets.
validate(StreamTypeService, MethodResolutionService, TimeProvider, VariableService) - Method in interface net.esper.view.ValidatedView
Validate the view.
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprAggregateNode
Gives the aggregation node a chance to validate the sub-expression types.
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprAvedevNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprAvgNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprCountNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprMedianNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprPlugInAggFunctionNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprStddevNode
 
validateAggregationChild(StreamTypeService, MethodResolutionService) - Method in class net.esper.eql.expression.ExprSumNode
 
validateDisallowSubquery(List<ExprNode>, StreamTypeService, MethodResolutionService, TimeProvider, VariableService) - Static method in class net.esper.filter.FilterSpecCompiler
Validates expression nodes and returns a list of validated nodes.
ValidatedView - Interface in net.esper.view
Interface for views that require validation against stream event types.
validateSingleNumericChild(StreamTypeService) - Method in class net.esper.eql.expression.ExprAggregateNode
For use by implementing classes, validates the aggregation node expecting a single numeric-type child node.
value - Variable in class net.esper.collection.apachecommons.AbstractHashedMap.HashEntry
The value
value - Variable in class net.esper.collection.apachecommons.AbstractKeyValue
The value
valueExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
valueOf(String) - Static method in enum net.esper.client.Configuration.PropertyResolutionStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationDBRef.CacheReferenceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationDBRef.ColumnChangeCaseEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationDBRef.ConnectionLifecycleEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationDBRef.MetadataOriginEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationEngineDefaults.Threading.Locking
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationEventTypeLegacy.AccessorStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationEventTypeLegacy.CodeGeneration
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.ConfigurationPlugInPatternObject.PatternObjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.EPStatementState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.soda.OutputLimitSelector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.soda.OutputLimitUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.soda.StreamSelector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.client.time.TimerControlEvent.ClockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.eql.spec.OnTriggerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.eql.spec.OutputLimitLimitType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.eql.spec.OutputLimitRateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.eql.spec.PluggableObjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.eql.spec.SelectClauseStreamSelectorEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.event.EventPropertyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.filter.FilterOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.pattern.guard.GuardEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.pattern.observer.ObserverEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.BitWiseOpEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.CronParameter.CronOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.MathArithTypeEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.MinMaxTypeEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.OuterJoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.PrimitiveValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.RelationalOpEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.type.ScheduleUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.util.DatabaseTypeEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.view.ViewEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.view.ViewFieldEnum
Returns the enum constant of this type with the specified name.
values() - Static method in enum net.esper.client.Configuration.PropertyResolutionStyle
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationDBRef.CacheReferenceType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationDBRef.ColumnChangeCaseEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationDBRef.ConnectionLifecycleEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationDBRef.MetadataOriginEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationEngineDefaults.Threading.Locking
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationEventTypeLegacy.AccessorStyle
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationEventTypeLegacy.CodeGeneration
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.ConfigurationPlugInPatternObject.PatternObjectType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.EPStatementState
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.soda.OutputLimitSelector
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.soda.OutputLimitUnit
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.soda.StreamSelector
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.client.time.TimerControlEvent.ClockType
Returns an array containing the constants of this enum type, in the order they're declared.
values - Variable in class net.esper.collection.apachecommons.AbstractHashedMap
Values
values() - Method in class net.esper.collection.apachecommons.AbstractHashedMap
Gets the values view of the map.
values() - Method in class net.esper.collection.apachecommons.AbstractReferenceMap
Returns a collection view of this map's values.
values() - Static method in enum net.esper.eql.spec.OnTriggerType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.eql.spec.OutputLimitLimitType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.eql.spec.OutputLimitRateType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.eql.spec.PluggableObjectType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.eql.spec.SelectClauseStreamSelectorEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.event.EventPropertyType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.filter.FilterOperator
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.pattern.guard.GuardEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.pattern.observer.ObserverEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.BitWiseOpEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.CronParameter.CronOperator
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.MathArithTypeEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.MinMaxTypeEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.OuterJoinType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.PrimitiveValueType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.RelationalOpEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.type.ScheduleUnit
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.util.DatabaseTypeEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.view.ViewEnum
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum net.esper.view.ViewFieldEnum
Returns an array containing the constants of this enum type, in the order they're declared.
valueType - Variable in class net.esper.collection.apachecommons.AbstractReferenceMap
The reference type for values.
VARIABLE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
VARIABLE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
VariableChangeCallback - Interface in net.esper.eql.variable
A callback interface for indicating a change in variable value.
VariableDeclarationException - Exception in net.esper.eql.variable
Exception indicating a problem in a variable declaration.
VariableDeclarationException(String) - Constructor for exception net.esper.eql.variable.VariableDeclarationException
Ctor.
VariableExistsException - Exception in net.esper.eql.variable
Exception indicating a a variable already exists.
VariableExistsException(String) - Constructor for exception net.esper.eql.variable.VariableExistsException
Ctor.
VariableNotFoundException - Exception in net.esper.eql.variable
Exception indicating a variable does not exists.
VariableNotFoundException(String) - Constructor for exception net.esper.eql.variable.VariableNotFoundException
Ctor.
VariableReader - Class in net.esper.eql.variable
Reads and writes variable values.
VariableReader(VariableVersionThreadLocal, Class, String, int, VersionedValueList<Object>) - Constructor for class net.esper.eql.variable.VariableReader
Ctor.
variables - Variable in class net.esper.client.Configuration
Map of variables.
VariableService - Interface in net.esper.eql.variable
Variables service for reading and writing variables, and for setting a version number for the current thread to consider variables for.
VariableServiceImpl - Class in net.esper.eql.variable
Variables service for reading and writing variables, and for setting a version number for the current thread to consider variables for.
VariableServiceImpl(long, TimeProvider, VariableStateHandler) - Constructor for class net.esper.eql.variable.VariableServiceImpl
Ctor.
VariableServiceImpl(int, long, TimeProvider, VariableStateHandler) - Constructor for class net.esper.eql.variable.VariableServiceImpl
Ctor.
VariableStateHandler - Interface in net.esper.eql.variable
Interface for a plug-in to VariableService to handle variable persistent state.
VariableTypeException - Exception in net.esper.eql.variable
Exception indicating a variable type error.
VariableTypeException(String) - Constructor for exception net.esper.eql.variable.VariableTypeException
Ctor.
VariableVersionThreadEntry - Class in net.esper.eql.variable
Thread-specific state in regards to variable versions.
VariableVersionThreadEntry(int, Map<Integer, Object>) - Constructor for class net.esper.eql.variable.VariableVersionThreadEntry
Ctor.
VariableVersionThreadLocal - Class in net.esper.eql.variable
A wrapper for a thread-local to hold the current version for variables visible for a thread, as well as uncommitted values of variables for a thread.
VariableVersionThreadLocal() - Constructor for class net.esper.eql.variable.VariableVersionThreadLocal
Ctor.
verifyJoinedPerStream(int, Map<Integer, int[]>) - Static method in class net.esper.eql.join.plan.NStreamOuterQueryPlanBuilder
Verifies that the tree-like structure representing which streams join (lookup) into which sub-streams is correct, ie.
verifyNameUniqueness(List<SelectExprElementCompiledSpec>, List<SelectExprElementStreamCompiledSpec>) - Static method in class net.esper.eql.core.SelectExprProcessorFactory
Verify that each given name occurs exactly one.
VersionedValue<T> - Class in net.esper.eql.variable
Holds a version of a value and a timestamp when that version is taken.
VersionedValue(int, T, long) - Constructor for class net.esper.eql.variable.VersionedValue
Ctor.
VersionedValueList<T> - Class in net.esper.eql.variable
A self-cleaning list of versioned-values.
VersionedValueList(String, int, T, long, long, Lock, int, boolean) - Constructor for class net.esper.eql.variable.VersionedValueList
Ctor.
View - Class in net.esper.client.soda
A view provides a projection upon a stream, such as a data window, grouping or unique.
View(String, String, List<Object>) - Constructor for class net.esper.client.soda.View
Creates a view.
View - Interface in net.esper.view
The View interface provides a way for a stream, data provider, or another view, to notify an object of additions and deletions to its data set.
VIEW_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
VIEW_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
Viewable - Interface in net.esper.view
The Viewable interface marks an object as supporting zero, one or more View instances.
ViewAttachException - Exception in net.esper.view
Thrown to indicate a validation error in staggered views.
ViewAttachException(String) - Constructor for exception net.esper.view.ViewAttachException
Ctor.
ViewCapability - Interface in net.esper.view
Interface for use by expression nodes to indicate view resource requirements allowing inspection and modification of view factories.
ViewCapDataWindowAccess - Class in net.esper.view
Describes that we need random access into a data window by index.
ViewCapDataWindowAccess() - Constructor for class net.esper.view.ViewCapDataWindowAccess
Ctor.
ViewCapPriorEventAccess - Class in net.esper.view
Describes that we need access to prior events (result events published by views), for use by the "prior" expression function.
ViewCapPriorEventAccess(Integer) - Constructor for class net.esper.view.ViewCapPriorEventAccess
Ctor.
ViewEnum - Enum in net.esper.view
Enum for all build-in views.
ViewEnumHelper - Class in net.esper.view
Helper producing a repository of built-in views.
ViewEnumHelper() - Constructor for class net.esper.view.ViewEnumHelper
 
viewExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
viewExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
ViewFactory - Interface in net.esper.view
Factory interface for a factory responsible for creating a View instance and for determining if an existing view meets requirements.
ViewFactoryChain - Class in net.esper.view
Holder for the logical chain of view factories.
ViewFactoryChain(EventType, List<ViewFactory>) - Constructor for class net.esper.view.ViewFactoryChain
Ctor.
ViewFactoryContext - Class in net.esper.view
Context calss for specific views within a statement.
ViewFactoryContext(StatementContext, int, int, String, String) - Constructor for class net.esper.view.ViewFactoryContext
Ctor.
ViewFactorySupport - Class in net.esper.view
Abstract base class for view factories that do not make re-useable views and that do not share view resources with expression nodes.
ViewFactorySupport() - Constructor for class net.esper.view.ViewFactorySupport
 
ViewFieldEnum - Enum in net.esper.view
Enumerates the valid values for each view's public fields.
viewListExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
ViewParameterException - Exception in net.esper.view
Thrown to indicate a validation error in view parameterization.
ViewParameterException(String) - Constructor for exception net.esper.view.ViewParameterException
Ctor.
ViewProcessingException - Exception in net.esper.view
This exception is thrown to indicate a problem with a view expression.
ViewProcessingException(String) - Constructor for exception net.esper.view.ViewProcessingException
Constructor.
ViewProcessingException(String, Throwable) - Constructor for exception net.esper.view.ViewProcessingException
Constructor for an inner exception and message.
ViewProcessingException(Throwable) - Constructor for exception net.esper.view.ViewProcessingException
Constructor.
ViewResolutionService - Interface in net.esper.view
Factory service for resolving view names and for creating view instances based on a view specification including view name and namespace.
ViewResolutionServiceImpl - Class in net.esper.view
Resolves view namespace and name to view factory class, using configuration.
ViewResolutionServiceImpl(PluggableObjectCollection) - Constructor for class net.esper.view.ViewResolutionServiceImpl
Ctor.
ViewResourceCallback - Interface in net.esper.eql.core
Callback for use by expression nodes to receive view resources.
ViewResourceDelegate - Interface in net.esper.eql.core
Service to expression nodes for indicating view resource requirements.
ViewResourceDelegateImpl - Class in net.esper.eql.core
Coordinates between view factories and requested resource (by expressions) the availability of view resources to expressions.
ViewResourceDelegateImpl(ViewFactoryChain[], StatementContext) - Constructor for class net.esper.eql.core.ViewResourceDelegateImpl
Ctor.
ViewService - Interface in net.esper.view
Service interface for creating views.
ViewServiceHelper - Class in net.esper.view
Utility methods to deal with chains of views, and for merge/group-by views.
ViewServiceHelper() - Constructor for class net.esper.view.ViewServiceHelper
 
ViewServiceImpl - Class in net.esper.view
Implementation of the view evaluation service business interface.
ViewServiceImpl() - Constructor for class net.esper.view.ViewServiceImpl
Ctor.
ViewServiceProvider - Class in net.esper.view
Static factory for implementations of the ViewService interface.
ViewServiceProvider() - Constructor for class net.esper.view.ViewServiceProvider
 
ViewSpec - Class in net.esper.eql.spec
Specification for a view object consists of a namespace, name and view object parameters.
ViewSpec(String, String, List<Object>) - Constructor for class net.esper.eql.spec.ViewSpec
Constructor.
ViewSupport - Class in net.esper.view
A helper class for View implementations that provides generic implementation for some of the methods.
ViewSupport() - Constructor for class net.esper.view.ViewSupport
Constructor.
ViewUpdatedCollection - Interface in net.esper.collection
A general-purpose collection interface for collections updated by view data.
visit(ExprNode) - Method in class net.esper.eql.expression.ExprNodeIdentifierVisitor
 
visit(ExprNode) - Method in class net.esper.eql.expression.ExprNodeSubselectVisitor
 
visit(ExprNode) - Method in class net.esper.eql.expression.ExprNodeVariableVisitor
 
visit(ExprNode) - Method in interface net.esper.eql.expression.ExprNodeVisitor
Visit the given expression node.
visit(EvalStateNode, Object) - Method in class net.esper.pattern.EvalStateNodePrinterVisitor
 
visit(EvalStateNode, Object) - Method in interface net.esper.pattern.EvalStateNodeVisitor
Invoked by each child node as part of accepting this visitor.

W

walk(AST, EQLBaseWalker, WalkRuleSelector, String) - Static method in class net.esper.eql.parse.ParseHelper
Walk parse tree starting at the rule the walkRuleSelector supplies.
WalkRuleSelector - Interface in net.esper.eql.parse
For selection of the AST tree walk rule to use.
WEAK - Static variable in class net.esper.collection.apachecommons.AbstractReferenceMap
Constant indicating that weak references should be used
WEEKDAY - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WEEKDAY - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
WEEKDAY_OPERATOR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WEEKDAY_OPERATOR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
weekDayOperator(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
weekDayOperator() - Method in class net.esper.eql.generated.EQLStatementParser
 
WeightedAverageView - Class in net.esper.view.stat
View for computing a weighted average.
WeightedAverageView(StatementContext, String, String) - Constructor for class net.esper.view.stat.WeightedAverageView
Constructor requires the name of the field to use in the parent view to compute the weighted average on, as well as the name of the field in the parent view to get the weight from.
WeightedAverageViewFactory - Class in net.esper.view.stat
Factory for WeightedAverageView instances.
WeightedAverageViewFactory() - Constructor for class net.esper.view.stat.WeightedAverageViewFactory
 
WHEN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WHEN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
whenClause() - Method in class net.esper.eql.generated.EQLStatementParser
 
WHERE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WHERE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
WHERE_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WHERE_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
whereClause(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
whereClause() - Method in class net.esper.eql.generated.EQLStatementParser
 
WILDCARD_SELECT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WILDCARD_SELECT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
WildcardParameter - Class in net.esper.type
Represents a wildcard as a parameter.
WildcardParameter() - Constructor for class net.esper.type.WildcardParameter
 
WINDOW - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WINDOW - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
WrapperEventBean - Class in net.esper.event
Event bean that wraps another event bean adding additional properties.
WrapperEventBean(EventBean, Map<String, Object>, EventType) - Constructor for class net.esper.event.WrapperEventBean
Ctor.
WrapperEventType - Class in net.esper.event
An event type that adds zero or more fields to an existing event type.
WrapperEventType(String, EventType, Map<String, Class>, EventAdapterService) - Constructor for class net.esper.event.WrapperEventType
Ctor.
write(int, Object) - Method in interface net.esper.eql.variable.VariableService
Writes a new variable value.
write(int, Object) - Method in class net.esper.eql.variable.VariableServiceImpl
 
write(byte[]) - Method in class net.esper.util.SimpleByteArrayOutputStream
 
write(byte[], int, int) - Method in class net.esper.util.SimpleByteArrayOutputStream
 
write(int) - Method in class net.esper.util.SimpleByteArrayOutputStream
 
WS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
WS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 

X

XMLEventBean - Class in net.esper.event.xml
EventBean wrapper for XML documents.
XMLEventBean(Node, EventType) - Constructor for class net.esper.event.xml.XMLEventBean
Ctor.
XPathNamespaceContext - Class in net.esper.event.xml
Provides the namespace context information for compiling XPath expressions.
XPathNamespaceContext() - Constructor for class net.esper.event.xml.XPathNamespaceContext
Ctor.
XPathPropertyGetter - Class in net.esper.event.xml
Getter for properties of DOM xml events.
XPathPropertyGetter(String, XPathExpression, QName) - Constructor for class net.esper.event.xml.XPathPropertyGetter
Ctor.

Z

ZeroDepthStream - Class in net.esper.view
Event stream implementation that does not keep any window by itself of the events coming into the stream.
ZeroDepthStream(EventType) - Constructor for class net.esper.view.ZeroDepthStream
Ctor.

_

_tokenNames - Static variable in class net.esper.eql.generated.EQLBaseWalker
 
_tokenNames - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_0 - Static variable in class net.esper.eql.generated.EQLBaseWalker
 
_tokenSet_0 - Static variable in class net.esper.eql.generated.EQLStatementLexer
 
_tokenSet_0 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_1 - Static variable in class net.esper.eql.generated.EQLBaseWalker
 
_tokenSet_1 - Static variable in class net.esper.eql.generated.EQLStatementLexer
 
_tokenSet_1 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_10 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_11 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_12 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_13 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_14 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_15 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_16 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_17 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_18 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_19 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_2 - Static variable in class net.esper.eql.generated.EQLBaseWalker
 
_tokenSet_2 - Static variable in class net.esper.eql.generated.EQLStatementLexer
 
_tokenSet_2 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_20 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_21 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_22 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_23 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_24 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_25 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_26 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_27 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_3 - Static variable in class net.esper.eql.generated.EQLStatementLexer
 
_tokenSet_3 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_4 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_5 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_6 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_7 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_8 - Static variable in class net.esper.eql.generated.EQLStatementParser
 
_tokenSet_9 - Static variable in class net.esper.eql.generated.EQLStatementParser
 

A B C D E F G H I J K L M N O P Q R S T U V W X Z _
© 2007 EsperTech Inc.
All rights reserved.
Visit us at espertech.com