Uses of Interface
com.espertech.esper.event.EventBean

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

Uses of EventBean in com.espertech.esper.client
 

Methods in com.espertech.esper.client that return types with arguments of type EventBean
 Iterator<EventBean> EPIterable.iterator()
          Returns a concurrency-unsafe iterator over events representing statement results (pull API).
 SafeIterator<EventBean> EPIterable.safeIterator()
          Returns a concurrency-safe iterator that iterates over events representing statement results (pull API) in the face of concurrent event processing by further threads.
 

Methods in com.espertech.esper.client with parameters of type EventBean
 void UnmatchedListener.update(EventBean event)
          Called upon the engine encountering an event not matched to any of the event stream filters of any active statement.
 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 com.espertech.esper.collection
 

Methods in com.espertech.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[] OneEventCollection.toArray()
          Returns an array holding the collected events.
 EventBean TransformEventMethod.transform(EventBean event)
          Transform event returning the transformed event.
 

Methods in com.espertech.esper.collection that return types with arguments of type EventBean
 ArrayDequeJDK6Backport<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.
protected  Map<EventBean,ArrayDequeJDK6Backport<EventBean>> TimeWindow.getReverseIndex()
          Returns the reverse index, for testing purposes.
protected  Map<EventBean,ArrayDequeJDK6Backport<EventBean>> TimeWindow.getReverseIndex()
          Returns the reverse index, for testing purposes.
 Iterator<EventBean> TimeWindow.iterator()
          Returns event iterator.
 

Methods in com.espertech.esper.collection with parameters of type EventBean
 void RollingEventBuffer.add(EventBean event)
          Add an event to the buffer.
 void OneEventCollection.add(EventBean event)
          Add an event to the collection.
 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.
 void TimeWindow.remove(EventBean event)
          Removes the event from the window, if remove stream handling is enabled.
 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 com.espertech.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 com.espertech.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(ArrayDequeJDK6Backport<Pair<Long,ArrayDequeJDK6Backport<EventBean>>> window)
          Ctor.
TransformEventIterator(Iterator<EventBean> sourceIterator, TransformEventMethod transformEventMethod)
          Ctor.
 

Uses of EventBean in com.espertech.esper.core
 

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

Methods in com.espertech.esper.core that return EventBean
 EventBean[] EPQueryResultImpl.getArray()
           
 EventBean[] EPQueryResult.getArray()
          Returns an array representing query result rows.
 EventBean StatementResultServiceImpl.getLastIterableEvent()
           
 EventBean StatementResultService.getLastIterableEvent()
          Returns the last iterable event, for use by patterns since these are not iterable.
 EventBean[] EPPreparedQueryResult.getResult()
          Returns the query result.
 

Methods in com.espertech.esper.core that return types with arguments of type EventBean
 Iterator<EventBean> UpdateDispatchViewBase.iterator()
           
 Iterator<EventBean> EPStatementImpl.iterator()
           
 Iterator<EventBean> EPQueryResultImpl.iterator()
           
 Iterator<EventBean> EPQueryResult.iterator()
          Returns an iterator representing query result rows.
 SafeIterator<EventBean> EPStatementImpl.safeIterator()
           
 

Methods in com.espertech.esper.core with parameters of type EventBean
 void PatternListenerDispatch.add(EventBean event)
          Add an event to be dispatched.
 void EPRuntimeImpl.processWrappedEvent(EventBean eventBean)
           
 void EPRuntimeEventSender.processWrappedEvent(EventBean eventBean)
          Equivalent to the sendEvent method of EPRuntime, for use to process an known event.
 void InternalEventRouter.route(EventBean event, EPStatementHandle statementHandle)
          Route the event such that the event is processed as required.
 void EPRuntimeImpl.route(EventBean event, EPStatementHandle epStatementHandle)
           
 void UpdateDispatchViewNonBlocking.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewNonBlocking.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewBlockingWait.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewBlockingWait.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewBlockingSpin.update(EventBean[] newData, EventBean[] oldData)
           
 void UpdateDispatchViewBlockingSpin.update(EventBean[] newData, EventBean[] oldData)
           
 

Constructors in com.espertech.esper.core with parameters of type EventBean
EPPreparedQueryResult(EventType eventType, EventBean[] result)
          Ctor.
 

Uses of EventBean in com.espertech.esper.epl.agg
 

Methods in com.espertech.esper.epl.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 com.espertech.esper.epl.core
 

Methods in com.espertech.esper.epl.core that return EventBean
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize)
          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 isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, Set<MultiKey<EventBean>> events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorHandThrough.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize)
          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 isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, Set<MultiKey<EventBean>> events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorHandThrough.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, Set<MultiKey<EventBean>> events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
 EventBean ResultSetRowPerGroupIterator.next()
           
 EventBean ResultSetAggregateGroupedIterator.next()
           
 EventBean ResultSetAggregateAllIterator.next()
           
 EventBean SelectExprWildcardProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 EventBean SelectExprResultProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 EventBean SelectExprProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
          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, boolean isSynthesize)
           
 EventBean SelectExprEvalProcessorStreams.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 EventBean SelectExprEvalProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 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 ResultSetProcessorSimpleTransform.transform(EventBean event)
           
 

Methods in com.espertech.esper.epl.core that return types with arguments of type EventBean
 Iterator<EventBean> ResultSetProcessorSimple.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorRowPerGroup.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorRowForAll.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorHandThrough.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorAggregateGrouped.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorAggregateAll.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessor.getIterator(Set<MultiKey<EventBean>> joinSet)
          Returns the iterator for iterating over a join-result.
 Iterator<EventBean> ResultSetProcessorSimple.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorRowPerGroup.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorRowForAll.getIterator(Viewable parent)
           
 Iterator<EventBean> ResultSetProcessorHandThrough.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.
 Iterator<EventBean> MethodPollingViewable.iterator()
           
 List<EventBean> MethodPollingExecStrategy.poll(Object[] lookupValues)
           
 

Methods in com.espertech.esper.epl.core with parameters of type EventBean
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, EventBean[] events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorHandThrough.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          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).
 EventTable[] MethodPollingViewable.poll(EventBean[][] lookupEventsPerStream, PollResultIndexingStrategy indexingStrategy)
           
 Object[] BindProcessor.process(EventBean[] eventsPerStream, boolean isNewData)
          Process select expressions into columns for native dispatch.
 EventBean SelectExprWildcardProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 EventBean SelectExprResultProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 EventBean SelectExprProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
          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, boolean isSynthesize)
           
 EventBean SelectExprEvalProcessorStreams.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 EventBean SelectExprEvalProcessor.process(EventBean[] eventsPerStream, boolean isNewData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorSimple.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorSimple.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowPerGroup.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowPerGroup.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowForAll.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowForAll.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorHandThrough.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorHandThrough.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateGrouped.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateGrouped.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateAll.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateAll.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessor.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
          For use by views posting their result, process the event rows that are entered and removed (new and old events).
 UniformPair<EventBean[]> ResultSetProcessor.processViewResult(EventBean[] newData, EventBean[] oldData, boolean isSynthesize)
          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 ResultSetProcessorSimpleTransform.transform(EventBean event)
           
 

Method parameters in com.espertech.esper.epl.core with type arguments of type EventBean
 Iterator<EventBean> ResultSetProcessorSimple.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorRowPerGroup.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorRowForAll.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorHandThrough.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorAggregateGrouped.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessorAggregateAll.getIterator(Set<MultiKey<EventBean>> joinSet)
           
 Iterator<EventBean> ResultSetProcessor.getIterator(Set<MultiKey<EventBean>> joinSet)
          Returns the iterator for iterating over a join-result.
protected static void ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          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 isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsHaving(SelectExprProcessor exprProcessor, Set<MultiKey<EventBean>> events, ExprNode optionalHavingNode, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, EventBean[] events, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          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 isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          Applies the select-clause to the given events returning the selected events.
protected static void ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, OrderByProcessor orderByProcessor, Set<MultiKey<EventBean>> events, boolean isNewData, boolean isSynthesize, List<EventBean> result, List<MultiKeyUntyped> optSortKeys)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorSimple.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, Set<MultiKey<EventBean>> events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
protected static EventBean[] ResultSetProcessorHandThrough.getSelectEventsNoHaving(SelectExprProcessor exprProcessor, Set<MultiKey<EventBean>> events, boolean isNewData, boolean isSynthesize)
          Applies the select-clause to the given events returning the selected events.
 UniformPair<EventBean[]> ResultSetProcessorSimple.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorSimple.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowPerGroup.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowPerGroup.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowForAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorRowForAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorHandThrough.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorHandThrough.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateGrouped.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateGrouped.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateAll.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
           
 UniformPair<EventBean[]> ResultSetProcessor.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
          For use by joins posting their result, process the event rows that are entered and removed (new and old events).
 UniformPair<EventBean[]> ResultSetProcessor.processJoinResult(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents, boolean isSynthesize)
          For use by joins posting their result, process the event rows that are entered and removed (new and old events).
 UniformPair<EventBean[]> ResultSetProcessorRowPerGroup.processOutputLimitedJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinEventsSet, boolean generateSynthetic, OutputLimitLimitType outputLimitLimitType)
           
 UniformPair<EventBean[]> ResultSetProcessorRowForAll.processOutputLimitedJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinEventsSet, boolean generateSynthetic, OutputLimitLimitType outputLimitLimitType)
           
 UniformPair<EventBean[]> ResultSetProcessorBaseSimple.processOutputLimitedJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinEventsSet, boolean generateSynthetic, OutputLimitLimitType outputLimitLimitType)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateGrouped.processOutputLimitedJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinEventsSet, boolean generateSynthetic, OutputLimitLimitType outputLimitLimitType)
           
 UniformPair<EventBean[]> ResultSetProcessorAggregateAll.processOutputLimitedJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinEventsSet, boolean generateSynthetic, OutputLimitLimitType outputLimitLimitType)
           
 UniformPair<EventBean[]> ResultSetProcessor.processOutputLimitedJoin(List<UniformPair<Set<MultiKey<EventBean>>>> joinEventsSet, boolean generateSynthetic, OutputLimitLimitType outputLimitLimitType)
          Processes batched events in case of output-rate limiting.
 

Constructor parameters in com.espertech.esper.epl.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 com.espertech.esper.epl.db
 

Methods in com.espertech.esper.epl.db that return types with arguments of type EventBean
 Iterator<EventBean> DatabasePollingViewable.iterator()
           
 List<EventBean> PollExecStrategyDBQuery.poll(Object[] lookupValues)
           
 List<EventBean> PollExecStrategy.poll(Object[] lookupValues)
          Poll events using the keys provided.
 

Methods in com.espertech.esper.epl.db with parameters of type EventBean
 EventTable[] DatabasePollingViewable.poll(EventBean[][] lookupEventsPerStream, PollResultIndexingStrategy indexingStrategy)
           
 

Uses of EventBean in com.espertech.esper.epl.expression
 

Methods in com.espertech.esper.epl.expression with parameters of type EventBean
 Object ExprVariableNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprTimestampNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprSubstitutionNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprSubselectNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprStreamUnderlyingNode.evaluate(EventBean[] eventsPerStream, boolean isNewData)
           
 Object ExprStreamInstanceMethodNode.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 lookup 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 com.espertech.esper.epl.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 lookup 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 com.espertech.esper.epl.join
 

Methods in com.espertech.esper.epl.join that return types with arguments of type EventBean
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposerStreamToWinImpl.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.
 Iterator<EventBean> HistoricalIndexLookupStrategyNoIndex.lookup(EventBean lookupEvent, EventTable index)
           
 Iterator<EventBean> HistoricalIndexLookupStrategyIndex.lookup(EventBean lookupEvent, EventTable indexTable)
           
 Iterator<EventBean> HistoricalIndexLookupStrategy.lookup(EventBean lookupEvent, EventTable index)
          Look up into the index, potentially using some of the properties in the lookup event, returning a partial or full result in respect to the index.
 Set<MultiKey<EventBean>> JoinSetComposerStreamToWinImpl.staticJoin()
           
 Set<MultiKey<EventBean>> JoinSetComposerImpl.staticJoin()
           
 Set<MultiKey<EventBean>> JoinSetComposer.staticJoin()
          For use in iteration over join statements, this must build a join tuple result set from all events in indexes, executing query strategies for each.
 Set<MultiKey<EventBean>> JoinExecutionStrategyImpl.staticJoin()
           
 Set<MultiKey<EventBean>> JoinExecutionStrategy.staticJoin()
          A static join is for use with iterating over join statements.
 

Methods in com.espertech.esper.epl.join with parameters of type EventBean
 void JoinSetComposerStreamToWinImpl.init(EventBean[][] eventsPerStream)
           
 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>>> JoinSetComposerStreamToWinImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 UniformPair<Set<MultiKey<EventBean>>> JoinSetComposerStreamToWinImpl.join(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream)
           
 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)
           
 Iterator<EventBean> HistoricalIndexLookupStrategyNoIndex.lookup(EventBean lookupEvent, EventTable index)
           
 Iterator<EventBean> HistoricalIndexLookupStrategyIndex.lookup(EventBean lookupEvent, EventTable indexTable)
           
 Iterator<EventBean> HistoricalIndexLookupStrategy.lookup(EventBean lookupEvent, EventTable index)
          Look up into the index, potentially using some of the properties in the lookup event, returning a partial or full result in respect to the index.
 

Method parameters in com.espertech.esper.epl.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.
 EventTable PollResultIndexingStrategyNoIndex.index(List<EventBean> pollResult, boolean isActiveCache)
           
 EventTable PollResultIndexingStrategyIndexCoerce.index(List<EventBean> pollResult, boolean isActiveCache)
           
 EventTable PollResultIndexingStrategyIndex.index(List<EventBean> pollResult, boolean isActiveCache)
           
 EventTable PollResultIndexingStrategy.index(List<EventBean> pollResult, boolean isActiveCache)
          Build and index of a poll result.
 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 com.espertech.esper.epl.join.assemble
 

Methods in com.espertech.esper.epl.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 com.espertech.esper.epl.join.exec
 

Methods in com.espertech.esper.epl.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 com.espertech.esper.epl.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 com.espertech.esper.epl.join.rep
 

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

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

Methods in com.espertech.esper.epl.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 com.espertech.esper.epl.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 com.espertech.esper.epl.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 com.espertech.esper.epl.join.table
 

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

Methods in com.espertech.esper.epl.join.table that return EventBean
 EventBean PropertyIndexedEventTableIterator.next()
           
 

Methods in com.espertech.esper.epl.join.table that return types with arguments of type EventBean
 Set<EventBean> UnindexedEventTable.getEventSet()
          Returns events in table.
 Iterator<EventBean> UnindexedEventTableList.iterator()
           
 Iterator<EventBean> UnindexedEventTable.iterator()
           
 Iterator<EventBean> PropertyIndexedEventTable.iterator()
           
 Iterator<EventBean> EventTable.iterator()
          Returns an iterator over events in the 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 com.espertech.esper.epl.join.table with parameters of type EventBean
 void UnindexedEventTableList.add(EventBean[] addEvents)
           
 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 UnindexedEventTableList.remove(EventBean[] removeEvents)
           
 void UnindexedEventTable.remove(EventBean[] removeEvents)
           
 void PropertyIndexedEventTable.remove(EventBean[] events)
          Remove events.
 void EventTable.remove(EventBean[] events)
          Remove events from table.
 

Constructor parameters in com.espertech.esper.epl.join.table with type arguments of type EventBean
PropertyIndexedEventTableIterator(Map<MultiKeyUntyped,Set<EventBean>> window)
          Ctor.
UnindexedEventTableList(List<EventBean> eventSet)
          Ctor.
 

Uses of EventBean in com.espertech.esper.epl.lookup
 

Methods in com.espertech.esper.epl.lookup that return types with arguments of type EventBean
 Set<EventBean> TableLookupStrategyNullRow.lookup(EventBean[] events)
           
 Set<EventBean> TableLookupStrategy.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 com.espertech.esper.epl.lookup with parameters of type EventBean
protected  Object[] IndexedTableLookupStrategyCoercing.getKeys(EventBean[] eventsPerStream)
           
protected  Object[] IndexedTableLookupStrategy.getKeys(EventBean[] eventsPerStream)
          Get the index lookup keys.
 Set<EventBean> TableLookupStrategyNullRow.lookup(EventBean[] events)
           
 Set<EventBean> TableLookupStrategy.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 com.espertech.esper.epl.named
 

Methods in com.espertech.esper.epl.named that return EventBean
 EventBean[] NamedWindowDeltaData.getNewData()
          Returns the insert stream events.
 EventBean[] NamedWindowDeltaData.getOldData()
          Returns the remove stream events.
 EventBean[] LookupStrategyTableScan.lookup(EventBean[] newData)
           
 EventBean[] LookupStrategyIndexed.lookup(EventBean[] newData)
           
 EventBean[] LookupStrategyAllRows.lookup(EventBean[] newData)
           
 EventBean[] LookupStrategy.lookup(EventBean[] newData)
          Determines the events to be deleted from a named window.
 EventBean FilteredEventIterator.next()
           
 

Methods in com.espertech.esper.epl.named that return types with arguments of type EventBean
 Iterator<EventBean> NamedWindowTailView.iterator()
           
 Iterator<EventBean> NamedWindowRootView.iterator()
           
 Iterator<EventBean> NamedWindowOnSelectView.iterator()
           
 Iterator<EventBean> NamedWindowOnDeleteView.iterator()
           
 Iterator<EventBean> NamedWindowConsumerView.iterator()
           
 Collection<EventBean> NamedWindowTailView.snapshot()
          Returns a snapshot of window contents, thread-safely
 

Methods in com.espertech.esper.epl.named with parameters of type EventBean
 void NamedWindowOnSelectView.handleMatching(EventBean[] triggerEvents, EventBean[] matchingEvents)
           
 void NamedWindowOnSelectView.handleMatching(EventBean[] triggerEvents, EventBean[] matchingEvents)
           
abstract  void NamedWindowOnExprBaseView.handleMatching(EventBean[] triggerEvents, EventBean[] matchingEvents)
          Implemented by on-trigger views to action on the combination of trigger and matching events in the named window.
abstract  void NamedWindowOnExprBaseView.handleMatching(EventBean[] triggerEvents, EventBean[] matchingEvents)
          Implemented by on-trigger views to action on the combination of trigger and matching events in the named window.
 void NamedWindowOnDeleteView.handleMatching(EventBean[] triggerEvents, EventBean[] matchingEvents)
           
 void NamedWindowOnDeleteView.handleMatching(EventBean[] triggerEvents, EventBean[] matchingEvents)
           
 EventBean[] LookupStrategyTableScan.lookup(EventBean[] newData)
           
 EventBean[] LookupStrategyIndexed.lookup(EventBean[] newData)
           
 EventBean[] LookupStrategyAllRows.lookup(EventBean[] newData)
           
 EventBean[] LookupStrategy.lookup(EventBean[] newData)
          Determines the events to be deleted from a named window.
 void NamedWindowRootView.removeOldData(EventBean[] oldData)
          Called by tail view to indicate that the data window view exired events that must be removed from index tables.
 void NamedWindowTailView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowTailView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowRootView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowRootView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowOnExprBaseView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowOnExprBaseView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowConsumerView.update(EventBean[] newData, EventBean[] oldData)
           
 void NamedWindowConsumerView.update(EventBean[] newData, EventBean[] oldData)
           
 

Method parameters in com.espertech.esper.epl.named with type arguments of type EventBean
 PropertyIndexedEventTable NamedWindowIndexRepository.addTable(JoinedPropDesc[] joinedPropDesc, Iterable<EventBean> prefilledEvents, EventType indexedType, boolean mustCoerce)
          Create a new index table or use an existing index table, by matching the join descriptor properties to an existing table.
 void NamedWindowRootView.setDataWindowContents(Iterable<EventBean> dataWindowContents)
          Sets the iterator to use to obtain current named window data window contents.
 

Constructors in com.espertech.esper.epl.named with parameters of type EventBean
NamedWindowDeltaData(EventBean[] newData, EventBean[] oldData)
          Ctor.
NamedWindowDeltaData(EventBean[] newData, EventBean[] oldData)
          Ctor.
 

Constructor parameters in com.espertech.esper.epl.named with type arguments of type EventBean
FilteredEventIterator(List<ExprNode> filters, Iterator<EventBean> parent)
          Ctor.
LookupStrategyAllRows(Iterable<EventBean> source)
          Ctor.
LookupStrategyTableScan(ExprNode joinExpr, Iterable<EventBean> iterable)
          Ctor.
 

Uses of EventBean in com.espertech.esper.epl.subquery
 

Methods in com.espertech.esper.epl.subquery that return types with arguments of type EventBean
 Iterator<EventBean> SubselectAggregatorView.iterator()
           
 

Methods in com.espertech.esper.epl.subquery with parameters of type EventBean
 void SubselectAggregatorView.update(EventBean[] newData, EventBean[] oldData)
           
 void SubselectAggregatorView.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in com.espertech.esper.epl.variable
 

Methods in com.espertech.esper.epl.variable that return types with arguments of type EventBean
 Iterator<EventBean> OnSetVariableView.iterator()
           
 Iterator<EventBean> CreateVariableView.iterator()
           
 

Methods in com.espertech.esper.epl.variable with parameters of type EventBean
 void OnSetVariableView.update(EventBean[] newData, EventBean[] oldData)
           
 void OnSetVariableView.update(EventBean[] newData, EventBean[] oldData)
           
 void CreateVariableView.update(EventBean[] newData, EventBean[] oldData)
           
 void CreateVariableView.update(EventBean[] newData, EventBean[] oldData)
           
 

Uses of EventBean in com.espertech.esper.epl.view
 

Methods in com.espertech.esper.epl.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 com.espertech.esper.epl.view that return types with arguments of type EventBean
 Iterator<EventBean> OutputProcessView.iterator()
           
 Iterator<EventBean> FilterExprView.iterator()
           
 

Methods in com.espertech.esper.epl.view with parameters of type EventBean
protected static EventBean[] FilterExprView.filterEvents(ExprEvaluator exprEvaluator, EventBean[] events, boolean isNewData)
          Filters events using the supplied evaluator.
 void OutputProcessViewSnapshot.update(EventBean[] newData, EventBean[] oldData)
          The update method is called if the view does not participate in a join.
 void OutputProcessViewSnapshot.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 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 FilterExprView.update(EventBean[] newData, EventBean[] oldData)
           
 void FilterExprView.update(EventBean[] newData, EventBean[] oldData)
           
 

Method parameters in com.espertech.esper.epl.view with type arguments of type EventBean
 void OutputProcessViewSnapshot.process(Set<MultiKey<EventBean>> newEvents, Set<MultiKey<EventBean>> oldEvents)
          This process (update) method is for participation in a join.
 void OutputProcessViewSnapshot.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 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 com.espertech.esper.epl.view with type arguments of type EventBean
FilterExprViewIterator(Iterator<EventBean> sourceIterator, ExprEvaluator filter)
          Ctor.
 

Uses of EventBean in com.espertech.esper.event
 

Classes in com.espertech.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 NaturalEventBean
          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.
 class WrapperEventBean
          Event bean that wraps another event bean adding additional properties.
 

Methods in com.espertech.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(ArrayDequeJDK6Backport<EventBean[]> eventVector)
          Flatten the vector of arrays to an array.
 EventBean TaggedCompositeEventBean.getEventBean(String property)
          Returns the event for the tag.
 EventBean CompositeEventBean.getEventBean(String property)
           
 EventBean NaturalEventBean.getOptionalSynthetic()
          Returns the synthetic event that can be attached.
 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 com.espertech.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 com.espertech.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 MapPOJOEntryPropertyGetter.get(EventBean obj)
           
 Object MapNestedEventPropertyGetter.get(EventBean obj)
           
 Object MapEventPropertyGetter.get(EventBean obj)
           
 Object MapEventBeanPropertyGetter.get(EventBean obj)
           
 Object MapEventBeanEntryPropertyGetter.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 MapPOJOEntryPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapNestedEventPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapEventPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapEventBeanPropertyGetter.isExistsProperty(EventBean eventBean)
           
 boolean MapEventBeanEntryPropertyGetter.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 com.espertech.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 com.espertech.esper.event with parameters of type EventBean
NaturalEventBean(EventType eventBeanType, Object[] natural, EventBean optionalSynthetic)
          Ctor.
WrapperEventBean(EventBean event, Map<String,Object> properties, EventType eventType)
          Ctor.
 

Constructor parameters in com.espertech.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 com.espertech.esper.event.property
 

Methods in com.espertech.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 com.espertech.esper.event.vaevent
 

Classes in com.espertech.esper.event.vaevent that implement EventBean
 class RevisionEventBeanDeclared
          Revision event bean for the overlayed scheme.
 class RevisionEventBeanMerge
          Merge-event for event revisions.
 class VariantEventBean
          An event bean that represents multiple potentially disparate underlying events and presents a unified face across each such types or even any type.
 

Methods in com.espertech.esper.event.vaevent that return EventBean
 EventBean RevisionStateMerge.getBaseEventUnderlying()
          Returns base event.
 EventBean RevisionStateDeclared.getBaseEventUnderlying()
          Returns base event.
 EventBean RevisionBeanHolder.getEventBean()
          Returns the contributing event.
 EventBean RevisionEventBeanMerge.getLastBaseEvent()
          Returns last base event.
 EventBean RevisionEventBeanDeclared.getLastBaseEvent()
          Returns last base event.
 EventBean VariantEventBean.getUnderlyingEventBean()
          Returns the underlying event.
 EventBean RevisionEventBeanMerge.getUnderlyingFullOrDelta()
          Returns wrapped event
 EventBean RevisionEventBeanDeclared.getUnderlyingFullOrDelta()
          Returns wrapped event.
 EventBean ValueAddEventProcessor.getValueAddEventBean(EventBean event)
          For use in executing an insert-into, wraps the given event applying the revision event type, but not yet computing a new revision.
 EventBean VAEVariantProcessor.getValueAddEventBean(EventBean event)
           
 EventBean VAERevisionProcessorMerge.getValueAddEventBean(EventBean event)
           
 EventBean VAERevisionProcessorDeclared.getValueAddEventBean(EventBean event)
           
 

Methods in com.espertech.esper.event.vaevent that return types with arguments of type EventBean
 Collection<EventBean> ValueAddEventProcessor.getSnapshot(EPStatementHandle createWindowStmtHandle, Viewable parent)
          Handle iteration over revision event contents.
 Collection<EventBean> VAEVariantProcessor.getSnapshot(EPStatementHandle createWindowStmtHandle, Viewable parent)
           
 Collection<EventBean> VAERevisionProcessorMerge.getSnapshot(EPStatementHandle createWindowStmtHandle, Viewable parent)
           
 Collection<EventBean> VAERevisionProcessorDeclared.getSnapshot(EPStatementHandle createWindowStmtHandle, Viewable parent)
           
 

Methods in com.espertech.esper.event.vaevent with parameters of type EventBean
 Object RevisionNestedPropertyGetter.get(EventBean obj)
           
static MultiKeyUntyped PropertyUtility.getKeys(EventBean event, EventPropertyGetter[] keyPropertyGetters)
          Returns a multi-key for an event and key property getters
 EventBean ValueAddEventProcessor.getValueAddEventBean(EventBean event)
          For use in executing an insert-into, wraps the given event applying the revision event type, but not yet computing a new revision.
 EventBean VAEVariantProcessor.getValueAddEventBean(EventBean event)
           
 EventBean VAERevisionProcessorMerge.getValueAddEventBean(EventBean event)
           
 EventBean VAERevisionProcessorDeclared.getValueAddEventBean(EventBean event)
           
 boolean RevisionNestedPropertyGetter.isExistsProperty(EventBean eventBean)
           
 void ValueAddEventProcessor.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
          Upon new events arriving into a named window (new data), and upon events being deleted via on-delete (old data), update child views of the root view and apply to index repository as required (fast deletion).
 void ValueAddEventProcessor.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
          Upon new events arriving into a named window (new data), and upon events being deleted via on-delete (old data), update child views of the root view and apply to index repository as required (fast deletion).
 void VAEVariantProcessor.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
           
 void VAEVariantProcessor.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
           
 void VAERevisionProcessorMerge.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
           
 void VAERevisionProcessorMerge.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
           
 void VAERevisionProcessorDeclared.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
           
 void VAERevisionProcessorDeclared.onUpdate(EventBean[] newData, EventBean[] oldData, NamedWindowRootView namedWindowRootView, NamedWindowIndexRepository indexRepository)
           
 void ValueAddEventProcessor.removeOldData(EventBean[] oldData, NamedWindowIndexRepository indexRepository)
          Called each time a data window posts a remove stream event, to indicate that a data window remove an event as it expired according to a specified expiration policy.
 void VAEVariantProcessor.removeOldData(EventBean[] oldData, NamedWindowIndexRepository indexRepository)
           
 void VAERevisionProcessorMerge.removeOldData(EventBean[] oldData, NamedWindowIndexRepository indexRepository)
           
 void VAERevisionProcessorDeclared.removeOldData(EventBean[] oldData, NamedWindowIndexRepository indexRepository)
           
 void RevisionStateMerge.setBaseEventUnderlying(EventBean baseEventUnderlying)
          Sets base event.
 void RevisionStateDeclared.setBaseEventUnderlying(EventBean baseEventUnderlying)
          Sets base event.
 void RevisionEventBeanMerge.setLastBaseEvent(EventBean lastBaseEvent)
          Sets last base event.
 void RevisionEventBeanDeclared.setLastBaseEvent(EventBean lastBaseEvent)
          Sets the last base event.
 

Constructors in com.espertech.esper.event.vaevent with parameters of type EventBean
RevisionBeanHolder(long version, EventBean eventBean, EventPropertyGetter[] getters)
          Ctor.
RevisionEventBeanDeclared(RevisionEventType eventType, EventBean underlying)
          Ctor.
RevisionEventBeanMerge(RevisionEventType revisionEventType, EventBean underlyingFull)
          Ctor.
RevisionStateDeclared(EventBean baseEventUnderlying, RevisionBeanHolder[] holders, RevisionEventBeanDeclared lastEvent)
          Ctor.
RevisionStateMerge(EventBean baseEventUnderlying, NullableObject<Object>[] overlays, RevisionEventBeanMerge lastEvent)
          Ctor.
VariantEventBean(VariantEventType variantEventType, EventBean underlying)
          Ctor.
 

Uses of EventBean in com.espertech.esper.event.xml
 

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

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

Uses of EventBean in com.espertech.esper.filter
 

Methods in com.espertech.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 com.espertech.esper.filter with parameters of type EventBean
ExprNodeAdapter(ExprNode exprNode, EventBean[] prototype, VariableService variableService)
          Ctor.
 

Uses of EventBean in com.espertech.esper.indicator.jmx
 

Methods in com.espertech.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 com.espertech.esper.pattern
 

Methods in com.espertech.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 com.espertech.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 com.espertech.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 com.espertech.esper.pattern with type arguments of type EventBean
 void PatternMatchCallback.matchFound(Map<String,EventBean> matchEvent)
          Indicate matching events.
 

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

Uses of EventBean in com.espertech.esper.plugin
 

Methods in com.espertech.esper.plugin that return EventBean
 EventBean PlugInEventBeanFactory.create(Object event, URI resolutionURI)
          Returns an event wrapper for the event object specific to the plug-in event representation or using one of the built-in types, or null if the event object is unknown and cannot be handled.
 

Uses of EventBean in com.espertech.esper.view
 

Methods in com.espertech.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 com.espertech.esper.view with parameters of type EventBean
 void ZeroDepthStream.insert(EventBean event)
           
 void EventStream.insert(EventBean event)
          Insert a new event onto the stream.
 EventTable[] HistoricalEventViewable.poll(EventBean[][] lookupEventsPerStream, PollResultIndexingStrategy indexingStrategy)
          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 com.espertech.esper.view.ext
 

Methods in com.espertech.esper.view.ext that return EventBean
 EventBean IStreamTimeOrderRandomAccess.getNewData(int index)
           
 EventBean IStreamSortedRandomAccess.getNewData(int index)
           
 EventBean IStreamTimeOrderRandomAccess.getOldData(int index)
           
 EventBean IStreamSortedRandomAccess.getOldData(int index)
           
 EventBean TimeOrderViewIterator.next()
           
 EventBean SortWindowIterator.next()
           
 

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

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

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

Constructor parameters in com.espertech.esper.view.ext with type arguments of type EventBean
SortWindowIterator(SortedMap<MultiKeyUntyped,LinkedList<EventBean>> window)
          Ctor.
TimeOrderViewIterator(SortedMap<Long,ArrayList<EventBean>> window)
          Ctor.
 

Uses of EventBean in com.espertech.esper.view.internal
 

Methods in com.espertech.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 com.espertech.esper.view.internal that return types with arguments of type EventBean
 Iterator<EventBean> PriorEventView.iterator()
           
 Iterator<EventBean> BufferView.iterator()
           
 

Methods in com.espertech.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 com.espertech.esper.view.stat
 

Methods in com.espertech.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 com.espertech.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 com.espertech.esper.view.std
 

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

Methods in com.espertech.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 com.espertech.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 com.espertech.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 com.espertech.esper.view.window
 

Methods in com.espertech.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 com.espertech.esper.view.window that return types with arguments of type EventBean
 Iterator<EventBean> TimeWindowView.iterator()
           
 Iterator<EventBean> TimeLengthBatchView.iterator()
           
 Iterator<EventBean> TimeBatchViewRStream.iterator()
           
 Iterator<EventBean> TimeBatchView.iterator()
           
 Iterator<EventBean> TimeAccumViewRStream.iterator()
           
 Iterator<EventBean> TimeAccumView.iterator()
           
 Iterator<EventBean> LengthWindowViewRStream.iterator()
           
 Iterator<EventBean> LengthWindowView.iterator()
           
 Iterator<EventBean> LengthBatchViewRStream.iterator()
           
 Iterator<EventBean> LengthBatchView.iterator()
           
 Iterator<EventBean> KeepAllView.iterator()
           
 Iterator<EventBean> ExternallyTimedWindowView.iterator()
           
 

Methods in com.espertech.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 TimeLengthBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeLengthBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeBatchViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeBatchViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeAccumViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeAccumViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeAccumView.update(EventBean[] newData, EventBean[] oldData)
           
 void TimeAccumView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthWindowViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthWindowViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthWindowView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthBatchViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthBatchViewRStream.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void LengthBatchView.update(EventBean[] newData, EventBean[] oldData)
           
 void KeepAllView.update(EventBean[] newData, EventBean[] oldData)
           
 void KeepAllView.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.
 


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