Package | Description |
---|---|
com.espertech.esper.client.hook |
Callback interfaces for use with statement annotations.
|
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.util |
Context partition utility or reference classes.
|
com.espertech.esper.core.service |
Implementation of client package interfaces, glue code
|
com.espertech.esper.core.start |
Classes related to start and stop of statements
|
com.espertech.esper.dataflow.core |
Data flow core classes.
|
com.espertech.esper.dataflow.interfaces |
Data flow operator and related interface.
|
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.expression |
This package contains the EPL expression nodes that represent all expressions such as used in select clauses, group-by and having clauses, or order-by clauses
|
com.espertech.esper.epl.join.base |
Join process interfaces and glue code
|
com.espertech.esper.epl.join.hint |
Hints related to joins.
|
com.espertech.esper.epl.named |
Named window classes are in this package
|
com.espertech.esper.epl.spec |
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.view |
Internal processing views for output rate limiting, filtering and internal event routing
|
com.espertech.esper.epl.virtualdw |
Virtual data window.
|
com.espertech.esper.filter |
Main switchboard filtering and routing of incoming events to interested statements is performed in this package.
|
com.espertech.esper.pattern |
Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active pattern instance
|
com.espertech.esper.rowregex |
Match-recognize expression tree and state objects.
|
com.espertech.esper.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
|
Modifier and Type | Method and Description |
---|---|
StatementContext |
VirtualDataWindowFactoryContext.getStatementContext()
Returns the statement contextual information and services.
|
StatementContext |
VirtualDataWindowContext.getStatementContext()
Returns the statement context which holds statement information (name, expression, id) and statement-level services.
|
Constructor and Description |
---|
ViewableActivatorStreamReuseView(EPServicesContext services,
StatementContext statementContext,
StatementSpecCompiled statementSpec,
FilterStreamSpecCompiled filterStreamSpec,
boolean join,
ExprEvaluatorContextStatement evaluatorContextStmt,
boolean filterSubselectSameStream,
int streamNum,
boolean isCanIterateUnbound) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
ContextControllerStatementBase.getStatementContext() |
StatementContext |
ContextControllerInitTermFactory.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
StatementContext |
AgentInstanceViewFactoryChainContext.getStatementContext() |
StatementContext |
AgentInstanceContext.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
static void |
StatementAgentInstanceUtil.stopSafe(java.util.Collection<StopCallback> terminationCallbacks,
StopCallback[] stopCallbacks,
StatementContext statementContext) |
static void |
StatementAgentInstanceUtil.stopSafe(StopCallback[] stopMethods,
StatementContext statementContext) |
static void |
StatementAgentInstanceUtil.stopSafe(StopCallback stopMethod,
StatementContext statementContext) |
Constructor and Description |
---|
AgentInstanceContext(StatementContext statementContext,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
int agentInstanceId,
AgentInstanceFilterProxy agentInstanceFilterProxy,
MappedEventBean agentInstanceProperties,
AgentInstanceScriptContext agentInstanceScriptContext) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
StatementMetadataFactoryContext.getStatementContext() |
StatementContext |
StatementLifecycleSvcImpl.EPStatementDesc.getStatementContext()
Returns the statement context.
|
StatementContext |
EPStatementSPI.getStatementContext()
Returns the statement context.
|
StatementContext |
EPStatementImpl.getStatementContext() |
StatementContext |
StatementContextFactoryDefault.makeContext(java.lang.String statementId,
java.lang.String statementName,
java.lang.String expression,
EPServicesContext engineServices,
java.util.Map<java.lang.String,java.lang.Object> optAdditionalContext,
boolean isFireAndForget,
java.lang.annotation.Annotation[] annotations,
EPIsolationUnitServices isolationUnitServices,
boolean stateless,
StatementSpecRaw statementSpecRaw) |
StatementContext |
StatementContextFactory.makeContext(java.lang.String statementId,
java.lang.String statementName,
java.lang.String expression,
EPServicesContext engineServices,
java.util.Map<java.lang.String,java.lang.Object> optAdditionalContext,
boolean isFireAndForget,
java.lang.annotation.Annotation[] annotations,
EPIsolationUnitServices isolationUnitServices,
boolean stateless,
StatementSpecRaw statementSpecRaw)
Create a new statement context consisting of statement-level services.
|
Constructor and Description |
---|
EPStatementDesc(EPStatementSPI epStatement,
EPStatementStartMethod startMethod,
StatementContext statementContext)
Ctor.
|
EPStatementImpl(java.lang.String expressionNoAnnotations,
boolean isPattern,
DispatchService dispatchService,
StatementLifecycleSvc statementLifecycleSvc,
long timeLastStateChange,
boolean isBlockingDispatch,
boolean isSpinBlockingDispatch,
long msecBlockingTimeout,
TimeSourceService timeSourceService,
StatementMetadata statementMetadata,
java.lang.Object userObject,
StatementContext statementContext,
boolean isFailed,
boolean nameProvided)
Ctor.
|
ExprEvaluatorContextStatement(StatementContext statementContext) |
StatementMetadataFactoryContext(java.lang.String statementName,
java.lang.String statementId,
StatementContext statementContext,
StatementSpecRaw statementSpec,
java.lang.String expression,
boolean pattern,
EPStatementObjectModel optionalModel) |
Modifier and Type | Method and Description |
---|---|
static PriorEventViewFactory |
EPStatementStartMethodHelperPrior.getPriorEventViewFactory(StatementContext statementContext,
int streamNum,
int viewFactoryNum,
boolean unboundStream) |
static EPStatementStartMethodSelectDesc |
EPStatementStartMethodSelectUtil.prepare(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext,
boolean recoveringResilient,
AgentInstanceContext defaultAgentInstanceContext,
boolean queryPlanLogging,
ViewableActivatorFactory optionalViewableActivatorFactory,
OutputProcessViewCallback optionalOutputProcessViewCallback,
SelectExprProcessorDeliveryCallback selectExprProcessorDeliveryCallback) |
EPStatementStartResult |
EPStatementStartMethodBase.start(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethod.start(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient)
Starts the EPL statement.
|
EPStatementStartResult |
EPStatementStartMethodUpdate.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodSelect.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodOnTrigger.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateWindow.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateVariable.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateSchema.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateIndex.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateGraph.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateExpression.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
EPStatementStartResult |
EPStatementStartMethodCreateContext.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
abstract EPStatementStartResult |
EPStatementStartMethodBase.startInternal(EPServicesContext services,
StatementContext statementContext,
boolean isNewStatement,
boolean isRecoveringStatement,
boolean isRecoveringResilient) |
Constructor and Description |
---|
EPPreparedExecuteInsertInto(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext) |
EPPreparedExecuteMethodQuery(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext)
Ctor.
|
EPPreparedExecuteSingleStream(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext)
Ctor.
|
EPPreparedExecuteSingleStreamDelete(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext) |
EPPreparedExecuteSingleStreamUpdate(StatementSpecCompiled statementSpec,
EPServicesContext services,
StatementContext statementContext) |
EPStatementStopMethodImpl(StatementContext statementContext,
java.util.List<StopCallback> stopCallbacks) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
DataFlowStmtDesc.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
void |
DataFlowServiceImpl.addStartGraph(CreateDataFlowDesc desc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
boolean newStatement) |
void |
DataFlowService.addStartGraph(CreateDataFlowDesc desc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
boolean newStatement) |
static DataflowStartDesc |
RealizationFactoryInterface.realize(java.lang.String dataFlowName,
java.util.Map<java.lang.Integer,java.lang.Object> operators,
java.util.Map<java.lang.Integer,OperatorMetadataDescriptor> operatorMetadata,
java.util.Set<java.lang.Integer> operatorBuildOrder,
java.util.List<LogicalChannelBinding> bindings,
DataFlowSignalManager dataFlowSignalManager,
EPDataFlowInstantiationOptions options,
EPServicesContext services,
StatementContext statementContext) |
Constructor and Description |
---|
DataFlowStmtDesc(CreateDataFlowDesc graphDesc,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
java.util.Map<GraphOperatorSpec,java.lang.annotation.Annotation[]> operatorAnnotations) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
DataFlowOpInitializeContext.getStatementContext() |
StatementContext |
DataFlowOpInitializateContext.getStatementContext() |
Constructor and Description |
---|
DataFlowOpInitializateContext(java.lang.String dataflowName,
java.lang.String dataflowInstanceId,
java.lang.Object dataflowInstanceUserObject,
java.util.Map<java.lang.Integer,DataFlowOpInputPort> inputPorts,
java.util.Map<java.lang.Integer,DataFlowOpOutputPort> outputPorts,
StatementContext statementContext,
EPServicesContext servicesContext,
AgentInstanceContext agentInstanceContext,
EPRuntimeEventSender runtimeEventSender,
EPServiceProvider engine,
java.lang.annotation.Annotation[] operatorAnnotations) |
DataFlowOpInitializeContext(StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
static ResultSetProcessorFactoryDesc |
ResultSetProcessorFactoryFactory.getProcessorPrototype(StatementSpecCompiled statementSpec,
StatementContext stmtContext,
StreamTypeService typeService,
ViewResourceDelegateUnverified viewResourceDelegate,
boolean[] isUnidirectionalStream,
boolean allowAggregation,
ContextPropertyRegistry contextPropertyRegistry,
SelectExprProcessorDeliveryCallback selectExprProcessorCallback)
Returns the result set process for the given select expression, group-by clause and
having clause given a set of types describing each stream in the from-clause.
|
Modifier and Type | Method and Description |
---|---|
static ScheduleSpec |
ExprNodeUtility.toCrontabSchedule(ExprNodeOrigin origin,
java.util.List<ExprNode> scheduleSpecExpressionList,
StatementContext context) |
static ExprNode |
ExprNodeUtility.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
StatementContext statementContext,
EventType optionalEventType) |
Modifier and Type | Method and Description |
---|---|
static JoinSetComposerPrototype |
JoinSetComposerPrototypeFactory.makeComposerPrototype(java.lang.String statementName,
java.lang.String statementId,
OuterJoinDesc[] outerJoinDescList,
ExprNode optionalFilterNode,
EventType[] streamTypes,
java.lang.String[] streamNames,
StreamJoinAnalysisResult streamJoinAnalysisResult,
boolean queryPlanLogging,
StatementContext statementContext,
HistoricalViewableDesc historicalViewableDesc,
ExprEvaluatorContext exprEvaluatorContext,
boolean selectsRemoveStream,
boolean hasAggregations)
Builds join tuple composer.
|
Modifier and Type | Method and Description |
---|---|
static ExcludePlanHint |
ExcludePlanHint.getHint(java.lang.String[] streamNames,
StatementContext statementContext) |
static ExprEvaluator |
ExcludePlanHintExprUtil.toExpression(java.lang.String hint,
StatementContext statementContext) |
Constructor and Description |
---|
ExcludePlanHint(java.lang.String[] streamNames,
java.util.List<ExprEvaluator> evaluators,
StatementContext statementContext) |
Modifier and Type | Method and Description |
---|---|
static NamedWindowOnExprFactory |
NamedWindowOnExprFactoryFactory.make(EventType namedWindowEventType,
java.lang.String namedWindowName,
java.lang.String namedWindowAlias,
OnTriggerDesc onTriggerDesc,
EventType filterEventType,
java.lang.String filterStreamName,
boolean addToFront,
InternalEventRouter internalEventRouter,
EventType outputEventType,
StatementContext statementContext,
StatementMetricHandle createNamedWindowMetricsHandle,
boolean isDistinct) |
Constructor and Description |
---|
NamedWindowOnMergeHelper(StatementContext statementContext,
OnTriggerMergeDesc onTriggerDesc,
EventType triggeringEventType,
java.lang.String triggeringStreamName,
InternalEventRouter internalEventRouter,
java.lang.String namedWindowName,
EventTypeSPI namedWindowType) |
Modifier and Type | Method and Description |
---|---|
StreamSpecCompiled |
StreamSpecRaw.compile(StatementContext statementContext,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger)
Compiles a raw stream specification consisting event type information and filter expressions
to an validated, optimized form for use with filter service
|
PatternStreamSpecCompiled |
PatternStreamSpecRaw.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
StreamSpecCompiled |
MethodStreamSpec.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
StreamSpecCompiled |
FilterStreamSpecRaw.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
StreamSpecCompiled |
DBStatementStreamSpec.compile(StatementContext statementContext,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
PatternStreamSpecCompiled |
PatternStreamSpecRaw.compile(StatementContext context,
java.util.Set<java.lang.String> eventTypeReferences,
boolean isInsertInto,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack,
MatchEventSpec priorTags,
java.util.Set<java.lang.String> priorAllTags,
boolean isJoin,
boolean isContextDeclaration,
boolean isOnTrigger) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
OutputProcessViewDirectFactory.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
boolean |
OutputProcessViewBaseWAfter.checkAfterCondition(EventBean[] newEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewBaseWAfter.checkAfterCondition(java.util.Set<MultiKey<EventBean>> newEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
boolean |
OutputProcessViewBaseWAfter.checkAfterCondition(UniformPair<EventBean[]> newOldEvents,
StatementContext statementContext)
Returns true if the after-condition is satisfied.
|
static OutputConditionFactory |
OutputConditionFactoryFactory.createCondition(OutputLimitSpec outputLimitSpec,
StatementContext statementContext,
boolean isGrouped,
boolean isWithHavingClause)
Creates an output condition instance.
|
static void |
OutputStrategyUtil.indicateEarlyReturn(StatementContext statementContext,
UniformPair<EventBean[]> newOldEvents)
Indicate statement result.
|
static OutputProcessViewFactory |
OutputProcessViewFactoryFactory.make(StatementSpecCompiled statementSpec,
InternalEventRouter internalEventRouter,
StatementContext statementContext,
EventType resultEventType,
OutputProcessViewCallback optionalOutputProcessViewCallback) |
Constructor and Description |
---|
OutputConditionCrontabFactory(java.util.List<ExprNode> scheduleSpecExpressionList,
StatementContext statementContext) |
OutputConditionExpressionFactory(ExprNode whenExpressionNode,
java.util.List<OnTriggerSetAssignment> assignments,
StatementContext statementContext,
ExprNode andWhenTerminatedExpr,
java.util.List<OnTriggerSetAssignment> afterTerminateAssignments) |
OutputConditionFirstFactory(OutputLimitSpec outputLimitSpec,
StatementContext statementContext,
boolean isGrouped,
boolean isWithHavingClause) |
OutputConditionTimeFactory(ExprTimePeriod timePeriod,
StatementContext statementContext)
Constructor.
|
OutputProcessViewConditionFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
java.lang.Integer afterConditionNumberOfEvents,
EventType resultEventType,
OutputConditionFactory outputConditionFactory,
int streamCount,
OutputProcessViewConditionFactory.ConditionType conditionType,
OutputLimitLimitType outputLimitLimitType,
boolean terminable) |
OutputProcessViewDirectDistinctOrAfterFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory,
boolean distinct,
ExprTimePeriod afterTimePeriod,
java.lang.Integer afterConditionNumberOfEvents,
EventType resultEventType) |
OutputProcessViewDirectFactory(StatementContext statementContext,
OutputStrategyPostProcessFactory postProcessFactory) |
Modifier and Type | Method and Description |
---|---|
void |
VirtualDWViewFactoryImpl.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
Modifier and Type | Method and Description |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes,
EventType eventType,
java.lang.String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext stmtContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack) |
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
java.lang.String eventTypeName,
java.util.List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes,
StreamTypeService streamTypeService,
java.lang.String optionalStreamName,
StatementContext statementContext,
java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
static java.util.List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
java.util.List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes,
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
Modifier and Type | Method and Description |
---|---|
StatementContext |
PatternContext.getStatementContext() |
StatementContext |
PatternAgentInstanceContext.getStatementContext() |
Modifier and Type | Method and Description |
---|---|
PatternContext |
PatternContextFactoryDefault.createContext(StatementContext statementContext,
int streamId,
EvalRootFactoryNode rootNode,
MatchedEventMapMeta matchedEventMapMeta,
boolean allowResilient) |
PatternContext |
PatternContextFactory.createContext(StatementContext statementContext,
int streamId,
EvalRootFactoryNode rootNode,
MatchedEventMapMeta matchedEventMapMeta,
boolean allowResilient)
Create a pattern context.
|
Constructor and Description |
---|
PatternContext(StatementContext statementContext,
int streamNumber,
MatchedEventMapMeta matchedEventMapMeta,
boolean isResilient)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
EventRowRegexNFAViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
java.util.Map<java.lang.String,java.util.Set<java.lang.String>> visibilityByIdentifier,
EventType parentViewType) |
static ObjectArrayBackedEventBean |
EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
EventType parentViewType) |
Modifier and Type | Method and Description |
---|---|
StatementContext |
ViewFactoryContext.getStatementContext()
Returns the statement context.
|
Modifier and Type | Method and Description |
---|---|
void |
ViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories)
Attaches the factory to a parent event type such that the factory can validate
attach requirements and determine an event type for resulting views.
|
ViewFactoryChain |
ViewServiceImpl.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecDefinitions,
StreamSpecOptions options,
StatementContext context) |
ViewFactoryChain |
ViewService.createFactories(int streamNum,
EventType parentEventType,
ViewSpec[] viewSpecList,
StreamSpecOptions options,
StatementContext context)
Returns a chain of view factories that can be used to obtain the final event type,
and that can later be used to actually create the chain of views or reuse existing views.
|
static java.util.List<ViewFactory> |
ViewServiceHelper.instantiateFactories(int streamNum,
java.util.List<ViewSpec> viewSpecList,
StatementContext statementContext)
Given a list of view specifications obtained from by parsing this method instantiates a list of view factories.
|
static ExprNode[] |
ViewFactorySupport.validate(java.lang.String viewName,
EventType eventType,
StatementContext statementContext,
java.util.List<ExprNode> expressions,
boolean allowConstantResult)
Validate the view parameter expressions and return the validated expression for later execution.
|
static java.lang.Object |
ViewFactorySupport.validateAndEvaluate(java.lang.String viewName,
StatementContext statementContext,
ExprNode expression)
Validate the view parameter expression and evaluate the expression returning the result object.
|
static java.util.List<java.lang.Object> |
ViewFactorySupport.validateAndEvaluate(java.lang.String viewName,
StatementContext statementContext,
java.util.List<ExprNode> expressions)
Validate the view parameter expressions and evaluate the expressions returning the result object.
|
static java.lang.Object |
ViewFactorySupport.validateAndEvaluateExpr(java.lang.String viewName,
StatementContext statementContext,
ExprNode expression,
StreamTypeService streamTypeService,
int expressionNumber) |
static ExprTimePeriodEvalDeltaConst |
ViewFactoryTimePeriodHelper.validateAndEvaluateTimeDelta(java.lang.String viewName,
StatementContext statementContext,
ExprNode expression,
java.lang.String expectedMessage,
int expressionNumber) |
static ExprNode |
ViewFactorySupport.validateExpr(java.lang.String viewName,
StatementContext statementContext,
ExprNode expression,
StreamTypeService streamTypeService,
int expressionNumber) |
Constructor and Description |
---|
ViewFactoryContext(StatementContext statementContext,
int streamNum,
int viewNum,
java.lang.String namespaceName,
java.lang.String viewName)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
void |
TimeOrderViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
SortWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
RankWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
Modifier and Type | Method and Description |
---|---|
void |
UnionViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
PriorEventViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
IntersectViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
Modifier and Type | Method and Description |
---|---|
void |
WeightedAverageViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
UnivariateStatisticsViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
RegressionLinestViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
CorrelationViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
static EventType |
WeightedAverageView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view.
|
static EventType |
UnivariateStatisticsView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view.
|
Modifier and Type | Method and Description |
---|---|
void |
UniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
SizeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
MergeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
LastElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
GroupByViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
FirstUniqueByPropertyViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
FirstElementViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
static EventType |
SizeView.createEventType(StatementContext statementContext,
StatViewAdditionalProps additionalProps,
int streamNum)
Creates the event type for this view
|
Modifier and Type | Method and Description |
---|---|
void |
TimeWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
TimeLengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
TimeBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
TimeAccumViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
LengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
LengthBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
KeepAllViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
FirstTimeViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
FirstLengthWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
ExternallyTimedWindowViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
ExternallyTimedBatchViewFactory.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |
void |
ExpressionViewFactoryBase.attach(EventType parentEventType,
StatementContext statementContext,
ViewFactory optionalParentFactory,
java.util.List<ViewFactory> parentViewFactories) |