Uses of Interface
com.espertech.esper.util.StopCallback

Packages that use StopCallback
com.espertech.esper.core.context.activator Activation of streams for statement start. 
com.espertech.esper.core.context.factory Statement agent instance factories. 
com.espertech.esper.core.context.mgr Context management. 
com.espertech.esper.core.context.stmt Registries for context partitions to handle aggregations, prev/prior and subselects. 
com.espertech.esper.core.context.subselect Subselect implementation. 
com.espertech.esper.core.context.util Context partition utility or reference classes. 
com.espertech.esper.core.service Implementation of client package interfaces, glue code 
com.espertech.esper.core.start Classes related to start and stop of statements 
com.espertech.esper.epl.agg.service Aggregation services. 
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.named Named window classes are in this package 
com.espertech.esper.epl.subquery Subquery helper classes are found here. 
com.espertech.esper.epl.table.onaction Table on-action handlers. 
com.espertech.esper.epl.view Internal processing views for output rate limiting, filtering and internal event routing 
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.rowregex Match-recognize expression tree and state objects. 
com.espertech.esper.util Utility classes that center around Java type handling, printing, reflection, debugging 
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.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 StopCallback in com.espertech.esper.core.context.activator
 

Classes in com.espertech.esper.core.context.activator that implement StopCallback
 class ViewableActivatorFilterProxyStopCallback
           
 class ViewableActivatorStreamReuseView
           
 

Methods in com.espertech.esper.core.context.activator that return StopCallback
 StopCallback ViewableActivationResult.getStopCallback()
           
 

Constructors in com.espertech.esper.core.context.activator with parameters of type StopCallback
ViewableActivationResult(Viewable viewable, StopCallback stopCallback, StatementAgentInstanceLock optionalLock, EvalRootState optionalPatternRoot, EvalRootMatchRemover optEvalRootMatchRemover, boolean suppressSameEventMatches, boolean discardPartialsOnMatch, ViewableActivationResultExtension viewableActivationResultExtension)
           
 

Uses of StopCallback in com.espertech.esper.core.context.factory
 

Methods in com.espertech.esper.core.context.factory that return StopCallback
 StopCallback StatementAgentInstanceFactoryResult.getStopCallback()
           
 

Methods in com.espertech.esper.core.context.factory with parameters of type StopCallback
 void StatementAgentInstanceFactoryResult.setStopCallback(StopCallback stopCallback)
           
 

Method parameters in com.espertech.esper.core.context.factory with type arguments of type StopCallback
protected static void StatementAgentInstanceFactorySelect.addViewStopCallback(java.util.List<StopCallback> stopCallbacks, java.util.List<View> topViews)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerTable.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks, boolean isRecoveringReslient)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerSplit.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks, boolean isRecoveringReslient)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerSetVariable.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks, boolean isRecoveringReslient)
           
 StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerNamedWindow.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks, boolean isRecoveringReslient)
           
abstract  StatementAgentInstanceFactoryOnTriggerBase.OnExprViewResult StatementAgentInstanceFactoryOnTriggerBase.determineOnExprView(AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbacks, boolean isRecoveringReslient)
           
 

Constructors in com.espertech.esper.core.context.factory with parameters of type StopCallback
StatementAgentInstanceFactoryCreateIndexResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext)
           
StatementAgentInstanceFactoryCreateSchemaResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext)
           
StatementAgentInstanceFactoryCreateTableResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationServiceTable aggregationReportingService)
           
StatementAgentInstanceFactoryCreateVariableResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext)
           
StatementAgentInstanceFactoryCreateWindowResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable eventStreamParentViewable, StatementAgentInstancePostLoad postLoad, Viewable topView, NamedWindowProcessorInstance processorInstance, ViewableActivationResult viewableActivationResult)
           
StatementAgentInstanceFactoryOnTriggerResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService aggregationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, EvalRootState optPatternRoot, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies, ViewableActivationResult viewableActivationResult)
           
StatementAgentInstanceFactoryResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorNodeStrategies, java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies, RegexExprPreviousEvalStrategy regexExprPreviousEvalStrategy, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies, java.util.List<StatementAgentInstancePreload> preloadList)
           
StatementAgentInstanceFactorySelectResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorNodeStrategies, java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies, RegexExprPreviousEvalStrategy regexExprPreviousEvalStrategy, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies, java.util.List<StatementAgentInstancePreload> preloadList, EvalRootState[] patternRoots, StatementAgentInstancePostLoad optionalPostLoadJoin, Viewable[] topViews, Viewable[] eventStreamViewables, ViewableActivationResult[] viewableActivationResults)
           
StatementAgentInstanceFactoryUpdateResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies)
           
 

Constructor parameters in com.espertech.esper.core.context.factory with type arguments of type StopCallback
StatementAgentInstanceFactoryOnTriggerNamedWindow(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, NamedWindowOnExprFactory onExprFactory, OutputProcessViewFactory outputProcessViewFactory, EventType activatorResultEventType, NamedWindowProcessor processor, java.util.List<StopCallback> stopCallbacks)
           
 

Uses of StopCallback in com.espertech.esper.core.context.mgr
 

Methods in com.espertech.esper.core.context.mgr that return StopCallback
 StopCallback AgentInstance.getStopCallback()
           
 

Constructors in com.espertech.esper.core.context.mgr with parameters of type StopCallback
AgentInstance(StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView)
           
 

Uses of StopCallback in com.espertech.esper.core.context.stmt
 

Subinterfaces of StopCallback in com.espertech.esper.core.context.stmt
 interface AIRegistryAggregation
           
 

Classes in com.espertech.esper.core.context.stmt that implement StopCallback
 class AIRegistryAggregationMap
           
 class AIRegistryAggregationMultiPerm
           
 class AIRegistryAggregationSingle
           
 

Uses of StopCallback in com.espertech.esper.core.context.subselect
 

Method parameters in com.espertech.esper.core.context.subselect with type arguments of type StopCallback
 SubSelectStrategyRealization SubSelectStrategyFactoryLocalViewPreloaded.instantiate(EPServicesContext services, Viewable viewableRoot, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList, int subqueryNumber, boolean isRecoveringResilient)
           
 SubSelectStrategyRealization SubSelectStrategyFactoryIndexShare.instantiate(EPServicesContext services, Viewable viewableRoot, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList, int subqueryNumber, boolean isRecoveringResilient)
           
 SubSelectStrategyRealization SubSelectStrategyFactory.instantiate(EPServicesContext services, Viewable viewableRoot, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList, int subqueryNumber, boolean isRecoveringResilient)
           
 

Uses of StopCallback in com.espertech.esper.core.context.util
 

Methods in com.espertech.esper.core.context.util that return StopCallback
static StopCallback StatementAgentInstanceUtil.getStopCallback(java.util.List<StopCallback> stopCallbacks, AgentInstanceContext agentInstanceContext)
           
 

Methods in com.espertech.esper.core.context.util that return types with arguments of type StopCallback
 java.util.Collection<StopCallback> AgentInstanceContext.getTerminationCallbackRO()
           
 java.util.Collection<StopCallback> AgentInstanceViewFactoryChainContext.getTerminationCallbacksRO()
           
 

Methods in com.espertech.esper.core.context.util with parameters of type StopCallback
 void AgentInstanceViewFactoryChainContext.addTerminationCallback(StopCallback callback)
           
 void AgentInstanceContext.addTerminationCallback(StopCallback callback)
           
 void AgentInstanceViewFactoryChainContext.removeTerminationCallback(StopCallback callback)
           
 void AgentInstanceContext.removeTerminationCallback(StopCallback callback)
           
static void StatementAgentInstanceUtil.stop(StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView, EPServicesContext servicesContext, boolean isStatementStop, boolean leaveLocksAcquired, boolean removedStatementResources)
           
static void StatementAgentInstanceUtil.stopSafe(java.util.Collection<StopCallback> terminationCallbacks, StopCallback[] stopCallbacks, StatementContext statementContext)
           
static void StatementAgentInstanceUtil.stopSafe(StopCallback[] stopMethods, StatementContext statementContext)
           
static void StatementAgentInstanceUtil.stopSafe(StopCallback stopMethod, StatementContext statementContext)
           
 

Method parameters in com.espertech.esper.core.context.util with type arguments of type StopCallback
static StopCallback StatementAgentInstanceUtil.getStopCallback(java.util.List<StopCallback> stopCallbacks, AgentInstanceContext agentInstanceContext)
           
static void StatementAgentInstanceUtil.stopSafe(java.util.Collection<StopCallback> terminationCallbacks, StopCallback[] stopCallbacks, StatementContext statementContext)
           
 

Uses of StopCallback in com.espertech.esper.core.service
 

Methods in com.espertech.esper.core.service that return StopCallback
 StopCallback EPStatementFactoryDefault.makeStopMethod(StatementAgentInstanceFactoryResult startResult)
           
 StopCallback EPStatementFactory.makeStopMethod(StatementAgentInstanceFactoryResult startResult)
           
 

Method parameters in com.espertech.esper.core.service with type arguments of type StopCallback
 void StatementExtensionSvcContext.contributeStopCallback(StatementAgentInstanceFactoryResult selectResult, java.util.List<StopCallback> stopCallbacks)
           
 

Uses of StopCallback in com.espertech.esper.core.start
 

Method parameters in com.espertech.esper.core.start with type arguments of type StopCallback
static java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> EPStatementStartMethodHelperSubselect.startSubselects(EPServicesContext services, SubSelectStrategyCollection subSelectStrategyCollection, AgentInstanceContext agentInstanceContext, java.util.List<StopCallback> stopCallbackList, boolean isRecoveringResilient)
           
 

Constructor parameters in com.espertech.esper.core.start with type arguments of type StopCallback
EPStatementStopMethodImpl(StatementContext statementContext, java.util.List<StopCallback> stopCallbacks)
           
 

Uses of StopCallback in com.espertech.esper.epl.agg.service
 

Subinterfaces of StopCallback in com.espertech.esper.epl.agg.service
 interface AggregationService
          Service for maintaining aggregation state.
 

Classes in com.espertech.esper.epl.agg.service that implement StopCallback
 class AggregationServiceBase
          All aggregation services require evaluation nodes which supply the value to be aggregated (summed, averaged, etc.) and aggregation state factories to make new aggregation states.
 class AggregationServiceBaseGrouped
          All aggregation services require evaluation nodes which supply the value to be aggregated (summed, averaged, etc.) and aggregation state factories to make new aggregation states.
 class AggregationServiceBaseUngrouped
          All aggregation services require evaluation nodes which supply the value to be aggregated (summed, averaged, etc.) and aggregation state factories to make new aggregation states.
 class AggregationServiceNull
          A null object implementation of the AggregationService interface.
 class AggregationServiceTable
           
 class AggSvcGroupAllAccessOnlyImpl
          Aggregation service for use when only first/last/window aggregation functions are used an none other.
 class AggSvcGroupAllLocalGroupBy
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupAllMixedAccessImpl
          Implementation for handling aggregation without any grouping (no group-by).
 class AggSvcGroupAllMixedAccessWTableImpl
          Implementation for handling aggregation without any grouping (no group-by).
 class AggSvcGroupAllNoAccessImpl
          Implementation for handling aggregation without any grouping (no group-by).
 class AggSvcGroupByAccessOnlyImpl
          Aggregation service for use when only first/last/window aggregation functions are used an none other.
 class AggSvcGroupByLocalGroupBy
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByMixedAccessImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByNoAccessImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByReclaimAgedImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByRefcountedNoAccessImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByRefcountedWAccessImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByRefcountedWAccessRollupImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByWTableBase
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByWTableImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByWTableRollupMultiKeyImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupByWTableRollupSingleKeyImpl
          Implementation for handling aggregation with grouping by group-keys.
 class AggSvcGroupLocalGroupByBase
          Implementation for handling aggregation with grouping by group-keys.
 

Uses of StopCallback in com.espertech.esper.epl.core
 

Subinterfaces of StopCallback in com.espertech.esper.epl.core
 interface ResultSetProcessor
          Processor for result sets coming from 2 sources.
 

Classes in com.espertech.esper.epl.core that implement StopCallback
 class MethodPollingViewable
          Polling-data provider that calls a static method on a class and passed parameters, and wraps the results as POJO events.
 class ResultSetProcessorAggregateAll
          Result set processor for the case: aggregation functions used in the select clause, and no group-by, and not all of the properties in the select clause are under an aggregation function.
 class ResultSetProcessorAggregateGrouped
          Result-set processor for the aggregate-grouped case: there is a group-by and one or more non-aggregation event properties in the select clause are not listed in the group by, and there are aggregation functions.
 class ResultSetProcessorBaseSimple
          Result set processor for the simplest case: no aggregation functions used in the select clause, and no group-by.
 class ResultSetProcessorHandThrough
          Result set processor for the hand-through case: no aggregation functions used in the select clause, and no group-by, no having and ordering.
 class ResultSetProcessorRowForAll
          Result set processor for the case: aggregation functions used in the select clause, and no group-by, and all properties in the select clause are under an aggregation function.
 class ResultSetProcessorRowPerGroup
          Result set processor for the fully-grouped case: there is a group-by and all non-aggregation event properties in the select clause are listed in the group by, and there are aggregation functions.
 class ResultSetProcessorRowPerGroupRollup
           
 class ResultSetProcessorRowPerGroupRollupUnbound
           
 class ResultSetProcessorRowPerGroupUnbound
           
 class ResultSetProcessorSimple
          Result set processor for the simplest case: no aggregation functions used in the select clause, and no group-by.
 

Uses of StopCallback in com.espertech.esper.epl.db
 

Classes in com.espertech.esper.epl.db that implement StopCallback
 class DatabasePollingViewable
          Implements a poller viewable that uses a polling strategy, a cache and some input parameters extracted from event streams to perform the polling.
 

Uses of StopCallback in com.espertech.esper.epl.named
 

Classes in com.espertech.esper.epl.named that implement StopCallback
 class NamedWindowConsumerView
          Represents a consumer of a named window that selects from a named window via a from-clause.
 

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

Classes in com.espertech.esper.epl.subquery that implement StopCallback
 class SubqueryStopCallback
          Implements a stop callback for use with subqueries to clear their indexes when a statement is stopped.
 

Uses of StopCallback in com.espertech.esper.epl.table.onaction
 

Classes in com.espertech.esper.epl.table.onaction that implement StopCallback
 class TableOnDeleteView
          View for the on-delete statement that handles removing events from a named window.
 class TableOnMergeView
           
 class TableOnSelectView
           
 class TableOnUpdateView
           
 class TableOnViewBase
           
 

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

Classes in com.espertech.esper.epl.view that implement StopCallback
 class OutputConditionExpression
          Output condition for output rate limiting that handles when-then expressions for controlling output.
 class OutputConditionTime
          Output condition that is satisfied at the end of every time interval of a given length.
 class OutputProcessViewBase
           
 class OutputProcessViewBaseCallback
          Factory for output processing views.
 class OutputProcessViewBaseWAfter
           
 class OutputProcessViewConditionDefault
          A view that prepares output events, batching incoming events and invoking the result set processor as necessary.
 class OutputProcessViewConditionDefaultPostProcess
          A view that prepares output events, batching incoming events and invoking the result set processor as necessary.
 class OutputProcessViewConditionFirst
          Handles output rate limiting for FIRST, only applicable with a having-clause and no group-by clause.
 class OutputProcessViewConditionFirstPostProcess
          Handles output rate limiting for FIRST, only applicable with a having-clause and no group-by clause.
 class OutputProcessViewConditionLastAllUnord
          Handles output rate limiting for LAST and without order-by.
 class OutputProcessViewConditionLastAllUnordPostProcessAll
           
 class OutputProcessViewConditionSnapshot
          A view that handles the "output snapshot" keyword in output rate stabilizing.
 class OutputProcessViewConditionSnapshotPostProcess
          A view that handles the "output snapshot" keyword in output rate stabilizing.
 class OutputProcessViewDirect
          Output process view that does not enforce any output policies and may simply hand over events to child views, does not handle distinct.
 class OutputProcessViewDirectDistinctOrAfter
          Output process view that does not enforce any output policies and may simply hand over events to child views, but works with distinct and after-output policies
 class OutputProcessViewDirectDistinctOrAfterPostProcess
          Output process view that does not enforce any output policies and may simply hand over events to child views, but works with distinct and after-output policies
 class OutputProcessViewDirectPostProcess
           
 

Uses of StopCallback in com.espertech.esper.pattern
 

Subinterfaces of StopCallback in com.espertech.esper.pattern
 interface EvalRootState
          Interface for a root state node accepting a callback to use to indicate pattern results.
 interface PatternStopCallback
          Interface for executing a stop on an active event expression.
 

Classes in com.espertech.esper.pattern that implement StopCallback
 class EvalRootStateNode
          This class is always the root node in the evaluation state tree representing any activated event expression.
 

Uses of StopCallback in com.espertech.esper.rowregex
 

Subinterfaces of StopCallback in com.espertech.esper.rowregex
 interface EventRowRegexNFAViewService
          Service interface for match recognize.
 

Classes in com.espertech.esper.rowregex that implement StopCallback
 class EventRowRegexNFAView
          View for match recognize support.
 

Uses of StopCallback in com.espertech.esper.util
 

Classes in com.espertech.esper.util that implement StopCallback
 class StopCallbackNoAction
          Stop callback that performs no action.
 

Fields in com.espertech.esper.util declared as StopCallback
static StopCallback StopCallbackNoAction.INSTANCE
           
static StopCallback CollectionUtil.STOP_CALLBACK_NONE
           
 

Uses of StopCallback in com.espertech.esper.view
 

Subinterfaces of StopCallback in com.espertech.esper.view
 interface HistoricalEventViewable
          Interface for views that poll data based on information from other streams.
 interface StoppableView
           
 

Uses of StopCallback in com.espertech.esper.view.ext
 

Classes in com.espertech.esper.view.ext that implement StopCallback
 class TimeOrderView
          Window retaining timestamped events up to a given number of seconds such that older events that arrive later are sorted into the window and released in timestamp order.
 

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

Classes in com.espertech.esper.view.internal that implement StopCallback
 class IntersectAsymetricView
          A view that represents an intersection of multiple data windows.
 class IntersectBatchView
          A view that represents an intersection of multiple data windows.
 class IntersectDefaultView
          A view that represents an intersection of multiple data windows.
 class UnionAsymetricView
          A view that represents a union of multiple data windows wherein at least one is asymetric: it does not present a insert stream for each insert stream event received.
 class UnionView
          A view that represents a union of multiple data windows.
 

Uses of StopCallback in com.espertech.esper.view.std
 

Classes in com.espertech.esper.view.std that implement StopCallback
 class AddPropertyValueOptionalView
          This view simply adds a property to the events posted to it.
 

Uses of StopCallback in com.espertech.esper.view.window
 

Classes in com.espertech.esper.view.window that implement StopCallback
 class ExpressionBatchView
          This view is a moving window extending the into the past until the expression passed to it returns false.
 class ExpressionViewBase
          This view is a moving window extending the into the past until the expression passed to it returns false.
 class ExpressionWindowView
          This view is a moving window extending the into the past until the expression passed to it returns false.
 class FirstTimeView
           
 class TimeAccumView
          A data window view that holds events in a stream and only removes events from a stream (rstream) if no more events arrive for a given time interval.
 class TimeAccumViewRStream
          A data window view that holds events in a stream and only removes events from a stream (rstream) if no more events arrive for a given time interval, also handling the remove stream by keeping set-like semantics.
 class TimeBatchView
          A data view that aggregates events in a stream and releases them in one batch at every specified time interval.
 class TimeBatchViewRStream
          Same as the TimeBatchView, this view also supports fast-remove from the batch for remove stream events.
 class TimeLengthBatchView
          A data view that aggregates events in a stream and releases them in one batch if either one of these conditions is reached, whichever comes first: One, a time interval passes.
 class TimeWindowView
          This view is a moving timeWindow extending the specified amount of milliseconds into the past.
 


© 2006-2016 EsperTech Inc.
All rights reserved.
Visit us at espertech.com