Uses of Interface
com.espertech.esper.view.Viewable

Packages that use Viewable
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.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.service.resource Core service statement resource holders. 
com.espertech.esper.core.start Classes related to start and stop of statements 
com.espertech.esper.dataflow.ops.epl Data flow built-in operator's helper classes. 
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.join.base Join process interfaces and glue code 
com.espertech.esper.epl.join.plan Inner join and outer join query planning 
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.mgmt Table-related services and metadata. 
com.espertech.esper.epl.table.onaction Table on-action handlers. 
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.epl.virtualdw Virtual data window. 
com.espertech.esper.event.vaevent Value added events are revision events and variant events. 
com.espertech.esper.rowregex Match-recognize expression tree and state objects. 
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 Viewable in com.espertech.esper.core.context.activator
 

Methods in com.espertech.esper.core.context.activator that return Viewable
 Viewable ViewableActivationResult.getViewable()
           
 

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

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

Methods in com.espertech.esper.core.context.factory that return Viewable
 Viewable StatementAgentInstanceFactoryCreateWindowResult.getEventStreamParentViewable()
           
 Viewable[] StatementAgentInstanceFactorySelectResult.getEventStreamViewables()
           
 Viewable StatementAgentInstanceFactoryResult.getFinalView()
           
 Viewable StatementAgentInstanceFactoryCreateWindowResult.getTopView()
           
 Viewable[] StatementAgentInstanceFactorySelectResult.getTopViews()
           
 

Constructors in com.espertech.esper.core.context.factory with parameters of type Viewable
StatementAgentInstanceFactoryCreateIndex(EPServicesContext services, CreateIndexDesc spec, Viewable finalView, NamedWindowProcessor namedWindowProcessor, java.lang.String tableName)
           
StatementAgentInstanceFactoryCreateIndexResult(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)
           
StatementAgentInstanceFactoryOnTriggerResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, AggregationService aggregationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, EvalRootState optPatternRoot, java.util.Map<ExprTableAccessNode,ExprTableAccessEvalStrategy> tableAccessStrategies)
           
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)
           
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)
           
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)
           
StatementAgentInstanceFactoryUpdateResult(Viewable finalView, StopCallback stopCallback, AgentInstanceContext agentInstanceContext, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies)
           
StatementAgentInstancePostLoadSelect(Viewable[] streamViews, JoinSetComposerDesc joinSetComposer, NamedWindowTailViewInstance[] namedWindowTailViews, FilterSpecCompiled[] namedWindowPostloadFilters, java.util.List<ExprNode>[] namedWindowFilters, java.lang.annotation.Annotation[] annotations, ExprEvaluatorContext exprEvaluatorContext)
           
 

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

Methods in com.espertech.esper.core.context.mgr that return Viewable
 Viewable AgentInstance.getFinalView()
           
 

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

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

Methods in com.espertech.esper.core.context.subselect that return Viewable
 Viewable SubSelectStrategyRealization.getSubselectView()
           
 Viewable SubSelectStrategyHolder.getSubselectView()
           
 

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

Constructors in com.espertech.esper.core.context.subselect with parameters of type Viewable
SubSelectStrategyHolder(ExprSubselectStrategy stategy, AggregationService subselectAggregationService, java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorStrategies, java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies, Viewable subselectView, StatementAgentInstancePostLoad postLoad)
           
SubSelectStrategyRealization(SubordTableLookupStrategy strategy, SubselectAggregationPreprocessorBase subselectAggregationPreprocessor, AggregationService subselectAggregationService, java.util.Map<ExprPriorNode,ExprPriorEvalStrategy> priorNodeStrategies, java.util.Map<ExprPreviousNode,ExprPreviousEvalStrategy> previousNodeStrategies, Viewable subselectView, StatementAgentInstancePostLoad postLoad)
           
 

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

Classes in com.espertech.esper.core.context.util that implement Viewable
 class ContextMergeView
           
 class ContextMergeViewForwarding
           
 

Methods in com.espertech.esper.core.context.util with parameters of type Viewable
static void StatementAgentInstanceUtil.stop(StopCallback stopCallback, AgentInstanceContext agentInstanceContext, Viewable finalView, EPServicesContext servicesContext, boolean isStatementStop, boolean leaveLocksAcquired)
           
 

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

Subinterfaces of Viewable in com.espertech.esper.core.service
 interface UpdateDispatchView
          Update dispatch view to indicate statement results to listeners.
 

Classes in com.espertech.esper.core.service that implement Viewable
 class InternalRoutePreprocessView
          View for use with pre-processing statement such as "update istream" for indicating previous and current event.
 class UpdateDispatchViewBase
          Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
 class UpdateDispatchViewBlockingSpin
          Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
 class UpdateDispatchViewBlockingWait
          Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
 class UpdateDispatchViewNonBlocking
          Convenience view for dispatching view updates received from a parent view to update listeners via the dispatch service.
 

Methods in com.espertech.esper.core.service with parameters of type Viewable
 void EPStatementSPI.setParentView(Viewable viewable)
          Sets the parent view.
 void EPStatementImpl.setParentView(Viewable viewable)
           
 

Uses of Viewable in com.espertech.esper.core.service.resource
 

Methods in com.espertech.esper.core.service.resource that return Viewable
 Viewable[] StatementResourceHolder.getEventStreamViewables()
           
 Viewable[] StatementResourceHolder.getTopViewables()
           
 

Constructors in com.espertech.esper.core.service.resource with parameters of type Viewable
StatementResourceHolder(StatementAgentInstanceLock agentInstanceLock, Viewable[] topViewables, Viewable[] eventStreamViewables, EvalRootState[] patternRoots, AggregationService aggegationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, StatementAgentInstancePostLoad postLoad)
           
StatementResourceHolder(StatementAgentInstanceLock agentInstanceLock, Viewable[] topViewables, Viewable[] eventStreamViewables, EvalRootState[] patternRoots, AggregationService aggegationService, java.util.Map<ExprSubselectNode,SubSelectStrategyHolder> subselectStrategies, StatementAgentInstancePostLoad postLoad)
           
 

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

Methods in com.espertech.esper.core.start that return Viewable
 Viewable FireAndForgetInstanceTable.getTailViewInstance()
           
 Viewable FireAndForgetInstanceNamedWindow.getTailViewInstance()
           
abstract  Viewable FireAndForgetInstance.getTailViewInstance()
           
 Viewable EPStatementStartResult.getViewable()
          Returns last view to attached to.
 

Constructors in com.espertech.esper.core.start with parameters of type Viewable
EPStatementStartResult(Viewable viewable, EPStatementStopMethod stopMethod)
          Ctor.
EPStatementStartResult(Viewable viewable, EPStatementStopMethod stopMethod, EPStatementDestroyMethod destroyMethod)
          Ctor.
 

Uses of Viewable in com.espertech.esper.dataflow.ops.epl
 

Classes in com.espertech.esper.dataflow.ops.epl that implement Viewable
 class EPLSelectUpdateDispatchView
           
 class EPLSelectViewable
           
 

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

Classes in com.espertech.esper.epl.core that implement Viewable
 class MethodPollingViewable
          Polling-data provider that calls a static method on a class and passed parameters, and wraps the results as POJO events.
 

Methods in com.espertech.esper.epl.core with parameters of type Viewable
static void ResultSetProcessorUtil.clearAndAggregateUngrouped(ExprEvaluatorContext exprEvaluatorContext, AggregationService aggregationService, Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorSimple.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorRowPerGroupUnbound.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorRowPerGroupRollupUnbound.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorRowPerGroupRollup.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorRowPerGroup.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorRowForAll.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorHandThrough.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorAggregateGrouped.getIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorAggregateAll.getIterator(Viewable parent)
           
 java.util.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.
 java.util.Iterator<EventBean> ResultSetProcessorRowPerGroup.obtainIterator(Viewable parent)
           
 java.util.Iterator<EventBean> ResultSetProcessorAggregateAll.obtainIterator(Viewable parent)
           
 

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

Classes in com.espertech.esper.epl.db that implement Viewable
 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 Viewable in com.espertech.esper.epl.join.base
 

Methods in com.espertech.esper.epl.join.base with parameters of type Viewable
 JoinSetComposerDesc JoinSetComposerPrototypeImpl.create(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext)
           
 JoinSetComposerDesc JoinSetComposerPrototypeHistorical2StreamImpl.create(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext)
           
 JoinSetComposerDesc JoinSetComposerPrototype.create(Viewable[] streamViews, boolean isFireAndForget, AgentInstanceContext agentInstanceContext)
           
 

Constructors in com.espertech.esper.epl.join.base with parameters of type Viewable
JoinSetComposerHistoricalImpl(java.util.Map<TableLookupIndexReqKey,EventTable>[] repositories, QueryStrategy[] queryStrategies, Viewable[] streamViews, ExprEvaluatorContext staticEvalExprEvaluatorContext)
          Ctor.
 

Uses of Viewable in com.espertech.esper.epl.join.plan
 

Methods in com.espertech.esper.epl.join.plan with parameters of type Viewable
 LookupInstructionExec LookupInstructionPlan.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal)
          Constructs the executable from the plan.
 ExecNode TableOuterLookupNode.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
           
 ExecNode TableLookupNode.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
           
 ExecNode QueryPlanNodeNoOp.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
           
abstract  ExecNode QueryPlanNode.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
          Make execution node from this specification.
 ExecNode NestedIterationNode.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexList, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
           
 ExecNode LookupInstructionQueryPlanNode.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
           
 ExecNode HistoricalDataPlanNode.makeExec(java.lang.String statementName, java.lang.String statementId, java.lang.annotation.Annotation[] annotations, java.util.Map<TableLookupIndexReqKey,EventTable>[] indexesPerStream, EventType[] streamTypes, Viewable[] streamViews, HistoricalStreamIndexList[] historicalStreamIndexLists, VirtualDWView[] viewExternal, java.util.concurrent.locks.Lock[] tableSecondaryIndexLocks)
           
 HistoricalTableLookupStrategy HistoricalDataPlanNode.makeOuterJoinStategy(Viewable[] streamViews, int pollingStreamNum, HistoricalStreamIndexList[] historicalStreamIndexLists)
          Returns the table lookup strategy for use in outer joins.
 

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

Classes in com.espertech.esper.epl.named that implement Viewable
 class NamedWindowConsumerView
          Represents a consumer of a named window that selects from a named window via a from-clause.
 class NamedWindowOnDeleteView
          View for the on-delete statement that handles removing events from a named window.
 class NamedWindowOnExprBaseView
          View for the on-delete statement that handles removing events from a named window.
 class NamedWindowOnMergeView
          View for the on-delete statement that handles removing events from a named window.
 class NamedWindowOnSelectView
          View for the on-select statement that handles selecting events from a named window.
 class NamedWindowOnUpdateView
          View for the on-delete statement that handles removing events from a named window.
 class NamedWindowRootViewInstance
          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 NamedWindowTailViewInstance
          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 via NamedWindowService to consuming statements.
 

Methods in com.espertech.esper.epl.named with parameters of type Viewable
 void NamedWindowRootViewInstance.setParent(Viewable parent)
           
 

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

Classes in com.espertech.esper.epl.subquery that implement Viewable
 class SubselectAggregatorViewBase
          View handling the insert and remove stream generated by a subselect for application to aggregation state.
 class SubselectAggregatorViewFilteredGrouped
           
 class SubselectAggregatorViewFilteredUngrouped
           
 class SubselectAggregatorViewUnfilteredGrouped
           
 class SubselectAggregatorViewUnfilteredUngrouped
           
 

Uses of Viewable in com.espertech.esper.epl.table.mgmt
 

Classes in com.espertech.esper.epl.table.mgmt that implement Viewable
 class TableStateViewableInternal
           
 class TableStateViewablePublic
           
 

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

Classes in com.espertech.esper.epl.table.onaction that implement Viewable
 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 Viewable in com.espertech.esper.epl.variable
 

Classes in com.espertech.esper.epl.variable that implement Viewable
 class CreateVariableView
          View for handling create-variable syntax.
 class OnSetVariableView
          A view that handles the setting of variables upon receipt of a triggering event.
 

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

Classes in com.espertech.esper.epl.view that implement Viewable
 class FilterExprView
          Simple filter view filtering events using a filter expression tree.
 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 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
           
 

Fields in com.espertech.esper.epl.view declared as Viewable
protected  Viewable OutputProcessViewBase.parentView
           
 

Methods in com.espertech.esper.epl.view that return Viewable
 Viewable OutputProcessViewBase.getParent()
           
 

Methods in com.espertech.esper.epl.view with parameters of type Viewable
static java.util.Iterator<EventBean> OutputStrategyUtil.getIterator(JoinExecutionStrategy joinExecutionStrategy, ResultSetProcessor resultSetProcessor, Viewable parentView, boolean distinct)
           
 void OutputProcessViewBase.setParent(Viewable parent)
           
 

Uses of Viewable in com.espertech.esper.epl.virtualdw
 

Classes in com.espertech.esper.epl.virtualdw that implement Viewable
 class VirtualDWViewImpl
           
 

Uses of Viewable in com.espertech.esper.event.vaevent
 

Methods in com.espertech.esper.event.vaevent with parameters of type Viewable
 java.util.Collection<EventBean> ValueAddEventProcessor.getSnapshot(EPStatementAgentInstanceHandle createWindowStmtHandle, Viewable parent)
          Handle iteration over revision event contents.
 java.util.Collection<EventBean> VAEVariantProcessor.getSnapshot(EPStatementAgentInstanceHandle createWindowStmtHandle, Viewable parent)
           
 java.util.Collection<EventBean> VAERevisionProcessorMerge.getSnapshot(EPStatementAgentInstanceHandle createWindowStmtHandle, Viewable parent)
           
 java.util.Collection<EventBean> VAERevisionProcessorDeclared.getSnapshot(EPStatementAgentInstanceHandle createWindowStmtHandle, Viewable parent)
           
 

Uses of Viewable in com.espertech.esper.rowregex
 

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

Methods in com.espertech.esper.rowregex with parameters of type Viewable
static EventRowRegexNFAViewService EventRowRegexHelper.recursiveFindRegexService(Viewable top)
           
 

Uses of Viewable in com.espertech.esper.view
 

Subinterfaces of Viewable in com.espertech.esper.view
 interface DataWindowView
          Tag interface for data window views.
 interface DerivedValueView
          Tag interface for derived-value views.
 interface EventStream
          A streams is a conduct for incoming events.
 interface HistoricalEventViewable
          Interface for views that poll data based on information from other streams.
 interface View
          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.view that implement Viewable
 class ViewableDefaultImpl
           
 class ViewSupport
          A helper class for View implementations that provides generic implementation for some of the methods.
 class ZeroDepthStreamIterable
          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 ZeroDepthStreamNoIterate
          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.
 

Fields in com.espertech.esper.view declared as Viewable
protected  Viewable ViewSupport.parent
          Parent viewable to this view - directly accessible by subclasses.
 

Methods in com.espertech.esper.view that return Viewable
 Viewable ViewServiceCreateResult.getFinalViewable()
           
 Viewable ViewSupport.getParent()
           
 Viewable View.getParent()
          Returns the View's parent Viewable.
 Viewable ViewServiceCreateResult.getTopViewable()
           
 

Methods in com.espertech.esper.view that return types with arguments of type Viewable
protected static Pair<Viewable,java.util.List<View>> ViewServiceHelper.matchExistingViews(Viewable rootViewable, java.util.List<ViewFactory> viewFactories)
          Match the views under the stream to the list of view specications passed in.
 

Methods in com.espertech.esper.view with parameters of type Viewable
 ViewServiceCreateResult ViewServiceImpl.createViews(Viewable eventStreamViewable, java.util.List<ViewFactory> viewFactories, AgentInstanceViewFactoryChainContext viewFactoryChainContext, boolean hasPreviousNode)
           
 ViewServiceCreateResult ViewService.createViews(Viewable eventStreamViewable, java.util.List<ViewFactory> viewFactoryChain, AgentInstanceViewFactoryChainContext viewFactoryChainContext, boolean hasPreviousNode)
          Creates the views given a chain of view factories.
static void ViewSupport.dumpChildViews(java.lang.String prefix, Viewable parentViewable)
          Convenience method for logging the child views of a Viewable.
static java.util.List<View> ViewSupport.findDescendent(Viewable parentView, Viewable descendentView)
          Find the descendent view in the view tree under the parent view returning the list of view nodes between the parent view and the descendent view.
protected static java.util.List<View> ViewServiceHelper.instantiateChain(Viewable parentViewable, java.util.List<ViewFactory> viewFactories, AgentInstanceViewFactoryChainContext viewFactoryChainContext)
          Instantiate a chain of views.
protected static Pair<Viewable,java.util.List<View>> ViewServiceHelper.matchExistingViews(Viewable rootViewable, java.util.List<ViewFactory> viewFactories)
          Match the views under the stream to the list of view specications passed in.
 void ViewServiceImpl.remove(EventStream eventStream, Viewable viewToRemove)
           
 void ViewService.remove(EventStream eventStream, Viewable view)
          Removes a view discoupling the view and any of it's parent views up the tree to the last shared parent view.
protected static java.util.List<View> ViewServiceHelper.removeChainLeafView(Viewable parentViewable, Viewable viewToRemove)
          Removes a view from a parent view returning the orphaned parent views in a list.
 void ViewSupport.setParent(Viewable parent)
           
 void View.setParent(Viewable parent)
          Called when the View is added to a Viewable object.
 

Constructors in com.espertech.esper.view with parameters of type Viewable
ViewServiceCreateResult(Viewable finalViewable, Viewable topViewable, java.util.List<View> newViews)
           
 

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

Classes in com.espertech.esper.view.ext that implement Viewable
 class RankWindowView
          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.
 class SortWindowView
          Window sorting by values in the specified field extending a specified number of elements from the lowest value up or the highest value down.
 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 Viewable in com.espertech.esper.view.internal
 

Classes in com.espertech.esper.view.internal that implement Viewable
 class BufferView
          A view that acts as an adapter between views and update listeners.
 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 IntersectView
          A view that represents an intersection of multiple data windows.
 class LastPostObserverView
          A view that retains the last update.
 class PatternRemoveDispatchView
          View to handle pattern discarding for a single stream (no join).
 class PriorEventView
          View that provides access to prior events posted by the parent view for use by 'prior' expression nodes.
 class RouteResultView
          View for processing split-stream syntax.
 class SingleStreamDispatchView
          View to dispatch for a single stream (no join).
 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.
 

Methods in com.espertech.esper.view.internal with parameters of type Viewable
 void PriorEventView.setParent(Viewable parent)
           
 

Uses of Viewable in com.espertech.esper.view.stat
 

Classes in com.espertech.esper.view.stat that implement Viewable
 class BaseBivariateStatisticsView
          View for computing statistics that require 2 input variable arrays containing X and Y datapoints.
 class CorrelationView
          A view that calculates correlation on two fields.
 class RegressionLinestView
          A view that calculates regression on two fields.
 class UnivariateStatisticsView
          View for computing statistics, which the view exposes via fields representing the sum, count, standard deviation for sample and for population and variance.
 class WeightedAverageView
          View for computing a weighted average.
 

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

Subinterfaces of Viewable in com.espertech.esper.view.std
 interface GroupByView
           
 interface MergeViewMarker
           
 

Classes in com.espertech.esper.view.std that implement Viewable
 class AddPropertyValueView
          This view simply adds a property to the events posted to it.
 class FirstElementView
          View retaining the very first event.
 class FirstUniqueByPropertyView
          This view retains the first event for each multi-key of distinct property values.
 class GroupByViewImpl
          The group view splits the data in a stream to multiple subviews, based on a key index.
 class GroupByViewReclaimAged
           
 class LastElementView
          This view is a very simple view presenting the last event posted by the parent view to any subviews.
 class MergeView
          The merge view works together with a group view that splits the data in a stream to multiple subviews, based on a key index.
 class SizeView
          This view is a very simple view presenting the number of elements in a stream or view.
 class UniqueByPropertyView
          This view includes only the most recent among events having the same value for the specified field or fields.
 

Methods in com.espertech.esper.view.std with parameters of type Viewable
 void AddPropertyValueView.setParent(Viewable parent)
           
 

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

Classes in com.espertech.esper.view.window that implement Viewable
 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 ExternallyTimedBatchView
          Batch window based on timestamp of arriving events.
 class ExternallyTimedWindowView
          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.
 class FirstLengthWindowView
          A length-first view takes the first N arriving events.
 class FirstTimeView
           
 class KeepAllView
          This view is a keep-all data window that simply keeps all events added.
 class LengthBatchView
          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 LengthBatchViewRStream
          Same as the LengthBatchView, this view also supports fast-remove from the batch for remove stream events.
 class LengthWindowView
          This view is a moving window extending the specified number of elements into the past.
 class LengthWindowViewRStream
          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.
 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-2015 EsperTech Inc.
All rights reserved.
Visit us at espertech.com