Uses of Interface
com.espertech.esper.common.internal.view.core.Viewable
Package
Description
Match-recognize core.
-
Uses of Viewable in com.espertech.esper.common.internal.context.activator
ModifierConstructorDescriptionViewableActivationResult
(Viewable viewable, AgentInstanceMgmtCallback stopCallback, EvalRootMatchRemover optEvalRootMatchRemover, boolean suppressSameEventMatches, boolean discardPartialsOnMatch, EvalRootState optionalPatternRoot, ViewableActivationResultExtension viewableActivationResultExtension, Runnable optPostContextMergeRunnable) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.core
ModifierConstructorDescriptionprotected
StatementAgentInstanceFactoryResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy rowRecogPreviousStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, Runnable postContextMergeRunnable) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createclass
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateClassResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createcontext
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateContextResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy regexExprPreviousEvalStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, ContextManagerRealization contextManagerRealization) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createdataflow
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateDataflowResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, DataflowDesc dataflow) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createexpression
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateExpressionResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createindex
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateIndexResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createschema
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateSchemaResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createtable
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateTableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, TableInstance tableInstance) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createvariable
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateVariableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createwindow
Modifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateNWResult.getEventStreamParentViewable()
StatementAgentInstanceFactoryCreateNWResult.getTopView()
ModifierConstructorDescriptionStatementAgentInstanceFactoryCreateNWResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable eventStreamParentViewable, Viewable topView, NamedWindowInstance namedWindowInstance, ViewableActivationResult viewableActivationResult) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.ontrigger.core
ModifierConstructorDescriptionStatementAgentInstanceFactoryOnTriggerResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy regexExprPreviousEvalStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, Runnable postContextMergeRunnable, EvalRootState optPatternRoot, ViewableActivationResult viewableActivationResult) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.ontrigger.onset
Modifier and TypeClassDescriptionclass
A view that handles the setting of variables upon receipt of a triggering event. -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit
-
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.select
Modifier and TypeMethodDescriptionViewable[]
StatementAgentInstanceFactorySelectResult.getEventStreamViewables()
Viewable[]
StatementAgentInstanceFactorySelectResult.getTopViews()
ModifierConstructorDescriptionStatementAgentInstanceFactorySelectResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService optionalAggegationService, Map<Integer, SubSelectFactoryResult> subselectStrategies, PriorEvalStrategy[] priorStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy regexExprPreviousEvalStrategy, Map<Integer, ExprTableEvalStrategy> tableAccessStrategies, List<StatementAgentInstancePreload> preloadList, Runnable postContextMergeRunnable, EvalRootState[] patternRoots, JoinSetComposer joinSetComposer, Viewable[] topViews, Viewable[] eventStreamViewables, ViewableActivationResult[] viewableActivationResults, ResultSetProcessor resultSetProcessor) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.update
ModifierConstructorDescriptionStatementAgentInstanceFactoryUpdateResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Map<Integer, SubSelectFactoryResult> subselectActivations) -
Uses of Viewable in com.espertech.esper.common.internal.context.util
Modifier and TypeClassDescriptionclass
class
class
View for use with pre-processing statement such as "update istream" for indicating previous and current event.Modifier and TypeMethodDescriptionstatic void
AgentInstanceUtil.stop
(AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView, boolean isStatementStop, boolean leaveLocksAcquired) ModifierConstructorDescriptionAgentInstance
(AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView) -
Uses of Viewable in com.espertech.esper.common.internal.epl.fafquery.processor
Modifier and TypeMethodDescriptionabstract Viewable
FireAndForgetInstance.getTailViewInstance()
FireAndForgetInstanceNamedWindow.getTailViewInstance()
FireAndForgetInstanceTable.getTailViewInstance()
-
Uses of Viewable in com.espertech.esper.common.internal.epl.historical.common
Modifier and TypeInterfaceDescriptioninterface
Interface for views that poll data based on information from other streams.Modifier and TypeClassDescriptionclass
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 Viewable in com.espertech.esper.common.internal.epl.historical.database.core
-
Uses of Viewable in com.espertech.esper.common.internal.epl.historical.method.core
-
Uses of Viewable in com.espertech.esper.common.internal.epl.join.base
Modifier and TypeMethodDescriptionJoinSetComposerPrototype.create
(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) JoinSetComposerPrototypeGeneral.create
(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) JoinSetComposerPrototypeHistorical2Stream.create
(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext, boolean isRecoveringResilient) ModifierConstructorDescriptionJoinSetComposerHistoricalImpl
(boolean allowInitIndex, Map<TableLookupIndexReqKey, EventTable>[] repositories, QueryStrategy[] queryStrategies, Viewable[] streamViews, ExprEvaluatorContext staticEvalExprEvaluatorContext) -
Uses of Viewable in com.espertech.esper.common.internal.epl.join.queryplan
Modifier and TypeMethodDescriptionHistoricalDataPlanNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) LookupInstructionQueryPlanNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) NestedIterationNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) abstract ExecNode
QueryPlanNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) QueryPlanNodeAllUnidirectionalOuter.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) QueryPlanNodeNoOp.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) TableLookupNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) TableOuterLookupNode.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal, Lock[] tableSecondaryIndexLocks) HistoricalDataPlanNode.makeOuterJoinStategy
(Viewable[] streamViews) Returns the table lookup strategy for use in outer joins. -
Uses of Viewable in com.espertech.esper.common.internal.epl.join.queryplanouter
Modifier and TypeMethodDescriptionLookupInstructionPlan.makeExec
(AgentInstanceContext agentInstanceContext, Map<TableLookupIndexReqKey, EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, VirtualDWView[] viewExternal) -
Uses of Viewable in com.espertech.esper.common.internal.epl.namedwindow.consume
Modifier and TypeClassDescriptionclass
Represents a consumer of a named window that selects from a named window via a from-clause. -
Uses of Viewable in com.espertech.esper.common.internal.epl.namedwindow.core
Modifier and TypeClassDescriptionclass
class
The root window in a named window plays multiple roles: It holds the indexes for deleting rows, if any on-delete statement requires such indexes.class
This view is hooked into a named window's view chain as the last view and handles dispatching of named window insert and remove stream results viaNamedWindowManagementService
to consuming statements. -
Uses of Viewable in com.espertech.esper.common.internal.epl.ontrigger
Modifier and TypeClassDescriptionclass
View for the on-delete statement that handles removing events from a named window.class
View for the on-delete statement that handles removing events from a named window.class
View for the on-delete statement that handles removing events from a named window.class
View for the on-select statement that handles selecting events from a named window.class
View for the on-delete statement that handles removing events from a named window.class
View for the on-delete statement that handles removing events from a named window.class
class
View for the on-delete statement that handles removing events from a named window.class
class
class
class
-
Uses of Viewable in com.espertech.esper.common.internal.epl.output.condition
Modifier and TypeClassDescriptionclass
A view that prepares output events, batching incoming events and invoking the result set processor as necessary. -
Uses of Viewable in com.espertech.esper.common.internal.epl.output.core
Modifier and TypeClassDescriptionclass
class
class
A view that handles the "output snapshot" keyword in output rate stabilizing.class
class
class
Modifier and TypeMethodDescriptionOutputStrategyUtil.getIterator
(JoinExecutionStrategy joinExecutionStrategy, ResultSetProcessor resultSetProcessor, Viewable parentView, boolean distinct, EventPropertyValueGetter distinctKeyGetter) NOTE: Code-generation-invoked method, method name and parameter order mattersvoid
-
Uses of Viewable in com.espertech.esper.common.internal.epl.output.view
Modifier and TypeClassDescriptionclass
class
A view that prepares output events, batching incoming events and invoking the result set processor as necessary.class
Handles output rate limiting for FIRST, only applicable with a having-clause and no group-by clause.class
Handles output rate limiting for FIRST, only applicable with a having-clause and no group-by clause.class
Handles output rate limiting for LAST and without order-by.class
A view that handles the "output snapshot" keyword in output rate stabilizing.class
Output process view that does not enforce any output policies and may simply hand over events to child views, does not handle distinct.class
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 policiesclass
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 policiesclass
-
Uses of Viewable in com.espertech.esper.common.internal.epl.resultset.core
Modifier and TypeMethodDescriptionstatic void
ResultSetProcessorUtil.clearAndAggregateUngrouped
(ExprEvaluatorContext exprEvaluatorContext, AggregationService aggregationService, Viewable parent) 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. -
Uses of Viewable in com.espertech.esper.common.internal.epl.resultset.handthru
Modifier and TypeMethodDescriptionResultSetProcessorHandThroughImpl.getIterator
(Viewable viewable) -
Uses of Viewable in com.espertech.esper.common.internal.epl.rowrecog.core
Modifier and TypeMethodDescriptionstatic RowRecogNFAViewService
RowRecogHelper.recursiveFindRegexService
(Viewable top) -
Uses of Viewable in com.espertech.esper.common.internal.epl.subselect
Modifier and TypeClassDescriptionclass
View handling the insert and remove stream generated by a subselect for application to aggregation state.class
class
class
class
Modifier and TypeMethodDescriptionSubSelectFactoryResult.getSubselectView()
SubSelectStrategyRealization.getSubselectView()
Modifier and TypeMethodDescriptionSubSelectStrategyFactory.instantiate
(Viewable viewableRoot, ExprEvaluatorContext exprEvaluatorContext, List<AgentInstanceMgmtCallback> stopCallbackList, int subqueryNumber, boolean isRecoveringResilient) SubSelectStrategyFactoryIndexShare.instantiate
(Viewable viewableRoot, ExprEvaluatorContext exprEvaluatorContext, List<AgentInstanceMgmtCallback> stopCallbackList, int subqueryNumber, boolean isRecoveringResilient) SubSelectStrategyFactoryLocalViewPreloaded.instantiate
(Viewable viewableRoot, ExprEvaluatorContext exprEvaluatorContext, List<AgentInstanceMgmtCallback> stopCallbackList, int subqueryNumber, boolean isRecoveringResilient) ModifierConstructorDescriptionSubSelectStrategyRealization
(SubordTableLookupStrategy lookupStrategy, SubselectAggregationPreprocessorBase subselectAggregationPreprocessor, AggregationService aggregationService, PriorEvalStrategy priorStrategy, PreviousGetterStrategy previousStrategy, Viewable subselectView, EventTable[] indexes) -
Uses of Viewable in com.espertech.esper.common.internal.epl.table.core
-
Uses of Viewable in com.espertech.esper.common.internal.epl.virtualdw
-
Uses of Viewable in com.espertech.esper.common.internal.statement.dispatch
Modifier and TypeInterfaceDescriptioninterface
Update dispatch view to indicate statement results to listeners. -
Uses of Viewable in com.espertech.esper.common.internal.statement.resource
Modifier and TypeMethodDescriptionViewable[]
StatementResourceHolder.getEventStreamViewables()
StatementResourceHolder.getFinalView()
Viewable[]
StatementResourceHolder.getTopViewables()
Modifier and TypeMethodDescriptionprotected void
StatementResourceHolder.setEventStreamViewables
(Viewable[] eventStreamViewables) protected void
StatementResourceHolder.setTopViewables
(Viewable[] topViewables) ModifierConstructorDescriptionStatementResourceHolder
(AgentInstanceContext agentInstanceContext, AgentInstanceMgmtCallback agentInstanceStopCallback, Viewable finalView, AggregationService aggregationService, PriorEvalStrategy[] priorEvalStrategies, PreviousGetterStrategy[] previousGetterStrategies, RowRecogPreviousStrategy rowRecogPreviousStrategy) -
Uses of Viewable in com.espertech.esper.common.internal.view.core
Modifier and TypeInterfaceDescriptioninterface
Tag interface for data window views.interface
Tag interface for derived-value views.interface
A streams is a conduct for incoming events.interface
The View interface provides a way for a stream, data provider, or another view, to notify an object of additions and deletions to its data set.Modifier and TypeClassDescriptionfinal class
View to handle pattern discarding for a single stream (no join).final class
View to dispatch for a single stream (no join).class
class
class
class
class
Event stream implementation that does not keep any window by itself of the events coming into the stream, however is itself iterable and keeps the last event.final class
Event stream implementation that does not keep any window by itself of the events coming into the stream, however is itself iterable and keeps the last event.class
Event stream implementation that does not keep any window by itself of the events coming into the stream, without the possibility to iterate the last event.final class
Modifier and TypeMethodDescriptionViewablePair.getLast()
View.getParent()
Returns the View's parent Viewable.ViewNoop.getParent()
ViewNullEvent.getParent()
ViewSupport.getParent()
ViewablePair.getTop()
Modifier and TypeMethodDescriptionstatic ViewablePair
ViewFactoryUtil.materialize
(ViewFactory[] factories, Viewable eventStreamParent, AgentInstanceViewFactoryChainContext viewFactoryChainContext, List<AgentInstanceMgmtCallback> stopCallbacks) void
Called when the View is added to a Viewable object.void
void
void
-
Uses of Viewable in com.espertech.esper.common.internal.view.derived
Modifier and TypeClassDescriptionclass
View for computing statistics that require 2 input variable arrays containing X and Y datapoints.class
A view that calculates correlation on two fields.class
A view that calculates regression on two fields.class
This view is a very simple view presenting the number of elements in a stream or view.class
View for computing statistics, which the view exposes via fields representing the sum, count, standard deviation for sample and for population and variance.class
View for computing a weighted average. -
Uses of Viewable in com.espertech.esper.common.internal.view.expression
Modifier and TypeClassDescriptionclass
This view is a moving window extending the into the past until the expression passed to it returns false.class
This view is a moving window extending the into the past until the expression passed to it returns false.class
This view is a moving window extending the into the past until the expression passed to it returns false. -
Uses of Viewable in com.espertech.esper.common.internal.view.exttimedbatch
Modifier and TypeClassDescriptionclass
Batch window based on timestamp of arriving events. -
Uses of Viewable in com.espertech.esper.common.internal.view.exttimedwin
Modifier and TypeClassDescriptionclass
View for a moving window extending the specified amount of time into the past, driven entirely by external timing supplied within long-type timestamp values in a field of the event beans that the view receives. -
Uses of Viewable in com.espertech.esper.common.internal.view.filter
Modifier and TypeClassDescriptionclass
Simple filter view filtering events using a filter expression tree. -
Uses of Viewable in com.espertech.esper.common.internal.view.firstevent
-
Uses of Viewable in com.espertech.esper.common.internal.view.firstlength
Modifier and TypeClassDescriptionclass
A length-first view takes the first N arriving events. -
Uses of Viewable in com.espertech.esper.common.internal.view.firsttime
-
Uses of Viewable in com.espertech.esper.common.internal.view.firstunique
Modifier and TypeClassDescriptionclass
This view retains the first event for each multi-key of distinct property values. -
Uses of Viewable in com.espertech.esper.common.internal.view.groupwin
Modifier and TypeClassDescriptionfinal class
This view simply adds a property to the events posted to it.class
The group view splits the data in a stream to multiple subviews, based on a key index.class
class
-
Uses of Viewable in com.espertech.esper.common.internal.view.intersect
Modifier and TypeClassDescriptionclass
A view that represents an intersection of multiple data windows.class
A view that represents an intersection of multiple data windows.class
A view that represents an intersection of multiple data windows.final class
A view that retains the last update. -
Uses of Viewable in com.espertech.esper.common.internal.view.keepall
Modifier and TypeClassDescriptionclass
This view is a keep-all data window that simply keeps all events added. -
Uses of Viewable in com.espertech.esper.common.internal.view.lastevent
Modifier and TypeClassDescriptionclass
This view is a very simple view presenting the last event posted by the parent view to any subviews. -
Uses of Viewable in com.espertech.esper.common.internal.view.length
Modifier and TypeClassDescriptionclass
This view is a moving window extending the specified number of elements into the past.class
This view is a moving window extending the specified number of elements into the past, allowing in addition to remove events efficiently for remove-stream events received by the view. -
Uses of Viewable in com.espertech.esper.common.internal.view.lengthbatch
Modifier and TypeClassDescriptionclass
A data view that aggregates events in a stream and releases them in one batch when a maximum number of events has been collected.class
Same as theLengthBatchView
, this view also supports fast-remove from the batch for remove stream events. -
Uses of Viewable in com.espertech.esper.common.internal.view.prior
Modifier and TypeClassDescriptionclass
View that provides access to prior events posted by the parent view for use by 'prior' expression nodes. -
Uses of Viewable in com.espertech.esper.common.internal.view.rank
Modifier and TypeClassDescriptionclass
Window sorting by values in the specified field extending a specified number of elements from the lowest value up or the highest value down and retaining only the last unique value per key. -
Uses of Viewable in com.espertech.esper.common.internal.view.sort
Modifier and TypeClassDescriptionclass
Window sorting by values in the specified field extending a specified number of elements from the lowest value up or the highest value down. -
Uses of Viewable in com.espertech.esper.common.internal.view.time_accum
Modifier and TypeClassDescriptionclass
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
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. -
Uses of Viewable in com.espertech.esper.common.internal.view.timebatch
Modifier and TypeClassDescriptionclass
A data view that aggregates events in a stream and releases them in one batch at every specified time interval.class
Same as theTimeBatchView
, this view also supports fast-remove from the batch for remove stream events. -
Uses of Viewable in com.espertech.esper.common.internal.view.timelengthbatch
Modifier and TypeClassDescriptionclass
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. -
Uses of Viewable in com.espertech.esper.common.internal.view.timetolive
Modifier and TypeClassDescriptionclass
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 Viewable in com.espertech.esper.common.internal.view.timewin
Modifier and TypeClassDescriptionclass
This view is a moving timeWindow extending the specified amount of milliseconds into the past. -
Uses of Viewable in com.espertech.esper.common.internal.view.union
Modifier and TypeClassDescriptionclass
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
A view that represents a union of multiple data windows. -
Uses of Viewable in com.espertech.esper.common.internal.view.unique
Modifier and TypeClassDescriptionclass
This view includes only the most recent among events having the same value for the specified field or fields. -
Uses of Viewable in com.espertech.esper.common.internal.view.util
Modifier and TypeClassDescriptionfinal class
A view that acts as an adapter between views and update listeners.