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

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
 
ACQUIRED_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
 
acquireLock() - Method in class net.esper.util.ManagedLock
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 class net.esper.event.BeanEventAdapter
Returns an adapter for the given Java Bean.
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
 
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
 
add(Object) - 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(K) - Method in class net.esper.collection.RefCountedSet
Add a key to the set.
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(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(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.QueryGraph.GraphValue
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(NumberSetParameter) - Method in class net.esper.eql.parse.ListParameter
Add to the list a further parameter.
add(String) - Method in class net.esper.eql.spec.InsertIntoDesc
Add a column name to the insert-into clause.
add(SelectExprElementUnnamedSpec) - Method in class net.esper.eql.spec.SelectClauseSpec
Adds an select expression within the select clause.
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(FilterParamIndex) - 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(FilterParamIndex, Object) - Method in class net.esper.filter.IndexTreePath
Add an index to end of the list representing a path through indexes.
add(String, EventBean) - Method in class net.esper.pattern.MatchedEventMap
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
 
addAll(Collection) - Method in class net.esper.collection.ArrayBackedCollection
 
addBeanType(String, String) - 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
 
addBeanType(String, String) - Method in class net.esper.event.EventAdapterServiceImpl
 
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.
addDatabaseReference(String, ConfigurationDBRef) - Method in class net.esper.client.Configuration
Add a database reference with a given database name.
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
 
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.
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
Add an import (a class or package).
addImport(String) - Method in class net.esper.eql.core.AutoImportServiceImpl
Add a package to the auto-import list, for testing.
addIndex(String[]) - 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
 
addListener(UpdateListener) - Method in interface net.esper.client.EPListenable
Add an listener that observes events.
addListener(UpdateListener) - Method in class net.esper.core.EPStatementSupport
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.
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.
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.
addParentView(AddPropertyValueView) - Method in class net.esper.view.std.MergeView
Add a parent data merge view.
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.
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() - Constructor for class net.esper.view.std.AddPropertyValueView
Empty constructor - required for Java bean.
AddPropertyValueView(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
 
addValue(ScheduleUnit, int) - Method in class net.esper.schedule.ScheduleSpec
For unit testing, add a single value, changing wildcards to value sets.
addView(View) - Method in class net.esper.eql.db.PollingViewable
 
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
 
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 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.
AggregationResultFuture - Interface in net.esper.eql.core
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.core
Service for maintaing aggregation state.
AggregationServiceBase - Class in net.esper.eql.core
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[], Aggregator[]) - Constructor for class net.esper.eql.core.AggregationServiceBase
Ctor.
AggregationServiceFactory - Class in net.esper.eql.core
Factory for aggregation service instances.
AggregationServiceFactory() - Constructor for class net.esper.eql.core.AggregationServiceFactory
 
AggregationServiceGroupAllImpl - Class in net.esper.eql.core
Implementation for handling aggregation without any grouping (no group-by).
AggregationServiceGroupAllImpl(ExprEvaluator[], Aggregator[]) - Constructor for class net.esper.eql.core.AggregationServiceGroupAllImpl
Ctor.
AggregationServiceGroupByImpl - Class in net.esper.eql.core
Implementation for handling aggregation with grouping by group-keys.
AggregationServiceGroupByImpl(ExprEvaluator[], Aggregator[]) - Constructor for class net.esper.eql.core.AggregationServiceGroupByImpl
Ctor.
AggregationServiceNull - Class in net.esper.eql.core
A null object implementation of the AggregationService interface.
AggregationServiceNull() - Constructor for class net.esper.eql.core.AggregationServiceNull
 
Aggregator - Interface in net.esper.eql.core
Maintains aggregation state applying values as entering and leaving the state.
aggregators - Variable in class net.esper.eql.core.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_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.core.AggregationService
Apply events as entering a window (new events).
applyEnter(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceGroupAllImpl
 
applyEnter(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceGroupByImpl
 
applyEnter(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceNull
 
applyLeave(EventBean[], MultiKeyUntyped) - Method in interface net.esper.eql.core.AggregationService
Apply events as leaving a window (old events).
applyLeave(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceGroupAllImpl
 
applyLeave(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceGroupByImpl
 
applyLeave(EventBean[], MultiKeyUntyped) - Method in class net.esper.eql.core.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.
arithmeticExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
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.
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, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.ext.SortWindowViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.internal.PriorEventViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.CorrelationViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.GroupByViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.LastElementViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.MergeViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.SizeViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
attach(EventType, ViewServiceContext, 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, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.LengthWindowViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.TimeBatchViewFactory
 
attach(EventType, ViewServiceContext, ViewFactory, List<ViewFactory>) - Method in class net.esper.view.window.TimeWindowViewFactory
 
AutoImportService - Interface in net.esper.eql.core
Interface for a service that resolves a class name to Java Class instances.
AutoImportServiceImpl - Class in net.esper.eql.core
A service that allows users to refer to classes by partial names.
AutoImportServiceImpl(String[]) - Constructor for class net.esper.eql.core.AutoImportServiceImpl
Ctor.
AVEDEV - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
AVEDEV - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
AVG - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
AVG - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 

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() - Constructor for class net.esper.view.stat.BaseBivariateStatisticsView
Default constructor - required by all views to adhere to the Java bean specification.
BaseBivariateStatisticsView(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(String) - Constructor for class net.esper.event.xml.BaseXMLEventType
Ctor.
BeanEventAdapter - Class in net.esper.event
A cache and factory class for obtaining EventType instances and EventBean instances for Java Bean events.
BeanEventAdapter(Map<String, ConfigurationEventTypeLegacy>) - Constructor for class net.esper.event.BeanEventAdapter
Ctor.
BeanEventType - Class in net.esper.event
Implementation of the EventType interface for handling JavaBean-type classes.
BeanEventType(Class, BeanEventAdapter, ConfigurationEventTypeLegacy) - Constructor for class net.esper.event.BeanEventType
Constructor takes a java bean class as an argument.
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
 
betweenList() - Method in class net.esper.eql.generated.EQLStatementParser
 
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.
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[]) - 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) - Static method in class net.esper.eql.join.plan.NStreamQueryPlanBuilder
Build a query plan based on the stream property relationships indicated in queryGraph.
build(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[], EventType) - Static method in class net.esper.eql.join.JoinSetComposerFactory
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, Map<String, EventType>, EventAdapterService) - Static method in class net.esper.eql.parse.ASTFilterSpecHelper
Creates a filter specification for the AST representing the filter expression.
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

canConvert(int, PrimitiveValueType) - Static method in class net.esper.eql.parse.ASTConstantHelper
Answers the question of whether a given AST constant node can be converted via parsing into a primitive value of a given type.
canProvideCapability(ViewCapability) - Method in class net.esper.view.ext.SortWindowViewFactory
 
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.window.ExternallyTimedWindowViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.LengthWindowViewFactory
 
canProvideCapability(ViewCapability) - Method in class net.esper.view.window.TimeBatchViewFactory
 
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.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.window.ExternallyTimedWindowViewFactory
 
canReuse(View) - Method in class net.esper.view.window.LengthWindowViewFactory
 
canReuse(View) - Method in class net.esper.view.window.TimeBatchViewFactory
 
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
 
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.
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.
checkType(Map<String, EventType>) - Method in interface net.esper.filter.FilterSpecParamRangeValue
Check the type against the map of event tag and type.
checkType(Map<String, EventType>) - Method in class net.esper.filter.RangeValueDouble
 
checkType(Map<String, EventType>) - Method in class net.esper.filter.RangeValueEventProp
 
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.ArrayBackedCollection
 
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
 
clone() - Method in class net.esper.view.stat.BaseStatisticsBean
 
close(Pair<Connection, PreparedStatement>) - Static method in class net.esper.eql.db.ConnectionCache
Close resources.
COALESCE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COALESCE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
coerceNumber(Number, Class) - Static method in class net.esper.util.JavaClassHelper
Coerce the given number to the given 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
 
COMMA - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COMMA - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
compare(DoubleRange, DoubleRange) - Method in class net.esper.filter.DoubleRangeComparator
 
compare(FilterValueSetParam, FilterValueSetParam) - Method in class net.esper.filter.FilterSpecParamComparator
 
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(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.
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(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 - 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
 
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.
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.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) - 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.
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.
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.
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(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
constant() - Method in class net.esper.eql.generated.EQLStatementParser
 
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.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
 
ContextAwareView - Interface in net.esper.view
Views use this interface to indicate that the view requires services out of the context, such as the scheduling service.
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.OutputProcessView
Called once the output condition has been met.
continueOutputProcessingView(boolean, boolean) - Method in class net.esper.eql.view.OutputProcessView
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.
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() - Constructor for class net.esper.view.stat.CorrelationView
Default constructor - required by all views to adhere to the Java bean specification.
CorrelationView(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 - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
COUNT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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(ViewSpec) - Static method in class net.esper.view.ViewFactoryFactory
Instantiates a view factory based on view name stored in the view spec.
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
 
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
 
createAnonymousMapTypeUnd(Map<String, EventType>) - 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.
createAnonymousMapTypeUnd(Map<String, EventType>) - 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
 
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, ViewServiceContext, OutputCallback) - Static method in class net.esper.eql.view.OutputConditionFactory
Creates an output condition instance.
createDBStatementView(int, DBStatementStreamSpec, DatabaseConfigService, EventAdapterService, EPStatementHandle) - Static method in class net.esper.eql.db.PollingViewableFactory
Creates the viewable for polling via database SQL query.
createEQL(String) - Method in interface net.esper.client.EPAdministrator
Create a query language statement.
createEQL(String) - Method in class net.esper.core.EPAdministratorImpl
 
createEventType(ViewServiceContext) - Static method in class net.esper.view.stat.CorrelationView
Creates the event type for this view.
createEventType(ViewServiceContext) - Static method in class net.esper.view.stat.MultiDimStatsView
Creates the event type for this view.
createEventType(ViewServiceContext) - Static method in class net.esper.view.stat.RegressionLinestView
Creates the event type for this view.
createEventType(ViewServiceContext) - Static method in class net.esper.view.stat.UnivariateStatisticsView
Creates the event type for this view.
createEventType(ViewServiceContext) - Static method in class net.esper.view.stat.WeightedAverageView
Creates the event type for this view.
createEventType(ViewServiceContext) - Static method in class net.esper.view.std.SizeView
Creates the event type for this view
createFactories(EventType, List<ViewSpec>, ViewServiceContext) - 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(EventType, List<ViewSpec>, ViewServiceContext) - 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.
createLookupPlan(QueryGraph, int, int, QueryPlanIndex) - 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.
createMapFromUnderlying(Map<String, EventBean>, EventType) - Method in interface net.esper.event.EventAdapterService
Create an aggregate event wrapper bean from a set of named events stored in a Map.
createMapFromUnderlying(Map<String, EventBean>, EventType) - Method in class net.esper.event.EventAdapterServiceImpl
 
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
 
createOrGetBeanType(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.
createPattern(String) - Method in interface net.esper.client.EPAdministrator
Create a event pattern statement for the expressing string passed.
createPattern(String) - Method in class net.esper.core.EPAdministratorImpl
 
createStream(FilterSpec, FilterService, EPStatementHandle, boolean) - Method in interface net.esper.view.stream.StreamFactoryService
Create or reuse existing EventStream instance representing that event filter.
createStream(FilterSpec, FilterService, EPStatementHandle) - Method in class net.esper.view.stream.StreamFactorySvcCreate
See the method of the same name in StreamFactoryService.
createStream(FilterSpec, FilterService, EPStatementHandle, boolean) - Method in class net.esper.view.stream.StreamFactorySvcImpl
 
createStream(FilterSpec, FilterService, EPStatementHandle) - Method in class net.esper.view.stream.StreamFactorySvcReuse
See the method of the same name in StreamFactoryService.
createStreamPlan(int, int[], QueryGraph, QueryPlanIndex[]) - 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.
createViews(Viewable, List<ViewFactory>, ViewServiceContext) - Method in interface net.esper.view.ViewService
Creates the views given a chain of view factories.
createViews(Viewable, List<ViewFactory>, ViewServiceContext) - Method in class net.esper.view.ViewServiceImpl
 
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
 
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
 
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.
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

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
 
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.
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, SchedulingService, ScheduleSlot, EPStatementHandle) - Constructor for class net.esper.eql.db.DataCacheExpiringImpl
Ctor.
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.window
Tag interface for data window views.
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) - 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) - 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
 
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.
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.
DESC - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
DESC - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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
 
determineStreamNames(List<StreamSpec>) - Static method in class net.esper.core.EPEQLStmtStartMethod
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
 
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
 
Dispatchable - Interface in net.esper.dispatch
Implementations are executed when the DispatchService receives a dispatch invocation.
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
 
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
 
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
 
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
 
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
 
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.
dropStream(FilterSpec, FilterService, boolean) - Method in interface net.esper.view.stream.StreamFactoryService
Drop the event stream associated with the filter passed in.
dropStream(FilterSpec, FilterService) - Method in class net.esper.view.stream.StreamFactorySvcCreate
See the method of the same name in StreamFactoryService.
dropStream(FilterSpec, FilterService, boolean) - Method in class net.esper.view.stream.StreamFactorySvcImpl
 
dropStream(FilterSpec, FilterService) - Method in class net.esper.view.stream.StreamFactorySvcReuse
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.

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.
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.
enter(Object) - Method in interface net.esper.eql.core.Aggregator
Apply the value as entering aggregation (entering window).
enter(Object) - Method in class net.esper.eql.core.UniqueValueAggregator
 
enter(Object) - Method in class net.esper.eql.expression.ExprAvedevNode.DoubleAvedev
 
enter(Object) - Method in class net.esper.eql.expression.ExprAvgNode.DoubleAvg
 
enter(Object) - Method in class net.esper.eql.expression.ExprCountNode.DatapointAggregator
 
enter(Object) - Method in class net.esper.eql.expression.ExprCountNode.NonNullDatapointAggregator
 
enter(Object) - Method in class net.esper.eql.expression.ExprMedianNode.DoubleMedian
 
enter(Object) - Method in class net.esper.eql.expression.ExprMinMaxAggrNode.MinMaxAggregator
 
enter(Object) - Method in class net.esper.eql.expression.ExprStddevNode.DoubleStddev
 
enter(Object) - Method in class net.esper.eql.expression.ExprSumNode.DoubleSum
 
enter(Object) - Method in class net.esper.eql.expression.ExprSumNode.FloatSum
 
enter(Object) - Method in class net.esper.eql.expression.ExprSumNode.IntegerSum
 
enter(Object) - Method in class net.esper.eql.expression.ExprSumNode.LongSum
 
enter(Object) - Method in class net.esper.eql.expression.ExprSumNode.NumberIntegerSum
 
entryIterator() - Method in class net.esper.collection.RefCountedSet
Returns an iterator over the entry set.
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, ManagedReadWriteLock) - Constructor for class net.esper.core.EPAdministratorImpl
Constructor - takes the services context as argument.
EPEQLStatementImpl - Class in net.esper.core
Statement implementation for EQL statements.
EPEQLStatementImpl(String, DispatchService, EPEQLStmtStartMethod, ManagedReadWriteLock) - Constructor for class net.esper.core.EPEQLStatementImpl
Ctor.
EPEQLStmtStartMethod - Class in net.esper.core
Starts and provides the stop method for EQL statements.
EPEQLStmtStartMethod(StatementSpec, String, EPServicesContext, EPStatementHandle) - Constructor for class net.esper.core.EPEQLStmtStartMethod
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.
EPPatternStatementImpl - Class in net.esper.core
Statement for patterns.
EPPatternStatementImpl(String, EventType, DispatchService, EventAdapterService, EPPatternStmtStartMethod, ManagedReadWriteLock) - Constructor for class net.esper.core.EPPatternStatementImpl
Constructor.
EPPatternStmtStartMethod - Class in net.esper.core
Method for starting a pattern statement.
EPPatternStmtStartMethod(EPServicesContext, PatternStarter, EPStatementHandle) - Constructor for class net.esper.core.EPPatternStmtStartMethod
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, ManagedReadWriteLock) - 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) - Constructor for class net.esper.core.EPServiceProviderImpl
Constructor - initializes services.
EPServiceProviderImpl.ConfigurationSnapshot - Class in net.esper.core
Snapshot of Configuration is held for re-initializing engine state from prior configuration values that may have been muted.
EPServiceProviderImpl.ConfigurationSnapshot(Configuration) - Constructor for class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Ctor.
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 instantiate implementations for all services.
EPServicesContext(SchedulingService, EventAdapterService, AutoImportService, DatabaseConfigService) - Constructor for class net.esper.core.EPServicesContext
Constructor - sets up new set of services.
EPStatement - Interface in net.esper.client
Interface to add and remove update listeners receiving events for an EP statement.
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(ManagedLock, String) - 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.
EPStatementStopMethod - Interface in net.esper.core
Method to call to stop an EPStatement.
EPStatementSupport - Class in net.esper.core
Base class for an EPStatement - provides listener registration functions.
EPStatementSupport() - Constructor for class net.esper.core.EPStatementSupport
 
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.
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
 
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(EventAdapterService) - Constructor for class net.esper.eql.parse.EQLTreeWalker
Ctor.
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.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.QueryGraph.GraphKey
 
equals(Object) - Method in class net.esper.eql.parse.TimePeriodParameter
 
equals(Object) - Method in class net.esper.event.EventPropertyDescriptor
 
equals(Object) - Method in class net.esper.event.WrapperEventBean
 
equals(Object) - Method in class net.esper.event.WrapperEventType
 
equals(Object) - Method in class net.esper.filter.DoubleRange
 
equals(Object) - Method in class net.esper.filter.FilterSpec
 
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.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.MatchedEventMap
 
equals(Object) - Method in class net.esper.schedule.ScheduleSpec
 
equals(Object) - Method in class net.esper.util.PlaceholderParser.ParameterFragment
 
equals(Object) - Method in class net.esper.util.PlaceholderParser.TextFragment
 
equals(Object) - Method in class net.esper.view.ViewSpec
 
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.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.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.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.ExprRegexpNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
equalsNode(ExprNode) - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
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.ExprStddevNode
 
equalsNodeAggregate(ExprAggregateNode) - Method in class net.esper.eql.expression.ExprSumNode
 
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 a "and" operator in the evaluation state tree.
EvalAndStateNode(Evaluator, LinkedList<EvalNode>, 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, EvalNode, 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(FilterSpec, 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, FilterSpec, String, 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, LinkedList<EvalNode>, 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(GuardFactory) - 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, GuardFactory, EvalNode, MatchedEventMap, PatternContext) - 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.
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, EvalNode, 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(ObserverFactory) - 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, ObserverFactory, 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, LinkedList<EvalNode>, 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
 
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.
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.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.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.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.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, 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.
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.core.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_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(Map<String, ConfigurationEventTypeLegacy>) - 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.
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.
EventTypeIndex - Class in net.esper.filter
Mapping of event type to a tree-like structure containing filter parameter constants in indexes FilterParamIndex 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_EXPR - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
EVERY_EXPR - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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.UpdateDispatchView
 
execute() - Method in interface net.esper.dispatch.Dispatchable
Execute dispatch.
execute() - Method in class net.esper.eql.join.JoinExecStrategyDispatchable
 
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.
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 And-condition.
ExprAndNode() - Constructor for class net.esper.eql.expression.ExprAndNode
 
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.
ExprAvedevNode.DoubleAvedev - Class in net.esper.eql.expression
Standard deviation always generates double-types numbers.
ExprAvedevNode.DoubleAvedev() - Constructor for class net.esper.eql.expression.ExprAvedevNode.DoubleAvedev
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.
ExprAvgNode.DoubleAvg - Class in net.esper.eql.expression
Average always generates double-types numbers.
ExprAvgNode.DoubleAvg() - Constructor for class net.esper.eql.expression.ExprAvgNode.DoubleAvg
 
ExprBetweenNode - Class in net.esper.eql.expression
Represents the between-clause function in an expression tree.
ExprBetweenNode(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.
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 a filter 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.
ExprCountNode.DatapointAggregator - Class in net.esper.eql.expression
Counts all datapoints including null values.
ExprCountNode.DatapointAggregator() - Constructor for class net.esper.eql.expression.ExprCountNode.DatapointAggregator
 
ExprCountNode.NonNullDatapointAggregator - Class in net.esper.eql.expression
Count all non-null values.
ExprCountNode.NonNullDatapointAggregator() - Constructor for class net.esper.eql.expression.ExprCountNode.NonNullDatapointAggregator
 
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() - Method in class net.esper.eql.generated.EQLStatementParser
 
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.
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.
ExprMedianNode.DoubleMedian - Class in net.esper.eql.expression
Average always generates double-types numbers.
ExprMedianNode.DoubleMedian() - Constructor for class net.esper.eql.expression.ExprMedianNode.DoubleMedian
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.
ExprMinMaxAggrNode.MinMaxAggregator - Class in net.esper.eql.expression
Min/max aggregator for all values.
ExprMinMaxAggrNode.MinMaxAggregator(MinMaxTypeEnum, Class) - Constructor for class net.esper.eql.expression.ExprMinMaxAggrNode.MinMaxAggregator
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.
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.
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
 
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
 
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.
ExprStddevNode.DoubleStddev - Class in net.esper.eql.expression
Standard deviation always generates double-types numbers.
ExprStddevNode.DoubleStddev() - Constructor for class net.esper.eql.expression.ExprStddevNode.DoubleStddev
 
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.
ExprSumNode.DoubleSum - Class in net.esper.eql.expression
Sum for double values.
ExprSumNode.DoubleSum() - Constructor for class net.esper.eql.expression.ExprSumNode.DoubleSum
 
ExprSumNode.FloatSum - Class in net.esper.eql.expression
Sum for float values.
ExprSumNode.FloatSum() - Constructor for class net.esper.eql.expression.ExprSumNode.FloatSum
 
ExprSumNode.IntegerSum - Class in net.esper.eql.expression
Sum for integer values.
ExprSumNode.IntegerSum() - Constructor for class net.esper.eql.expression.ExprSumNode.IntegerSum
 
ExprSumNode.LongSum - Class in net.esper.eql.expression
Sum for long values.
ExprSumNode.LongSum() - Constructor for class net.esper.eql.expression.ExprSumNode.LongSum
 
ExprSumNode.NumberIntegerSum - Class in net.esper.eql.expression
Sum for any number value.
ExprSumNode.NumberIntegerSum() - Constructor for class net.esper.eql.expression.ExprSumNode.NumberIntegerSum
 
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.
ExprValidator - Interface in net.esper.eql.expression
Validation interface for expression nodes.
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() - Constructor for class net.esper.view.window.ExternallyTimedWindowView
Default constructor - required by all views to adhere to the Java bean specification.
ExternallyTimedWindowView(String, long, ViewUpdatedCollection) - 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.
fillEquivalentNav(QueryGraph) - Static method in class net.esper.eql.join.plan.QueryGraph
Fill in equivalent key properties (navigation entries) on all streams.
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.
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.
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 FilterParamIndex 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
 
filterIdentifier() - Method in class net.esper.eql.generated.EQLStatementParser
 
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
 
filterParamBetween() - Method in class net.esper.eql.generated.EQLStatementParser
 
filterParamComparator(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
filterParamConstant() - Method in class net.esper.eql.generated.EQLStatementParser
 
filterParameter() - Method in class net.esper.eql.generated.EQLStatementParser
 
FilterParamIndex - 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.
FilterParamIndex(String, FilterOperator, EventType) - Constructor for class net.esper.filter.FilterParamIndex
Constructor.
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.
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.
filterParamInList() - Method in class net.esper.eql.generated.EQLStatementParser
 
filterParamRangeAndIn() - Method in class net.esper.eql.generated.EQLStatementParser
 
filterParamSet() - Method in class net.esper.eql.generated.EQLStatementParser
 
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
 
FilterSpec - Class in net.esper.filter
Contains the filter criteria to sift through events.
FilterSpec(EventType, List<FilterSpecParam>) - Constructor for class net.esper.filter.FilterSpec
Constructor - validates parameter list against event type, throws exception if invalid property names or mismatcing filter operators are found.
FilterSpecParam - Class in net.esper.filter
This class represents one filter parameter in an FilterSpec filter specification.
FilterSpecParamComparator - 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.
FilterSpecParamComparator() - Constructor for class net.esper.filter.FilterSpecParamComparator
 
FilterSpecParamConstant - Class in net.esper.filter
This class represents a single, constant value filter parameter in an FilterSpec 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 FilterSpec filter specification.
FilterSpecParamEventProp(String, FilterOperator, String, String) - Constructor for class net.esper.filter.FilterSpecParamEventProp
Constructor.
FilterSpecParamIn - Class in net.esper.filter
This class represents a 'in' filter parameter in an FilterSpec filter specification.
FilterSpecParamIn(String, FilterOperator, List<FilterSpecParamInValue>, boolean, Class) - 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 FilterSpec 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.
FilterSpecValidator - Class in net.esper.filter
Utility class for validating filter specifications.
FilterSpecValidator() - Constructor for class net.esper.filter.FilterSpecValidator
 
FilterStreamSpec - 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.
FilterStreamSpec(FilterSpec, List<ViewSpec>, String) - Constructor for class net.esper.eql.spec.FilterStreamSpec
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.
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<FilterParamIndex>) - 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>, FilterParamIndex) - 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.
FIRST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FIRST - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
flatten(LinkedList<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
 
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
 
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.eql.parse
Encapsulates a parameter specifying a frequency, i.e.
FrequencyParameter(int) - Constructor for class net.esper.eql.parse.FrequencyParameter
Ctor.
FROM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
FROM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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.
funcIdent() - Method in class net.esper.eql.generated.EQLStatementParser
 

G

GE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
generateMatchEvents(MatchedEventMap, EvalStateNode, Hashtable<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.
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(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(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.KeyedFastPropertyGetter
 
get(EventBean) - Method in class net.esper.event.property.KeyedMethodPropertyGetter
 
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.FilterParamIndex
Get the event evaluation instance associated with the constant.
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.FilterParamIndexRange
 
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.
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.
getAggregationFunction() - Method in class net.esper.eql.expression.ExprAggregateNode
Returns the aggregation state prototype for use in grouping aggregation states per group-by keys.
getAggregationFunction() - Method in class net.esper.eql.expression.ExprAvedevNode
 
getAggregationFunction() - Method in class net.esper.eql.expression.ExprAvgNode
 
getAggregationFunction() - Method in class net.esper.eql.expression.ExprCountNode
 
getAggregationFunction() - Method in class net.esper.eql.expression.ExprMedianNode
 
getAggregationFunction() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
 
getAggregationFunction() - Method in class net.esper.eql.expression.ExprStddevNode
 
getAggregationFunction() - Method in class net.esper.eql.expression.ExprSumNode
 
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.ExprStddevNode
 
getAggregationFunctionName() - Method in class net.esper.eql.expression.ExprSumNode
 
getAndFlush() - Method in class net.esper.collection.FlushedEventBuffer
Get the events currently buffered.
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.
getAssignedName() - Method in class net.esper.eql.spec.SelectExprElementNamedSpec
Returns the name of the item in the select clause.
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.
getAutoImports() - Method in class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Returns list of automatic import packages and classes.
getAutoImportService() - Method in class net.esper.core.EPServicesContext
Returns the import and class name resolution service.
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.
getBuffer() - Method in class net.esper.view.internal.PriorEventView
Returns the underlying buffer used for access to prior events.
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
 
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.
getClassName() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the driver manager 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.ExprStaticMethodNode
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.
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.
getClazz() - Method in enum net.esper.view.ViewEnum
Gets the implementation class underlying the view.
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.
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.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.
getConfigurationInputStream(String) - Static method in class net.esper.client.Configuration
Get the configuration file as an InputStream.
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.
getConstantTypeName(int) - Static method in class net.esper.eql.parse.ASTConstantHelper
Returns the type name for the given AST constant type.
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).
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.eql.spec.DBStatementStreamSpec
Returns the database name.
getDatabaseReferences() - Method in class net.esper.client.Configuration
Returns a map of string database names to database configuration options.
getDatabaseRefs() - Method in class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Returns a map of database name to database configuration.
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
 
getDataCacheDesc() - Method in class net.esper.client.ConfigurationDBRef
Return a query result data cache descriptor.
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.WrapperEventType
 
getDeepSuperTypes() - Method in class net.esper.event.xml.BaseXMLEventType
 
getDefaultNamespace() - Method in class net.esper.client.ConfigurationEventTypeXMLDOM
Returns the default namespace.
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.
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.
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.
getDouble() - Method in class net.esper.type.DoubleValue
Return the value as an unboxed.
getEmitService() - Method in class net.esper.core.EPServicesContext
Returns service for emitting events.
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
 
getEpStatementHandle() - Method in class net.esper.core.EPStatementHandleCallback
Returns the statement handle.
getEpStatementHandle() - Method in class net.esper.pattern.PatternContext
Returns the statement's resource handle for locking.
getEpStatementHandle() - Method in class net.esper.view.ViewServiceContext
Returns the statement's resource locks.
getEvalNode() - Method in class net.esper.eql.spec.PatternStreamSpec
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.pattern.PatternContext
Returns teh service providing event adaptering or wrapping.
getEventAdapterService() - Method in class net.esper.view.ViewServiceContext
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.
getEventIndex() - Method in class net.esper.eql.join.exec.FullTableScanLookupStrategy
Returns the associated table.
getEventNameTag(AST) - Static method in class net.esper.eql.parse.ASTFilterSpecHelper
Returns the name tag for the event in the filter spec, if any, else null.
getEventRate() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the event rate.
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.EPEQLStatementImpl
 
getEventType() - Method in class net.esper.core.EPPatternStatementImpl
 
getEventType() - Method in class net.esper.core.UpdateDispatchView
 
getEventType() - Method in class net.esper.eql.db.PollingViewable
 
getEventType() - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
Returns event type of the lookup event.
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.CompositeEventBean
 
getEventType(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.
getEventType(String) - Method in class net.esper.event.EventAdapterServiceImpl
 
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.WrapperEventBean
 
getEventType() - Method in class net.esper.event.xml.XMLEventBean
 
getEventType() - Method in class net.esper.filter.FilterSpec
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.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.LengthWindowView
 
getEventType() - Method in class net.esper.view.window.LengthWindowViewFactory
 
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.TimeWindowView
 
getEventType() - Method in class net.esper.view.window.TimeWindowViewFactory
 
getEventType() - Method in class net.esper.view.ZeroDepthStream
 
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
Returns the mapping of event type alias to Java class name.
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
Returns the mapping of event type alias to legacy java event type information.
getEventTypesMapEvents() - Method in class net.esper.client.Configuration
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
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.
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.
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.
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.
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.
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.
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.
getFilterForValue() - Method in interface net.esper.filter.FilterValueSetParam
Return the filter parameter constant to filter for.
getFilterForValue() - Method in class net.esper.filter.FilterValueSetParamImpl
 
getFilterOperator() - Method in class net.esper.filter.FilterParamIndex
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
 
getFilterRootNode() - Method in class net.esper.eql.spec.StatementSpec
Returns the WHERE-clause root node of filter expression.
getFilterService() - Method in class net.esper.core.EPServicesContext
Returns filter evaluation service implementation.
getFilterService() - Method in class net.esper.pattern.PatternContext
Returns service to use for filter evaluation.
getFilterSpec() - Method in class net.esper.eql.spec.FilterStreamSpec
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.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
 
getFilterValueClass(Map<String, EventType>) - Method in class net.esper.filter.FilterSpecParam
Return the filter parameter constant's class.
getFilterValueClass(Map<String, EventType>) - Method in class net.esper.filter.FilterSpecParamConstant
 
getFilterValueClass(Map<String, EventType>) - Method in class net.esper.filter.FilterSpecParamEventProp
 
getFilterValueClass(Map<String, EventType>) - Method in class net.esper.filter.FilterSpecParamIn
 
getFilterValueClass(Map<String, EventType>) - Method in class net.esper.filter.FilterSpecParamRange
 
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.eql.parse.FrequencyParameter
Returns frequency.
getFromStream() - Method in class net.esper.eql.join.exec.LookupInstructionExec
Returns the stream number of the stream supplying the event to use for lookup.
getGetter(String) - Method in class net.esper.event.BaseConfigurableEventType
 
getGetter(String) - Method in class net.esper.event.BeanEventType
 
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(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.FilterParamIndex
Returns getter for property.
getGroupByExpressions() - Method in class net.esper.eql.spec.StatementSpec
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.
getHavingExprRootNode() - Method in class net.esper.eql.spec.StatementSpec
Returns expression root node representing the having-clause, if present, or null if no having clause was supplied.
getHigh() - Method in class net.esper.eql.parse.RangeParameter
Returns end of range.
getImports() - Method in class net.esper.client.Configuration
Returns the class and package imports.
getImports() - Method in class net.esper.eql.core.AutoImportServiceImpl
For testing, returns imports.
getIndex() - Method in class net.esper.eql.join.exec.IndexedTableLookupStrategy
Returns index to look up in.
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.
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.
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.
getInitialReferencePoint() - Method in class net.esper.view.window.TimeBatchView
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.
getInsertIntoDesc() - Method in class net.esper.eql.spec.StatementSpec
Return a descriptor with the insert-into event name and optional list of columns.
getInternalEventRouter() - Method in class net.esper.core.EPServicesContext
Returns router for internal event processing.
getIntValue() - Method in class net.esper.eql.parse.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.
getJavaClassAliases() - Method in class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Returns event type alias to Java class name mapping.
getKey() - Method in class net.esper.event.property.MappedProperty
Returns the key value for mapped access.
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.
getKeys() - Method in class net.esper.collection.MultiKeyUntyped
Returns keys.
getLeftNode() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns left hand identifier node.
getLegacyAliases() - Method in class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Returns the map of event type alias to legacy event type configuration.
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.
getListeners() - Method in class net.esper.core.EPStatementSupport
Returns the set of listeners to the statement.
getListOfValues() - Method in class net.esper.filter.FilterSpecParamIn
Returns the list of values we are asking to match.
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.eql.parse.RangeParameter
Returns start of range.
getMapAliases() - Method in class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Returns a map of event type alias to Map-event type properties.
getMappedProperty(String) - Method in class net.esper.event.BeanEventType
Looks up and returns a cached mapped property's descriptor.
getMatchingEvent(String) - Method in class net.esper.pattern.MatchedEventMap
Returns a single event instance given the tag identifier, or null if the tag could not be located.
getMatchingEvents() - Method in class net.esper.pattern.MatchedEventMap
Returns a Hashtable containing the events where the key is the event tag string and the value is the event instance.
getMax() - Method in class net.esper.filter.DoubleRange
Returns high 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
 
getMethodName() - Method in class net.esper.eql.expression.ExprStaticMethodNode
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.
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.
getMin() - Method in class net.esper.filter.DoubleRange
Returns low endpoint.
getMsecIntervalSize() - Method in class net.esper.eql.view.OutputConditionTime
Returns the interval size in milliseconds.
getMsecIntervalSize() - Method in class net.esper.view.window.TimeBatchView
Returns the interval size in milliseconds.
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 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.
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.
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(int) - Method in class net.esper.view.ext.IStreamSortedRandomAccess
 
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.
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.
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.
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.eql.parse.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.
getObjectName() - Method in class net.esper.view.ViewSpec
Returns the object name.
getObjectNamespace() - Method in class net.esper.view.ViewSpec
Returns namespace for view object.
getObjectParameters() - Method in class net.esper.view.ViewSpec
Returns the list of object parameters.
getOldData(int) - Method in class net.esper.view.ext.IStreamSortedRandomAccess
 
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.
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.
getOptionalAsName() - Method in class net.esper.eql.spec.SelectExprElementUnnamedSpec
Returns the name of the item in the select clause.
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.
getOptionalStreamName() - Method in class net.esper.eql.spec.StreamSpec
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.
getOrderByList() - Method in class net.esper.eql.spec.StatementSpec
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.StatementSpec
Returns the LEFT/RIGHT/FULL OUTER JOIN-type and property name descriptor, if applicable.
getOuterJoinType() - Method in class net.esper.eql.spec.OuterJoinDesc
Returns the type of outer join (left/right/full).
getOutputLimitSpec() - Method in class net.esper.eql.spec.StatementSpec
Returns the output limit definition, if any.
getPageField() - Method in class net.esper.view.stat.MultiDimStatsView
Returns the name of the field to extract the page values from.
getParameters() - Method in class net.esper.eql.parse.ListParameter
Returns list of parameters.
getParameters() - Method in class net.esper.filter.FilterSpec
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.
getParamTypes() - Method in class net.esper.eql.expression.ExprStaticMethodNode
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.
getParentEvent() - Method in class net.esper.eql.join.rep.Node
Returns lookup event.
getPermutation(int, int, int[]) - Static method in class net.esper.collection.PermutationEnumeration
Returns permutation.
getPlan(int, List<OuterJoinDesc>, ExprNode, String[]) - Static method in class net.esper.eql.join.plan.QueryPlanBuilder
Build query plan using the filter.
getPrefix(String) - Method in class net.esper.event.xml.XPathNamespaceContext
 
getPrefixes(String) - Method in class net.esper.event.xml.XPathNamespaceContext
 
getProcessor(List<SelectExprElementNamedSpec>, List<ExprNode>, List<Pair<ExprNode, Boolean>>, 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<Pair<ExprNode, Boolean>>, StreamTypeService, EventAdapterService, AutoImportService, ViewResourceDelegate) - 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<SelectExprElementNamedSpec>, boolean, InsertIntoDesc, StreamTypeService, EventAdapterService) - Static method in class net.esper.eql.core.SelectExprProcessorFactory
Returns the processor to use for a given select-clause.
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.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.QueryGraph.GraphValue
Returns property names for left stream.
getPropertiesRight() - Method in class net.esper.eql.join.plan.QueryGraph.GraphValue
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.FilterParamIndex
Returns boxed property type.
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.FilterParamIndex
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.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.
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(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
 
getPropertyValues() - Method in class net.esper.view.std.AddPropertyValueView
Returns the value to set for the field.
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.
getQueryStrategies() - Method in class net.esper.eql.join.JoinSetComposerImpl
Returns query strategies.
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 class net.esper.filter.FilterParamIndex
Supplies the lock for protected access.
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.FilterParamIndexRange
 
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.
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.
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.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.
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.
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.pattern.PatternContext
Returns the schedule bucket for ordering schedule callbacks within this pattern.
getScheduleBucket() - Method in class net.esper.view.ViewServiceContext
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.pattern.PatternContext
Returns service to use for schedule evaluation.
getSchedulingService() - Method in class net.esper.view.ViewServiceContext
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.
getSelectClauseSpec() - Method in class net.esper.eql.spec.StatementSpec
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.SelectExprElementNamedSpec
Returns the expression node representing the item in the select clause.
getSelectExpression() - Method in class net.esper.eql.spec.SelectExprElementUnnamedSpec
Returns the expression node representing the item in the select clause.
getSelectList() - Method in class net.esper.eql.spec.SelectClauseSpec
Returns the list of select expressions.
getSelectStreamSelectorEnum() - Method in class net.esper.eql.spec.StatementSpec
Returns the stream selector (rstream/istream).
getService(List<ExprAggregateNode>, boolean, ExprNode, List<ExprNode>) - Static method in class net.esper.eql.core.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.LengthWindowView
Returns the size of the length window.
getSlope() - Method in class net.esper.view.stat.RegressionBean
Returns the slope.
getSortFieldNames() - Method in class net.esper.view.ext.SortWindowView
Returns the field names supplying the values to sort by.
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.eql.spec.DBStatementStreamSpec
Returns the SQL with substitution parameters.
getStatementLock() - Method in class net.esper.core.EPStatementHandle
Returns statement resource lock.
getStatementSpec() - Method in class net.esper.eql.parse.EQLTreeWalker
Returns statement specification.
getStaticMethod() - Method in class net.esper.eql.expression.ExprStaticMethodNode
Returns the static 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.
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.
getStreamName() - Method in class net.esper.eql.core.PropertyResolutionDescriptor
Returns 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.
getStreamOrPropertyName() - Method in class net.esper.eql.expression.ExprIdentNode
For unit testing, returns stream or property name candidate.
getStreamService() - Method in class net.esper.core.EPServicesContext
Returns stream service.
getStreamSpecs() - Method in class net.esper.eql.spec.StatementSpec
Returns the FROM-clause stream definitions.
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.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.WrapperEventType
 
getSuperTypes() - Method in class net.esper.event.xml.BaseXMLEventType
 
getTables() - Method in class net.esper.eql.join.JoinSetComposerImpl
Returns tables.
getTaggedEventTypes() - Method in class net.esper.eql.spec.PatternStreamSpec
Returns event types tagged in the pattern expression.
getText() - Method in interface net.esper.client.EPStatement
Returns the underlying expression text or XML.
getText() - Method in class net.esper.core.EPEQLStatementImpl
 
getText() - Method in class net.esper.core.EPPatternStatementImpl
 
getTime() - Method in interface net.esper.schedule.SchedulingService
Gets the last time known to the scheduling service.
getTime() - Method in class net.esper.schedule.SchedulingServiceImpl
 
getTimeInMillis() - Method in class net.esper.client.time.CurrentTimeEvent
Returns the time in milliseconds.
getTimeRate() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the rate in seconds, if supplied, or zero if not supplied.
getTimerService() - Method in class net.esper.core.EPServicesContext
Returns time provider service implementation.
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.eql.expression.ExprAndNode
 
getType() - Method in class net.esper.eql.expression.ExprAvedevNode
 
getType() - Method in class net.esper.eql.expression.ExprAvgNode
 
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.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.ExprCountNode
 
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.ExprLikeNode
 
getType() - Method in class net.esper.eql.expression.ExprMathNode
 
getType() - Method in class net.esper.eql.expression.ExprMedianNode
 
getType() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
 
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.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.ExprStddevNode
 
getType() - Method in class net.esper.eql.expression.ExprSumNode
 
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.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
 
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 enum net.esper.type.PrimitiveValueType
Returns the name of the type.
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.WrapperEventBean
 
getUnderlying() - Method in class net.esper.event.xml.XMLEventBean
 
getUnderlyingEvent() - Method in class net.esper.event.WrapperEventBean
Returns the wrapped event.
getUnderlyingMap() - Method in class net.esper.event.WrapperEventBean
Returns the underlying map storing the additional properties, if any.
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.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.
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.
getUrl() - Method in class net.esper.client.ConfigurationDBRef.DriverManagerConnection
Returns the database URL to use to obtains connections.
getValidatedSubtree(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprNode
Validates the expression node subtree that has this node as root.
getValue(int) - Method in class net.esper.collection.SortedDoubleVector
Returns the value at a given index.
getValue(int) - Method in interface net.esper.eql.core.AggregationResultFuture
Returns current aggregation state, for use by expression node representing an aggregation function.
getValue(int) - Method in class net.esper.eql.core.AggregationServiceGroupAllImpl
 
getValue(int) - Method in class net.esper.eql.core.AggregationServiceGroupByImpl
 
getValue(int) - Method in class net.esper.eql.core.AggregationServiceNull
 
getValue() - Method in interface net.esper.eql.core.Aggregator
Returns the current value held.
getValue() - Method in class net.esper.eql.core.UniqueValueAggregator
 
getValue() - Method in class net.esper.eql.expression.ExprAvedevNode.DoubleAvedev
 
getValue() - Method in class net.esper.eql.expression.ExprAvgNode.DoubleAvg
 
getValue() - Method in class net.esper.eql.expression.ExprCountNode.DatapointAggregator
 
getValue() - Method in class net.esper.eql.expression.ExprCountNode.NonNullDatapointAggregator
 
getValue() - Method in class net.esper.eql.expression.ExprMedianNode.DoubleMedian
 
getValue() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode.MinMaxAggregator
 
getValue() - Method in class net.esper.eql.expression.ExprStddevNode.DoubleStddev
 
getValue() - Method in class net.esper.eql.expression.ExprSumNode.DoubleSum
 
getValue() - Method in class net.esper.eql.expression.ExprSumNode.FloatSum
 
getValue() - Method in class net.esper.eql.expression.ExprSumNode.IntegerSum
 
getValue() - Method in class net.esper.eql.expression.ExprSumNode.LongSum
 
getValue() - Method in class net.esper.eql.expression.ExprSumNode.NumberIntegerSum
 
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
 
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.FilterSpec
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.eql.parse.FrequencyParameter
 
getValuesInRange(int, int) - Method in class net.esper.eql.parse.IntParameter
 
getValuesInRange(int, int) - Method in class net.esper.eql.parse.ListParameter
 
getValuesInRange(int, int) - Method in interface net.esper.eql.parse.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.eql.parse.RangeParameter
 
getValuesInRange(int, int) - Method in class net.esper.eql.parse.WildcardParameter
 
getValueType() - Method in interface net.esper.eql.core.Aggregator
Returns the type of the current value.
getValueType() - Method in class net.esper.eql.core.UniqueValueAggregator
 
getValueType() - Method in class net.esper.eql.expression.ExprAvedevNode.DoubleAvedev
 
getValueType() - Method in class net.esper.eql.expression.ExprAvgNode.DoubleAvg
 
getValueType() - Method in class net.esper.eql.expression.ExprCountNode.DatapointAggregator
 
getValueType() - Method in class net.esper.eql.expression.ExprCountNode.NonNullDatapointAggregator
 
getValueType() - Method in class net.esper.eql.expression.ExprMedianNode.DoubleMedian
 
getValueType() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode.MinMaxAggregator
 
getValueType() - Method in class net.esper.eql.expression.ExprStddevNode.DoubleStddev
 
getValueType() - Method in class net.esper.eql.expression.ExprSumNode.DoubleSum
 
getValueType() - Method in class net.esper.eql.expression.ExprSumNode.FloatSum
 
getValueType() - Method in class net.esper.eql.expression.ExprSumNode.IntegerSum
 
getValueType() - Method in class net.esper.eql.expression.ExprSumNode.LongSum
 
getValueType() - Method in class net.esper.eql.expression.ExprSumNode.NumberIntegerSum
 
getViewFactoryChain() - Method in class net.esper.view.ViewFactoryChain
Returns the chain of view factories.
getViews() - Method in class net.esper.eql.db.PollingViewable
 
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.
getViewServiceContext() - Method in interface net.esper.view.ContextAwareView
Returns the context instances used by the view.
getViewServiceContext() - Method in class net.esper.view.stat.BaseBivariateStatisticsView
 
getViewServiceContext() - Method in class net.esper.view.stat.MultiDimStatsView
 
getViewServiceContext() - Method in class net.esper.view.stat.UnivariateStatisticsView
 
getViewServiceContext() - Method in class net.esper.view.stat.WeightedAverageView
 
getViewServiceContext() - Method in class net.esper.view.std.AddPropertyValueView
 
getViewServiceContext() - Method in class net.esper.view.std.GroupByView
 
getViewServiceContext() - Method in class net.esper.view.std.MergeView
 
getViewServiceContext() - Method in class net.esper.view.std.SizeView
 
getViewServiceContext() - Method in class net.esper.view.window.TimeBatchView
 
getViewServiceContext() - Method in class net.esper.view.window.TimeWindowView
 
getViewSpecs() - Method in class net.esper.eql.spec.StreamSpec
Returns view definitions to use to construct views to derive data on stream.
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.TimeBatchView
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.
getXAverage() - Method in class net.esper.view.stat.BaseStatisticsBean
Returns the average of all X data points.
getXmlDOMAliases() - Method in class net.esper.core.EPServiceProviderImpl.ConfigurationSnapshot
Returns map of event alias and XML DOM configs.
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(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() - Constructor for class net.esper.view.std.GroupByView
Default constructor - required by all views to adhere to the Java bean specification.
GroupByView(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
 
GT - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
GT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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.
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.

H

hasData() - Method in class net.esper.core.PatternListenerDispatch
Returns true if at least one event has been added.
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.QueryGraph.GraphKey
 
hashCode() - Method in class net.esper.event.WrapperEventBean
 
hashCode() - Method in class net.esper.event.WrapperEventType
 
hashCode() - Method in class net.esper.filter.DoubleRange
 
hashCode() - Method in class net.esper.filter.FilterSpec
 
hashCode() - Method in class net.esper.pattern.MatchedEventMap
 
hashCode() - Method in class net.esper.schedule.ScheduleSpec
 
hasMoreElements() - Method in class net.esper.collection.NumberSetPermutationEnumeration
 
hasMoreElements() - Method in class net.esper.collection.PermutationEnumeration
 
hasNext() - Method in class net.esper.collection.IterablesListIterator
 
hasNext() - Method in class net.esper.collection.NullIterator
 
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.join.rep.NodeCursorIterator
 
hasNext() - Method in class net.esper.eql.join.rep.SingleCursorIterator
 
hasNext() - Method in class net.esper.view.ext.SortWindowIterator
 
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.db.PollingViewable
 
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
 
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) - 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.
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_SET - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
IN_SET - 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.
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.
IndexFactory - Class in net.esper.filter
Factory for FilterParamIndex 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 FilterParamIndex 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
 
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(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
 
initialize() - Method in interface net.esper.client.EPServiceProvider
Frees any resources associated with this runtime instance.
initialize() - Method in class net.esper.core.EPServiceProviderImpl
 
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
 
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
 
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) - Constructor for class net.esper.filter.InSetOfValuesEventProp
Ctor.
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(List<ViewFactory>) - 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(List<ViewFactory>) - Method in class net.esper.view.ViewCapDataWindowAccess
 
inspect(List<ViewFactory>) - Method in class net.esper.view.ViewCapPriorEventAccess
 
instantiateChain(List<View>, Viewable, List<ViewFactory>, ViewServiceContext) - Static method in class net.esper.view.ViewServiceHelper
Instantiate a chain of views.
instantiateFactories(List<ViewSpec>) - 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.
INT_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
INT_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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.
INTERNAL_CLOCK_RESOLUTION_MSEC - Static variable in interface net.esper.timer.TimerService
Resolution in milliseconds of the internal clock.
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) - Constructor for class net.esper.eql.view.InternalRouteView
Ctor.
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.eql.parse
Parameter supplying a single int value is a set of numbers.
IntParameter(int) - Constructor for class net.esper.eql.parse.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
 
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.
isComparisonOperator() - Method in enum net.esper.filter.FilterOperator
Returns true for relational comparison operators which excludes the = equals operator, else returns false.
isDisplayFirstOnly() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns true to output the first event only.
isDisplayLastOnly() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns true to output the last event 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.ArrayBackedCollection
 
isEmpty() - Method in class net.esper.collection.TimeWindow
Returns true if the window is currently empty.
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.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.LengthWindowView
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.TimeWindowView
Returns true if the window is empty, or false if not empty.
isEventLimit() - Method in class net.esper.eql.spec.OutputLimitSpec
Returns the number of events, or zero if no number of events was supplied.
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.
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.
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.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.
isNavigable(int, int) - Method in class net.esper.eql.join.plan.QueryGraph
Returns true if there is a relationship between streams via equal properties.
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.
isNumeric(Class) - Static method in class net.esper.util.JavaClassHelper
Determines if the class passed in is one of the numeric classes.
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.WrapperEventType
 
isRangeOperator() - Method in enum net.esper.filter.FilterOperator
Returns true for all range operators, false if not a range operator.
isRequiresParameters() - Method in enum net.esper.view.ViewEnum
Returns true if the view requires one or more parameters, false if the view doesn't require any parameters.
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() - 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() - Constructor for class net.esper.view.window.IStreamRelativeAccess
Ctor.
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() - Constructor for class net.esper.view.ext.IStreamSortedRandomAccess
 
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 interface net.esper.eql.expression.ExprNodeVisitor
Allows visitor to indicate whether to visit a given node.
isWildcard(int, int) - Method in class net.esper.eql.parse.FrequencyParameter
 
isWildcard(int, int) - Method in class net.esper.eql.parse.IntParameter
 
isWildcard(int, int) - Method in class net.esper.eql.parse.ListParameter
 
isWildcard(int, int) - Method in interface net.esper.eql.parse.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.eql.parse.RangeParameter
 
isWildcard(int, int) - Method in class net.esper.eql.parse.WildcardParameter
 
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 an iterator over events.
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.EPEQLStatementImpl
 
iterator() - Method in class net.esper.core.EPPatternStatementImpl
 
iterator() - Method in class net.esper.core.UpdateDispatchView
 
iterator() - Method in class net.esper.eql.db.PollingViewable
 
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.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.LengthWindowView
 
iterator() - Method in class net.esper.view.window.TimeBatchView
 
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
 
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.
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 - Class in net.esper.eql.join
Factory for building a JoinSetComposer from analyzing filter nodes, for fast join tuple result set composition.
JoinSetComposerFactory() - Constructor for class net.esper.eql.join.JoinSetComposerFactory
 
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.

K

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.

L

LAND - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LAND - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
LAST - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LAST - 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
Constructor.
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.
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 - 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.core.Aggregator
Apply the value as leaving aggregation (leaving window).
leave(Object) - Method in class net.esper.eql.core.UniqueValueAggregator
 
leave(Object) - Method in class net.esper.eql.expression.ExprAvedevNode.DoubleAvedev
 
leave(Object) - Method in class net.esper.eql.expression.ExprAvgNode.DoubleAvg
 
leave(Object) - Method in class net.esper.eql.expression.ExprCountNode.DatapointAggregator
 
leave(Object) - Method in class net.esper.eql.expression.ExprCountNode.NonNullDatapointAggregator
 
leave(Object) - Method in class net.esper.eql.expression.ExprMedianNode.DoubleMedian
 
leave(Object) - Method in class net.esper.eql.expression.ExprMinMaxAggrNode.MinMaxAggregator
 
leave(Object) - Method in class net.esper.eql.expression.ExprStddevNode.DoubleStddev
 
leave(Object) - Method in class net.esper.eql.expression.ExprSumNode.DoubleSum
 
leave(Object) - Method in class net.esper.eql.expression.ExprSumNode.FloatSum
 
leave(Object) - Method in class net.esper.eql.expression.ExprSumNode.IntegerSum
 
leave(Object) - Method in class net.esper.eql.expression.ExprSumNode.LongSum
 
leave(Object) - Method in class net.esper.eql.expression.ExprSumNode.NumberIntegerSum
 
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
 
LengthWindowView - Class in net.esper.view.window
This view is a moving window extending the specified number of elements into the past.
LengthWindowView() - Constructor for class net.esper.view.window.LengthWindowView
Default constructor - required by all views to adhere to the Java bean specification.
LengthWindowView(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
 
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 - 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
 
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.
ListParameter - Class in net.esper.eql.parse
Represents a list of values in a set of numeric parameters.
ListParameter() - Constructor for class net.esper.eql.parse.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
 
LONG_TYPE - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LONG_TYPE - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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(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[], 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.
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.
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 - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
LT - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 

M

makeComposer(List<OuterJoinDesc>, ExprNode, EventType[], String[], Viewable[], SelectClauseStreamSelectorEnum) - Static method in class net.esper.eql.join.JoinSetComposerFactory
Builds join tuple composer.
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.
makeGuard(PatternContext, Quitable) - Method in interface net.esper.pattern.guard.GuardFactory
Constructs a guard instance.
makeGuard(PatternContext, Quitable) - Method in class net.esper.pattern.guard.TimerWithinGuardFactory
 
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.
makeNew() - Method in class net.esper.eql.db.ConnectionCache
Make a new pair of resources.
makeObserver(PatternContext, MatchedEventMap, ObserverEventEvaluator) - Method in interface net.esper.pattern.observer.ObserverFactory
Make an observer instance.
makeObserver(PatternContext, MatchedEventMap, ObserverEventEvaluator) - Method in class net.esper.pattern.observer.TimerAtObserverFactory
 
makeObserver(PatternContext, MatchedEventMap, ObserverEventEvaluator) - Method in class net.esper.pattern.observer.TimerObserverFactory
 
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.
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[], ViewServiceContext) - Static method in class net.esper.view.std.GroupByView
Instantiate subviews for the given group view and the given key value to group-by.
makeView(ViewServiceContext) - Method in class net.esper.view.ext.SortWindowViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.internal.PriorEventViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.stat.CorrelationViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.std.GroupByViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.std.LastElementViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.std.MergeViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.std.SizeViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
makeView(ViewServiceContext) - Method in interface net.esper.view.ViewFactory
Create a new view.
makeView(ViewServiceContext) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.window.LengthWindowViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.window.TimeBatchViewFactory
 
makeView(ViewServiceContext) - Method in class net.esper.view.window.TimeWindowViewFactory
 
ManagedLock - Class in net.esper.util
Simple lock based on ReentrantLock that associates a name with the lock and traces locking and unlocking.
ManagedLock(String) - Constructor for class net.esper.util.ManagedLock
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) - Constructor for class net.esper.util.ManagedReadWriteLock
Ctor.
mapAliases - Variable in class net.esper.client.Configuration
The type aliases for events that result when maps are sent into the engine.
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.
MatchedEventMap - 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.
MatchedEventMap() - Constructor for class net.esper.pattern.MatchedEventMap
Constructor creates an empty collection of events.
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.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(Map<String, EventBean>) - Method in class net.esper.core.EPPatternStatementImpl
 
matchFound(EventBean) - Method in interface net.esper.filter.FilterHandleCallback
Indicate that an event was evaluated by the FilterService which matches the filter specification FilterSpec 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 - 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.schedule.ScheduleUnit
Returns minimum valid value for the unit.
maxFunc() - Method in class net.esper.eql.generated.EQLStatementParser
 
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
 
MEDIAN - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
MEDIAN - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
mEQUAL(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
mEQUALS(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 
merge(MatchedEventMap) - Method in class 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.
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() - Constructor for class net.esper.view.std.MergeView
Default constructor - required by all views to adhere to the Java bean specification.
MergeView(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
 
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
 
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.schedule.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
 
MinMaxTypeEnum - Enum in net.esper.type
Enumeration for the type of arithmatic to use.
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
 
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() - Constructor for class net.esper.view.stat.MultiDimStatsView
Empty constructor - views are Java beans.
MultiDimStatsView(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.
multiplyExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
mWS(boolean) - Method in class net.esper.eql.generated.EQLStatementLexer
 

N

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>, BeanEventAdapter) - 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>, BeanEventAdapter) - Constructor for class net.esper.event.property.NestedPropertyGetter
Ctor.
net.esper.client - package net.esper.client
This package defines the central Esper Client APIs.
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.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.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.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.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() - Method in interface net.esper.eql.core.Aggregator
Make a new, initalized aggregation state.
newAggregator() - Method in class net.esper.eql.core.UniqueValueAggregator
 
newAggregator() - Method in class net.esper.eql.expression.ExprAvedevNode.DoubleAvedev
 
newAggregator() - Method in class net.esper.eql.expression.ExprAvgNode.DoubleAvg
 
newAggregator() - Method in class net.esper.eql.expression.ExprCountNode.DatapointAggregator
 
newAggregator() - Method in class net.esper.eql.expression.ExprCountNode.NonNullDatapointAggregator
 
newAggregator() - Method in class net.esper.eql.expression.ExprMedianNode.DoubleMedian
 
newAggregator() - Method in class net.esper.eql.expression.ExprMinMaxAggrNode.MinMaxAggregator
 
newAggregator() - Method in class net.esper.eql.expression.ExprStddevNode.DoubleStddev
 
newAggregator() - Method in class net.esper.eql.expression.ExprSumNode.DoubleSum
 
newAggregator() - Method in class net.esper.eql.expression.ExprSumNode.FloatSum
 
newAggregator() - Method in class net.esper.eql.expression.ExprSumNode.IntegerSum
 
newAggregator() - Method in class net.esper.eql.expression.ExprSumNode.LongSum
 
newAggregator() - Method in class net.esper.eql.expression.ExprSumNode.NumberIntegerSum
 
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.
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.
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() - Static method in class net.esper.timer.TimerServiceProvider
Creates an implementation of the TimerService interface.
newService() - 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.
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalAndNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalEveryNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalFilterNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalFollowedByNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalGuardNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - 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) - Method in class net.esper.pattern.EvalNotNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalObserverNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalOrNode
 
newState(Evaluator, MatchedEventMap, PatternContext) - Method in class net.esper.pattern.EvalRootNode
 
next() - Method in class net.esper.collection.IterablesListIterator
 
next() - Method in class net.esper.collection.NullIterator
 
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.join.rep.NodeCursorIterator
 
next() - Method in class net.esper.eql.join.rep.SingleCursorIterator
 
next() - Method in class net.esper.view.ext.SortWindowIterator
 
nextElement() - Method in class net.esper.collection.NumberSetPermutationEnumeration
 
nextElement() - Method in class net.esper.collection.PermutationEnumeration
 
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
 
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.
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_SET - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
NOT_IN_SET - 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
 
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_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
 
NumberSetParameter - Interface in net.esper.eql.parse
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
 
numStreams - Variable in class net.esper.eql.join.assemble.BaseAssemblyNode
Number of streams in statement.

O

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.
ON - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
ON - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
orderByElement(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
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<Pair<ExprNode, Boolean>>, 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) - 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
 
outerJoinList() - Method in class net.esper.eql.generated.EQLStatementParser
 
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, OutputCallback) - Constructor for class net.esper.eql.view.OutputConditionCount
Constructor.
OutputConditionFactory - Class in net.esper.eql.view
Factory for output condition instances.
OutputConditionFactory() - Constructor for class net.esper.eql.view.OutputConditionFactory
 
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, ViewServiceContext, 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, ViewServiceContext, OutputCallback) - Constructor for class net.esper.eql.view.OutputConditionTime
Constructor.
outputLimit() - Method in class net.esper.eql.generated.EQLStatementParser
 
outputLimitExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
OutputLimitSpec - Class in net.esper.eql.spec
Spec for building an EventBatch.
OutputLimitSpec(int, OutputLimitSpec.DisplayLimit) - Constructor for class net.esper.eql.spec.OutputLimitSpec
Ctor.
OutputLimitSpec(double, OutputLimitSpec.DisplayLimit) - Constructor for class net.esper.eql.spec.OutputLimitSpec
Ctor.
OutputLimitSpec.DisplayLimit - Enum in net.esper.eql.spec
Enum controlling the type of output limiting.
OutputProcessView - Class in net.esper.eql.view
A view that prepares output events, batching incoming events and invoking the result set processor as necessary.
OutputProcessView(ResultSetProcessor, int, OutputLimitSpec, ViewServiceContext) - Constructor for class net.esper.eql.view.OutputProcessView
Ctor.
OutputProcessView.OutputProcessTransform - Class in net.esper.eql.view
Method to transform an event based on the select expression.
OutputProcessView.OutputProcessTransform(ResultSetProcessor) - Constructor for class net.esper.eql.view.OutputProcessView.OutputProcessTransform
Ctor.

P

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.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, BeanEventAdapter) - 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, XPathFactory, String) - 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) - Method in class net.esper.type.ShortValue
 
parse(String) - Method in class net.esper.type.StringValue
 
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
 
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.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.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
 
PatternContext - Class in net.esper.pattern
Contains handles to implementations of services needed by evaluation nodes.
PatternContext(FilterService, SchedulingService, ScheduleBucket, EventAdapterService, EPStatementHandle) - Constructor for class net.esper.pattern.PatternContext
Constructor.
patternExpression() - Method in class net.esper.eql.generated.EQLStatementParser
 
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.
patternOp(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
PatternStarter - Interface in net.esper.pattern
Interface for observing when an event expression needs to start (by adding the first listener).
PatternStopCallback - Interface in net.esper.pattern
Interface for executing a stop on an active event expression.
PatternStreamSpec - Class in net.esper.eql.spec
Specification for building an event stream out of a pattern statement and views staggered onto the pattern statement.
PatternStreamSpec(EvalNode, Map<String, EventType>, List<ViewSpec>, String) - Constructor for class net.esper.eql.spec.PatternStreamSpec
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.
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 interface net.esper.eql.db.PollExecStrategy
Poll events using the keys provided.
poll(Object[]) - Method in class net.esper.eql.db.PollExecStrategyDBQuery
 
poll(EventBean[][]) - Method in class net.esper.eql.db.PollingViewable
 
poll(EventBean[][]) - 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.
PollingViewable - 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.
PollingViewable(int, List<String>, PollExecStrategy, DataCache, EventType) - Constructor for class net.esper.eql.db.PollingViewable
Ctor.
PollingViewableFactory - Class in net.esper.eql.db
Factory for a view onto historical data via SQL statement.
PollingViewableFactory() - Constructor for class net.esper.eql.db.PollingViewableFactory
 
PREVIOUS - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
PREVIOUS - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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 - 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(boolean) - Constructor for class net.esper.view.internal.PriorEventViewFactory
Ctor.
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.
process(EventBean[], boolean) - Method in class net.esper.eql.core.SelectExprEvalProcessor
 
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.OutputProcessView
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
 
Property - Interface in net.esper.event.property
Interface for a property of an event of type BeanEventType (JavaBean event).
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
 
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
 
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.
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.
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.
put(K, V) - Method in class net.esper.collection.RefCountedMap
Add and key and value with a reference count as one.
put(Object[], List<EventBean>) - 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[], List<EventBean>) - Method in class net.esper.eql.db.DataCacheExpiringImpl
 
put(Object[], List<EventBean>) - Method in class net.esper.eql.db.DataCacheLRUImpl
Adds an entry to this cache.
put(Object[], List<EventBean>) - Method in class net.esper.eql.db.DataCacheNullImpl
 
put(Object, EventEvaluator) - Method in class net.esper.filter.FilterParamIndex
Store the event evaluation instance for the given constant.
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.FilterParamIndexRange
 

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.
QueryGraph.GraphKey - Class in net.esper.eql.join.plan
Key consisting of 2 integer stream numbers.
QueryGraph.GraphKey(int, int) - Constructor for class net.esper.eql.join.plan.QueryGraph.GraphKey
Ctor.
QueryGraph.GraphValue - Class in net.esper.eql.join.plan
Property lists stored as a value for each stream-to-stream relationship.
QueryGraph.GraphValue() - Constructor for class net.esper.eql.join.plan.QueryGraph.GraphValue
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[][]) - 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.
rangeOperand() - Method in class net.esper.eql.generated.EQLStatementParser
 
RangeParameter - Class in net.esper.eql.parse
Represents a range of numbers as a parameter.
RangeParameter(int, int) - Constructor for class net.esper.eql.parse.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.
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
 
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.
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.
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
 
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() - Constructor for class net.esper.view.stat.RegressionLinestView
Default constructor - required by all views to adhere to the Java bean specification.
RegressionLinestView(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
 
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.
RELEASE_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
 
RELEASED_TEXT - Static variable in class net.esper.util.ManagedReadWriteLock
 
releaseLock() - Method in class net.esper.util.ManagedLock
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.ArrayBackedCollection
 
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.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() - Method in class net.esper.collection.TimeWindowIterator
 
remove() - Method in class net.esper.collection.TransformEventIterator
 
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(EventBean[]) - Method in class net.esper.eql.join.table.UnindexedEventTable
 
remove(FilterHandle) - Method in class net.esper.filter.EventTypeIndexBuilder
Remove a filter callback from the given index node.
remove(FilterParamIndex) - 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.FilterParamIndex
Remove the event evaluation instance for the given constant.
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.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.view.ext.SortWindowIterator
 
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
 
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.EPStatementSupport
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.
removeDuplicateProperties(List<EventPropertyDescriptor>) - Static method in class net.esper.event.property.PropertyHelper
Removed duplicate properties using the property name to find unique properties.
removeFirst() - Method in class net.esper.filter.IndexTreePath
Remove and return first index.
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 an listener that observes events.
removeListener(UpdateListener) - Method in class net.esper.core.EPStatementSupport
Remove a listeners to a statement.
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.
removeView(View) - Method in class net.esper.eql.db.PollingViewable
 
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
 
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.
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
 
reset() - Method in class net.esper.client.Configuration
Reset to an empty configuration.
resetPattern(String) - Method in class net.esper.util.LikeUtil
Resets the search pattern.
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.AutoImportService
Gets the Class object for the class name.
resolveClass(String) - Method in class net.esper.eql.core.AutoImportServiceImpl
 
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[], AutoImportService) - Static method in class net.esper.util.StaticMethodResolver
Attempts to find the static method described by the parameters, or a method of the same name that will accept the same type of parameters.
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.
ResultSetProcessor - Interface in net.esper.eql.core
Processor for result sets coming from 2 sources.
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.
retainAll(Collection) - Method in class net.esper.collection.ArrayBackedCollection
 
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
 
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.
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.
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) - Method in class net.esper.core.EPRuntimeImpl
 
route(EventBean) - Method in interface net.esper.core.InternalEventRouter
Route the event such that the event is processed as required.
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

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() - Method in class net.esper.eql.db.DataCacheExpiringImpl
 
scheduledTrigger() - Method in class net.esper.pattern.guard.TimerWithinGuard
 
scheduledTrigger() - Method in class net.esper.pattern.observer.TimerAtObserver
 
scheduledTrigger() - Method in class net.esper.pattern.observer.TimerIntervalObserver
 
scheduledTrigger() - 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.
ScheduleServiceException - Exception in net.esper.schedule
This exception is thrown to indicate a problem with scheduling, such as trying to add a scheduling callback that already existed or trying to remove one that didn't exist.
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.schedule
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(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
selectClause() - Method in class net.esper.eql.generated.EQLStatementParser
 
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<SelectExprElementUnnamedSpec>) - 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.
SelectExprElementNamedSpec - 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.
SelectExprElementNamedSpec(ExprNode, String) - Constructor for class net.esper.eql.spec.SelectExprElementNamedSpec
Ctor.
SelectExprElementUnnamedSpec - 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.
SelectExprElementUnnamedSpec(ExprNode, String) - Constructor for class net.esper.eql.spec.SelectExprElementUnnamedSpec
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<SelectExprElementNamedSpec>, InsertIntoDesc, boolean, StreamTypeService, EventAdapterService) - Constructor for class net.esper.eql.core.SelectExprEvalProcessor
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
 
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.TimeBatchView
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
 
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.
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.
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
 
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 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
 
setCatalog(String) - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Sets the name of the catalog on new database connections.
setCodeGeneration(ConfigurationEventTypeLegacy.CodeGeneration) - Method in class net.esper.client.ConfigurationEventTypeLegacy
Sets the code generation flags.
setColumnField(String) - Method in class net.esper.view.stat.MultiDimStatsView
Sets the name of the field to extract the column values from.
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.
setCube(Cube) - Method in class net.esper.indicator.jmx.JMXLastCubeElementDynamicMBean
Set the cube to display.
setCurrentRow(MultiKeyUntyped) - Method in interface net.esper.eql.core.AggregationService
Set the current aggregation state row - for use when evaluation nodes are asked to evaluate.
setCurrentRow(MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceGroupAllImpl
 
setCurrentRow(MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceGroupByImpl
 
setCurrentRow(MultiKeyUntyped) - Method in class net.esper.eql.core.AggregationServiceNull
 
setDataSourceConnection(String, Properties) - Method in class net.esper.client.ConfigurationDBRef
Sets the connection factory to use DataSource to obtain a connection.
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.
setDerivedMeasures(String[]) - Method in class net.esper.view.stat.MultiDimStatsView
Sets the names of measures to derive from facts.
setDimension(Dimension) - Method in class net.esper.view.stat.olap.DimensionMemberImpl
Set the dimension this member belongs to.
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.
setEvents(Set<EventBean>) - Method in class net.esper.eql.join.rep.Node
Store lookup results.
setEventType(EventType) - Method in class net.esper.view.std.AddPropertyValueView
 
setEventType(EventType) - Method in class net.esper.view.std.MergeView
Sets event type - required for successful view copy.
setExpiryTimeCache(double, double) - Method in class net.esper.client.ConfigurationDBRef
Configures an expiry-time cache of the given maximum age in seconds and pruge 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.
setFieldName(String) - Method in class net.esper.view.stat.UnivariateStatisticsView
Set the field name of the field to report statistics on.
setFieldNameWeight(String) - Method in class net.esper.view.stat.WeightedAverageView
Sets the name of the field supplying the weight values.
setFieldNameX(String) - Method in class net.esper.view.stat.BaseBivariateStatisticsView
Sets the field name of the X data column.
setFieldNameX(String) - Method in class net.esper.view.stat.WeightedAverageView
Sets the name of the field supplying the X values.
setFieldNameY(String) - Method in class net.esper.view.stat.BaseBivariateStatisticsView
Sets the field name of the Y data column.
setFilterExprRootNode(ExprNode) - Method in class net.esper.eql.spec.StatementSpec
Sets the where clause filter expression node.
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
 
setGroupFieldNames(String[]) - Method in class net.esper.view.std.GroupByView
Sets the field name that provides the key valie by which to group by.
setGroupFieldNames(String[]) - Method in class net.esper.view.std.MergeView
Sets the field name that contains the values to group by.
setHavingExprRootNode(ExprNode) - Method in class net.esper.eql.spec.StatementSpec
Sets the having-clause filter expression node.
setInitialReferencePoint(Long) - Method in class net.esper.view.window.TimeBatchView
Sets the reference point to use to anchor interval start and end dates to.
setInsertIntoDesc(InsertIntoDesc) - Method in class net.esper.eql.spec.StatementSpec
Sets the definition for any insert-into clause.
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.
setIsDescendingValues(Boolean[]) - Method in class net.esper.view.ext.SortWindowView
Set the sort order for the sort properties.
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.
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.
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
 
setLRUCache(int) - Method in class net.esper.client.ConfigurationDBRef
Configures a LRU cache of the given size for the database.
setMeasureField(String) - Method in class net.esper.view.stat.MultiDimStatsView
Sets the name of the field to extract the measure values from.
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
 
setMillisecondsBeforeExpiry(long) - Method in class net.esper.view.window.ExternallyTimedWindowView
Sets the window size in milliseconds.
setMillisecondsBeforeExpiry(long) - Method in class net.esper.view.window.TimeWindowView
Sets the size of the time window in millisecond.
setMsecIntervalSize(long) - Method in class net.esper.view.window.TimeBatchView
Sets the interval size in milliseconds.
setNamespaceContext(XPathNamespaceContext) - Method in class net.esper.event.xml.BaseXMLEventType
Sets the namespace context for use in XPath expression resolution.
setObserver(BufferObserver) - Method in class net.esper.view.internal.BufferView
Set the observer for indicating new and old data.
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.
setOptionalSortedRandomAccess(IStreamSortedRandomAccess) - Method in class net.esper.view.ext.SortWindowView
Sets the friend handling the random access, can be null if not required.
setOutputLimitSpec(OutputLimitSpec) - Method in class net.esper.eql.spec.StatementSpec
Sets the output limiting definition.
setPageField(String) - Method in class net.esper.view.stat.MultiDimStatsView
Sets the name of the field to extract the page values from.
setParent(Node) - Method in class net.esper.eql.join.rep.Node
Sets the parent node.
setParent(Viewable) - Method in class net.esper.view.ext.SortWindowView
 
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.
setParentEvent(EventBean) - Method in class net.esper.eql.join.rep.Node
Set the parent lookup (from stream) event whose results (to stream) are stored.
setPropertyNames(String[]) - Method in class net.esper.view.std.AddPropertyValueView
Sets the field name for which to set the merge value for.
setPropertyValues(Object[]) - Method in class net.esper.view.std.AddPropertyValueView
Sets the value for the field to merge into the events coming into this view.
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.ext.SortWindowViewFactory
 
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.window.ExternallyTimedWindowViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.LengthWindowViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.TimeBatchViewFactory
 
setProvideCapability(ViewCapability, ViewResourceCallback) - Method in class net.esper.view.window.TimeWindowViewFactory
 
setReadOnly(Boolean) - Method in class net.esper.client.ConfigurationDBRef.ConnectionSettings
Indicates whether to set any new connections for this database to read-only.
setResult(List<EventBean[]>, EventBean) - Method in class net.esper.eql.join.exec.LookupInstructionExecNode.MyResultAssembler
Supplies the result list to which to add result rows.
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.
setRowField(String) - Method in class net.esper.view.stat.MultiDimStatsView
Sets the name of the field to extract the row values from.
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.
setSelectStreamDirEnum(SelectClauseStreamSelectorEnum) - Method in class net.esper.eql.spec.StatementSpec
Sets the stream selector (rstream/istream/both etc).
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
 
setSize(int) - Method in class net.esper.view.window.LengthWindowView
Sets the size of the length window.
setSortFieldNames(String[]) - Method in class net.esper.view.ext.SortWindowView
Set the names of the properties to sort on.
setSortWindowSize(int) - Method in class net.esper.view.ext.SortWindowView
Set the number of elements kept by the sort window.
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
 
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
 
setTimestampFieldName(String) - Method in class net.esper.view.window.ExternallyTimedWindowView
Sets the field name to get timestamp values from.
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.
setUniqueFieldName(String) - Method in class net.esper.view.std.UniqueByPropertyView
Sets the name of the field supplying the unique value to keep the most recent record for.
setViewParameters(List<Object>) - Method in class net.esper.view.ext.SortWindowViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.internal.PriorEventViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.stat.CorrelationViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.stat.MultiDimStatsViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.stat.RegressionLinestViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.stat.UnivariateStatisticsViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.stat.WeightedAverageViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.std.GroupByViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.std.LastElementViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.std.MergeViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.std.SizeViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.std.UniqueByPropertyViewFactory
 
setViewParameters(List<Object>) - Method in interface net.esper.view.ViewFactory
Indicates user EQL query view parameters to the view factory.
setViewParameters(List<Object>) - Method in class net.esper.view.window.ExternallyTimedWindowViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.window.LengthWindowViewFactory
 
setViewParameters(List<Object>) - Method in class net.esper.view.window.TimeBatchViewFactory
 
setViewParameters(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
 
setViewServiceContext(ViewServiceContext) - Method in interface net.esper.view.ContextAwareView
Set the services context containing service handles.
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.stat.BaseBivariateStatisticsView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.stat.MultiDimStatsView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.stat.UnivariateStatisticsView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.stat.WeightedAverageView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.std.AddPropertyValueView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.std.GroupByView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.std.MergeView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.std.SizeView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.window.TimeBatchView
 
setViewServiceContext(ViewServiceContext) - Method in class net.esper.view.window.TimeWindowView
 
setViewUpdatedCollection(IStreamRandomAccess) - Method in class net.esper.view.window.LengthWindowView
Sets the buffer for keeping a reference to prior or previous events.
setViewUpdatedCollection(IStreamRandomAccess) - Method in class net.esper.view.window.TimeBatchView
Sets the buffer for keeping a reference to prior or previous events.
setViewUpdatedCollection(IStreamRandomAccess) - Method in class net.esper.view.window.TimeWindowView
Sets the buffer for keeping a reference to prior or previous events.
shallowCopy() - Method in class net.esper.pattern.MatchedEventMap
Make a shallow copy of this collection.
shallowCopyView(View) - Static method in class net.esper.view.ViewSupport
Copies the view by copying the bean properties of the view but does not copy the views children, does not copy or set the property for the parent view.
ShortValue - Class in net.esper.type
Placeholder for a short-typed value in an event expression.
ShortValue() - Constructor for class net.esper.type.ShortValue
 
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.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.FilterParamIndex
Return the number of distinct filter parameter constants stored.
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.FilterParamIndexRange
 
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() - Constructor for class net.esper.view.std.SizeView
Constructor.
SizeViewFactory - Class in net.esper.view.std
Factory for SizeView instances.
SizeViewFactory() - Constructor for class net.esper.view.std.SizeViewFactory
 
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
 
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[], EventBean[][], boolean) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
sort(EventBean[], EventBean[][], MultiKeyUntyped[], boolean) - Method in class net.esper.eql.core.OrderByProcessorSimple
 
SortedDoubleVector - 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.
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.
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.
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() - Constructor for class net.esper.view.ext.SortWindowView
Default constructor - required by all views to adhere to the Java bean specification.
SortWindowView(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
 
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
 
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.EPEQLStatementImpl
 
start() - Method in class net.esper.core.EPEQLStmtStartMethod
Starts the EQL statement.
start() - Method in class net.esper.core.EPPatternStatementImpl
 
start(PatternMatchCallback) - Method in class net.esper.core.EPPatternStmtStartMethod
Start pattern.
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.
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
 
StatementSpec - Class in net.esper.eql.spec
Specification object representing a complete EQL statement including all EQL constructs.
StatementSpec() - Constructor for class net.esper.eql.spec.StatementSpec
 
StaticMethodResolver - Class in net.esper.util
Used for retrieving static method objects.
StaticMethodResolver() - Constructor for class net.esper.util.StaticMethodResolver
 
statisticsBean - Variable in class net.esper.view.stat.BaseBivariateStatisticsView
This bean can be overridden by subclasses providing extra values such as correlation, regression.
STDDEV - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
STDDEV - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
stop() - Method in interface net.esper.client.EPStatement
Stop the statement.
stop() - Method in class net.esper.core.EPEQLStatementImpl
 
stop() - Method in class net.esper.core.EPPatternStatementImpl
 
stop() - Method in interface net.esper.core.EPStatementStopMethod
Stops a statement.
stop() - Method in class net.esper.eql.db.PollingViewable
 
stop() - Method in class net.esper.pattern.EvalRootStateNode
 
stop() - Method in interface net.esper.util.StopCallback
Stops the underlying resources.
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_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
 
StreamFactorySvcCreate - Class in net.esper.view.stream
Service implementation to create a new event stream and register newly with the filter service.
StreamFactorySvcCreate() - Constructor for class net.esper.view.stream.StreamFactorySvcCreate
Ctor.
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() - Constructor for class net.esper.view.stream.StreamFactorySvcImpl
Ctor.
StreamFactorySvcReuse - Class in net.esper.view.stream
Service implementation to reuse event streams and existing filters using reference counting to remove filters when not used.
StreamFactorySvcReuse() - Constructor for class net.esper.view.stream.StreamFactorySvcReuse
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.
StreamSpec - 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.
StreamSpec(String, List<ViewSpec>) - Constructor for class net.esper.eql.spec.StreamSpec
Ctor.
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.
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.
SUM - Static variable in interface net.esper.eql.generated.EqlEvalTokenTypes
 
SUM - Static variable in interface net.esper.eql.generated.EqlTokenTypes
 
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.
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.
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
 
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
 
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() - Constructor for class net.esper.view.window.TimeBatchView
Default constructor - required by all views to adhere to the Java bean specification.
TimeBatchView(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
 
timePeriodDef(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
TimePeriodParameter - Class in net.esper.eql.parse
Parameter for views that accept time period information such as "5 sec 100 msec".
TimePeriodParameter(double) - Constructor for class net.esper.eql.parse.TimePeriodParameter
Ctor.
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(Object[]) - Constructor for class net.esper.pattern.observer.TimerAtObserverFactory
Ctor.
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
 
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.
TimerObserverFactory - Class in net.esper.pattern.observer
Factory for making observer instances.
TimerObserverFactory(ScheduleSpec) - Constructor for class net.esper.pattern.observer.TimerObserverFactory
Ctor.
TimerObserverFactory(int) - Constructor for class net.esper.pattern.observer.TimerObserverFactory
Ctor.
TimerObserverFactory(double) - Constructor for class net.esper.pattern.observer.TimerObserverFactory
Ctor.
TimerObserverFactory(TimePeriodParameter) - Constructor for class net.esper.pattern.observer.TimerObserverFactory
Ctor.
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() - Constructor for class net.esper.timer.TimerServiceImpl
Constructor.
TimerServiceProvider - Class in net.esper.timer
Static factory for implementations of the TimerService interface.
TimerServiceProvider() - Constructor for class net.esper.timer.TimerServiceProvider
 
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(int) - Constructor for class net.esper.pattern.guard.TimerWithinGuardFactory
Creates a timer guard.
TimerWithinGuardFactory(double) - Constructor for class net.esper.pattern.guard.TimerWithinGuardFactory
Creates a timer guard.
TimerWithinGuardFactory(long) - Constructor for class net.esper.pattern.guard.TimerWithinGuardFactory
Creates a timer guard.
TimerWithinGuardFactory(TimePeriodParameter) - Constructor for class net.esper.pattern.guard.TimerWithinGuardFactory
Creates a timer guard.
TimeWindow - Class in net.esper.collection
Container for events per time slot.
TimeWindow() - 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() - Constructor for class net.esper.view.window.TimeWindowView
Default constructor - required by all views to adhere to the Java bean specification.
TimeWindowView(long, ViewUpdatedCollection) - 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(Object[]) - Method in class net.esper.collection.ArrayBackedCollection
 
toArray(List<EventBean>) - Static method in class net.esper.event.EventBeanUtility
Convert list of events to array, returning null for empty or null lists.
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.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.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.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.ExprRegexpNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
toExpressionString() - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
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.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.eql.db.DBOutputTypeDesc
 
toString() - Method in class net.esper.eql.expression.ExprIdentNode
 
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.GraphKey
 
toString() - Method in class net.esper.eql.join.plan.QueryGraph.GraphValue
 
toString() - Method in class net.esper.eql.join.plan.QueryGraph
 
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.view.OutputConditionCount
 
toString() - Method in class net.esper.eql.view.OutputConditionTime
 
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.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.FilterParamIndex
 
toString() - Method in class net.esper.filter.FilterSpec
 
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.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.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.MatchedEventMap
 
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.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.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.ViewSpec
 
toString() - Method in class net.esper.view.window.ExternallyTimedWindowView
 
toString() - Method in class net.esper.view.window.LengthWindowView
 
toString() - Method in class net.esper.view.window.TimeBatchView
 
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.view.OutputProcessView.OutputProcessTransform
 
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.
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
 
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.
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() - Constructor for class net.esper.view.std.UniqueByPropertyView
Default constructor - required by all views to adhere to the Java bean specification.
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
 
UniqueValueAggregator - Class in net.esper.eql.core
Aggregator for use on top of another aggregator that handles unique value aggregation (versus all-value aggregation) for the underlying aggregator.
UniqueValueAggregator(Aggregator) - Constructor for class net.esper.eql.core.UniqueValueAggregator
Ctor.
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() - Constructor for class net.esper.view.stat.UnivariateStatisticsView
Default constructor - required by all views to adhere to the Java bean specification.
UnivariateStatisticsView(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
 
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.UpdateDispatchView
 
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.OutputProcessView
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.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.LengthWindowView
 
update(EventBean[], EventBean[]) - Method in class net.esper.view.window.TimeBatchView
 
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.
UpdateDispatchView - Class in net.esper.core
Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
UpdateDispatchView(Set<UpdateListener>, DispatchService) - Constructor for class net.esper.core.UpdateDispatchView
Ctor.
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
 

V

validate(StreamTypeService) - Method in class net.esper.eql.db.PollingViewable
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprAndNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprAvedevNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprAvgNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprBetweenNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprBitWiseNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprCaseNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprCoalesceNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprConcatNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprConstantNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprCountNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprEqualsNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprIdentNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprInNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprLikeNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprMathNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprMedianNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprMinMaxAggrNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprMinMaxRowNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprNotNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprOrNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprPreviousNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprPriorNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprRegexpNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprRelationalOpNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprStaticMethodNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprStddevNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in class net.esper.eql.expression.ExprSumNode
 
validate(StreamTypeService, AutoImportService, ViewResourceDelegate) - Method in interface net.esper.eql.expression.ExprValidator
Validate node.
validate(Map<String, EventType>) - Method in interface net.esper.filter.FilterSpecParamInValue
Check the type of the property against the map of event tag and type.
validate(FilterSpec, Map<String, EventType>) - Static method in class net.esper.filter.FilterSpecValidator
Validates a filter specification.
validate(Map<String, EventType>) - Method in class net.esper.filter.InSetOfValuesConstant
 
validate(Map<String, EventType>) - Method in class net.esper.filter.InSetOfValuesEventProp
 
validate(Map<ScheduleUnit, SortedSet<Integer>>) - Static method in class net.esper.schedule.ScheduleSpec
Validate units and their value sets.
validate(StreamTypeService) - Method in interface net.esper.view.ValidatedView
Validate the view.
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.
valueExpr(AST) - Method in class net.esper.eql.generated.EQLBaseWalker
 
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.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.time.TimerControlEvent.ClockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.esper.eql.spec.OutputLimitSpec.DisplayLimit
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.schedule.ScheduleUnit
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.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.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.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.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.time.TimerControlEvent.ClockType
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.OutputLimitSpec.DisplayLimit
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.schedule.ScheduleUnit
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.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.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.
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<SelectExprElementNamedSpec>) - Static method in class net.esper.eql.core.SelectExprProcessorFactory
Verify that each given name occurs exactly one.
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(Integer) - 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.
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.
ViewFactoryFactory - Class in net.esper.view
Static factory for creating view instances based on a view specification and a given parent view.
ViewFactoryFactory() - Constructor for class net.esper.view.ViewFactoryFactory
 
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.
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[]) - Constructor for class net.esper.eql.core.ViewResourceDelegateImpl
Ctor.
ViewService - Interface in net.esper.view
Service interface for creating views.
viewServiceContext - Variable in class net.esper.view.stat.BaseBivariateStatisticsView
Services required by implementing classes.
ViewServiceContext - Class in net.esper.view
Contains handles to the implementation of the the scheduling service for use in view evaluation.
ViewServiceContext(SchedulingService, ScheduleBucket, EventAdapterService, EPStatementHandle) - Constructor for class net.esper.view.ViewServiceContext
Constructor.
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.view
Encapsulates the information required to specify a object construction.
ViewSpec(String, String, List<Object>) - Constructor for class net.esper.view.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 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.
WeightedAverageView - Class in net.esper.view.stat
View for computing a weighted average.
WeightedAverageView() - Constructor for class net.esper.view.stat.WeightedAverageView
Default constructor - required by all views to adhere to the Java bean specification.
WeightedAverageView(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.eql.parse
Represents a wildcard as a parameter.
WildcardParameter() - Constructor for class net.esper.eql.parse.WildcardParameter
 
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(EventType, Map<String, Class>, EventAdapterService) - Constructor for class net.esper.event.WrapperEventType
Ctor.
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_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_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.EQLStatementLexer
 
_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 _