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

N

n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.CreateIndexExprContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.CreateVariableExprContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalRelationalExpressionContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.GopConfigContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.GopOutItemContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.GopParamsItemContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.OnExprFromContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.OnMergeExprContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.OnUpdateExprContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.PropertyExpressionAnnotationContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.PropertyExpressionAtomicContext
 
n - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.QualifyExpressionContext
 
n1 - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RangeOperandContext
 
n1 - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RowLimitContext
 
n2 - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RangeOperandContext
 
n2 - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RowLimitContext
 
Name - Annotation Type in com.espertech.esper.client.annotation
Annotation for use in EPL statement to define a statement name.
name - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ContextContextNestedContext
 
name - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.CreateContextExprContext
 
name - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.CreateDataflowContext
 
name - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.CreateSchemaDefContext
 
name - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ExpressionDeclContext
 
name() - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.VirtualMachineMetrics
Returns the name of the currently-running jvm.
name(String, String, Class) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.MetricNameFactory
 
name(String, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.MetricNameFactory
 
NAME - Static variable in class com.espertech.esper.view.std.FirstElementViewFactory
 
NAME - Static variable in class com.espertech.esper.view.std.FirstUniqueByPropertyViewFactory
 
NAME - Static variable in class com.espertech.esper.view.std.LastElementViewFactory
 
NAME - Static variable in class com.espertech.esper.view.std.UniqueByPropertyViewFactory
 
NamedWindowConsumerCallback - Interface in com.espertech.esper.epl.named
 
NamedWindowConsumerDesc - Class in com.espertech.esper.epl.named
 
NamedWindowConsumerDesc(List<ExprNode>, PropertyEvaluator, AgentInstanceContext) - Constructor for class com.espertech.esper.epl.named.NamedWindowConsumerDesc
 
NamedWindowConsumerDispatchUnit - Class in com.espertech.esper.epl.named
Holds a unit of dispatch that is a result of a named window processing incoming or timer events.
NamedWindowConsumerDispatchUnit(NamedWindowDeltaData, Map<EPStatementAgentInstanceHandle, List<NamedWindowConsumerView>>) - Constructor for class com.espertech.esper.epl.named.NamedWindowConsumerDispatchUnit
Ctor.
NamedWindowConsumerStreamSpec - Class in com.espertech.esper.epl.spec
Specification for use of an existing named window.
NamedWindowConsumerStreamSpec(String, String, ViewSpec[], List<ExprNode>, StreamSpecOptions, PropertyEvaluator) - Constructor for class com.espertech.esper.epl.spec.NamedWindowConsumerStreamSpec
Ctor.
NamedWindowConsumerView - Class in com.espertech.esper.epl.named
Represents a consumer of a named window that selects from a named window via a from-clause.
NamedWindowConsumerView(ExprEvaluator[], PropertyEvaluator, EventType, NamedWindowConsumerCallback, ExprEvaluatorContext, boolean) - Constructor for class com.espertech.esper.epl.named.NamedWindowConsumerView
Ctor.
NamedWindowDeltaData - Class in com.espertech.esper.epl.named
A holder for events posted by a named window as an insert and remove stream.
NamedWindowDeltaData(EventBean[], EventBean[]) - Constructor for class com.espertech.esper.epl.named.NamedWindowDeltaData
Ctor.
NamedWindowDeltaData(NamedWindowDeltaData, NamedWindowDeltaData) - Constructor for class com.espertech.esper.epl.named.NamedWindowDeltaData
Ctor aggregates two deltas into a single delta.
NamedWindowIndexRepEntry - Class in com.espertech.esper.epl.named
 
NamedWindowIndexRepEntry(EventTable, String, int) - Constructor for class com.espertech.esper.epl.named.NamedWindowIndexRepEntry
 
NamedWindowIndexRepository - Class in com.espertech.esper.epl.named
A repository of index tables for use with a single named window and all it's deleting statements that may use the indexes to correlate triggering events with indexed events of the named window.
NamedWindowIndexRepository() - Constructor for class com.espertech.esper.epl.named.NamedWindowIndexRepository
Ctor.
NamedWindowLifecycleEvent - Class in com.espertech.esper.epl.named
Event indicating named window lifecycle management.
NamedWindowLifecycleEvent.LifecycleEventType - Enum in com.espertech.esper.epl.named
Event types.
NamedWindowLifecycleObserver - Interface in com.espertech.esper.epl.named
Observer named window events.
NamedWindowLookupStrategy - Interface in com.espertech.esper.epl.named
A deletion strategy is for use with named window in on-delete statements and encapsulates the strategy for resolving one or more events arriving in the on-clause of an on-delete statement to one or more events to be deleted from the named window.
NamedWindowLookupStrategyAllRows - Class in com.espertech.esper.epl.named
Deletes from a named window all events simply using the named window's data window iterator.
NamedWindowLookupStrategyAllRows(Iterable<EventBean>) - Constructor for class com.espertech.esper.epl.named.NamedWindowLookupStrategyAllRows
Ctor.
NamedWindowLookupStrategyIndexed - Class in com.espertech.esper.epl.named
Uses an index to determine event to be deleted or selected from a named window.
NamedWindowLookupStrategyIndexed(ExprEvaluator, SubordTableLookupStrategy) - Constructor for class com.espertech.esper.epl.named.NamedWindowLookupStrategyIndexed
Ctor.
NamedWindowLookupStrategyIndexedUnfiltered - Class in com.espertech.esper.epl.named
Uses an index to determine event to be deleted or selected from a named window.
NamedWindowLookupStrategyIndexedUnfiltered(SubordTableLookupStrategy) - Constructor for class com.espertech.esper.epl.named.NamedWindowLookupStrategyIndexedUnfiltered
Ctor.
NamedWindowLookupStrategyTableScan - Class in com.espertech.esper.epl.named
Determine events to be deleted from a named window using the where-clause and full table scan.
NamedWindowLookupStrategyTableScan(ExprEvaluator, Iterable<EventBean>) - Constructor for class com.espertech.esper.epl.named.NamedWindowLookupStrategyTableScan
Ctor.
NamedWindowLookupStrategyType - Enum in com.espertech.esper.epl.named
 
NamedWindowOnDeleteView - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnDeleteView(NamedWindowLookupStrategy, NamedWindowRootViewInstance, ExprEvaluatorContext, NamedWindowOnDeleteViewFactory) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnDeleteView
 
NamedWindowOnDeleteViewFactory - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnDeleteViewFactory(EventType, StatementResultService) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnDeleteViewFactory
 
namedWindowOnExpr(QueryPlanIndexDescOnExpr) - Method in interface com.espertech.esper.epl.join.util.QueryPlanIndexHook
 
NamedWindowOnExprBaseView - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnExprBaseView(NamedWindowLookupStrategy, NamedWindowRootViewInstance, ExprEvaluatorContext) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnExprBaseView
Ctor.
NamedWindowOnExprBaseViewFactory - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnExprFactory - Interface in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnExprFactoryFactory - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnExprFactoryFactory() - Constructor for class com.espertech.esper.epl.named.NamedWindowOnExprFactoryFactory
 
NamedWindowOnMergeAction - Class in com.espertech.esper.epl.named
 
NamedWindowOnMergeActionDel - Class in com.espertech.esper.epl.named
 
NamedWindowOnMergeActionDel(ExprEvaluator) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeActionDel
 
NamedWindowOnMergeActionIns - Class in com.espertech.esper.epl.named
 
NamedWindowOnMergeActionIns(ExprEvaluator, SelectExprProcessor, InternalEventRouter, EPStatementHandle, InternalEventRouteDest, boolean) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeActionIns
 
NamedWindowOnMergeActionUpd - Class in com.espertech.esper.epl.named
 
NamedWindowOnMergeActionUpd(ExprEvaluator, NamedWindowUpdateHelper) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeActionUpd
 
NamedWindowOnMergeHelper - Class in com.espertech.esper.epl.named
Factory for handles for updates/inserts/deletes/select
NamedWindowOnMergeHelper(StatementContext, OnTriggerMergeDesc, EventType, String, InternalEventRouter, String, EventTypeSPI) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeHelper
 
NamedWindowOnMergeMatch - Class in com.espertech.esper.epl.named
 
NamedWindowOnMergeMatch(ExprNode, List<NamedWindowOnMergeAction>) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeMatch
 
NamedWindowOnMergeView - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnMergeView(NamedWindowLookupStrategy, NamedWindowRootViewInstance, ExprEvaluatorContext, NamedWindowOnMergeViewFactory) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeView
 
NamedWindowOnMergeViewFactory - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnMergeViewFactory(EventType, NamedWindowOnMergeHelper, StatementResultService, StatementMetricHandle, MetricReportingService) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnMergeViewFactory
 
NamedWindowOnSelectView - Class in com.espertech.esper.epl.named
View for the on-select statement that handles selecting events from a named window.
NamedWindowOnSelectView(NamedWindowLookupStrategy, NamedWindowRootViewInstance, ExprEvaluatorContext, NamedWindowOnSelectViewFactory, ResultSetProcessor, boolean, boolean) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnSelectView
 
NamedWindowOnSelectViewFactory - Class in com.espertech.esper.epl.named
View for the on-select statement that handles selecting events from a named window.
NamedWindowOnSelectViewFactory(EventType, InternalEventRouter, boolean, EPStatementHandle, EventBeanReader, boolean, EventType, StatementResultService, InternalEventRouteDest, boolean) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnSelectViewFactory
 
NamedWindowOnUpdateView - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnUpdateView(NamedWindowLookupStrategy, NamedWindowRootViewInstance, ExprEvaluatorContext, NamedWindowOnUpdateViewFactory) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnUpdateView
 
NamedWindowOnUpdateViewFactory - Class in com.espertech.esper.epl.named
View for the on-delete statement that handles removing events from a named window.
NamedWindowOnUpdateViewFactory(EventType, StatementResultService, NamedWindowUpdateHelper) - Constructor for class com.espertech.esper.epl.named.NamedWindowOnUpdateViewFactory
 
NamedWindowProcessor - Class in com.espertech.esper.epl.named
An instance of this class is associated with a specific named window.
NamedWindowProcessor(String, NamedWindowService, String, boolean, EventType, StatementResultService, ValueAddEventProcessor, String, String, boolean, boolean, boolean, MetricReportingService, boolean, boolean, StatementMetricHandle, Set<String>, String) - Constructor for class com.espertech.esper.epl.named.NamedWindowProcessor
Ctor.
NamedWindowProcessorInstance - Class in com.espertech.esper.epl.named
An instance of this class is associated with a specific named window.
NamedWindowProcessorInstance(Integer, NamedWindowProcessor, AgentInstanceContext) - Constructor for class com.espertech.esper.epl.named.NamedWindowProcessorInstance
 
NamedWindowRootView - Class in com.espertech.esper.epl.named
The root window in a named window plays multiple roles: It holds the indexes for deleting rows, if any on-delete statement requires such indexes.
NamedWindowRootView(ValueAddEventProcessor, boolean, MetricReportingService, EventType, boolean, boolean, Set<String>) - Constructor for class com.espertech.esper.epl.named.NamedWindowRootView
 
NamedWindowRootViewInstance - Class in com.espertech.esper.epl.named
The root window in a named window plays multiple roles: It holds the indexes for deleting rows, if any on-delete statement requires such indexes.
NamedWindowRootViewInstance(NamedWindowRootView, AgentInstanceContext) - Constructor for class com.espertech.esper.epl.named.NamedWindowRootViewInstance
 
NamedWindowSelectedProps - Class in com.espertech.esper.core.service
Selected properties for a create-window expression in the model-after syntax.
NamedWindowSelectedProps(Class, String, EventType) - Constructor for class com.espertech.esper.core.service.NamedWindowSelectedProps
Ctor.
NamedWindowService - Interface in com.espertech.esper.epl.named
Service to manage named window dispatches, locks and processors on an engine level.
NamedWindowServiceImpl - Class in com.espertech.esper.epl.named
This service hold for each named window a dedicated processor and a lock to the named window.
NamedWindowServiceImpl(SchedulingService, StatementLockFactory, VariableService, boolean, ManagedReadWriteLock, ExceptionHandlingService, boolean, MetricReportingService) - Constructor for class com.espertech.esper.epl.named.NamedWindowServiceImpl
Ctor.
NamedWindowSubqueryStopCallback - Class in com.espertech.esper.epl.named
 
NamedWindowSubqueryStopCallback(NamedWindowProcessorInstance, SubordTableLookupStrategy) - Constructor for class com.espertech.esper.epl.named.NamedWindowSubqueryStopCallback
 
NamedWindowTailView - Class in com.espertech.esper.epl.named
This view is hooked into a named window's view chain as the last view and handles dispatching of named window insert and remove stream results via NamedWindowService to consuming statements.
NamedWindowTailView(EventType, NamedWindowService, StatementResultService, ValueAddEventProcessor, boolean, boolean) - Constructor for class com.espertech.esper.epl.named.NamedWindowTailView
 
NamedWindowTailViewInstance - Class in com.espertech.esper.epl.named
This view is hooked into a named window's view chain as the last view and handles dispatching of named window insert and remove stream results via NamedWindowService to consuming statements.
NamedWindowTailViewInstance(NamedWindowRootViewInstance, NamedWindowTailView, AgentInstanceContext) - Constructor for class com.espertech.esper.epl.named.NamedWindowTailViewInstance
 
NamedWindowUpdateHelper - Class in com.espertech.esper.epl.named
 
NamedWindowUpdateHelper(EventBeanCopyMethod, NamedWindowUpdateItem[]) - Constructor for class com.espertech.esper.epl.named.NamedWindowUpdateHelper
 
NamedWindowUpdateItem - Class in com.espertech.esper.epl.named
 
NamedWindowUpdateItem(ExprEvaluator, String, EventPropertyWriter, boolean, TypeWidener) - Constructor for class com.espertech.esper.epl.named.NamedWindowUpdateItem
 
NamedWindowUtil - Class in com.espertech.esper.epl.named
 
NamedWindowUtil() - Constructor for class com.espertech.esper.epl.named.NamedWindowUtil
 
NameParameterCountKey - Class in com.espertech.esper.collection
A hash key that include a name and a count, wherein the combination of name and count defines the uniqueness.
NameParameterCountKey(String, int) - Constructor for class com.espertech.esper.collection.NameParameterCountKey
 
NamespaceNamePair - Class in com.espertech.esper.event.xml
Pair of namespace and name.
NamespaceNamePair(String, String) - Constructor for class com.espertech.esper.event.xml.NamespaceNamePair
Ctor.
NativeEventType - Interface in com.espertech.esper.event
Marker interface for event types that need not transpose their property.
NaturalEventBean - Class in com.espertech.esper.event
An event that is carries multiple representations of event properties: A synthetic representation that is designed for delivery as EventBean to client UpdateListener code, and a natural representation as a bunch of Object-type properties for fast delivery to client subscriber objects via method call.
NaturalEventBean(EventType, Object[], EventBean) - Constructor for class com.espertech.esper.event.NaturalEventBean
Ctor.
ne - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalEqualsExpressionContext
 
negatedExpression() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.BitWiseExpressionContext
 
negatedExpression(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.BitWiseExpressionContext
 
negatedExpression() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NegatedExpressionContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NegatedExpressionContext
 
neq(String, Object) - Static method in class com.espertech.esper.client.soda.Expressions
Not-Equals between a property and a constant.
neq(Expression, Expression) - Static method in class com.espertech.esper.client.soda.Expressions
Not-Equals between expression results.
neqProperty(String, String) - Static method in class com.espertech.esper.client.soda.Expressions
Not-Equals between properties.
NestedGetterPair - Class in com.espertech.esper.event.util
Value-object for rendering support of a nested property value.
NestedGetterPair(EventPropertyGetter, String, RendererMeta, boolean) - Constructor for class com.espertech.esper.event.util.NestedGetterPair
Ctor.
NestedIterationExecNode - Class in com.espertech.esper.epl.join.exec.base
Execution node that performs a nested iteration over all child nodes.
NestedIterationExecNode(int[]) - Constructor for class com.espertech.esper.epl.join.exec.base.NestedIterationExecNode
Ctor.
NestedIterationNode - Class in com.espertech.esper.epl.join.plan
Plan to perform a nested iteration over child nodes.
NestedIterationNode(int[]) - Constructor for class com.espertech.esper.epl.join.plan.NestedIterationNode
Ctor.
NestedProperty - Class in com.espertech.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>) - Constructor for class com.espertech.esper.event.property.NestedProperty
Ctor.
NestedPropertyGetter - Class in com.espertech.esper.event.bean
Getter for one or more levels deep nested properties.
NestedPropertyGetter(List<EventPropertyGetter>, EventAdapterService, Class, Class) - Constructor for class com.espertech.esper.event.bean.NestedPropertyGetter
Ctor.
newAccesses(int, boolean, AggregationStateFactory[]) - Method in interface com.espertech.esper.epl.core.MethodResolutionService
 
newAccesses(int, boolean, AggregationStateFactory[], Object, Object, AggregationGroupByRollupLevel) - Method in interface com.espertech.esper.epl.core.MethodResolutionService
 
newAccesses(int, boolean, AggregationStateFactory[]) - Method in class com.espertech.esper.epl.core.MethodResolutionServiceImpl
 
newAccesses(int, boolean, AggregationStateFactory[], Object, Object, AggregationGroupByRollupLevel) - Method in class com.espertech.esper.epl.core.MethodResolutionServiceImpl
 
newAggregator() - Method in interface com.espertech.esper.client.hook.AggregationFunctionFactory
Make a new, initalized aggregation state.
newAggregators(AggregationMethodFactory[], int, Object, Object, AggregationGroupByRollupLevel) - Method in interface com.espertech.esper.epl.core.MethodResolutionService
Returns a new set of aggregators given an existing prototype-set of aggregators for a given context partition and group key.
newAggregators(AggregationMethodFactory[], int) - Method in interface com.espertech.esper.epl.core.MethodResolutionService
Returns a new set of aggregators given an existing prototype-set of aggregators for a given context partition (no groups).
newAggregators(AggregationMethodFactory[], int) - Method in class com.espertech.esper.epl.core.MethodResolutionServiceImpl
 
newAggregators(AggregationMethodFactory[], int, Object, Object, AggregationGroupByRollupLevel) - Method in class com.espertech.esper.epl.core.MethodResolutionServiceImpl
 
newAggregatorsInternal(AggregationMethodFactory[], int) - Method in class com.espertech.esper.epl.core.MethodResolutionServiceImpl
 
newAssign() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
newAssign() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.UnaryExpressionContext
 
newAssign(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.UnaryExpressionContext
 
NewAssignContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NewAssignContext
 
newChildNum(int) - Method in class com.espertech.esper.pattern.EvalStateNodeNumber
Generates a new child node number to the current node number with the given child id.
newContext(AgentInstanceContext, boolean) - Method in interface com.espertech.esper.core.context.factory.StatementAgentInstanceFactory
 
newContext(AgentInstanceContext, boolean) - Method in class com.espertech.esper.core.context.factory.StatementAgentInstanceFactoryCreateVariable
 
newContext(AgentInstanceContext, boolean) - Method in class com.espertech.esper.core.context.factory.StatementAgentInstanceFactoryCreateWindow
 
newContext(AgentInstanceContext, boolean) - Method in class com.espertech.esper.core.context.factory.StatementAgentInstanceFactoryOnTrigger
 
newContext(AgentInstanceContext, boolean) - Method in class com.espertech.esper.core.context.factory.StatementAgentInstanceFactorySelect
 
newContext(AgentInstanceContext, boolean) - Method in class com.espertech.esper.core.context.factory.StatementAgentInstanceFactoryUpdate
 
newCounter(Class<?>, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Counter and registers it under the given class and name.
newCounter(Class<?>, String, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Counter and registers it under the given class and name.
newCounter(MetricName) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Counter and registers it under the given metric name.
newCounter(Class<?>, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Counter and registers it under the given class and name.
newCounter(Class<?>, String, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Counter and registers it under the given class and name.
newCounter(MetricName) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Counter and registers it under the given metric name.
newData(int, FlushedEventBuffer, FlushedEventBuffer) - Method in class com.espertech.esper.epl.join.base.JoinExecStrategyDispatchable
 
newData(int, FlushedEventBuffer, FlushedEventBuffer) - Method in class com.espertech.esper.epl.subquery.SubselectBufferObserver
 
newData(int, FlushedEventBuffer, FlushedEventBuffer) - Method in interface com.espertech.esper.view.internal.BufferObserver
Receive new and old events from a stream.
newData(int, EventBean[], EventBean[]) - Method in class com.espertech.esper.view.internal.IntersectAsymetricView
 
newData(int, EventBean[], EventBean[]) - Method in class com.espertech.esper.view.internal.IntersectBatchView
 
newData(int, EventBean[], EventBean[]) - Method in class com.espertech.esper.view.internal.IntersectView
 
newData(int, EventBean[], EventBean[]) - Method in interface com.espertech.esper.view.internal.LastPostObserver
Receive new and old events from a stream.
newData(int, EventBean[], EventBean[]) - Method in class com.espertech.esper.view.internal.UnionAsymetricView
 
newData(int, EventBean[], EventBean[]) - Method in class com.espertech.esper.view.internal.UnionView
 
newEventPrepare(EventBean) - Method in class com.espertech.esper.rowregex.RegexPartitionStateRandomAccessImpl
Add new event.
newGauge(Class<?>, String, Gauge<T>) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Given a new Gauge, registers it under the given class and name.
newGauge(Class<?>, String, String, Gauge<T>) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Given a new Gauge, registers it under the given class and name.
newGauge(MetricName, Gauge<T>) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Given a new Gauge, registers it under the given metric name.
newGauge(Class<?>, String, Gauge<T>) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Given a new Gauge, registers it under the given class and name.
newGauge(Class<?>, String, String, Gauge<T>) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Given a new Gauge, registers it under the given class and name.
newGauge(MetricName, Gauge<T>) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Given a new Gauge, registers it under the given metric name.
newHistogram(Class<?>, String, boolean) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Histogram and registers it under the given class and name.
newHistogram(Class<?>, String, String, boolean) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Histogram and registers it under the given class, name, and scope.
newHistogram(Class<?>, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new non-biased Histogram and registers it under the given class and name.
newHistogram(Class<?>, String, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new non-biased Histogram and registers it under the given class, name, and scope.
newHistogram(MetricName, boolean) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Histogram and registers it under the given metric name.
newHistogram(Class<?>, String, boolean) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Histogram and registers it under the given class and name.
newHistogram(Class<?>, String, String, boolean) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Histogram and registers it under the given class, name, and scope.
newHistogram(MetricName, boolean) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Histogram and registers it under the given metric name.
newHistogram(Class<?>, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new non-biased Histogram and registers it under the given class and name.
newHistogram(Class<?>, String, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new non-biased Histogram and registers it under the given class, name, and scope.
newHistogram(MetricName) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new non-biased Histogram and registers it under the given metric name.
newInstance(String, String, String, ExprEvaluator) - Static method in class com.espertech.esper.epl.expression.ExprEvaluatorProxy
 
newInstance(String, String, ExprNode) - Static method in class com.espertech.esper.epl.expression.ExprNodeProxy
 
newInstance(String, String, ScheduleHandleCallback) - Static method in class com.espertech.esper.schedule.ScheduleHandleCallbackProxy
 
newInstance(String, String, String, EventStream) - Static method in class com.espertech.esper.view.stream.EventStreamProxy
 
newInstance(String, String, ViewFactory, String) - Static method in class com.espertech.esper.view.ViewFactoryProxy
 
newInstance(String, String, String, View) - Static method in class com.espertech.esper.view.ViewProxy
 
NewItem - Class in com.espertech.esper.epl.spec
 
NewItem(String, ExprNode) - Constructor for class com.espertech.esper.epl.spec.NewItem
 
NEWKW - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarLexer
 
NEWKW - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NEWKW() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.UnaryExpressionContext
 
newLatch(EventBean) - Method in class com.espertech.esper.core.service.InsertIntoLatchFactory
Returns a new latch.
newLexer(CharStream) - Static method in class com.espertech.esper.epl.parse.ParseHelper
 
newline - Static variable in class com.espertech.esper.core.deploy.EPLModuleUtil
Newline character.
newline - Static variable in class com.espertech.esper.epl.parse.ParseHelper
Newline.
newMeter(Class<?>, String, String, TimeUnit) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Meter and registers it under the given class and name.
newMeter(Class<?>, String, String, String, TimeUnit) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Meter and registers it under the given class, name, and scope.
newMeter(MetricName, String, TimeUnit) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Meter and registers it under the given metric name.
newMeter(Class<?>, String, String, TimeUnit) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Meter and registers it under the given class and name.
newMeter(Class<?>, String, String, String, TimeUnit) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Meter and registers it under the given class, name, and scope.
newMeter(MetricName, String, TimeUnit) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Meter and registers it under the given metric name.
NewOperatorExpression - Class in com.espertech.esper.client.soda
The "new" operator is useful to format an event or event property from a list of column names and expressions.
NewOperatorExpression() - Constructor for class com.espertech.esper.client.soda.NewOperatorExpression
Ctor.
NewOperatorExpression(List<String>) - Constructor for class com.espertech.esper.client.soda.NewOperatorExpression
Ctor.
newParser(CommonTokenStream) - Static method in class com.espertech.esper.epl.parse.ParseHelper
 
newParserContext() - Static method in class com.espertech.esper.epl.script.mvel.MVELInvoker
 
newResult(UniformPair<EventBean[]>) - Method in class com.espertech.esper.core.context.util.ContextMergeView
 
newResult(UniformPair<EventBean[]>) - Method in interface com.espertech.esper.core.service.UpdateDispatchView
Convenience method that accepts a pair of new and old data as this is the most treated unit.
newResult(UniformPair<EventBean[]>) - Method in class com.espertech.esper.core.service.UpdateDispatchViewBlockingSpin
 
newResult(UniformPair<EventBean[]>) - Method in class com.espertech.esper.core.service.UpdateDispatchViewBlockingWait
 
newResult(UniformPair<EventBean[]>) - Method in class com.espertech.esper.core.service.UpdateDispatchViewNonBlocking
 
newResult(UniformPair<EventBean[]>) - Method in class com.espertech.esper.dataflow.ops.epl.EPLSelectUpdateDispatchView
 
newScheduledThreadPool(int, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new scheduled thread pool of a given size with the given name, or returns an existing thread pool if one was already created with the same name.
newService() - Static method in class com.espertech.esper.dispatch.DispatchServiceProvider
Returns new service.
newService(ConfigurationEngineDefaults.FilterServiceProfile) - Static method in class com.espertech.esper.filter.FilterServiceProvider
Creates an implementation of the FilterEvaluationService interface.
newService(TimeSourceService) - Static method in class com.espertech.esper.schedule.SchedulingServiceProvider
Creates an implementation of the SchedulingService interface.
newService(String, boolean) - Static method in class com.espertech.esper.view.stream.StreamFactoryServiceProvider
Creates an implementation of the StreamFactoryService interface.
newService() - Static method in class com.espertech.esper.view.ViewServiceProvider
Creates an implementation of the ViewService interface.
newSiblingState() - Method in class com.espertech.esper.pattern.EvalStateNodeNumber
Generates a new sibling node number to the current node.
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalAndNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalAuditNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalEveryDistinctNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalEveryNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalFilterNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalFollowedByNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalGuardNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalMatchUntilNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in interface com.espertech.esper.pattern.EvalNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalNodeBase
Create the evaluation state node containing the truth value state for each operator in an event expression.
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalNotNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalObserverNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalOrNode
 
newState(Evaluator, EvalStateNodeNumber, long) - Method in class com.espertech.esper.pattern.EvalRootNode
 
newStatement(String, String, EPIsolationUnitServices) - Method in interface com.espertech.esper.core.service.StatementIsolationService
Indicates a new statement created in an isolated service.
newStatement(String, String, EPIsolationUnitServices) - Method in class com.espertech.esper.core.service.StatementIsolationServiceImpl
 
newThread(Runnable) - Method in class com.espertech.esper.core.thread.EngineThreadFactory
 
newTimer(Class<?>, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Timer and registers it under the given class and name, measuring elapsed time in milliseconds and invocations per second.
newTimer(Class<?>, String, TimeUnit, TimeUnit) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Timer and registers it under the given class and name.
newTimer(Class<?>, String, String) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Timer and registers it under the given class, name, and scope, measuring elapsed time in milliseconds and invocations per second.
newTimer(Class<?>, String, String, TimeUnit, TimeUnit) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Timer and registers it under the given class, name, and scope.
newTimer(MetricName, TimeUnit, TimeUnit) - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.MetricsRegistry
Creates a new Timer and registers it under the given metric name.
newTimer(Class<?>, String, TimeUnit, TimeUnit) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Timer and registers it under the given class and name.
newTimer(Class<?>, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Timer and registers it under the given class and name, measuring elapsed time in milliseconds and invocations per second.
newTimer(Class<?>, String, String, TimeUnit, TimeUnit) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Timer and registers it under the given class, name, and scope.
newTimer(Class<?>, String, String) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Timer and registers it under the given class, name, and scope, measuring elapsed time in milliseconds and invocations per second.
newTimer(MetricName, TimeUnit, TimeUnit) - Static method in class com.espertech.esper.metrics.codahale_metrics.metrics.Metrics
Creates a new Timer and registers it under the given metric name.
next() - Method in interface com.espertech.esper.collection.apachecommons.MapIterator
Gets the next key from the Map.
next() - Method in class com.espertech.esper.collection.ArrayBackedCollection.ArrayBackedCollectionIterator
 
next() - Method in class com.espertech.esper.collection.ArrayEventIterator
 
next() - Method in class com.espertech.esper.collection.ArrayMaxEventIterator
 
next() - Method in class com.espertech.esper.collection.EventDistinctIterator
 
next() - Method in class com.espertech.esper.collection.EventUnderlyingIterator
 
next() - Method in class com.espertech.esper.collection.IterablesArrayIterator
 
next() - Method in class com.espertech.esper.collection.IterablesListIterator
 
next() - Method in class com.espertech.esper.collection.MixedEventBeanAndCollectionIteratorBase
 
next() - Method in class com.espertech.esper.collection.NullIterator
 
next() - Method in class com.espertech.esper.collection.ReversedArrayEventIterator
 
next() - Method in class com.espertech.esper.collection.SafeIteratorImpl
 
next() - Method in class com.espertech.esper.collection.SafeIteratorNull
 
next() - Method in class com.espertech.esper.collection.SingleEventIterator
 
next() - Method in class com.espertech.esper.collection.SingleObjectIterator
 
next() - Method in class com.espertech.esper.collection.SuperIterator
 
next() - Method in class com.espertech.esper.collection.TransformEventIterator
 
next() - Method in class com.espertech.esper.core.context.mgr.AgentInstanceArrayIterator
 
next() - Method in interface com.espertech.esper.dataflow.interfaces.DataFlowSourceOperator
 
next() - Method in class com.espertech.esper.dataflow.ops.BeaconSource
 
next() - Method in class com.espertech.esper.dataflow.ops.EPStatementSource
 
next() - Method in class com.espertech.esper.dataflow.ops.EventBusSource
 
next() - Method in class com.espertech.esper.dataflow.runnables.GraphSourceRunnable
 
next() - Method in class com.espertech.esper.dataflow.util.DefaultSupportSourceOp
 
next() - Method in class com.espertech.esper.epl.core.ResultSetAggregateAllIterator
 
next() - Method in class com.espertech.esper.epl.core.ResultSetAggregateGroupedIterator
 
next() - Method in class com.espertech.esper.epl.core.ResultSetRowPerGroupIterator
 
next() - Method in class com.espertech.esper.epl.enummethod.dot.ArrayWrappingIterator
 
next() - Method in class com.espertech.esper.epl.enummethod.dot.ExprDotStaticMethodWrapArrayEvents.WrappingIterator
 
next() - Method in class com.espertech.esper.epl.join.rep.NodeCursorIterator
 
next() - Method in class com.espertech.esper.epl.join.rep.SingleCursorIterator
 
next() - Method in class com.espertech.esper.epl.join.table.PropertyIndexedEventTableIterator
 
next() - Method in class com.espertech.esper.epl.join.table.PropertySortedEventTableIterator
 
next() - Method in class com.espertech.esper.epl.named.FilteredEventIterator
 
next() - Method in class com.espertech.esper.epl.view.FilterExprViewIterator
 
next() - Method in class com.espertech.esper.util.DOMElementIterator
 
next() - Method in class com.espertech.esper.view.window.ExpressionWindowTimestampEventPairIterator
 
nextDeploymentId() - Method in interface com.espertech.esper.core.deploy.DeploymentStateService
Allocates a new deployment id.
nextDeploymentId() - Method in class com.espertech.esper.core.deploy.DeploymentStateServiceImpl
 
nextElement() - Method in class com.espertech.esper.collection.CombinationEnumeration
 
nextElement() - Method in class com.espertech.esper.collection.NumberAscCombinationEnumeration
 
nextElement() - Method in class com.espertech.esper.collection.NumberSetPermutationEnumeration
 
nextElement() - Method in class com.espertech.esper.collection.NumberSetShiftGroupEnumeration
 
nextElement() - Method in class com.espertech.esper.collection.PermutationEnumeration
 
ni - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EventPropertyAtomicContext
 
nm - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ObserverExpressionContext
 
NoCache - Annotation Type in com.espertech.esper.client.annotation
For use with EsperHA, denotes a datawindow that hold no events in memory.
NoCaseSensitiveStream - Class in com.espertech.esper.epl.parse
For use with ANTLR to create a case-insensitive token stream.
NoCaseSensitiveStream(Reader) - Constructor for class com.espertech.esper.epl.parse.NoCaseSensitiveStream
Ctor.
NOCONTEXT_AGENTINSTANCEID - Static variable in interface com.espertech.esper.epl.variable.VariableService
 
Node - Class in com.espertech.esper.epl.join.rep
Node is the structure to hold results of event lookups in joined streams.
Node(int) - Constructor for class com.espertech.esper.epl.join.rep.Node
Ctor.
NodeCursorIterator - Class in com.espertech.esper.epl.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 com.espertech.esper.epl.join.rep.NodeCursorIterator
Ctor.
NoLock - Annotation Type in com.espertech.esper.client.annotation
Annotation for use in EPL statements to suppress any statement-level locking (use with caution, see below).
nonconstEvaluator() - Method in interface com.espertech.esper.epl.expression.ExprTimePeriod
 
nonconstEvaluator() - Method in class com.espertech.esper.epl.expression.ExprTimePeriodImpl
 
nonHeapUsage() - Method in class com.espertech.esper.metrics.codahale_metrics.metrics.core.VirtualMachineMetrics
Returns the percentage of the JVM's non-heap memory (e.g., direct buffers) which is being used.
NonnumericCasterComputer(SimpleTypeCaster) - Constructor for class com.espertech.esper.epl.expression.ExprCastNode.NonnumericCasterComputer
Ctor.
NOOP_REVERSE - Static variable in class com.espertech.esper.epl.enummethod.dot.EnumMethodEnumParams
 
NOPARAM - Static variable in class com.espertech.esper.epl.datetime.eval.DatetimeMethodEnumParams
 
not(Expression) - Static method in class com.espertech.esper.client.soda.Expressions
Not expression negates the sub-expression to the not which is expected to return boolean-typed values.
not(PatternExpr) - Static method in class com.espertech.esper.client.soda.Patterns
Not-keyword pattern expression flips the truth-value of the pattern sub-expression.
NOT_EQUAL - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarLexer
 
NOT_EQUAL() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalEqualsExpressionContext
 
NOT_EQUAL(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalEqualsExpressionContext
 
NOT_EQUAL - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NOT_EXPR - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarLexer
 
NOT_EXPR() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalEqualsExpressionContext
 
NOT_EXPR(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalEqualsExpressionContext
 
NOT_EXPR() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EvalRelationalExpressionContext
 
NOT_EXPR() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.MergeUnmatchedContext
 
NOT_EXPR() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NegatedExpressionContext
 
NOT_EXPR - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NOT_EXPR() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.QualifyExpressionContext
 
NotExpression - Class in com.espertech.esper.client.soda
Negates the contained-within subexpression.
NotExpression(Expression) - Constructor for class com.espertech.esper.client.soda.NotExpression
Ctor.
NotExpression() - Constructor for class com.espertech.esper.client.soda.NotExpression
Ctor - for use to create an expression tree, without child expression.
notFilter(String) - Static method in class com.espertech.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not MyEvent" syntax.
notFilter(String, String) - Static method in class com.espertech.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not tag=MyEvent" syntax.
notFilter(Filter) - Static method in class com.espertech.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not MyEvent(vol > 100)" syntax.
notFilter(Filter, String) - Static method in class com.espertech.esper.client.soda.Patterns
Pattern not-operator and filter in combination, equivalent to the "not tag=MyEvent(vol > 100)" syntax.
notIn(String, Object...) - Static method in class com.espertech.esper.client.soda.Expressions
Not-In-expression that is equivalent to the syntax of "property not in (value, value, ...
notIn(Expression, Expression...) - Static method in class com.espertech.esper.client.soda.Expressions
Not-In-expression that is equivalent to the syntax of "property not in (value, value, ...
notLike(String, String) - Static method in class com.espertech.esper.client.soda.Expressions
SQL-Like negated (not like).
notLike(Expression, Expression) - Static method in class com.espertech.esper.client.soda.Expressions
SQL-Like negated (not like).
notLike(String, Object, String) - Static method in class com.espertech.esper.client.soda.Expressions
SQL-Like negated (not like).
notLike(Expression, Expression, Expression) - Static method in class com.espertech.esper.client.soda.Expressions
SQL-Like negated (not like).
notRegexp(Expression, Expression) - Static method in class com.espertech.esper.client.soda.Expressions
Regular expression negated (not regexp).
notRegexp(Expression, Expression, String) - Static method in class com.espertech.esper.client.soda.Expressions
Regular expression negated (not regexp).
notRegexp(String, String) - Static method in class com.espertech.esper.client.soda.Expressions
Regular expression negated (not regexp).
notRegexp(String, String, String) - Static method in class com.espertech.esper.client.soda.Expressions
Regular expression negated (not regexp).
ns - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ObserverExpressionContext
 
ns - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ViewExpressionContext
 
NStreamOuterQueryPlanBuilder - Class in com.espertech.esper.epl.join.plan
Builds a query plan for 3 or more streams in a outer join.
NStreamOuterQueryPlanBuilder() - Constructor for class com.espertech.esper.epl.join.plan.NStreamOuterQueryPlanBuilder
 
NStreamQueryPlanBuilder - Class in com.espertech.esper.epl.join.plan
Builds a query plan for 3 or more streams in a join.
NStreamQueryPlanBuilder() - Constructor for class com.espertech.esper.epl.join.plan.NStreamQueryPlanBuilder
 
NStreamQueryPlanBuilder.BestChainResult - Class in com.espertech.esper.epl.join.plan
Encapsulates the chain information.
nu - Variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ConstantContext
 
NULL_EVENT_ITER - Static variable in class com.espertech.esper.collection.SafeIteratorNull
 
NULL_EVENT_ITERATOR - Static variable in class com.espertech.esper.util.CollectionUtil
 
NullableObject<T> - Class in com.espertech.esper.util
A generic class to hold an object that may itself be a null value versus an undefined (not existing) value.
NullableObject(T) - Constructor for class com.espertech.esper.util.NullableObject
Ctor.
NullEPType - Class in com.espertech.esper.epl.rettype
 
NullEPType() - Constructor for class com.espertech.esper.epl.rettype.NullEPType
 
NullIterator<T> - Class in com.espertech.esper.collection
Iterator that never returns an elements.
NullIterator() - Constructor for class com.espertech.esper.collection.NullIterator
 
NUM_DOUBLE - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarLexer
 
NUM_DOUBLE - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NUM_FLOAT - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarLexer
 
NUM_FLOAT - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NUM_LONG - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarLexer
 
NUM_LONG - Static variable in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.Builtin_priorContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.CreateContextChoiceContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.EventPropertyAtomicContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.FrequencyOperandContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.LastOperatorContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumberconstantContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.OutputLimitAfterContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.OutputLimitContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.PatternFilterAnnotationContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RangeOperandContext
 
number(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RangeOperandContext
 
number() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.WeekDayOperatorContext
 
NumberAscCombinationEnumeration - Class in com.espertech.esper.collection
Provides an enumeration of each combination of numbers between zero and N-1 with N must be at least 1, with each combination cannot have duplicates, with each combination at least one element, with the longest combination gets returned first and the least long combination of the highest N-1 value last.
NumberAscCombinationEnumeration(int) - Constructor for class com.espertech.esper.collection.NumberAscCombinationEnumeration
 
NumberCasterComputer(SimpleTypeCaster) - Constructor for class com.espertech.esper.epl.expression.ExprCastNode.NumberCasterComputer
Ctor.
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ConstantContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.DayPartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.HourPartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.MillisecondPartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.MinutePartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.MonthPartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumericListParameterContext
 
numberconstant(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RowLimitContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.RowLimitContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.SecondPartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.WeekPartContext
 
numberconstant() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.YearPartContext
 
NumberconstantContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumberconstantContext
 
NumberContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumberContext
 
NumberSetParameter - Interface in com.espertech.esper.type
Interface to generate a set of integers from parameters that include ranges, lists and frequencies.
NumberSetPermutationEnumeration - Class in com.espertech.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 com.espertech.esper.collection.NumberSetPermutationEnumeration
Ctor.
NumberSetShiftGroupEnumeration - Class in com.espertech.esper.collection
Enumeration that first returns a round-shift-left of all numbers and when that is exhausted it returns number sets using grouped algo until exhausted.
NumberSetShiftGroupEnumeration(int[]) - Constructor for class com.espertech.esper.collection.NumberSetShiftGroupEnumeration
Ctor.
numberSetStar() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ExpressionWithTimeContext
 
numberSetStar() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NumberSetStarContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumberSetStarContext
 
numericListParameter() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
numericListParameter(int) - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumericParameterListContext
 
numericListParameter() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumericParameterListContext
 
NumericListParameterContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumericListParameterContext
 
numericParameterList() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.ExpressionWithTimeContext
 
numericParameterList() - Method in class com.espertech.esper.epl.generated.EsperEPL2GrammarParser
 
NumericParameterListContext(ParserRuleContext, int) - Constructor for class com.espertech.esper.epl.generated.EsperEPL2GrammarParser.NumericParameterListContext
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links