Uses of Interface
net.esper.event.EventBean

Packages that use EventBean
net.esper.client This package defines the central Esper Client APIs. 
net.esper.collection Internal collection classes 
net.esper.core Implementation of client package interfaces, glue code 
net.esper.eql.agg Contains aggregation service and aggregators 
net.esper.eql.core Contains EQL statement specification classes define the constructs that make up an EQL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
net.esper.eql.db Database SQL polling views and caches 
net.esper.eql.expression This package contains the EQL expression nodes that represent all expressions such as used in select clauses, group-by and having clauses, or order-by clauses 
net.esper.eql.join Join process interfaces and glue code 
net.esper.eql.join.assemble Outer join result set assembly code 
net.esper.eql.join.exec Inner join execution 
net.esper.eql.join.rep Outer join result set handling 
net.esper.eql.join.table Indexes for views 
net.esper.eql.subquery Subquery execution strategies and lookup indexes 
net.esper.eql.view Internal processing views for output rate limiting, filtering and internal event routing 
net.esper.event This package defines the Esper Client event API. 
net.esper.event.property Parsers and business objects to handle nested, indexed, mapped or generally complex properties for use in JavaBean access 
net.esper.event.xml XML event wrappers 
net.esper.filter Main switchboard filtering and routing of incoming events to interested statements is performed in this package. 
net.esper.indicator.jmx Classes for indicating events through a JMX console 
net.esper.pattern Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active pattern instance 
net.esper.view View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering. 
net.esper.view.ext Extension views that providing services such as sorting, which don't fit much into other categories. 
net.esper.view.internal Internal management views for buffering view results and providing these to joins. 
net.esper.view.stat Views computing statistical values. 
net.esper.view.std Base service views that perform typical SQL-like functions such as unique, grouping, size, last etc. 
net.esper.view.window Window views are in this package 
 

Uses of EventBean in net.esper.client
 

Methods in net.esper.client that return types with arguments of type EventBean
 Iterator<EventBean> EPIterable.iterator()
          Returns an iterator over events.
 

Methods in net.esper.client with parameters of type EventBean
 void UpdateListener.update(EventBean[] newEvents, EventBean[] oldEvents)
          Notify that new events are available or old events are removed.
 void UpdateListener.update(EventBean[] newEvents, EventBean[] oldEvents)
          Notify that new events are available or old events are removed.
 void StatementAwareUpdateListener.update(EventBean[] newEvents, EventBean[] oldEvents, EPStatement statement, EPServiceProvider epServiceProvider)
          Notify that new events are available or old events are removed.
 void StatementAwareUpdateListener.update(EventBean[] newEvents, EventBean[] oldEvents, EPStatement statement, EPServiceProvider epServiceProvider)
          Notify that new events are available or old events are removed.
 

Uses of EventBean in net.esper.collection
 

Methods in net.esper.collection that return EventBean
 EventBean RollingEventBuffer.get(int index)
          Get an event prior to the last event posted given a number of events before the last.
 EventBean[] FlushedEventBuffer.getAndFlush()
          Get the events currently buffered.
 EventBean TransformEventIterator.next()
           
 EventBean TimeWindowIterator.next()
           
 EventBean SingleEventIterator.next()
           
 EventBean IterablesListIterator.next()
           
 EventBean ArrayEventIterator.next()
           
 EventBean TransformEventMethod.transform(EventBean event)
          Transform event returning the transformed event.
 

Methods in net.esper.collection that return types with arguments of type EventBean
 List<EventBean> TimeWindow.expireEvents(long expireBefore)
          Return and remove events in time-slots earlier (less) then the timestamp passed in, returning the list of events expired.
 Iterator<EventBean> TimeWindow.iterator()
          Returns event iterator.
 

Methods in net.esper.collection with parameters of type EventBean
 void RollingEventBuffer.add(EventBean event)
          Add an event to the buffer.
 void RollingEventBuffer.add(EventBean[] events)
          Add events to the buffer.
 void FlushedEventBuffer.add(EventBean[] events)
          Add an event array to buffer.
 void TimeWindow.add(long timestamp, EventBean bean)
          Adds event to the time window for the specified timestamp.
 EventBean TransformEventMethod.transform(EventBean event)
          Transform event returning the transformed event.
 void ViewUpdatedCollection.update(EventBean[] newData, EventBean[] oldData)
          Accepts view insert and remove stream.
 void ViewUpdatedCollection.update(EventBean[] newData, EventBean[] oldData)
          Accepts view insert and remove stream.
 

Constructors in net.esper.collection with parameters of type EventBean
ArrayEventIterator(EventBean[] events)
          Ctor.
SingleEventIterator(EventBean eventBean)
          Constructor, takes the single event to iterate over as a parameter.
 

Constructor parameters in net.esper.collection with type arguments of type EventBean
IterablesListIterator(List<Iterable<EventBean>> iterables)
          Constructor - takes a list of Iterable that supply the iterators to iterate over.
TimeWindowIterator(LinkedList<Pair<Long,LinkedList<EventBean>>> window)
          Ctor.
TransformEventIterator(Iterator<EventBean> sourceIterator, TransformEventMethod transformEventMethod)
          Ctor.
 

Uses of EventBean in net.esper.core
 

Fields in net.esper.core declared as EventBean
protected  EventBean UpdateDispatchViewBase.lastIterableEvent
          For iteration with patterns.
 

Methods in net.esper.core that return types with arguments of type EventBean
 Iterator<EventBean> UpdateDispatchViewBase.iterator()
           
 Iterator<EventBean> EPStatementImpl.iterator()
           
 

Methods in net.esper.core with parameters of type EventBean
 void PatternListenerDispatch.add(EventBean event)
          Add an event to be dispatched.
 void InternalEventRouter.route(EventBean[] events, EPStatementHandle statementHandle)
          Route the event such that the event is processed as required.
 void EPRuntimeImpl.route(EventBean[] events, EPStatementHandle epStatementHandle)
           
 void UpdateDispatchViewNonBlocking.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewNonBlocking.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewBlocking.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewBlocking.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in net.esper.eql.agg
 

Methods in net.esper.eql.agg with parameters of type EventBean
 void AggregationServiceNull.applyEnter(EventBean[] eventsPerStream, MultiKeyUntyped optionalGroupKeyPerRow)
           
 void AggregationServiceGroupByImpl.applyEnter(EventBean[] eventsPerStream, MultiKeyUntyped groupByKey)
           
 void AggregationServiceGroupAllImpl.applyEnter(EventBean[] eventsPerStream, MultiKeyUntyped optionalGroupKeyPerRow)
           
 void AggregationService.applyEnter(EventBean[] eventsPerStream, MultiKeyUntyped optionalGroupKeyPerRow)
          Apply events as entering a window (new events).
 void AggregationServiceNull.applyLeave(EventBean[] eventsPerStream, MultiKeyUntyped optionalGroupKeyPerRow)
           
 void AggregationServiceGroupByImpl.applyLeave(EventBean[] eventsPerStream, MultiKeyUntyped groupByKey)
           
 void AggregationServiceGroupAllImpl.applyLeave(EventBean[] eventsPerStream, MultiKeyUntyped optionalGroupKeyPerRow)
           
 void AggregationService.applyLeave(EventBean[] eventsPerStream, MultiKeyUntyped optionalGroupKeyPerRow)
          Apply events as leaving a window (old events).
 

Uses of EventBean in net.esper.eql.core
 

Methods in net.esper.eql.core that return EventBean
protected static EventBean[] ResultSetProcessorSimple.applyOutputLimit(EventBean[] events, boolean isOutputLimitLastOnly)
          Applies the last/all event output limit clause.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, ExprNode optionalHavingNode, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
 EventBean ResultSetRowPerGroupIterator.next()
           
 EventBean ResultSetAggregateGroupedIterator.next()
           
 EventBean ResultSetAggregateAllIterator.next()
           
 EventBean SelectExprProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
          Computes the select-clause results and returns an event of the result event type that contains, in it's properties, the selected items.
 EventBean SelectExprJoinWildcardProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
           
 EventBean SelectExprEvalProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
           
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, boolean isNewData)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, boolean isNewData)
          Sort the output events.
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, MultiKeyUntyped[] groupByKeys, boolean isNewData)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, MultiKeyUntyped[] groupByKeys, boolean isNewData)
          Sort the output events, using the provided group-by keys for evaluating grouped aggregation functions, and avoiding the cost of recomputing the keys.
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, MultiKeyUntyped[] orderKeys)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, MultiKeyUntyped[] orderKeys)
          Sort a given array of outgoing events using the sort keys returning a sorted outgoing event array.
 EventBean ResultSetProcessorSimple.ResultSetSimpleTransform.transform(EventBean event)
           
 

Methods in net.esper.eql.core that return types with arguments of type EventBean
protected static Set<MultiKey<EventBean>> ResultSetProcessorSimple.applyOutputLimit(Set<MultiKey<EventBean>> eventSet, boolean isOutputLimitLastOnly)
          Applies the last/all event output limit clause.
 Iterator<EventBean> ResultSetProcessorSimple.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorRowPerGroup.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorRowForAll.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorAggregateGrouped.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorAggregateAll.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessor.getIterator(Viewable parent)
          Returns the iterator implementing the group-by and aggregation and order-by logic specific to each case of use of these construct.
 

Methods in net.esper.eql.core with parameters of type EventBean
protected static EventBean[] ResultSetProcessorSimple.applyOutputLimit(EventBean[] events, boolean isOutputLimitLastOnly)
          Applies the last/all event output limit clause.
protected  MultiKeyUntyped ResultSetProcessorRowPerGroup.generateGroupKey(EventBean[] eventsPerStream, boolean isNewData)
          Generates the group-by key for the row
protected  MultiKeyUntyped ResultSetProcessorAggregateGrouped.generateGroupKey(EventBean[] eventsPerStream, boolean isNewData)
          Generates the group-by key for the row
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
 MultiKeyUntyped OrderByProcessorSimple.getSortKey(EventBean[] eventsPerStream, boolean isNewData)
           
 MultiKeyUntyped OrderByProcessor.getSortKey(EventBean[] eventsPerStream, boolean isNewData)
          Returns the sort key for a given row.
 MultiKeyUntyped[] OrderByProcessorSimple.getSortKeyPerRow(EventBean[] generatingEvents, boolean isNewData)
           
 MultiKeyUntyped[] OrderByProcessor.getSortKeyPerRow(EventBean[] generatingEvents, boolean isNewData)
          Returns the sort key for a each row where a row is a single event (no join, single stream).
 EventBean SelectExprProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
          Computes the select-clause results and returns an event of the result event type that contains, in it's properties, the selected items.
 EventBean SelectExprJoinWildcardProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
           
 EventBean SelectExprEvalProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorSimple.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorSimple.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowPerGroup.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowPerGroup.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowForAll.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowForAll.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateGrouped.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateGrouped.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateAll.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateAll.processViewResult(EventBean[] newData, EventBean[] oldData)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessor.processViewResult(EventBean[] newData, EventBean[] oldData)
          For use by views posting their result, process the event rows that are entered and removed (new and old events).
 Pair<EventBean[],EventBean[]> ResultSetProcessor.processViewResult(EventBean[] newData, EventBean[] oldData)
          For use by views posting their result, process the event rows that are entered and removed (new and old events).
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, boolean isNewData)
           
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, boolean isNewData)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, boolean isNewData)
          Sort the output events.
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, boolean isNewData)
          Sort the output events.
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, MultiKeyUntyped[] groupByKeys, boolean isNewData)
           
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, MultiKeyUntyped[] groupByKeys, boolean isNewData)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, MultiKeyUntyped[] groupByKeys, boolean isNewData)
          Sort the output events, using the provided group-by keys for evaluating grouped aggregation functions, and avoiding the cost of recomputing the keys.
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, EventBean[][] generatingEvents, MultiKeyUntyped[] groupByKeys, boolean isNewData)
          Sort the output events, using the provided group-by keys for evaluating grouped aggregation functions, and avoiding the cost of recomputing the keys.
 EventBean[] OrderByProcessorSimple.sort(EventBean[] outgoingEvents, MultiKeyUntyped[] orderKeys)
           
 EventBean[] OrderByProcessor.sort(EventBean[] outgoingEvents, MultiKeyUntyped[] orderKeys)
          Sort a given array of outgoing events using the sort keys returning a sorted outgoing event array.
 EventBean ResultSetProcessorSimple.ResultSetSimpleTransform.transform(EventBean event)
           
 

Method parameters in net.esper.eql.core with type arguments of type EventBean
protected static Set<MultiKey<EventBean>> ResultSetProcessorSimple.applyOutputLimit(Set<MultiKey<EventBean>> eventSet, boolean isOutputLimitLastOnly)
          Applies the last/all event output limit clause.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, ExprNode optionalHavingNode, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, boolean isOutputLimiting, boolean isOutputLimitLastOnly, boolean isNewData)
          Applies the select-clause to the given events returning the selected events.
 Pair<EventBean[],EventBean[]> ResultSetProcessorSimple.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorSimple.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowPerGroup.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowPerGroup.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowForAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorRowForAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateGrouped.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateGrouped.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessorAggregateAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 Pair<EventBean[],EventBean[]> ResultSetProcessor.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          For use by joins posting their result, process the event rows that are entered and removed (new and old events).
 Pair<EventBean[],EventBean[]> ResultSetProcessor.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          For use by joins posting their result, process the event rows that are entered and removed (new and old events).
 

Constructor parameters in net.esper.eql.core with type arguments of type EventBean
ResultSetAggregateAllIterator(Iterator<EventBean> sourceIterator, ResultSetProcessorAggregateAll resultSetProcessor)
          Ctor.
ResultSetAggregateGroupedIterator(Iterator<EventBean> sourceIterator, ResultSetProcessorAggregateGrouped resultSetProcessor, AggregationService aggregationService)
          Ctor.
ResultSetRowPerGroupIterator(Iterator<EventBean> sourceIterator, ResultSetProcessorRowPerGroup resultSetProcessor, AggregationService aggregationService)
          Ctor.
 

Uses of EventBean in net.esper.eql.db
 

Methods in net.esper.eql.db that return types with arguments of type EventBean
 List<EventBean> DataCacheNullImpl.getCached(Object[] lookupKeys)
           
 List<EventBean> DataCacheLRUImpl.getCached(Object[] lookupKeys)
          Retrieves an entry from the cache.
 List<EventBean> DataCacheExpiringImpl.getCached(Object[] lookupKeys)
           
 List<EventBean> DataCache.getCached(Object[] lookupKeys)
          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.
 Iterator<EventBean> PollingViewable.iterator()
           
 List<EventBean> PollExecStrategyDBQuery.poll(Object[] lookupValues)
           
 List<EventBean> PollExecStrategy.poll(Object[] lookupValues)
          Poll events using the keys provided.
 

Methods in net.esper.eql.db with parameters of type EventBean
 List<EventBean>[] PollingViewable.poll(EventBean[][] lookupEventsPerStream)
           
 

Method parameters in net.esper.eql.db with type arguments of type EventBean
 void DataCacheNullImpl.put(Object[] lookupKeys, List<EventBean> rows)
           
 void DataCacheLRUImpl.put(Object[] key, List<EventBean> value)
          Adds an entry to this cache.
 void DataCacheExpiringImpl.put(Object[] lookupKeys, List<EventBean> rows)
           
 void DataCache.put(Object[] lookupKeys, List<EventBean> rows)
          Puts into the cache a key and a list of rows, or an empty list if zero rows.
 

Uses of EventBean in net.esper.eql.expression
 

Methods in net.esper.eql.expression with parameters of type EventBean
 Object ExprTimestampNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprSubstitutionNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprSubselectNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprStaticMethodNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprRelationalOpNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprRegexpNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprPropertyExistsNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprPriorNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprPreviousNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprOrNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprNotNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprMinMaxRowNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprMathNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprLikeNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprInstanceofNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprInNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprIdentNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprEvaluator.evaluate(EventBean[] eventsPerStream, boolean isNewData)
          Evaluate event tuple and return result.
 Object ExprEqualsNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprConstantNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprConcatNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprCoalesceNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprCastNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprCaseNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprBitWiseNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprBetweenNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprArrayNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprAndNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprAggregateNode.evaluate(EventBean[] events, boolean isNewData)
           
 Object ExprSubselectRowNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
           
abstract  Object ExprSubselectNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
          Evaluate the subquery expression returning an evaluation result object.
 Object ExprSubselectInNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
           
 Object ExprSubselectExistsNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
           
 boolean ExprIdentNode.evaluatePropertyExists(EventBean[] eventsPerStream, boolean isNewData)
          Returns true if the property exists, or false if not.
 

Method parameters in net.esper.eql.expression with type arguments of type EventBean
 Object ExprSubselectRowNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
           
abstract  Object ExprSubselectNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
          Evaluate the subquery expression returning an evaluation result object.
 Object ExprSubselectInNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
           
 Object ExprSubselectExistsNode.evaluate(EventBean[] eventsPerStream, boolean isNewData, Set<EventBean> matchingEvents)
           
 

Uses of EventBean in net.esper.eql.join
 

Methods in net.esper.eql.join that return types with arguments of type EventBean
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposerImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposer.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
          Return join tuple result set from new data and old data for each stream.
 

Methods in net.esper.eql.join with parameters of type EventBean
 void JoinSetComposerImpl.init(EventBean[][] eventsPerStream)
           
 void JoinSetComposer.init(EventBean[][] eventsPerStream)
          Provides initialization events per stream to composer to populate join indexes, if required
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposerImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposerImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposer.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
          Return join tuple result set from new data and old data for each stream.
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposer.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
          Return join tuple result set from new data and old data for each stream.
 void JoinExecutionStrategyImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 void JoinExecutionStrategyImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 void JoinExecutionStrategy.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
          Execute join.
 void JoinExecutionStrategy.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
          Execute join.
 void QueryStrategy.lookup(EventBean[] lookupEvents, Set<MultiKey<EventBean>> joinSet)
          Look up events returning tuples of joined events.
 void HistoricalDataQueryStrategy.lookup(EventBean[] lookupEvents, Set<MultiKey<EventBean>> joinSet)
           
 void ExecNodeQueryStrategy.lookup(EventBean[] lookupEvents, Set<MultiKey<EventBean>> joinSet)
           
 

Method parameters in net.esper.eql.join with type arguments of type EventBean
protected static void JoinSetFilter.filter(ExprNode filterExprNode, Set<MultiKey<EventBean>> events, boolean isNewData)
          Filter event by applying the filter nodes evaluation method.
 void QueryStrategy.lookup(EventBean[] lookupEvents, Set<MultiKey<EventBean>> joinSet)
          Look up events returning tuples of joined events.
 void HistoricalDataQueryStrategy.lookup(EventBean[] lookupEvents, Set<MultiKey<EventBean>> joinSet)
           
 void ExecNodeQueryStrategy.lookup(EventBean[] lookupEvents, Set<MultiKey<EventBean>> joinSet)
           
 void JoinSetProcessor.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          Process join result set.
 void JoinSetProcessor.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          Process join result set.
 void JoinSetFilter.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 void JoinSetFilter.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
           
 

Uses of EventBean in net.esper.eql.join.assemble
 

Methods in net.esper.eql.join.assemble with parameters of type EventBean
 void CartesianProdAssemblyNode.ChildStreamResults.add(int fromStreamIndex, EventBean[] row)
          Add result from stream.
 void RootRequiredAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void RootRequiredAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void RootOptionalAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void RootOptionalAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void RootCartProdAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void RootCartProdAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void ResultAssembler.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
          Publish a result row.
 void ResultAssembler.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
          Publish a result row.
 void LeafAssemblyNode.result(EventBean[] row, int streamNum, EventBean myEvent, Node myNode)
           
 void LeafAssemblyNode.result(EventBean[] row, int streamNum, EventBean myEvent, Node myNode)
           
 void CartesianProdAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void CartesianProdAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void BranchRequiredAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void BranchRequiredAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void BranchOptionalAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void BranchOptionalAssemblyNode.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 

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

Methods in net.esper.eql.join.exec that return types with arguments of type EventBean
 Set<EventBean> TableLookupStrategy.lookup(EventBean event)
          Returns matched events for a event to look up for.
 Set<EventBean> IndexedTableLookupStrategy.lookup(EventBean event)
           
 Set<EventBean> FullTableScanLookupStrategy.lookup(EventBean event)
           
 

Methods in net.esper.eql.join.exec with parameters of type EventBean
 Set<EventBean> TableLookupStrategy.lookup(EventBean event)
          Returns matched events for a event to look up for.
 Set<EventBean> IndexedTableLookupStrategy.lookup(EventBean event)
           
 Set<EventBean> FullTableScanLookupStrategy.lookup(EventBean event)
           
 void TableOuterLookupExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void TableOuterLookupExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void TableLookupExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void TableLookupExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void NestedIterationExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void NestedIterationExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void LookupInstructionExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
 void LookupInstructionExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
           
abstract  void ExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
          Process single event using the prefill events to compile lookup results.
abstract  void ExecNode.process(EventBean lookupEvent, EventBean[] prefillPath, List<EventBean[]> result)
          Process single event using the prefill events to compile lookup results.
protected  void NestedIterationExecNode.recursiveNestedJoin(EventBean lookupEvent, int nestingOrderIndex, EventBean[] currentPath, List<EventBean[]> result)
          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.
protected  void NestedIterationExecNode.recursiveNestedJoin(EventBean lookupEvent, int nestingOrderIndex, EventBean[] currentPath, List<EventBean[]> result)
          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.
 void LookupInstructionExecNode.MyResultAssembler.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void LookupInstructionExecNode.MyResultAssembler.result(EventBean[] row, int fromStreamNum, EventBean myEvent, Node myNode)
           
 void LookupInstructionExecNode.MyResultAssembler.setResult(List<EventBean[]> result, EventBean rootEvent)
          Supplies the result list to which to add result rows.
 

Uses of EventBean in net.esper.eql.join.rep
 

Methods in net.esper.eql.join.rep that return EventBean
 EventBean Cursor.getEvent()
          Supplies current event.
 EventBean Node.getParentEvent()
          Returns lookup event.
 

Methods in net.esper.eql.join.rep that return types with arguments of type EventBean
 Set<EventBean> Node.getEvents()
          Returns the results of the lookup.
 

Methods in net.esper.eql.join.rep with parameters of type EventBean
 void Node.setParentEvent(EventBean parentEvent)
          Set the parent lookup (from stream) event whose results (to stream) are stored.
 

Method parameters in net.esper.eql.join.rep with type arguments of type EventBean
 void RepositoryImpl.addResult(Cursor cursor, Set<EventBean> lookupResults, int resultStream)
           
 void Repository.addResult(Cursor cursor, Set<EventBean> lookupResults, int resultStream)
          Add a lookup result.
 void Node.setEvents(Set<EventBean> events)
          Store lookup results.
 

Constructors in net.esper.eql.join.rep with parameters of type EventBean
Cursor(EventBean event, int stream, Node node)
          Ctor.
RepositoryImpl(int rootStream, EventBean rootEvent, int numStreams)
          Ctor.
 

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

Fields in net.esper.eql.join.table with type parameters of type EventBean
protected  Map<MultiKeyUntyped,Set<EventBean>> PropertyIndexedEventTable.propertyIndex
          Index table.
 

Methods in net.esper.eql.join.table that return types with arguments of type EventBean
 Set<EventBean> UnindexedEventTable.getEventSet()
          Returns events in table.
 Set<EventBean> PropertyIndTableCoerceAll.lookup(Object[] keys)
          Returns the set of events that have the same property value as the given event.
 Set<EventBean> PropertyIndexedEventTable.lookup(Object[] keys)
          Returns the set of events that have the same property value as the given event.
 

Methods in net.esper.eql.join.table with parameters of type EventBean
 void UnindexedEventTable.add(EventBean[] addEvents)
           
 void PropertyIndexedEventTable.add(EventBean[] events)
          Add an array of events.
 void EventTable.add(EventBean[] events)
          Add events to table.
protected  MultiKeyUntyped PropertyIndTableCoerceAdd.getMultiKey(EventBean event)
           
protected  MultiKeyUntyped PropertyIndexedEventTable.getMultiKey(EventBean event)
          Determine multikey for index access.
 void UnindexedEventTable.remove(EventBean[] removeEvents)
           
 void PropertyIndexedEventTable.remove(EventBean[] events)
          Remove events.
 void EventTable.remove(EventBean[] events)
          Remove events from table.
 

Uses of EventBean in net.esper.eql.subquery
 

Methods in net.esper.eql.subquery that return types with arguments of type EventBean
 Set<EventBean> SubqueryTableLookupStrategy.lookup(EventBean[] events)
          Returns matched events for a set of events to look up for.
 Set<EventBean> IndexedTableLookupStrategy.lookup(EventBean[] eventsPerStream)
           
 Set<EventBean> FullTableScanLookupStrategy.lookup(EventBean[] eventPerStream)
           
 

Methods in net.esper.eql.subquery with parameters of type EventBean
protected  Object[] IndexedTableLookupStrategyCoercing.getKeys(EventBean[] eventsPerStream)
           
protected  Object[] IndexedTableLookupStrategy.getKeys(EventBean[] eventsPerStream)
          Get the index lookup keys.
 Set<EventBean> SubqueryTableLookupStrategy.lookup(EventBean[] events)
          Returns matched events for a set of events to look up for.
 Set<EventBean> IndexedTableLookupStrategy.lookup(EventBean[] eventsPerStream)
           
 Set<EventBean> FullTableScanLookupStrategy.lookup(EventBean[] eventPerStream)
           
 

Uses of EventBean in net.esper.eql.view
 

Methods in net.esper.eql.view that return EventBean
protected static EventBean[] FilterExprView.filterEvents(ExprEvaluator exprEvaluator, EventBean[] events, boolean isNewData)
          Filters events using the supplied evaluator.
 EventBean FilterExprViewIterator.next()
           
 

Methods in net.esper.eql.view that return types with arguments of type EventBean
 Iterator<EventBean> OutputProcessView.iterator()
           
 Iterator<EventBean> IStreamRStreamSelectorView.iterator()
           
 Iterator<EventBean> InternalRouteView.iterator()
           
 Iterator<EventBean> FilterExprView.iterator()
           
 

Methods in net.esper.eql.view with parameters of type EventBean
protected static EventBean[] FilterExprView.filterEvents(ExprEvaluator exprEvaluator, EventBean[] events, boolean isNewData)
          Filters events using the supplied evaluator.
 void OutputProcessViewPolicy.update(EventBean[] newData, EventBean[] oldData)
          The update method is called if the view does not participate in a join.
 void OutputProcessViewPolicy.update(EventBean[] newData, EventBean[] oldData)
          The update method is called if the view does not participate in a join.
 void OutputProcessViewDirect.update(EventBean[] newData, EventBean[] oldData)
          The update method is called if the view does not participate in a join.
 void OutputProcessViewDirect.update(EventBean[] newData, EventBean[] oldData)
          The update method is called if the view does not participate in a join.
 void IStreamRStreamSelectorView.update(EventBean[] newData, EventBean[] oldData)
           
 void IStreamRStreamSelectorView.update(EventBean[] newData, EventBean[] oldData)
           
 void InternalRouteView.update(EventBean[] newData, EventBean[] oldData)
           
 void InternalRouteView.update(EventBean[] newData, EventBean[] oldData)
           
 void FilterExprView.update(EventBean[] newData, EventBean[] oldData)
           
 void FilterExprView.update(EventBean[] newData, EventBean[] oldData)
           
 

Method parameters in net.esper.eql.view with type arguments of type EventBean
 void OutputProcessViewPolicy.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          This process (update) method is for participation in a join.
 void OutputProcessViewPolicy.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          This process (update) method is for participation in a join.
 void OutputProcessViewDirect.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          This process (update) method is for participation in a join.
 void OutputProcessViewDirect.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          This process (update) method is for participation in a join.
 

Constructor parameters in net.esper.eql.view with type arguments of type EventBean
FilterExprViewIterator(Iterator<EventBean> sourceIterator, ExprEvaluator filter)
          Ctor.
 

Uses of EventBean in net.esper.event
 

Classes in net.esper.event that implement EventBean
 class BeanEventBean
          Wrapper for Java bean (POJO or regular) Java objects the represent events.
 class CompositeEventBean
          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.
 class MapEventBean
          Wrapper for events represented by a Map of key-value pairs that are the event properties.
 class WrapperEventBean
          Event bean that wraps another event bean adding additional properties.
 

Methods in net.esper.event that return EventBean
 EventBean EventAdapterServiceImpl.adapterForBean(Object event)
          Create an event bean given an event of object id.
 EventBean EventAdapterService.adapterForBean(Object event)
          Wrap the native event returning an EventBean.
 EventBean EventAdapterServiceImpl.adapterForCompositeEvent(EventType eventType, Map<String,EventBean> taggedEvents)
           
 EventBean EventAdapterService.adapterForCompositeEvent(EventType eventType, Map<String,EventBean> taggedEvents)
          Creates a wrapper for a composite event type.
 EventBean EventAdapterServiceImpl.adapterForDOM(Node node)
           
 EventBean EventAdapterService.adapterForDOM(Node node)
          Returns an adapter for the XML DOM document that exposes it's data as event properties for use in statements.
 EventBean EventAdapterServiceImpl.adapterForMap(Map event, String eventTypeAlias)
           
 EventBean EventAdapterService.adapterForMap(Map event, String eventTypeAlias)
          Wrap the Map-type event returning an EventBean using the event type alias name to identify the EventType that the event should carry.
protected static EventBean[] EventBeanUtility.append(EventBean[] source, EventBean[] append)
          Append arrays.
 EventBean EventAdapterServiceImpl.createMapFromValues(Map<String,Object> properties, EventType eventType)
           
 EventBean EventAdapterService.createMapFromValues(Map<String,Object> properties, EventType eventType)
          Create an event wrapper bean from a set of event properties (name and value objectes) stored in a Map.
 EventBean EventAdapterServiceImpl.createWrapper(EventBean event, Map<String,Object> properties, EventType eventType)
           
 EventBean EventAdapterService.createWrapper(EventBean event, Map<String,Object> properties, EventType eventType)
          Creata a wrapper around an event and some additional properties
static EventBean[] EventBeanUtility.flatten(List<EventBean[]> eventVector)
          Flatten the vector of arrays to an array.
 EventBean WrapperEventBean.getUnderlyingEvent()
          Returns the wrapped event.
static EventBean[] EventBeanUtility.toArray(List<EventBean> eventList)
          Convert list of events to array, returning null for empty or null lists.
 

Methods in net.esper.event that return types with arguments of type EventBean
static UniformPair<Set<MultiKey<EventBean>>> EventBeanUtility.flattenBatchJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinPostings)
          Flattens a list of pairs of join result sets.
 

Methods in net.esper.event with parameters of type EventBean
protected static EventBean[] EventBeanUtility.append(EventBean[] source, EventBean[] append)
          Append arrays.
protected static EventBean[] EventBeanUtility.append(EventBean[] source, EventBean[] append)
          Append arrays.
 EventBean EventAdapterServiceImpl.createWrapper(EventBean event, Map<String,Object> properties, EventType eventType)
           
 EventBean EventAdapterService.createWrapper(EventBean event, Map<String,Object> properties, EventType eventType)
          Creata a wrapper around an event and some additional properties
 Object ReflectionPropMethodGetter.get(EventBean obj)
           
 Object ReflectionPropFieldGetter.get(EventBean obj)
           
 Object EventPropertyGetter.get(EventBean eventBean)
          Return the value for the property in the event object specified when the instance was obtained.
 Object CGLibPropertyGetter.get(EventBean obj)
           
static MultiKeyUntyped EventBeanUtility.getMultiKey(EventBean event, EventPropertyGetter[] propertyGetters)
          Returns Multikey instance for given event and getters.
static Object[] EventBeanUtility.getPropertyArray(EventBean event, EventPropertyGetter[] propertyGetters)
          Returns object array containing property values of given properties, retrieved via EventPropertyGetter instances.
 boolean ReflectionPropMethodGetter.isExistsProperty(EventBean eventBean)
           
 boolean ReflectionPropFieldGetter.isExistsProperty(EventBean eventBean)
           
 boolean EventPropertyGetter.isExistsProperty(EventBean eventBean)
          Returns true if the property exists, or false if the type does not have such a property.
 boolean CGLibPropertyGetter.isExistsProperty(EventBean eventBean)
           
static String EventBeanUtility.printEvent(EventBean event)
          Format the event and return a string representation.
 

Method parameters in net.esper.event with type arguments of type EventBean
 EventBean EventAdapterServiceImpl.adapterForCompositeEvent(EventType eventType, Map<String,EventBean> taggedEvents)
           
 EventBean EventAdapterService.adapterForCompositeEvent(EventType eventType, Map<String,EventBean> taggedEvents)
          Creates a wrapper for a composite event type.
static UniformPair<Set<MultiKey<EventBean>>> EventBeanUtility.flattenBatchJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinPostings)
          Flattens a list of pairs of join result sets.
static EventBean[] EventBeanUtility.toArray(List<EventBean> eventList)
          Convert list of events to array, returning null for empty or null lists.
 

Constructors in net.esper.event with parameters of type EventBean
WrapperEventBean(EventBean event, Map<String,Object> properties, EventType eventType)
          Ctor.
 

Constructor parameters in net.esper.event with type arguments of type EventBean
CompositeEventBean(Map<String,EventBean> wrappedEvents, EventType eventType)
          Ctor.
MapEventBean(EventType eventType, Map<String,EventBean> events)
          Constructor for initialization with existing values.
 

Uses of EventBean in net.esper.event.property
 

Methods in net.esper.event.property with parameters of type EventBean
 Object NestedPropertyGetter.get(EventBean eventBean)
           
 Object MapPropertyGetter.get(EventBean eventBean)
           
 Object MapNestedPropertyGetter.get(EventBean eventBean)
           
 Object MapMappedPropertyGetter.get(EventBean eventBean)
           
 Object MapIndexedPropertyGetter.get(EventBean eventBean)
           
 Object KeyedMethodPropertyGetter.get(EventBean obj)
           
 Object KeyedFastPropertyGetter.get(EventBean obj)
           
 Object DynamicPropertyGetterBase.get(EventBean obj)
           
 Object ArrayMethodPropertyGetter.get(EventBean obj)
           
 Object ArrayFieldPropertyGetter.get(EventBean obj)
           
 Object ArrayFastPropertyGetter.get(EventBean obj)
           
 boolean NestedPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapNestedPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapMappedPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapIndexedPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean KeyedMethodPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean KeyedFastPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean DynamicPropertyGetterBase.isExistsProperty(EventBean eventBean)
           
 boolean ArrayMethodPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean ArrayFieldPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean ArrayFastPropertyGetter.isExistsProperty(EventBean eventBean)
           
 

Uses of EventBean in net.esper.event.xml
 

Classes in net.esper.event.xml that implement EventBean
 class XMLEventBean
          EventBean wrapper for XML documents.
 

Methods in net.esper.event.xml with parameters of type EventBean
 Object XPathPropertyGetter.get(EventBean eventBean)
           
 boolean XPathPropertyGetter.isExistsProperty(EventBean eventBean)
           
 

Uses of EventBean in net.esper.filter
 

Methods in net.esper.filter with parameters of type EventBean
 boolean ExprNodeAdapter.evaluate(EventBean event)
          Evaluate the boolean expression given the event as a stream zero event.
 void FilterServiceImpl.evaluate(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterService.evaluate(EventBean event, Collection<FilterHandle> matches)
          Finds matching filters to the event passed in and invokes their associated callback method.
 void FilterParamIndexRange.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexNotRange.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexNotIn.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexNotEquals.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexIn.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexEquals.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexCompare.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterParamIndexBooleanExpr.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
           
 void FilterHandleSetNode.matchEvent(EventBean eventBean, Collection<FilterHandle> matches)
          Evaluate an event by asking each index to match the event.
 void EventTypeIndex.matchEvent(EventBean event, Collection<FilterHandle> matches)
           
 void EventEvaluator.matchEvent(EventBean event, Collection<FilterHandle> matches)
          Perform the matching of an event based on the event property values, adding any callbacks for matches found to the matches list.
 void FilterHandleCallback.matchFound(EventBean event)
          Indicate that an event was evaluated by the FilterService which matches the filter specification FilterSpecCompiled associated with this callback.
 

Constructors in net.esper.filter with parameters of type EventBean
ExprNodeAdapter(ExprNode exprNode, EventBean[] prototype)
          Ctor.
 

Uses of EventBean in net.esper.indicator.jmx
 

Methods in net.esper.indicator.jmx with parameters of type EventBean
 void JMXLastElementObserver.setLastValue(EventBean element)
          Update JMX last element view with a new value.
 void JMXLastElementDynamicMBean.setLastValue(EventBean lastValue)
           
 void JMXLastCubeElementDynamicMBean.setLastValue(EventBean element)
          Set last element containing the cube information to render.
 void JMXLastEventIndicator.update(EventBean[] newData, EventBean[] oldData)
           
 void JMXLastEventIndicator.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in net.esper.pattern
 

Methods in net.esper.pattern that return EventBean
 EventBean MatchedEventMapImpl.getMatchingEvent(String tag)
          Returns a single event instance given the tag identifier, or null if the tag could not be located.
 EventBean MatchedEventMap.getMatchingEvent(String tag)
          Returns a single event instance given the tag identifier, or null if the tag could not be located.
 

Methods in net.esper.pattern that return types with arguments of type EventBean
 Map<String,EventBean> MatchedEventMapImpl.getMatchingEvents()
          Returns a map containing the events where the key is the event tag string and the value is the event instance.
 

Methods in net.esper.pattern with parameters of type EventBean
 void MatchedEventMapImpl.add(String tag, EventBean event)
          Add an event to the collection identified by the given tag.
 void MatchedEventMap.add(String tag, EventBean event)
          Add an event to the collection identified by the given tag.
 void EvalFilterStateNode.matchFound(EventBean event)
           
 

Method parameters in net.esper.pattern with type arguments of type EventBean
 void PatternMatchCallback.matchFound(Map<String,EventBean> matchEvent)
          Indicate matching events.
 

Constructor parameters in net.esper.pattern with type arguments of type EventBean
MatchedEventMapImpl(Map<String,EventBean> events)
          Ctor.
 

Uses of EventBean in net.esper.view
 

Methods in net.esper.view that return types with arguments of type EventBean
 Iterator<EventBean> ZeroDepthStream.iterator()
           
 Iterator<EventBean> EventCollection.iterator()
          Allows iteration through all elements in this event collection.
 

Methods in net.esper.view with parameters of type EventBean
 void ZeroDepthStream.insert(EventBean event)
           
 void EventStream.insert(EventBean event)
          Insert a new event onto the stream.
 List<EventBean>[] HistoricalEventViewable.poll(EventBean[][] lookupEventsPerStream)
          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.
 void View.update(EventBean[] newData, EventBean[] oldData)
          Notify that data has been added or removed from the Viewable parent.
 void View.update(EventBean[] newData, EventBean[] oldData)
          Notify that data has been added or removed from the Viewable parent.
 void ViewSupport.updateChildren(EventBean[] newData, EventBean[] oldData)
          Updates all the children with new data.
 void ViewSupport.updateChildren(EventBean[] newData, EventBean[] oldData)
          Updates all the children with new data.
protected static void ViewSupport.updateChildren(List<View> childViews, EventBean[] newData, EventBean[] oldData)
          Updates all the children with new data.
protected static void ViewSupport.updateChildren(List<View> childViews, EventBean[] newData, EventBean[] oldData)
          Updates all the children with new data.
 

Uses of EventBean in net.esper.view.ext
 

Methods in net.esper.view.ext that return EventBean
 EventBean IStreamSortedRandomAccess.getNewData(int index)
           
 EventBean IStreamSortedRandomAccess.getOldData(int index)
           
 EventBean SortWindowIterator.next()
           
 

Methods in net.esper.view.ext that return types with arguments of type EventBean
 Iterator<EventBean> SortWindowView.iterator()
           
 

Methods in net.esper.view.ext with parameters of type EventBean
 void SortWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void SortWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 

Method parameters in net.esper.view.ext with type arguments of type EventBean
 void IStreamSortedRandomAccess.refresh(TreeMap<MultiKeyUntyped,LinkedList<EventBean>> sortedEvents, int currentSize, int maxSize)
          Refreshes the random access data with the updated information.
 

Constructor parameters in net.esper.view.ext with type arguments of type EventBean
SortWindowIterator(SortedMap<MultiKeyUntyped,LinkedList<EventBean>> window)
          Ctor.
 

Uses of EventBean in net.esper.view.internal
 

Methods in net.esper.view.internal that return EventBean
 EventBean PriorEventBufferUnbound.getNewData(int index)
           
 EventBean PriorEventBufferUnbound.getOldData(int index)
           
 EventBean PriorEventViewFactory.RelativeAccessImpl.getRelativeToEvent(EventBean event, int prevIndex)
           
 EventBean PriorEventBufferSingle.getRelativeToEvent(EventBean event, int priorToIndex)
           
 EventBean PriorEventBufferMulti.getRelativeToEvent(EventBean event, int priorToIndex)
           
 

Methods in net.esper.view.internal that return types with arguments of type EventBean
 Iterator<EventBean> PriorEventView.iterator()
           
 Iterator<EventBean> BufferView.iterator()
           
 

Methods in net.esper.view.internal with parameters of type EventBean
 EventBean PriorEventViewFactory.RelativeAccessImpl.getRelativeToEvent(EventBean event, int prevIndex)
           
 EventBean PriorEventBufferSingle.getRelativeToEvent(EventBean event, int priorToIndex)
           
 EventBean PriorEventBufferMulti.getRelativeToEvent(EventBean event, int priorToIndex)
           
 void PriorEventView.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventView.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventBufferUnbound.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventBufferUnbound.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventBufferSingle.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventBufferSingle.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventBufferMulti.update(EventBean[] newData, EventBean[] oldData)
           
 void PriorEventBufferMulti.update(EventBean[] newData, EventBean[] oldData)
           
 void BufferView.update(EventBean[] newData, EventBean[] oldData)
           
 void BufferView.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in net.esper.view.stat
 

Methods in net.esper.view.stat that return types with arguments of type EventBean
 Iterator<EventBean> WeightedAverageView.iterator()
           
 Iterator<EventBean> UnivariateStatisticsView.iterator()
           
 Iterator<EventBean> MultiDimStatsView.iterator()
           
 Iterator<EventBean> BaseBivariateStatisticsView.iterator()
           
 

Methods in net.esper.view.stat with parameters of type EventBean
 void WeightedAverageView.update(EventBean[] newData, EventBean[] oldData)
           
 void WeightedAverageView.update(EventBean[] newData, EventBean[] oldData)
           
 void UnivariateStatisticsView.update(EventBean[] newData, EventBean[] oldData)
           
 void UnivariateStatisticsView.update(EventBean[] newData, EventBean[] oldData)
           
 void MultiDimStatsView.update(EventBean[] newData, EventBean[] oldData)
           
 void MultiDimStatsView.update(EventBean[] newData, EventBean[] oldData)
           
 void BaseBivariateStatisticsView.update(EventBean[] newData, EventBean[] oldData)
           
 void BaseBivariateStatisticsView.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in net.esper.view.std
 

Fields in net.esper.view.std declared as EventBean
protected  EventBean LastElementView.lastEvent
          The last new element posted from a parent view.
 

Methods in net.esper.view.std that return EventBean
protected static EventBean AddPropertyValueView.addProperty(EventBean originalEvent, String[] propertyNames, Object[] propertyValues, EventType targetEventType, EventAdapterService eventAdapterService)
          Add a property to the event passed in.
 

Methods in net.esper.view.std that return types with arguments of type EventBean
 Iterator<EventBean> UniqueByPropertyView.iterator()
           
 Iterator<EventBean> SizeView.iterator()
           
 Iterator<EventBean> MergeView.iterator()
           
 Iterator<EventBean> LastElementView.iterator()
           
 Iterator<EventBean> GroupByView.iterator()
           
 Iterator<EventBean> AddPropertyValueView.iterator()
           
 

Methods in net.esper.view.std with parameters of type EventBean
protected static EventBean AddPropertyValueView.addProperty(EventBean originalEvent, String[] propertyNames, Object[] propertyValues, EventType targetEventType, EventAdapterService eventAdapterService)
          Add a property to the event passed in.
 void UniqueByPropertyView.update(EventBean[] newData, EventBean[] oldData)
           
 void UniqueByPropertyView.update(EventBean[] newData, EventBean[] oldData)
           
 void SizeView.update(EventBean[] newData, EventBean[] oldData)
           
 void SizeView.update(EventBean[] newData, EventBean[] oldData)
           
 void MergeView.update(EventBean[] newData, EventBean[] oldData)
           
 void MergeView.update(EventBean[] newData, EventBean[] oldData)
           
 void LastElementView.update(EventBean[] newData, EventBean[] oldData)
           
 void LastElementView.update(EventBean[] newData, EventBean[] oldData)
           
 void GroupByView.update(EventBean[] newData, EventBean[] oldData)
           
 void GroupByView.update(EventBean[] newData, EventBean[] oldData)
           
 void AddPropertyValueView.update(EventBean[] newData, EventBean[] oldData)
           
 void AddPropertyValueView.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in net.esper.view.window
 

Methods in net.esper.view.window that return EventBean
 EventBean RandomAccessByIndex.getNewData(int index)
          Returns an new data event given an index.
 EventBean IStreamRandomAccess.getNewData(int index)
           
 EventBean RandomAccessByIndex.getOldData(int index)
          Returns an old data event given an index.
 EventBean IStreamRandomAccess.getOldData(int index)
           
 EventBean RelativeAccessByEventNIndex.getRelativeToEvent(EventBean event, int index)
          Returns the prior event to the given event counting back the number of events as supplied by index.
 EventBean IStreamRelativeAccess.getRelativeToEvent(EventBean event, int prevIndex)
           
 

Methods in net.esper.view.window that return types with arguments of type EventBean
 Iterator<EventBean> TimeWindowView.iterator()
           
 Iterator<EventBean> TimeBatchView.iterator()
           
 Iterator<EventBean> LengthWindowView.iterator()
           
 Iterator<EventBean> LengthBatchView.iterator()
           
 Iterator<EventBean> ExternallyTimedWindowView.iterator()
           
 

Methods in net.esper.view.window with parameters of type EventBean
 IStreamRelativeAccess RelativeAccessByEventNIndexGetter.getAccessor(EventBean event)
          Returns the access into window contents given an event.
 EventBean RelativeAccessByEventNIndex.getRelativeToEvent(EventBean event, int index)
          Returns the prior event to the given event counting back the number of events as supplied by index.
 EventBean IStreamRelativeAccess.getRelativeToEvent(EventBean event, int prevIndex)
           
 void TimeWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void IStreamRelativeAccess.update(EventBean[] newData, EventBean[] oldData)
           
 void IStreamRelativeAccess.update(EventBean[] newData, EventBean[] oldData)
           
 void IStreamRandomAccess.update(EventBean[] newData, EventBean[] oldData)
           
 void IStreamRandomAccess.update(EventBean[] newData, EventBean[] oldData)
           
 void ExternallyTimedWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void ExternallyTimedWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void RelativeAccessByEventNIndexGetter.updated(IStreamRelativeAccess iStreamRelativeAccess, EventBean[] newData)
           
 void IStreamRelativeAccess.IStreamRelativeAccessUpdateObserver.updated(IStreamRelativeAccess iStreamRelativeAccess, EventBean[] newData)
          Callback to indicate an update.