Uses of Interface
com.espertech.esper.common.internal.view.core.Viewable
Packages that use Viewable
Package
Description
Match-recognize core.
-
Uses of Viewable in com.espertech.esper.common.internal.context.activator
Methods in com.espertech.esper.common.internal.context.activator that return ViewableConstructors in com.espertech.esper.common.internal.context.activator with parameters of type ViewableModifierConstructorDescriptionViewableActivationResult
(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
Methods in com.espertech.esper.common.internal.context.aifactory.core that return ViewableConstructors in com.espertech.esper.common.internal.context.aifactory.core with parameters of type ViewableModifierConstructorDescriptionprotected
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
Constructors in com.espertech.esper.common.internal.context.aifactory.createclass with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateClassResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createcontext
Constructors in com.espertech.esper.common.internal.context.aifactory.createcontext with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateContextResult
(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
Constructors in com.espertech.esper.common.internal.context.aifactory.createdataflow with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateDataflowResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, DataflowDesc dataflow) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createexpression
Constructors in com.espertech.esper.common.internal.context.aifactory.createexpression with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateExpressionResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createindex
Constructors in com.espertech.esper.common.internal.context.aifactory.createindex with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateIndexResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createschema
Constructors in com.espertech.esper.common.internal.context.aifactory.createschema with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateSchemaResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createtable
Constructors in com.espertech.esper.common.internal.context.aifactory.createtable with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateTableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, TableInstance tableInstance) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createvariable
Classes in com.espertech.esper.common.internal.context.aifactory.createvariable that implement ViewableConstructors in com.espertech.esper.common.internal.context.aifactory.createvariable with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateVariableResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext) -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.createwindow
Methods in com.espertech.esper.common.internal.context.aifactory.createwindow that return ViewableModifier and TypeMethodDescriptionStatementAgentInstanceFactoryCreateNWResult.getEventStreamParentViewable()
StatementAgentInstanceFactoryCreateNWResult.getTopView()
Constructors in com.espertech.esper.common.internal.context.aifactory.createwindow with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryCreateNWResult
(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
Constructors in com.espertech.esper.common.internal.context.aifactory.ontrigger.core with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryOnTriggerResult
(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
Classes in com.espertech.esper.common.internal.context.aifactory.ontrigger.onset that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.context.aifactory.ontrigger.onsplit that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.context.aifactory.select
Methods in com.espertech.esper.common.internal.context.aifactory.select that return ViewableModifier and TypeMethodDescriptionViewable[]
StatementAgentInstanceFactorySelectResult.getEventStreamViewables()
Viewable[]
StatementAgentInstanceFactorySelectResult.getTopViews()
Constructors in com.espertech.esper.common.internal.context.aifactory.select with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactorySelectResult
(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
Constructors in com.espertech.esper.common.internal.context.aifactory.update with parameters of type ViewableModifierConstructorDescriptionStatementAgentInstanceFactoryUpdateResult
(Viewable finalView, AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Map<Integer, SubSelectFactoryResult> subselectActivations) -
Uses of Viewable in com.espertech.esper.common.internal.context.util
Classes in com.espertech.esper.common.internal.context.util that implement ViewableModifier and TypeClassDescriptionclass
class
class
View for use with pre-processing statement such as "update istream" for indicating previous and current event.Methods in com.espertech.esper.common.internal.context.util that return ViewableMethods in com.espertech.esper.common.internal.context.util with parameters of type ViewableModifier and TypeMethodDescriptionstatic void
AgentInstanceUtil.stop
(AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView, boolean isStatementStop, boolean leaveLocksAcquired) Constructors in com.espertech.esper.common.internal.context.util with parameters of type ViewableModifierConstructorDescriptionAgentInstance
(AgentInstanceMgmtCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView) -
Uses of Viewable in com.espertech.esper.common.internal.epl.fafquery.processor
Methods in com.espertech.esper.common.internal.epl.fafquery.processor that return ViewableModifier and TypeMethodDescriptionabstract Viewable
FireAndForgetInstance.getTailViewInstance()
FireAndForgetInstanceNamedWindow.getTailViewInstance()
FireAndForgetInstanceTable.getTailViewInstance()
-
Uses of Viewable in com.espertech.esper.common.internal.epl.historical.common
Subinterfaces of Viewable in com.espertech.esper.common.internal.epl.historical.commonModifier and TypeInterfaceDescriptioninterface
Interface for views that poll data based on information from other streams.Classes in com.espertech.esper.common.internal.epl.historical.common that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.epl.historical.database.core that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.epl.historical.method.core
Classes in com.espertech.esper.common.internal.epl.historical.method.core that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.epl.join.base
Methods in com.espertech.esper.common.internal.epl.join.base with parameters of type ViewableModifier 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) Constructors in com.espertech.esper.common.internal.epl.join.base with parameters of type ViewableModifierConstructorDescriptionJoinSetComposerHistoricalImpl
(boolean allowInitIndex, Map<TableLookupIndexReqKey, EventTable>[] repositories, QueryStrategy[] queryStrategies, Viewable[] streamViews, ExprEvaluatorContext staticEvalExprEvaluatorContext) -
Uses of Viewable in com.espertech.esper.common.internal.epl.join.queryplan
Methods in com.espertech.esper.common.internal.epl.join.queryplan with parameters of type ViewableModifier 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
Methods in com.espertech.esper.common.internal.epl.join.queryplanouter with parameters of type ViewableModifier 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
Classes in com.espertech.esper.common.internal.epl.namedwindow.consume that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.epl.namedwindow.core that implement ViewableModifier 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.Methods in com.espertech.esper.common.internal.epl.namedwindow.core with parameters of type Viewable -
Uses of Viewable in com.espertech.esper.common.internal.epl.ontrigger
Classes in com.espertech.esper.common.internal.epl.ontrigger that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.epl.output.condition that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.epl.output.core that implement ViewableModifier and TypeClassDescriptionclass
class
class
A view that handles the "output snapshot" keyword in output rate stabilizing.class
class
class
Fields in com.espertech.esper.common.internal.epl.output.core declared as ViewableMethods in com.espertech.esper.common.internal.epl.output.core that return ViewableMethods in com.espertech.esper.common.internal.epl.output.core with parameters of type ViewableModifier 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
Classes in com.espertech.esper.common.internal.epl.output.view that implement ViewableModifier 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
Methods in com.espertech.esper.common.internal.epl.resultset.core with parameters of type ViewableModifier 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
Methods in com.espertech.esper.common.internal.epl.resultset.handthru with parameters of type ViewableModifier and TypeMethodDescriptionResultSetProcessorHandThroughImpl.getIterator
(Viewable viewable) -
Uses of Viewable in com.espertech.esper.common.internal.epl.rowrecog.core
Classes in com.espertech.esper.common.internal.epl.rowrecog.core that implement ViewableMethods in com.espertech.esper.common.internal.epl.rowrecog.core with parameters of type ViewableModifier and TypeMethodDescriptionstatic RowRecogNFAViewService
RowRecogHelper.recursiveFindRegexService
(Viewable top) -
Uses of Viewable in com.espertech.esper.common.internal.epl.subselect
Classes in com.espertech.esper.common.internal.epl.subselect that implement ViewableModifier and TypeClassDescriptionclass
View handling the insert and remove stream generated by a subselect for application to aggregation state.class
class
class
class
Methods in com.espertech.esper.common.internal.epl.subselect that return ViewableModifier and TypeMethodDescriptionSubSelectFactoryResult.getSubselectView()
SubSelectStrategyRealization.getSubselectView()
Methods in com.espertech.esper.common.internal.epl.subselect with parameters of type ViewableModifier 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) Constructors in com.espertech.esper.common.internal.epl.subselect with parameters of type ViewableModifierConstructorDescriptionSubSelectStrategyRealization
(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
Classes in com.espertech.esper.common.internal.epl.table.core that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.epl.virtualdw
Classes in com.espertech.esper.common.internal.epl.virtualdw that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.statement.dispatch
Subinterfaces of Viewable in com.espertech.esper.common.internal.statement.dispatchModifier and TypeInterfaceDescriptioninterface
Update dispatch view to indicate statement results to listeners. -
Uses of Viewable in com.espertech.esper.common.internal.statement.resource
Methods in com.espertech.esper.common.internal.statement.resource that return ViewableModifier and TypeMethodDescriptionViewable[]
StatementResourceHolder.getEventStreamViewables()
StatementResourceHolder.getFinalView()
Viewable[]
StatementResourceHolder.getTopViewables()
Methods in com.espertech.esper.common.internal.statement.resource with parameters of type ViewableModifier and TypeMethodDescriptionprotected void
StatementResourceHolder.setEventStreamViewables
(Viewable[] eventStreamViewables) protected void
StatementResourceHolder.setTopViewables
(Viewable[] topViewables) Constructors in com.espertech.esper.common.internal.statement.resource with parameters of type ViewableModifierConstructorDescriptionStatementResourceHolder
(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
Subinterfaces of Viewable in com.espertech.esper.common.internal.view.coreModifier 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.Classes in com.espertech.esper.common.internal.view.core that implement ViewableModifier 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
Fields in com.espertech.esper.common.internal.view.core declared as ViewableMethods in com.espertech.esper.common.internal.view.core that return ViewableModifier and TypeMethodDescriptionViewablePair.getLast()
View.getParent()
Returns the View's parent Viewable.ViewNoop.getParent()
ViewNullEvent.getParent()
ViewSupport.getParent()
ViewablePair.getTop()
Methods in com.espertech.esper.common.internal.view.core with parameters of type ViewableModifier 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
Constructors in com.espertech.esper.common.internal.view.core with parameters of type Viewable -
Uses of Viewable in com.espertech.esper.common.internal.view.derived
Classes in com.espertech.esper.common.internal.view.derived that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.expression that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.exttimedbatch that implement ViewableModifier and TypeClassDescriptionclass
Batch window based on timestamp of arriving events. -
Uses of Viewable in com.espertech.esper.common.internal.view.exttimedwin
Classes in com.espertech.esper.common.internal.view.exttimedwin that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.filter that implement ViewableModifier and TypeClassDescriptionclass
Simple filter view filtering events using a filter expression tree. -
Uses of Viewable in com.espertech.esper.common.internal.view.firstevent
Classes in com.espertech.esper.common.internal.view.firstevent that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.view.firstlength
Classes in com.espertech.esper.common.internal.view.firstlength that implement ViewableModifier and TypeClassDescriptionclass
A length-first view takes the first N arriving events. -
Uses of Viewable in com.espertech.esper.common.internal.view.firsttime
Classes in com.espertech.esper.common.internal.view.firsttime that implement Viewable -
Uses of Viewable in com.espertech.esper.common.internal.view.firstunique
Classes in com.espertech.esper.common.internal.view.firstunique that implement ViewableModifier 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
Subinterfaces of Viewable in com.espertech.esper.common.internal.view.groupwinClasses in com.espertech.esper.common.internal.view.groupwin that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.intersect that implement ViewableModifier 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.Methods in com.espertech.esper.common.internal.view.intersect that return ViewableMethods in com.espertech.esper.common.internal.view.intersect with parameters of type Viewable -
Uses of Viewable in com.espertech.esper.common.internal.view.keepall
Classes in com.espertech.esper.common.internal.view.keepall that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.lastevent that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.length that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.lengthbatch that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.prior that implement ViewableModifier and TypeClassDescriptionclass
View that provides access to prior events posted by the parent view for use by 'prior' expression nodes.Methods in com.espertech.esper.common.internal.view.prior with parameters of type Viewable -
Uses of Viewable in com.espertech.esper.common.internal.view.rank
Classes in com.espertech.esper.common.internal.view.rank that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.sort that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.time_accum that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.timebatch that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.timelengthbatch that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.timetolive that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.timewin that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.union that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.unique that implement ViewableModifier 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
Classes in com.espertech.esper.common.internal.view.util that implement ViewableModifier and TypeClassDescriptionfinal class
A view that acts as an adapter between views and update listeners.