Modifier and Type | Method and Description |
---|---|
static ExprNode |
DataFlowParameterValidation.validate(String name,
ExprNode expr,
Class expectedReturnType,
DataFlowOpForgeInitializeContext context)
Validate the provided expression.
|
static ExprNode |
DataFlowParameterValidation.validate(String name,
ExprNode expr,
EventType eventType,
Class expectedReturnType,
DataFlowOpForgeInitializeContext context)
Validate the provided expression.
|
Modifier and Type | Method and Description |
---|---|
static ExprNode |
DataFlowParameterValidation.validate(String name,
ExprNode expr,
Class expectedReturnType,
DataFlowOpForgeInitializeContext context)
Validate the provided expression.
|
static ExprNode |
DataFlowParameterValidation.validate(String name,
ExprNode expr,
EventType eventType,
Class expectedReturnType,
DataFlowOpForgeInitializeContext context)
Validate the provided expression.
|
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
AggregationFunctionValidationContext.getExpressions()
Returns the parameter expressions themselves for interrogation.
|
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,List<ExprNode>> |
AggregationFunctionValidationContext.getNamedParameters()
Returns any named parameters or null if there are no named parameters
|
Constructor and Description |
---|
AggregationFunctionValidationContext(Class[] parameterTypes,
boolean[] constantValue,
Object[] constantValues,
boolean distinct,
boolean windowed,
ExprNode[] expressions,
LinkedHashMap<String,List<ExprNode>> namedParameters)
Ctor.
|
Constructor and Description |
---|
AggregationFunctionValidationContext(Class[] parameterTypes,
boolean[] constantValue,
Object[] constantValues,
boolean distinct,
boolean windowed,
ExprNode[] expressions,
LinkedHashMap<String,List<ExprNode>> namedParameters)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
AggregationMultiFunctionValidationContext.getAllParameterExpressions()
Returns positional and non-positional parameters.
|
ExprNode |
AggregationMultiFunctionValidationContext.getOptionalFilterExpression()
Returns the filter expression when provided
|
ExprNode[] |
AggregationMultiFunctionValidationContext.getParameterExpressions()
Returns positional parameters expressions to this aggregation function.
|
ExprNode[] |
AggregationMultiFunctionAggregationMethodContext.getParameters()
Returns the parameter expressions
|
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,List<ExprNode>> |
AggregationMultiFunctionValidationContext.getNamedParameters()
Gets the named parameters as a list
|
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
DateTimeMethodValidateContext.getCurrentParameters()
Returns the parameters to the date-time method.
|
Constructor and Description |
---|
DateTimeMethodValidateContext(DotMethodFP footprintFound,
StreamTypeService streamTypeService,
DatetimeMethodDesc currentMethod,
List<ExprNode> currentParameters,
StatementRawInfo statementRawInfo)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
EnumMethodValidateContext.getCurrentParameters()
Returns the parameters to the enumeration method.
|
Constructor and Description |
---|
EnumMethodValidateContext(DotMethodFP footprintFound,
EventType inputEventType,
Class inputCollectionComponentType,
StreamTypeService streamTypeService,
EnumMethodEnum currentMethod,
List<ExprNode> currentParameters,
StatementRawInfo statementRawInfo)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
InjectionStrategyClassNewInstance |
InjectionStrategyClassNewInstance.addExpression(String name,
ExprNode value)
Add an expression to be provided by invoking the setter method of the class, at deployment time,
the setter should accept an
ExprEvaluator instance. |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
VirtualDataWindowForgeContext.getParameterExpressions()
Returns the expressions passed as parameters to the virtual data window.
|
Constructor and Description |
---|
VirtualDataWindowForgeContext(EventType eventType,
Object[] parameters,
ExprNode[] parameterExpressions,
String namedWindowName,
ViewForgeEnv viewForgeEnv,
Serializable customConfiguration)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static CodegenExpression |
MultiKeyCodegen.codegenExprEvaluatorMayMultikey(ExprNode[] expressionNodes,
Class[] optionalCoercionTypes,
MultiKeyClassRef multiKeyClassRef,
CodegenMethod method,
CodegenClassScope classScope) |
static CodegenMethod |
MultiKeyCodegen.codegenMethod(ExprNode[] expressionNodes,
MultiKeyClassRef multiKeyClassRef,
CodegenMethodScope parent,
CodegenClassScope classScope) |
static MultiKeyPlan |
MultiKeyPlanner.planMultiKey(ExprNode[] criteriaExpressions,
boolean lenientEquals,
StatementRawInfo raw,
SerdeCompileTimeResolver serdeResolver) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
CompilerServices.compileExpression(String expression,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
OutputLimitSpec.getAndAfterTerminateExpr() |
ExprNode |
CreateVariableDesc.getAssignment()
Returns the assignment expression, or null if none
|
ExprNode[] |
ContextSpecInitiatedTerminated.getDistinctExpressions() |
ExprNode |
MatchRecognizeMeasureItem.getExpr()
Returns the expression.
|
ExprNode |
GroupByClauseElementExpr.getExpr() |
ExprNode |
OnTriggerSetAssignment.getExpression()
Returns the expression providing the new variable value, or null if none
|
ExprNode |
MatchRecognizeDefineItem.getExpression()
Returns the expression.
|
ExprNode |
ContextSpecCategoryItem.getExpression() |
ExprNode |
OrderByItem.getExprNode()
Returns the order-by expression node.
|
ExprNode[] |
GroupByClauseExpressions.getGroupByNodes() |
ExprNode |
StatementSpecRaw.getHavingClause()
Returns expression root node representing the having-clause, if present, or null if no having clause was supplied.
|
ExprNode |
CreateWindowDesc.getInsertFilter()
Returns the expression to filter insert-from events, or null if none supplied.
|
ExprNode |
NewItem.getOptExpression() |
ExprNode |
CreateTableColumn.getOptExpression() |
ExprNode[] |
GroupByClauseExpressions.getOptHavingNodePerLevel() |
ExprNode |
OnTriggerMergeMatched.getOptionalMatchCond() |
ExprNode |
OnTriggerMergeEntry.getOptionalMatchCond() |
ExprNode |
UpdateDesc.getOptionalWhereClause()
Returns the where-clause if defined.
|
ExprNode |
PropertyEvalAtom.getOptionalWhereClause()
Returns the where clause, if specified.
|
ExprNode |
OnTriggerMergeAction.getOptionalWhereClause() |
ExprNode[][] |
GroupByClauseExpressions.getOptOrderByPerLevel() |
ExprNode[][] |
GroupByClauseExpressions.getSelectClausePerLevel() |
ExprNode |
SelectClauseExprRawSpec.getSelectExpression()
Returns the expression node representing the item in the select clause.
|
ExprNode |
PropertyEvalAtom.getSplitterExpression() |
ExprNode |
OutputLimitSpec.getWhenExpressionNode()
Returns the when-keyword trigger expression, or null if not using when.
|
ExprNode |
StatementSpecRaw.getWhereClause()
Gets the where clause.
|
ExprNode |
OnTriggerSplitStream.getWhereClause()
Returns the where clause or null if not defined
|
ExprNode |
OuterJoinDesc.makeExprNode(StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
OutputLimitSpec.getCrontabAtSchedule()
Returns crontab parameters, or null if not using crontab-at output.
|
List<List<ExprNode>> |
ContextSpecConditionCrontab.getCrontabs() |
List<ExprNode> |
MethodStreamSpec.getExpressions()
Returns the parameter expressions.
|
List<ExprNode> |
GroupByClauseElementCombinedExpr.getExpressions() |
List<ExprNode> |
ForClauseItemSpec.getExpressions() |
List<ExprNode> |
CreateIndexItem.getExpressions() |
List<ExprNode> |
TableQueryStreamSpec.getFilterExpressions() |
List<ExprNode> |
NamedWindowConsumerStreamSpec.getFilterExpressions()
Returns list of filter expressions onto the named window, or no filter expressions if none defined.
|
List<ExprNode> |
FilterSpecRaw.getFilterExpressions()
Returns the list of filter expressions.
|
List<ExprNode> |
ObjectSpec.getObjectParameters()
Returns the list of object parameters.
|
List<ExprNode> |
CreateIndexItem.getParameters() |
List<ExprNode> |
MatchRecognizeSpec.getPartitionByExpressions()
Returns partition expressions.
|
Map<Integer,List<ExprNode>> |
StatementSpecRaw.getSqlParameters() |
Modifier and Type | Method and Description |
---|---|
void |
OutputLimitSpec.setAndAfterTerminateExpr(ExprNode andAfterTerminateExpr) |
void |
CreateVariableDesc.setAssignment(ExprNode assignment) |
void |
MatchRecognizeMeasureItem.setExpr(ExprNode validated)
Sets the validated expression.
|
void |
OnTriggerSetAssignment.setExpression(ExprNode expression)
Sets the expression providing the new variable value
|
void |
MatchRecognizeDefineItem.setExpression(ExprNode validated)
Sets the validated expression
|
void |
StatementSpecRaw.setHavingClause(ExprNode havingClause)
Sets the having-clause filter expression node.
|
void |
CreateWindowDesc.setInsertFilter(ExprNode insertFilter)
Sets the filter expression to use to apply
|
void |
OnTriggerMergeMatched.setOptionalMatchCond(ExprNode optionalMatchCond) |
void |
OnTriggerMergeEntry.setOptionalMatchCond(ExprNode optionalMatchCond) |
void |
UpdateDesc.setOptionalWhereClause(ExprNode optionalWhereClause)
Sets the where-clause if defined.
|
void |
OnTriggerMergeAction.setOptionalWhereClause(ExprNode optionalWhereClause) |
void |
OutputLimitSpec.setWhenExpressionNode(ExprNode whenExpressionNode)
Sets a new when-keyword trigger expression.
|
void |
StatementSpecRaw.setWhereClause(ExprNode whereClause)
Sets the where clause or null if none
|
Modifier and Type | Method and Description |
---|---|
void |
ForClauseItemSpec.setExpressions(List<ExprNode> expressions) |
void |
MatchRecognizeSpec.setPartitionByExpressions(List<ExprNode> partitionByExpressions)
Returns partition expressions.
|
void |
StatementSpecRaw.setSqlParameters(Map<Integer,List<ExprNode>> sqlParameters) |
Constructor and Description |
---|
ContextSpecCategoryItem(ExprNode expression,
String name) |
ContextSpecInitiatedTerminated(ContextSpecCondition startCondition,
ContextSpecCondition endCondition,
boolean overlapping,
ExprNode[] distinctExpressions) |
CreateTableColumn(String columnName,
ExprNode optExpression,
ClassIdentifierWArray optType,
List<AnnotationDesc> annotations,
Boolean primaryKey) |
CreateVariableDesc(ClassIdentifierWArray variableType,
String variableName,
ExprNode assignment,
boolean constant)
Ctor.
|
CreateWindowDesc(String windowName,
List<ViewSpec> viewSpecs,
StreamSpecOptions streamSpecOptions,
boolean insert,
ExprNode insertFilter,
List<ColumnDesc> columns,
String asEventTypeName)
Ctor.
|
GroupByClauseElementExpr(ExprNode expr) |
GroupByClauseExpressions(ExprNode[] groupByNodes) |
GroupByClauseExpressions(ExprNode[] groupByNodes,
int[][] groupByRollupLevels,
ExprNode[][] selectClauseCopy,
ExprNode[] optHavingNodeCopy,
ExprNode[][] optOrderByPerLevel) |
GroupByClauseExpressions(ExprNode[] groupByNodes,
int[][] groupByRollupLevels,
ExprNode[][] selectClauseCopy,
ExprNode[] optHavingNodeCopy,
ExprNode[][] optOrderByPerLevel) |
GroupByClauseExpressions(ExprNode[] groupByNodes,
int[][] groupByRollupLevels,
ExprNode[][] selectClauseCopy,
ExprNode[] optHavingNodeCopy,
ExprNode[][] optOrderByPerLevel) |
GroupByClauseExpressions(ExprNode[] groupByNodes,
int[][] groupByRollupLevels,
ExprNode[][] selectClauseCopy,
ExprNode[] optHavingNodeCopy,
ExprNode[][] optOrderByPerLevel) |
MatchRecognizeDefineItem(String identifier,
ExprNode expression)
Ctor.
|
MatchRecognizeMeasureItem(ExprNode expr,
String name)
Ctor.
|
NewItem(String name,
ExprNode optExpression) |
OnTriggerMergeAction(ExprNode optionalWhereClause) |
OnTriggerMergeActionDelete(ExprNode optionalMatchCond) |
OnTriggerMergeActionInsert(ExprNode optionalWhereClause,
String optionalStreamName,
List<String> columns,
List<SelectClauseElementRaw> selectClause) |
OnTriggerMergeActionUpdate(ExprNode optionalMatchCond,
List<OnTriggerSetAssignment> assignments) |
OnTriggerMergeEntry(ExprNode optionalMatchCond) |
OnTriggerMergeMatched(boolean matchedUnmatched,
ExprNode optionalMatchCond,
List<OnTriggerMergeAction> actions) |
OnTriggerSetAssignment(ExprNode expression)
Ctor.
|
OnTriggerSplitStream(InsertIntoDesc insertInto,
SelectClauseSpecRaw selectClause,
OnTriggerSplitStreamFromClause fromClause,
ExprNode whereClause)
Ctor.
|
OrderByItem(ExprNode exprNode,
boolean ascending)
Ctor.
|
OutputLimitSpec(Double rate,
String variableForRate,
OutputLimitRateType rateType,
OutputLimitLimitType displayLimit,
ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> thenExpressions,
List<ExprNode> crontabAtSchedule,
ExprTimePeriod timePeriodExpr,
ExprTimePeriod afterTimePeriodExpr,
Integer afterNumberOfEvents,
boolean andAfterTerminate,
ExprNode andAfterTerminateExpr,
List<OnTriggerSetAssignment> andAfterTerminateSetExpressions) |
PropertyEvalAtom(ExprNode splitterExpression,
String optionalResultEventType,
String optionalAsName,
SelectClauseSpecRaw optionalSelectClause,
ExprNode optionalWhereClause)
Ctor.
|
SelectClauseExprRawSpec(ExprNode selectExpression,
String optionalAsName,
boolean isEvents)
Ctor.
|
UpdateDesc(String optionalStreamName,
List<OnTriggerSetAssignment> assignments,
ExprNode optionalWhereClause)
Ctor.
|
Constructor and Description |
---|
ContextSpecConditionCrontab(List<List<ExprNode>> crontabs,
boolean immediate) |
CreateIndexItem(List<ExprNode> expressions,
String type,
List<ExprNode> parameters) |
CreateIndexItem(List<ExprNode> expressions,
String type,
List<ExprNode> parameters) |
FilterSpecRaw(String eventTypeName,
List<ExprNode> filterExpressions,
PropertyEvalSpec optionalPropertyEvalSpec)
Ctor.
|
ForClauseItemSpec(String keyword,
List<ExprNode> expressions) |
GroupByClauseElementCombinedExpr(List<ExprNode> expressions) |
MethodStreamSpec(String optionalStreamName,
ViewSpec[] viewSpecs,
String ident,
String className,
String methodName,
List<ExprNode> expressions,
String eventTypeName)
Ctor.
|
NamedWindowConsumerStreamSpec(NamedWindowMetaData namedWindow,
String optionalAsName,
ViewSpec[] viewSpecs,
List<ExprNode> filterExpressions,
StreamSpecOptions streamSpecOptions,
PropertyEvaluatorForge optPropertyEvaluator) |
ObjectSpec(String namespace,
String objectName,
List<ExprNode> objectParameters)
Constructor.
|
OutputLimitSpec(Double rate,
String variableForRate,
OutputLimitRateType rateType,
OutputLimitLimitType displayLimit,
ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> thenExpressions,
List<ExprNode> crontabAtSchedule,
ExprTimePeriod timePeriodExpr,
ExprTimePeriod afterTimePeriodExpr,
Integer afterNumberOfEvents,
boolean andAfterTerminate,
ExprNode andAfterTerminateExpr,
List<OnTriggerSetAssignment> andAfterTerminateSetExpressions) |
PatternGuardSpec(String namespace,
String objectName,
List<ExprNode> objectParameters)
Constructor.
|
PatternObserverSpec(String namespace,
String objectName,
List<ExprNode> objectParameters)
Constructor.
|
TableQueryStreamSpec(String optionalStreamName,
ViewSpec[] viewSpecs,
StreamSpecOptions streamSpecOptions,
TableMetaData table,
List<ExprNode> filterExpressions) |
ViewSpec(String namespace,
String objectName,
List<ExprNode> viewParameters)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExpressionCopier.copy(ExprNode exprNode) |
static ExprNode |
StatementSpecMapper.mapExpression(Expression expression,
StatementSpecMapContext env) |
static ExprNode |
ASTAggregationHelper.tryResolveAsAggregation(ClasspathImportServiceCompileTime classpathImportService,
boolean distinct,
String functionName,
LazyAllocatedMap<ConfigurationCompilerPlugInAggregationMultiFunction,AggregationMultiFunctionForge> plugInAggregations) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExpressionCopier.copy(ExprNode exprNode) |
static Expression |
StatementSpecMapper.unmap(ExprNode expression)
Unmap expresission.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
SelectClauseExprCompiledSpec.getSelectExpression()
Returns the expression node representing the item in the select clause.
|
ExprNode |
FilterSpecParaForgeMap.removeEntry(FilterSpecParamForge param)
Removes a filter parameter and it's associated expression node
|
static ExprNode |
FilterSpecCompilerMakeParamUtil.rewriteOrToInIfApplicable(ExprNode constituent) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
FilterSpecValidatedDesc.getExpressions() |
List<ExprNode> |
FilterSpecParaForgeMap.getUnassignedExpressions()
Returns all expression nodes for which no filter parameter exists.
|
Modifier and Type | Method and Description |
---|---|
protected static FilterSpecParamForge |
FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
String statementName)
For a given expression determine if this is optimizable and create the filter parameter
representing the expression, or null if not optimizable.
|
void |
FilterSpecParaForgeMap.put(ExprNode exprNode,
FilterSpecParamForge param)
Add a node and filter param.
|
void |
FilterSpecParaForgeMap.removeNode(ExprNode node) |
static ExprNode |
FilterSpecCompilerMakeParamUtil.rewriteOrToInIfApplicable(ExprNode constituent) |
void |
SelectClauseExprCompiledSpec.setSelectExpression(ExprNode selectExpression)
Sets the select expression to use.
|
static boolean |
StreamSpecCompiler.validateMatchUntil(ExprNode lowerBounds,
ExprNode upperBounds,
boolean isAllowLowerZero)
Validate.
|
Constructor and Description |
---|
SelectClauseExprCompiledSpec(ExprNode selectExpression,
String assignedName,
String providedName,
boolean isEvents)
Ctor.
|
Constructor and Description |
---|
FilterSpecValidatedDesc(List<ExprNode> expressions,
List<StmtClassForgeableFactory> additionalForgeables) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
CompileExpressionSPI.compileExpression(String epl,
EventType[] eventTypes,
String[] streamNames) |
Constructor and Description |
---|
ViewableActivatorNamedWindowForge(NamedWindowConsumerStreamSpec spec,
NamedWindowMetaData namedWindow,
ExprNode filterEvaluator,
QueryGraphForge filterQueryGraph,
boolean subquery,
PropertyEvaluatorForge optPropertyEvaluator) |
ViewableActivatorTableForge(TableMetaData table,
ExprNode optionalFilterExpression) |
Modifier and Type | Method and Description |
---|---|
SAIFFInitializeBuilder |
SAIFFInitializeBuilder.exprnode(String name,
ExprNode value) |
Constructor and Description |
---|
StatementAgentInstanceFactoryCreateNWForge(ViewableActivatorFilterForge activator,
String namedWindowName,
List<ViewFactoryForge> views,
NamedWindowMetaData insertFromNamedWindow,
ExprNode insertFromFilter,
EventType asEventType,
String resultSetProcessorProviderClassName) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
OnSplitItemForge.getWhereClause() |
Constructor and Description |
---|
OnSplitItemForge(ExprNode whereClause,
boolean isNamedWindowInsert,
TableMetaData insertIntoTable,
ResultSetProcessorDesc resultSetProcessorDesc,
PropertyEvaluatorForge propertyEvaluator) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
OnTriggerPlanValidationResult.getValidatedJoin() |
protected static ExprNode |
OnTriggerPlanValidator.validateJoinNamedWindow(ExprNodeOrigin exprNodeOrigin,
ExprNode deleteJoinExpr,
EventType namedWindowType,
String namedWindowStreamName,
String namedWindowName,
EventType filteredType,
String filterStreamName,
String filteredTypeName,
String optionalTableName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
Modifier and Type | Method and Description |
---|---|
protected static ExprNode |
OnTriggerPlanValidator.validateJoinNamedWindow(ExprNodeOrigin exprNodeOrigin,
ExprNode deleteJoinExpr,
EventType namedWindowType,
String namedWindowStreamName,
String namedWindowName,
EventType filteredType,
String filterStreamName,
String filteredTypeName,
String optionalTableName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
Constructor and Description |
---|
OnTriggerPlanValidationResult(Map<ExprSubselectNode,SubSelectFactoryForge> subselectForges,
Map<ExprTableAccessNode,ExprTableEvalStrategyFactoryForge> tableAccessForges,
ResultSetProcessorDesc resultSetProcessorPrototype,
ExprNode validatedJoin,
String zeroStreamAliasName,
List<StmtClassForgeableFactory> additionalForgeables) |
Constructor and Description |
---|
InternalEventRouterDescForge(EventBeanCopyMethodForge copyMethod,
TypeWidenerSPI[] wideners,
EventType eventType,
Annotation[] annotations,
ExprNode optionalWhereClause,
String[] properties,
ExprNode[] assignments) |
InternalEventRouterDescForge(EventBeanCopyMethodForge copyMethod,
TypeWidenerSPI[] wideners,
EventType eventType,
Annotation[] annotations,
ExprNode optionalWhereClause,
String[] properties,
ExprNode[] assignments) |
Constructor and Description |
---|
ContextControllerHashedGetterCRC32SingleForge(ExprNode eval,
int granularity) |
ContextControllerHashedGetterHashSingleForge(ExprNode eval,
int granularity) |
Constructor and Description |
---|
ContextControllerHashedGetterCRC32SerializedForge(List<ExprNode> nodes,
int granularity) |
ContextControllerHashedGetterHashMultiple(List<ExprNode> expressions,
int granularity) |
ContextControllerHashedGetterSingleRowForge(Pair<Class,ClasspathImportSingleRowDesc> func,
List<ExprNode> parameters,
int granularity,
EventType eventType,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Constructor and Description |
---|
StatementInformationalsCompileTime(String statementNameCompileTime,
boolean alwaysSynthesizeOutputEvents,
String optionalContextName,
String optionalContextModuleName,
NameAccessModifier optionalContextVisibility,
boolean canSelfJoin,
boolean hasSubquery,
boolean needDedup,
Annotation[] annotations,
boolean stateless,
Serializable userObjectCompileTime,
int numFilterCallbacks,
int numScheduleCallbacks,
int numNamedWindowCallbacks,
StatementType statementType,
int priority,
boolean preemptive,
boolean hasVariables,
boolean writesToTables,
boolean hasTableAccess,
Class[] selectClauseTypes,
String[] selectClauseColumnNames,
boolean forClauseDelivery,
ExprNode[] groupDelivery,
MultiKeyClassRef groupDeliveryMultiKey,
Map<StatementProperty,Object> properties,
boolean hasMatchRecognize,
boolean instrumented,
CodegenPackageScope packageScope,
String insertIntoLatchName,
boolean allowSubscriber,
ExpressionScriptProvided[] onScripts) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
AggregatorAccessWFilterBase.optionalFilter |
Modifier and Type | Method and Description |
---|---|
static AggregationAgentForge |
AggregationAgentForgeFactory.make(int streamNum,
ExprNode optionalFilter,
ClasspathImportService classpathImportService,
boolean isFireAndForget,
String statementName) |
Constructor and Description |
---|
AggregationStateKeyWStream(int streamNum,
EventType eventType,
AggregationStateTypeWStream stateType,
ExprNode[] criteraExprNodes,
ExprNode filterExprNode) |
AggregationStateKeyWStream(int streamNum,
EventType eventType,
AggregationStateTypeWStream stateType,
ExprNode[] criteraExprNodes,
ExprNode filterExprNode) |
AggregatorAccessWFilterBase(ExprNode optionalFilter) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
AggregationStateCountMinSketchForge.getExpression() |
Modifier and Type | Method and Description |
---|---|
boolean |
AggregationPortableValidationCountMinSketch.isAggregationMethod(String name,
ExprNode[] parameters,
ExprValidationContext validationContext) |
AggregationMultiFunctionMethodDesc |
AggregationPortableValidationCountMinSketch.validateAggregationMethod(ExprValidationContext validationContext,
String aggMethodName,
ExprNode[] params) |
Constructor and Description |
---|
AgregationMethodCountMinSketchFreqForge(ExprNode frequencyEval) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
AggregationStateLinearForge.getExpression() |
Modifier and Type | Method and Description |
---|---|
boolean |
AggregationPortableValidationLinear.isAggregationMethod(String name,
ExprNode[] parameters,
ExprValidationContext validationContext) |
AggregationMultiFunctionMethodDesc |
AggregationPortableValidationLinear.validateAggregationMethod(ExprValidationContext validationContext,
String aggMethodName,
ExprNode[] params) |
Constructor and Description |
---|
AggregationMethodLinearFirstLastForge(Class underlyingType,
AggregationAccessorLinearType accessType,
ExprNode optionalEvaluator) |
AggregationMethodLinearFirstLastIndexForge(Class underlyingType,
AggregationAccessorLinearType accessType,
Integer optionalConstant,
ExprNode optionalIndexEval) |
AggregationMethodLinearWindowForge(Class arrayType,
ExprNode optionalEvaluator) |
AggregatorAccessLinearJoin(AggregationStateLinearForge forge,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
ExprNode optionalFilter) |
AggregatorAccessLinearNonJoin(AggregationStateLinearForge forge,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
ExprNode optionalFilter) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
AggregationStateFactoryForgePlugin.getExpression() |
Modifier and Type | Method and Description |
---|---|
boolean |
AggregationPortableValidationPluginMultiFunc.isAggregationMethod(String name,
ExprNode[] parameters,
ExprValidationContext validationContext) |
AggregationMultiFunctionMethodDesc |
AggregationPortableValidationPluginMultiFunc.validateAggregationMethod(ExprValidationContext validationContext,
String aggMethodName,
ExprNode[] params) |
Constructor and Description |
---|
AggregatorAccessPlugin(int col,
boolean join,
CodegenCtor ctor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
ExprNode optionalFilter,
AggregationMultiFunctionStateModeManaged mode) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
SortedAggregationStateDesc.getCriteria() |
ExprNode |
AggregationStateSortedForge.getExpression() |
ExprNode |
AggregationStateMinMaxByEverForge.getExpression() |
Modifier and Type | Method and Description |
---|---|
boolean |
AggregationPortableValidationSorted.isAggregationMethod(String nameMixed,
ExprNode[] parameters,
ExprValidationContext validationContext) |
AggregationMultiFunctionMethodDesc |
AggregationPortableValidationSorted.validateAggregationMethod(ExprValidationContext validationContext,
String aggMethodName,
ExprNode[] params) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
AggregationStateFactoryForge.getExpression() |
Modifier and Type | Method and Description |
---|---|
static AggregationMultiFunctionAnalysisResult |
AggregationMultiFunctionAnalysisHelper.analyzeAccessAggregations(List<AggregationServiceAggExpressionDesc> aggregations,
ClasspathImportServiceCompileTime classpathImportService,
boolean isFireAndForget,
String statementName,
ExprNode[] groupByNodes) |
static CodegenMethod |
AggregationServiceCodegenUtil.computeMultiKeyCodegen(int idNumber,
ExprNode[] partitionForges,
MultiKeyClassRef optionalMultiKey,
CodegenClassScope classScope,
CodegenNamedMethods namedMethods) |
static AggregationServiceForgeDesc |
AggregationServiceFactoryFactory.getService(List<ExprAggregateNode> selectAggregateExprNodes,
Map<ExprNode,String> selectClauseNamedNodes,
List<ExprDeclaredNode> declaredExpressions,
ExprNode[] groupByNodes,
MultiKeyClassRef groupByMultiKey,
List<ExprAggregateNode> havingAggregateExprNodes,
List<ExprAggregateNode> orderByAggregateExprNodes,
List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
Annotation[] annotations,
VariableCompileTimeResolver variableCompileTimeResolver,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
EventType[] typesPerStream,
AggregationGroupByRollupDescForge groupByRollupDesc,
String optionalContextName,
IntoTableSpec intoTableSpec,
TableCompileTimeResolver tableCompileTimeResolver,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect,
ClasspathImportServiceCompileTime classpathImportService,
StatementRawInfo raw,
SerdeCompileTimeResolver serdeResolver) |
static AggregationServiceForgeDesc |
AggregationServiceFactoryFactory.getService(List<ExprAggregateNode> selectAggregateExprNodes,
Map<ExprNode,String> selectClauseNamedNodes,
List<ExprDeclaredNode> declaredExpressions,
ExprNode[] groupByNodes,
MultiKeyClassRef groupByMultiKey,
List<ExprAggregateNode> havingAggregateExprNodes,
List<ExprAggregateNode> orderByAggregateExprNodes,
List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
Annotation[] annotations,
VariableCompileTimeResolver variableCompileTimeResolver,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
EventType[] typesPerStream,
AggregationGroupByRollupDescForge groupByRollupDesc,
String optionalContextName,
IntoTableSpec intoTableSpec,
TableCompileTimeResolver tableCompileTimeResolver,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect,
ClasspathImportServiceCompileTime classpathImportService,
StatementRawInfo raw,
SerdeCompileTimeResolver serdeResolver) |
boolean |
AggregationPortableValidationBase.isAggregationMethod(String name,
ExprNode[] parameters,
ExprValidationContext validationContext) |
boolean |
AggregationPortableValidation.isAggregationMethod(String name,
ExprNode[] parameters,
ExprValidationContext validationContext) |
AggregationMultiFunctionMethodDesc |
AggregationPortableValidationBase.validateAggregationMethod(ExprValidationContext validationContext,
String aggMethodName,
ExprNode[] params) |
AggregationMultiFunctionMethodDesc |
AggregationPortableValidation.validateAggregationMethod(ExprValidationContext validationContext,
String aggMethodName,
ExprNode[] params) |
Modifier and Type | Method and Description |
---|---|
static AggregationServiceForgeDesc |
AggregationServiceFactoryFactory.getService(List<ExprAggregateNode> selectAggregateExprNodes,
Map<ExprNode,String> selectClauseNamedNodes,
List<ExprDeclaredNode> declaredExpressions,
ExprNode[] groupByNodes,
MultiKeyClassRef groupByMultiKey,
List<ExprAggregateNode> havingAggregateExprNodes,
List<ExprAggregateNode> orderByAggregateExprNodes,
List<ExprAggregateNodeGroupKey> groupKeyExpressions,
boolean hasGroupByClause,
Annotation[] annotations,
VariableCompileTimeResolver variableCompileTimeResolver,
boolean isDisallowNoReclaim,
ExprNode whereClause,
ExprNode havingClause,
EventType[] typesPerStream,
AggregationGroupByRollupDescForge groupByRollupDesc,
String optionalContextName,
IntoTableSpec intoTableSpec,
TableCompileTimeResolver tableCompileTimeResolver,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect,
ClasspathImportServiceCompileTime classpathImportService,
StatementRawInfo raw,
SerdeCompileTimeResolver serdeResolver) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
AggGroupByDesc.getGroupByNodes() |
Constructor and Description |
---|
AggGroupByDesc(AggregationRowStateForgeDesc rowStateForgeDescs,
boolean isUnidirectional,
boolean isFireAndForget,
boolean isOnSelect,
ExprNode[] groupByNodes,
MultiKeyClassRef groupByMultiKey) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
AggregationGroupByLocalGroupLevel.getPartitionExpr() |
ExprNode[] |
AggregationLocalGroupByLevelForge.getPartitionForges() |
ExprNode[] |
AggregationLocalGroupByColumnForge.getPartitionForges() |
Modifier and Type | Method and Description |
---|---|
static AggregationLocalGroupByPlanDesc |
AggregationGroupByLocalGroupByAnalyzer.analyze(ExprForge[][] methodForges,
AggregationForgeFactory[] methodFactories,
AggregationStateFactoryForge[] accessAggregations,
AggregationGroupByLocalGroupDesc localGroupDesc,
ExprNode[] groupByExpressions,
MultiKeyClassRef groupByMultiKey,
AggregationAccessorSlotPairForge[] accessors,
StatementRawInfo raw,
SerdeCompileTimeResolver serdeResolver) |
Constructor and Description |
---|
AggregationGroupByLocalGroupLevel(ExprNode[] partitionExpr,
List<AggregationServiceAggExpressionDesc> expressions) |
AggregationLocalGroupByColumnForge(boolean defaultGroupLevel,
ExprNode[] partitionForges,
int methodOffset,
boolean methodAgg,
AggregationAccessorSlotPairForge pair,
int levelNum) |
AggregationLocalGroupByLevelForge(ExprForge[][] methodForges,
AggregationForgeFactory[] methodFactories,
AggregationStateFactoryForge[] accessStateForges,
ExprNode[] partitionForges,
MultiKeyClassRef partitionMKClasses,
boolean defaultLevel) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
AggregationForgeFactoryAvedev.positionalParameters |
Constructor and Description |
---|
AggregationForgeFactoryAvedev(ExprAvedevNode parent,
Class aggregatedValueType,
DataInputOutputSerdeForge distinctSerde,
ExprNode[] positionalParameters) |
AggregatorAvedev(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
Constructor and Description |
---|
AggregatorAvgBig(AggregationForgeFactoryAvg factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
AggregatorAvgNonBig(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
Class sumType) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
AggregatorMethodWDistinctWFilterBase.optionalFilter |
Constructor and Description |
---|
AggregatorMethodWDistinctWFilterBase(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
AggregatorMethodWDistinctWFilterWValueBase(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
Constructor and Description |
---|
AggregatorCount(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
boolean isEver) |
Constructor and Description |
---|
AggregatorFirstEver(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
Class childType,
DataInputOutputSerdeForge serde) |
AggregatorLastEver(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
Class childType,
DataInputOutputSerdeForge serde) |
Constructor and Description |
---|
AggregatorMedian(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
Constructor and Description |
---|
AggregatorMinMax(AggregationForgeFactoryMinMax factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
AggregatorMinMaxEver(AggregationForgeFactoryMinMax factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
DataInputOutputSerdeForge serde) |
Constructor and Description |
---|
AggregatorNth(AggregationForgeFactoryNth factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
Constructor and Description |
---|
AggregatorPlugInManaged(AggregationForgeFactoryPlugin factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
AggregationFunctionModeManaged mode) |
Constructor and Description |
---|
AggregatorRate(AggregationForgeFactoryRate factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
AggregatorRateEver(AggregationForgeFactoryRate factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
Constructor and Description |
---|
AggregatorStddev(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter) |
Constructor and Description |
---|
AggregatorSumBase(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
Class sumType) |
AggregatorSumBig(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
Class sumType) |
AggregatorSumNonBig(AggregationForgeFactory factory,
int col,
CodegenCtor rowCtor,
CodegenMemberCol membersColumnized,
CodegenClassScope classScope,
Class optionalDistinctValueType,
DataInputOutputSerdeForge optionalDistinctSerde,
boolean hasFilter,
ExprNode optionalFilter,
Class sumType) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
AggSvcGroupByRollupForge.groupByNodes |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
GroupByRollupPlanDesc.getExpressions() |
Modifier and Type | Method and Description |
---|---|
static GroupByClauseExpressions |
GroupByExpressionHelper.getGroupByRollupExpressions(List<GroupByClauseElement> groupByElements,
SelectClauseSpecRaw selectClauseSpec,
ExprNode optionalHavingNode,
List<OrderByItem> orderByList,
ExpressionCopier expressionCopier) |
int |
GroupByRollupEvalContext.getIndex(ExprNode node) |
Constructor and Description |
---|
AggSvcGroupByRollupForge(AggregationRowStateForgeDesc rowStateForgeDesc,
AggregationGroupByRollupDescForge rollupDesc,
ExprNode[] groupByNodes) |
GroupByRollupNodeSingleExpr(ExprNode expression) |
GroupByRollupPlanDesc(ExprNode[] expressions,
AggregationGroupByRollupDescForge rollupDesc) |
Constructor and Description |
---|
GroupByRollupEvalContext(Map<ExprNode,Integer> expressionToIndex) |
GroupByRollupNodeCombinedExpr(List<ExprNode> expressions) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
EventBusSourceForge.filter |
Modifier and Type | Method and Description |
---|---|
void |
BeaconSourceForge.setProperty(String name,
ExprNode value) |
Modifier and Type | Method and Description |
---|---|
static CalendarFieldEnum |
CalendarOpUtil.getEnum(String methodName,
ExprNode exprNode) |
static ReformatFormatForgeDesc |
CalendarOpUtil.validateGetFormatterType(EPType inputType,
String methodName,
ExprNode exprNode) |
Modifier and Type | Method and Description |
---|---|
CalendarForge |
CalendarForgeFactory.getOp(DatetimeMethodDesc desc,
String methodNameUsed,
List<ExprNode> parameters,
ExprForge[] forges) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
FilterExprAnalyzerDTIntervalAffector.getIndexExpressions() |
ExprNode[] |
FilterExprAnalyzerDTBetweenAffector.getIndexExpressions() |
Modifier and Type | Method and Description |
---|---|
List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTIntervalAffector.getKeyExpressions() |
List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTBetweenAffector.getKeyExpressions() |
Modifier and Type | Method and Description |
---|---|
static ExprDotDTMethodDesc |
ExprDotDTFactory.validateMake(StreamTypeService streamTypeService,
Deque<ExprChainedSpec> chainSpecStack,
DatetimeMethodDesc dtMethod,
String dtMethodName,
EPType inputType,
List<ExprNode> parameters,
ExprDotNodeFilterAnalyzerInput inputDesc,
TimeAbacus timeAbacus,
TableCompileTimeResolver tableCompileTimeResolver,
ClasspathImportServiceCompileTime classpathImportService,
StatementRawInfo statementRawInfo) |
Constructor and Description |
---|
FilterExprAnalyzerDTBetweenAffector(EventType[] typesPerStream,
int targetStreamNum,
String targetPropertyName,
ExprNode start,
ExprNode end,
boolean includeLow,
boolean includeHigh) |
Modifier and Type | Method and Description |
---|---|
FilterExprAnalyzerDTIntervalAffector |
IntervalForgeImpl.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodDesc currentMethod,
List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc)
Obtain information used by filter analyzer to handle this dot-method invocation as part of query planning/indexing.
|
FilterExprAnalyzerDTIntervalAffector |
IntervalForge.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodDesc currentMethod,
List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc) |
IntervalForge |
IntervalForgeFactory.getForge(StreamTypeService streamTypeService,
DatetimeMethodDesc method,
String methodNameUsed,
List<ExprNode> parameters,
TimeAbacus timeAbacus,
TableCompileTimeResolver tableCompileTimeResolver) |
static IntervalComputerForge |
IntervalComputerForgeFactory.make(DatetimeMethodDesc method,
List<ExprNode> expressions,
TimeAbacus timeAbacus) |
Constructor and Description |
---|
IntervalForgeImpl(DatetimeMethodDesc method,
String methodNameUse,
StreamTypeService streamTypeService,
List<ExprNode> expressions,
TimeAbacus timeAbacus,
TableCompileTimeResolver tableCompileTimeResolver) |
Modifier and Type | Method and Description |
---|---|
FilterExprAnalyzerAffector |
DTMPluginReformatForge.getFilterDesc(EventType[] typesPerStream,
DatetimeMethodDesc currentMethod,
List<ExprNode> currentParameters,
ExprDotNodeFilterAnalyzerInput inputDesc) |
Constructor and Description |
---|
DTMPluginReformatForge(Class inputType,
DateTimeMethodOpsReformat reformatOp,
List<ExprNode> reformatOpParams) |
DTMPluginValueChangeForge(Class inputType,
DateTimeMethodOpsModify transformOp,
List<ExprNode> transformOpParams) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
ReformatBetweenNonConstantParamsForge.end |
protected ExprNode |
ReformatBetweenNonConstantParamsForge.start |
Constructor and Description |
---|
ReformatBetweenConstantParamsForge(List<ExprNode> parameters) |
ReformatBetweenNonConstantParamsForge(List<ExprNode> parameters) |
Modifier and Type | Class and Description |
---|---|
class |
ExprLambdaGoesNode
Represents the case-when-then-else control flow function is an expression tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprDotEvalParam.getBody() |
ExprNode |
ExprLambdaGoesNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprLambdaGoesNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Method and Description |
---|---|
void |
ExprDotForgeEnumMethodBase.init(Integer streamOfProviderIfApplicable,
EnumMethodDesc enumMethodDesc,
String enumMethodUsedName,
EPType typeInfo,
List<ExprNode> parameters,
ExprValidationContext validationContext) |
void |
ExprDotForgeEnumMethod.init(Integer streamOfProviderIfApplicable,
EnumMethodDesc lambda,
String lambdaUsedName,
EPType currentInputType,
List<ExprNode> parameters,
ExprValidationContext validationContext) |
void |
ExprDotForgeEnumMethodBase.initialize(DotMethodFP footprint,
EnumMethodEnum enumMethod,
String enumMethodUsedName,
EventType inputEventType,
Class collectionComponentType,
List<ExprNode> parameters,
StreamTypeService streamTypeService,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Constructor and Description |
---|
ExprDotEvalParam(int parameterNum,
ExprNode body,
ExprForge bodyForge) |
ExprDotEvalParamExpr(int parameterNum,
ExprNode body,
ExprForge bodyForge) |
ExprDotEvalParamLambda(int parameterNum,
ExprNode body,
ExprForge bodyEvaluator,
int streamCountIncoming,
List<String> goesToNames,
EventType[] goesToTypes) |
Modifier and Type | Method and Description |
---|---|
void |
ExprDotForgeEnumMethodPlugin.initialize(DotMethodFP footprint,
EnumMethodEnum enumMethod,
String enumMethodUsedName,
EventType inputEventType,
Class collectionComponentType,
List<ExprNode> parameters,
StreamTypeService streamTypeService,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprAggMultiFunctionNode |
Modifier and Type | Class and Description |
---|---|
class |
ExprAggMultiFunctionCountMinSketchNode
Represents the Count-min sketch aggregate function.
|
class |
ExprAggMultiFunctionLinearAccessNode |
class |
ExprAggMultiFunctionSortedMinMaxByNode |
class |
ExprPlugInMultiFunctionAggNode
Represents a custom aggregation function in an expresson tree.
|
Modifier and Type | Method and Description |
---|---|
static int |
ExprAggMultiFunctionUtil.validateStreamWildcardGetStreamNum(ExprNode node) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprAggregateNode
Base expression node that represents an aggregation function such as 'sum' or 'count'.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprAggregateNodeBase
Base expression node that represents an aggregation function such as 'sum' or 'count'.
|
class |
ExprAggregateNodeGroupKey |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
ExprAggregateNodeBase.optionalFilter |
protected ExprNode[] |
ExprAggregateNodeBase.positionalParams |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprAggregateNodeGroupKey.getForgeRenderable() |
ExprNode |
ExprAggregateNodeBase.getForgeRenderable() |
ExprNode |
ExprAggregateNodeParamDesc.getOptionalFilter() |
ExprNode |
ExprAggregateNodeBase.getOptionalFilter() |
ExprNode |
ExprAggregateNode.getOptionalFilter() |
ExprNode[] |
ExprAggregateLocalGroupByDesc.getPartitionExpressions() |
ExprNode[] |
ExprAggregateNodeParamDesc.getPositionalParams() |
ExprNode[] |
ExprAggregateNodeBase.getPositionalParams() |
ExprNode[] |
ExprAggregateNode.getPositionalParams() |
ExprNode |
ExprAggregateNodeGroupKey.validate(ExprValidationContext validationContext) |
ExprNode |
ExprAggregateNodeBase.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprAggregateNodeGroupKey.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprAggregateNodeBase.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
static void |
ExprAggregateNodeUtil.getAggregatesBottomUp(ExprNode[][] nodes,
List<ExprAggregateNode> aggregateNodes) |
static void |
ExprAggregateNodeUtil.getAggregatesBottomUp(ExprNode[] nodes,
List<ExprAggregateNode> aggregateNodes) |
static void |
ExprAggregateNodeUtil.getAggregatesBottomUp(ExprNode topNode,
List<ExprAggregateNode> aggregateNodes)
Populates into the supplied list all aggregation functions within this expression, if any.
|
static ExprAggregateNodeParamDesc |
ExprAggregateNodeUtil.getValidatePositionalParams(ExprNode[] childNodes,
boolean builtinAggregationFunc) |
static boolean |
ExprAggregateNodeUtil.isNonPositionalParameter(ExprNode node) |
void |
ExprAggregateNodeBase.validateFilter(ExprNode filterEvaluator) |
Modifier and Type | Method and Description |
---|---|
static int |
ExprAggregateNodeUtil.countPositionalArgs(List<ExprNode> args) |
Constructor and Description |
---|
ExprAggregateLocalGroupByDesc(ExprNode[] partitionExpressions) |
ExprAggregateNodeParamDesc(ExprNode[] positionalParams,
ExprAggregateLocalGroupByDesc optLocalGroupBy,
ExprNode optionalFilter) |
ExprAggregateNodeParamDesc(ExprNode[] positionalParams,
ExprAggregateLocalGroupByDesc optLocalGroupBy,
ExprNode optionalFilter) |
Modifier and Type | Class and Description |
---|---|
class |
ExprAvedevNode
Represents the avedev(...) aggregate function is an expression tree.
|
class |
ExprAvgNode
Represents the avg(...) aggregate function is an expression tree.
|
class |
ExprCountEverNode
Represents the "countever" aggregate function is an expression tree.
|
class |
ExprCountNode
Represents the count(...) and count(*) and count(distinct ...) aggregate function is an expression tree.
|
class |
ExprFirstLastEverNode
Represents the "firstever" and "lastever: aggregate function is an expression tree.
|
class |
ExprLeavingAggNode
Represents the leaving() aggregate function is an expression tree.
|
class |
ExprMedianNode
Represents the median(...) aggregate function is an expression tree.
|
class |
ExprMinMaxAggrNode
Represents the min/max(distinct? ...) aggregate function is an expression tree.
|
class |
ExprNthAggNode
Represents the nth(...) and aggregate function is an expression tree.
|
class |
ExprPlugInAggNode
Represents a custom aggregation function in an expresson tree.
|
class |
ExprRateAggNode
Represents the rate(...) and aggregate function is an expression tree.
|
class |
ExprStddevNode
Represents the stddev(...) aggregate function is an expression tree.
|
class |
ExprSumNode
Represents the sum(...) aggregate function is an expression tree.
|
Modifier and Type | Method and Description |
---|---|
static ExprForge[] |
ExprMethodAggUtil.getDefaultForges(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream) |
static ExprEvaluator |
ExprMethodAggUtil.getMultiNodeEvaluator(ExprNode[] childNodes,
boolean join,
EventType[] typesPerStream) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprConstantNode
Represents a constant in an expressiun tree.
|
interface |
ExprIdentNode
Represents an stream property identifier in a filter expressiun tree.
|
interface |
ExprStreamRefNode
Represents a stream-reference.
|
interface |
ExprStreamUnderlyingNode
Represents an stream selector that returns the streams underlying event, or null if undefined.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprConstantNodeImpl
Represents a constant in an expressiun tree.
|
class |
ExprContextPropertyNodeImpl
Represents an stream property identifier in a filter expressiun tree.
|
class |
ExprCurrentEvaluationContextNode
Represents the "current_evaluation_context" function in an expression tree.
|
class |
ExprGroupingIdNode |
class |
ExprGroupingNode |
class |
ExprIdentNodeImpl
Represents an stream property identifier in a filter expressiun tree.
|
class |
ExprNamedParameterNodeImpl |
class |
ExprNodeBase
Superclass for filter nodes in a filter expression tree.
|
class |
ExprNodeValidated
A placeholder for another expression node that has been validated already.
|
class |
ExprNumberSetCronParam
Expression for a parameter within a crontab.
|
class |
ExprNumberSetFrequency
Expression for use within crontab to specify a frequency.
|
class |
ExprNumberSetList
Expression for use within crontab to specify a list of values.
|
class |
ExprNumberSetRange
Expression for use within crontab to specify a range.
|
class |
ExprOrderedExpr
A placeholder expression for view/pattern object parameters that allow
sorting expression values ascending or descending.
|
class |
ExprStreamUnderlyingNodeImpl
Represents an stream selector that returns the streams underlying event, or null if undefined.
|
class |
ExprSubstitutionNode
Represents a substitution value to be substituted in an expression tree, not valid for any purpose of use
as an expression, however can take a place in an expression tree.
|
class |
ExprTypedNoEvalNode
Represents an expression node that returns the predefined type and
that cannot be evaluated.
|
class |
ExprWildcardImpl
Expression for use within crontab to specify a wildcard.
|
Modifier and Type | Field and Description |
---|---|
static ExprNode[] |
ExprNodeUtilityQuery.EMPTY_EXPR_ARRAY |
Modifier and Type | Method and Description |
---|---|
static ExprNode[] |
ExprNodeUtilityMake.addExpression(ExprNode[] expressions,
ExprNode expression) |
static ExprNode |
ExprNodeUtilityMake.connectExpressionsByLogicalAnd(List<ExprNode> nodes,
ExprNode optionalAdditionalFilter) |
static ExprNode |
ExprNodeUtilityMake.connectExpressionsByLogicalAndWhenNeeded(Collection<ExprNode> nodes) |
ExprNode[] |
ExprNodeBase.getChildNodes() |
ExprNode[] |
ExprNode.getChildNodes()
Returns list of child nodes.
|
ExprNode[] |
ExprNamedParameterNode.getChildNodes() |
ExprNode |
ExprStreamUnderlyingNodeImpl.getForgeRenderable() |
ExprNode |
ExprNamedParameterNodeImpl.getForgeRenderable() |
ExprNode |
ExprNodeProxy.getOriginalObject() |
ExprNode |
ExprNodePropOrStreamExprDesc.getOriginator() |
static ExprNode |
ExprNodeUtilityValidate.getValidatedAssignment(OnTriggerSetAssignment assignment,
ExprValidationContext validationContext) |
static ExprNode |
ExprNodeUtilityValidate.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode exprNode,
ExprValidationContext validationContext)
Validates the expression node subtree that has this
node as root.
|
static ExprNode[] |
ExprNodeUtilityQuery.toArray(Collection<ExprNode> expressions) |
ExprNode |
ExprWildcardImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprValidator.validate(ExprValidationContext validationContext) |
ExprNode |
ExprTypedNoEvalNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprSubstitutionNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprStreamUnderlyingNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprOrderedExpr.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNumberSetRange.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNumberSetList.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNumberSetFrequency.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNumberSetCronParam.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNodeValidated.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNamedParameterNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprIdentNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprGroupingNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprGroupingIdNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprCurrentEvaluationContextNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprContextPropertyNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprConstantNodeImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static Pair<String,ExprNode> |
ExprNodeUtilityValidate.checkGetAssignmentToProp(ExprNode node) |
static Pair<String,ExprNode> |
ExprNodeUtilityValidate.checkGetAssignmentToVariableOrProp(ExprNode node) |
static List<ExprNode> |
ExprNodeUtilityQuery.collectChainParameters(List<ExprChainedSpec> chainSpec) |
static List<Pair<ExprNode,ExprNode>> |
ExprNodeUtilityQuery.findExpression(ExprNode selectExpression,
ExprNode searchExpression) |
static List<Pair<ExprNode,ExprNode>> |
ExprNodeUtilityQuery.findExpression(ExprNode selectExpression,
ExprNode searchExpression) |
List<ExprNode> |
ExprNodeInnerNodeProvider.getAdditionalNodes() |
List<ExprNode> |
ExprChainedSpec.getParameters() |
Modifier and Type | Method and Description |
---|---|
static void |
ExprNodeUtilityQuery.acceptChain(ExprNodeVisitorWithParent visitor,
List<ExprChainedSpec> chainSpec,
ExprNode parent) |
void |
ExprNodeBase.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
void |
ExprNode.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent)
Accept a visitor that receives both parent and child node.
|
static void |
ExprNodeUtilityQuery.acceptParams(ExprNodeVisitorWithParent visitor,
List<ExprNode> params,
ExprNode parent) |
void |
ExprNodeBase.addChildNode(ExprNode childNode) |
void |
ExprNode.addChildNode(ExprNode childNode)
Adds a child node.
|
void |
ExprNodeBase.addChildNodeToFront(ExprNode childNode) |
static ExprNode[] |
ExprNodeUtilityMake.addExpression(ExprNode[] expressions,
ExprNode expression) |
static ExprNode[] |
ExprNodeUtilityMake.addExpression(ExprNode[] expressions,
ExprNode expression) |
static void |
ExprNodeUtilityAggregation.addNonAggregatedProps(ExprNode exprNode,
ExprNodePropOrStreamSet set,
EventType[] types,
ContextPropertyRegistry contextPropertyRegistry) |
static Pair<String,ExprNode> |
ExprNodeUtilityValidate.checkGetAssignmentToProp(ExprNode node) |
static Pair<String,ExprNode> |
ExprNodeUtilityValidate.checkGetAssignmentToVariableOrProp(ExprNode node) |
static CodegenExpression |
MinMaxTypeEnum.ComputerBigDecCoerce.codegen(boolean max,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode[] nodes,
SimpleNumberBigDecimalCoercer[] convertors) |
static CodegenExpression |
MinMaxTypeEnum.ComputerBigIntCoerce.codegen(boolean max,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode[] nodes,
SimpleNumberBigIntegerCoercer[] convertors) |
static CodegenExpression |
MinMaxTypeEnum.MinComputerDoubleCoerce.codegen(CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode[] nodes,
Class returnType) |
static CodegenExpression |
MinMaxTypeEnum.MaxComputerDoubleCoerce.codegen(CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode[] nodes,
Class returnType) |
static CodegenExpression |
ExprNodeUtilityCodegen.codegenEvaluators(ExprNode[] expressions,
CodegenMethodScope parent,
Class originator,
CodegenClassScope classScope) |
static CodegenMethod |
ExprNodeUtilityCodegen.codegenMapSelect(ExprNode[] selectClause,
String[] selectAsNames,
Class generator,
CodegenMethodScope parent,
CodegenClassScope classScope) |
static ExprNode |
ExprNodeUtilityMake.connectExpressionsByLogicalAnd(List<ExprNode> nodes,
ExprNode optionalAdditionalFilter) |
static boolean |
ExprNodeUtilityCompare.deepEquals(ExprNode[] one,
ExprNode[] two,
boolean ignoreStreamPrefix)
Compares two expression nodes via deep comparison, considering all
child nodes of either side.
|
static boolean |
ExprNodeUtilityCompare.deepEquals(ExprNode[] one,
ExprNode[] two,
boolean ignoreStreamPrefix)
Compares two expression nodes via deep comparison, considering all
child nodes of either side.
|
static boolean |
ExprNodeUtilityCompare.deepEquals(ExprNode nodeOne,
ExprNode nodeTwo,
boolean ignoreStreamPrefix)
Compare two expression nodes and their children in exact child-node sequence,
returning true if the 2 expression nodes trees are equals, or false if they are not equals.
|
static boolean |
ExprNodeUtilityCompare.deepEqualsIgnoreDupAndOrder(ExprNode[] setOne,
ExprNode[] setTwo) |
static boolean |
ExprNodeUtilityCompare.deepEqualsIgnoreDupAndOrder(ExprNode[] setOne,
ExprNode[] setTwo) |
static boolean |
ExprNodeUtilityCompare.deepEqualsIsSubset(ExprNode[] subset,
ExprNode[] superset) |
static boolean |
ExprNodeUtilityCompare.deepEqualsIsSubset(ExprNode[] subset,
ExprNode[] superset) |
static boolean |
ExprNodeUtilityCompare.deepEqualsNullChecked(ExprNode nodeOne,
ExprNode nodeTwo,
boolean ignoreStreamPrefix) |
boolean |
ExprWildcardImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprTypedNoEvalNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprSubstitutionNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprStreamUnderlyingNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprOrderedExpr.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNumberSetRange.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNumberSetList.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNumberSetFrequency.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNumberSetCronParam.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNodeValidated.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix)
Return true if a expression node semantically equals the current node, or false if not.
|
boolean |
ExprNamedParameterNodeImpl.equalsNode(ExprNode other,
boolean ignoreStreamPrefix) |
boolean |
ExprIdentNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprGroupingNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprGroupingIdNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprCurrentEvaluationContextNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprContextPropertyNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprConstantNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
static List<Pair<ExprNode,ExprNode>> |
ExprNodeUtilityQuery.findExpression(ExprNode selectExpression,
ExprNode searchExpression) |
static ExprEvaluator[] |
ExprNodeUtilityQuery.getEvaluatorsNoCompile(ExprNode[] exprNodes) |
static List<Pair<Integer,String>> |
ExprNodeUtilityQuery.getExpressionProperties(ExprNode exprNode,
boolean visitAggregateNodes) |
static Class[] |
ExprNodeUtilityQuery.getExprResultTypes(ExprNode[] nodes) |
static ExprForge[] |
ExprNodeUtilityQuery.getForges(ExprNode[] exprNodes) |
static ExprNodePropOrStreamSet |
ExprNodeUtilityAggregation.getGroupByPropertiesValidateHasOne(ExprNode[] groupByNodes) |
static String[] |
ExprNodeUtilityQuery.getIdentResolvedPropertyNames(ExprNode[] nodes) |
static Set<Integer> |
ExprNodeUtilityQuery.getIdentStreamNumbers(ExprNode child) |
static String[] |
ExprNodeUtilityQuery.getPropertiesPerExpressionExpectSingle(ExprNode[] exprNodes) |
static Set<String> |
ExprNodeUtilityQuery.getPropertyNamesIfAllProps(ExprNode[] expressions) |
static void |
ExprNodeUtilityValidate.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode[][] exprNode,
ExprValidationContext validationContext) |
static void |
ExprNodeUtilityValidate.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode[] exprNode,
ExprValidationContext validationContext) |
static ExprNode |
ExprNodeUtilityValidate.getValidatedSubtree(ExprNodeOrigin origin,
ExprNode exprNode,
ExprValidationContext validationContext)
Validates the expression node subtree that has this
node as root.
|
static boolean |
ExprNodeUtilityAggregation.hasRemoveStreamForAggregations(ExprNode child,
StreamTypeService streamTypeService,
boolean unidirectionalJoin)
Returns true if all properties within the expression are witin data window'd streams.
|
static boolean |
ExprNodeUtilityQuery.isConstant(ExprNode exprNode) |
static boolean |
ExprNodeUtilityQuery.isExpressionsAllPropsOnly(ExprNode[] exprNodes) |
static String |
ExprNodeUtilityValidate.isMinimalExpression(ExprNode expression)
Check if the expression is minimal: does not have a subselect, aggregation and does not need view resources
|
static Object |
ExprNodeProxy.newInstance(ExprNode exprNode) |
static void |
ExprNodeUtilityModify.replaceChainChildNode(ExprNode nodeToReplace,
ExprNode newNode,
List<ExprChainedSpec> chainSpec) |
static void |
ExprNodeUtilityModify.replaceChildNode(ExprNode parentNode,
ExprNode nodeToReplace,
ExprNode newNode) |
void |
ExprNodeBase.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
void |
ExprNode.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
static void |
ExprNodeUtilityMake.setChildIdentNodesOptionalEvent(ExprNode exprNode) |
void |
ExprNodeBase.setChildNode(int index,
ExprNode newNode) |
void |
ExprNode.setChildNode(int index,
ExprNode newNode) |
void |
ExprNodeBase.setChildNodes(ExprNode... nodes) |
void |
ExprNode.setChildNodes(ExprNode... nodes) |
static void |
ExprNodeUtilityPrint.toExpressionString(ExprNode node,
StringWriter buffer) |
static String[] |
ExprNodeUtilityPrint.toExpressionStringMinPrecedenceAsArray(ExprNode[] nodes) |
static String |
ExprNodeUtilityPrint.toExpressionStringMinPrecedenceAsList(ExprNode[] nodes) |
static void |
ExprNodeUtilityPrint.toExpressionStringMinPrecedenceAsList(ExprNode[] nodes,
StringWriter writer) |
static String |
ExprNodeUtilityPrint.toExpressionStringMinPrecedenceSafe(ExprNode node) |
static void |
ExprNodeUtilityPrint.toExpressionStringParameterList(ExprNode[] childNodes,
StringWriter buffer) |
static void |
ExprNodeUtilityPrint.toExpressionStringParams(StringWriter writer,
ExprNode[] params) |
static String[] |
ExprNodeUtilityPrint.toExpressionStringsMinPrecedence(ExprNode[] expressions) |
static void |
ExprNodeUtilityPrint.toExpressionStringWFunctionName(String functionName,
ExprNode[] childNodes,
StringWriter writer) |
static void |
ExprNodeUtilityValidate.validateNoSpecialsGroupByExpressions(ExprNode[] groupByNodes) |
static void |
ExprNodeUtilityValidate.validatePlainExpression(ExprNodeOrigin origin,
ExprNode expression) |
static void |
ExprNodeUtilityValidate.validatePlainExpression(ExprNodeOrigin origin,
ExprNode[] expressions) |
Modifier and Type | Method and Description |
---|---|
static void |
ExprNodeUtilityQuery.acceptParams(ExprNodeVisitor visitor,
List<ExprNode> params) |
static void |
ExprNodeUtilityQuery.acceptParams(ExprNodeVisitorWithParent visitor,
List<ExprNode> params) |
static void |
ExprNodeUtilityQuery.acceptParams(ExprNodeVisitorWithParent visitor,
List<ExprNode> params,
ExprNode parent) |
void |
ExprNodeBase.addChildNodes(Collection<ExprNode> childNodeColl) |
void |
ExprNode.addChildNodes(Collection<ExprNode> childNodes)
Adds child nodes.
|
static ExprAndNode |
ExprNodeUtilityMake.connectExpressionsByLogicalAnd(Collection<ExprNode> nodes) |
static ExprNode |
ExprNodeUtilityMake.connectExpressionsByLogicalAnd(List<ExprNode> nodes,
ExprNode optionalAdditionalFilter) |
static ExprNode |
ExprNodeUtilityMake.connectExpressionsByLogicalAndWhenNeeded(Collection<ExprNode> nodes) |
static boolean |
ExprNodeUtilityCompare.deepEquals(List<ExprNode> one,
List<ExprNode> two) |
static boolean |
ExprNodeUtilityCompare.deepEquals(List<ExprNode> one,
List<ExprNode> two) |
static ExprEvaluator[] |
ExprNodeUtilityQuery.getEvaluatorsNoCompile(List<ExprNode> childNodes) |
static Class[] |
ExprNodeUtilityQuery.getExprResultTypes(List<ExprNode> expressions) |
static Map<String,ExprNamedParameterNode> |
ExprNodeUtilityValidate.getNamedExpressionsHandleDups(List<ExprNode> parameters) |
static ExprNodePropOrStreamSet |
ExprNodeUtilityAggregation.getNonAggregatedProps(EventType[] types,
List<ExprNode> exprNodes,
ContextPropertyRegistry contextPropertyRegistry) |
static boolean |
ExprNodeUtilityQuery.hasStreamSelect(List<ExprNode> exprNodes) |
static boolean |
ExprNodeUtilityQuery.isAllConstants(List<ExprNode> parameters) |
static ExprNodeUtilMethodDesc |
ExprNodeUtilityResolve.resolveMethodAllowWildcardAndStream(String className,
Class optionalClass,
String methodName,
List<ExprNode> parameters,
boolean allowWildcard,
EventType wildcardType,
ExprNodeUtilResolveExceptionHandler exceptionHandler,
String functionName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
void |
ExprChainedSpec.setParameters(List<ExprNode> parameters) |
static ExprNode[] |
ExprNodeUtilityQuery.toArray(Collection<ExprNode> expressions) |
static void |
ExprNodeUtilityPrint.toExpressionStringIncludeParen(List<ExprNode> parameters,
StringWriter buffer) |
static void |
ExprNodeUtilityPrint.toExpressionStringParameterList(List<ExprNode> parameters,
StringWriter buffer) |
Constructor and Description |
---|
ExprNodePropOrStreamExprDesc(int streamNum,
ExprNode originator) |
ExprNodeProxy(ExprNode exprNode) |
ExprNodeValidated(ExprNode inner)
Ctor.
|
Constructor and Description |
---|
ExprChainedSpec(String name,
List<ExprNode> parameters,
boolean property) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprDeclaredNode
Expression instance as declared elsewhere.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprDeclaredNodeImpl
Expression instance as declared elsewhere.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprDeclaredNodeImpl.getBody() |
ExprNode |
ExprDeclaredNode.getBody() |
ExprNode |
ExprDeclaredNodeImpl.getExpressionBodyCopy() |
ExprNode |
ExprDeclaredForgeBase.getForgeRenderable() |
ExprNode |
ExprDeclaredNodeImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
ExprDeclaredNodeImpl.getAdditionalNodes() |
List<ExprNode> |
ExprDeclaredNodeImpl.getChainParameters() |
List<ExprNode> |
ExprDeclaredNode.getChainParameters() |
Modifier and Type | Method and Description |
---|---|
void |
ExprDeclaredNodeImpl.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
boolean |
ExprDeclaredNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Method and Description |
---|---|
static Pair<ExprDeclaredNodeImpl,StatementSpecMapContext> |
ExprDeclaredHelper.getExistsDeclaredExpr(String name,
List<ExprNode> parameters,
Collection<ExpressionDeclItem> stmtLocalExpressions,
ContextCompileTimeDescriptor contextCompileTimeDescriptor,
StatementSpecMapEnv mapEnv) |
static ExprNodeScript |
ExprDeclaredHelper.getExistsScript(String defaultDialect,
String expressionName,
List<ExprNode> parameters,
Collection<ExpressionScriptProvided> scriptExpressions,
StatementSpecMapEnv mapEnv) |
Constructor and Description |
---|
ExprDeclaredNodeImpl(ExpressionDeclItem prototype,
List<ExprNode> chainParameters,
ContextCompileTimeDescriptor contextDescriptor,
ExprNode expressionBodyCopy) |
Constructor and Description |
---|
ExprDeclaredForgeRewriteWValue(ExprDeclaredNodeImpl parent,
ExprForge innerForge,
boolean isCache,
boolean audit,
String statementName,
ExprEnumerationForge[] eventEnumerationForges,
ObjectArrayEventType valueEventType,
List<ExprNode> valueExpressions) |
ExprDeclaredNodeImpl(ExpressionDeclItem prototype,
List<ExprNode> chainParameters,
ContextCompileTimeDescriptor contextDescriptor,
ExprNode expressionBodyCopy) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprDotNode
Represents an Dot-operator expression, for use when "(expression).method(...).method(...)"
|
Modifier and Type | Class and Description |
---|---|
class |
ExprAppDotMethodImpl |
class |
ExprDotNodeAggregationMethodRootNode |
class |
ExprDotNodeImpl
Represents an Dot-operator expression, for use when "(expression).method(...).method(...)"
|
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
ExprDotNodeAggregationMethodForge.parameters |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprDotNodeForgeStaticMethod.getForgeRenderable() |
ExprNode |
ExprDotNodeForgePropertyExpr.getForgeRenderable() |
ExprNode |
ExprDotNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprDotNodeAggregationMethodRootNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprAppDotMethodImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
ExprDotNodeImpl.getAdditionalNodes() |
Modifier and Type | Method and Description |
---|---|
void |
ExprDotNodeImpl.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
void |
ExprDotNodeAggregationMethodRootNode.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
boolean |
ExprDotNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprDotNodeAggregationMethodRootNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprAppDotMethodImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
static ExprDotEnumerationSourceForge |
ExprDotNodeUtility.getEnumerationSource(ExprNode inputExpression,
StreamTypeService streamTypeService,
boolean hasEnumerationMethod,
boolean disablePropertyExpressionEventCollCache,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
void |
ExprDotNodeImpl.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
Modifier and Type | Class and Description |
---|---|
class |
ExprEvalSystemProperty |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprEvalSystemProperty.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprEvalSystemProperty.equalsNode(ExprNode other,
boolean ignoreStreamPrefix) |
Constructor and Description |
---|
ExprEvalWithTypeWidener(TypeWidenerSPI widener,
ExprNode validated,
Class targetType) |
Modifier and Type | Class and Description |
---|---|
class |
ExprCaseNode
Represents the case-when-then-else control flow function is an expression tree.
|
class |
ExprCastNode
Represents the CAST(expression, type) function is an expression tree.
|
class |
ExprCoalesceNode
Represents the COALESCE(a,b,...) function is an expression tree.
|
class |
ExprEventIdentityEqualsNode |
class |
ExprInstanceofNode
Represents the INSTANCEOF(a,b,...) function is an expression tree.
|
class |
ExprIStreamNode
Represents the RSTREAM() function in an expression tree.
|
class |
ExprMinMaxRowNode
Represents the MAX(a,b) and MIN(a,b) functions is an expression tree.
|
class |
ExprPlugInSingleRowNode
Represents an invocation of a plug-in single-row function in the expression tree.
|
class |
ExprPropertyExistsNode
Represents the EXISTS(property) function in an expression tree.
|
class |
ExprTypeofNode
Represents the TYPEOF(a) function is an expression tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprTypeofNodeForgeStreamEvent.getForgeRenderable() |
ExprNode |
ExprTypeofNodeForgeFragmentType.getForgeRenderable() |
ExprNode |
ExprPropertyExistsNode.getForgeRenderable() |
ExprNode |
ExprIStreamNode.getForgeRenderable() |
ExprNode |
ExprCaseNodeForge.getOptionalCompareExprNode() |
ExprNode |
ExprCaseNode.CaseAnalysis.getOptionalCompareExprNode() |
ExprNode |
ExprCaseNodeForge.getOptionalElseExprNode() |
ExprNode |
ExprCaseNode.CaseAnalysis.getOptionalElseExprNode() |
ExprNode |
ExprTypeofNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprPropertyExistsNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprPlugInSingleRowNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprMinMaxRowNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprIStreamNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprInstanceofNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprEventIdentityEqualsNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprCoalesceNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprCastNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprCaseNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
ExprPlugInSingleRowNode.getAdditionalNodes() |
List<UniformPair<ExprNode>> |
ExprCaseNodeForge.getWhenThenNodeList() |
List<UniformPair<ExprNode>> |
ExprCaseNode.CaseAnalysis.getWhenThenNodeList() |
Modifier and Type | Method and Description |
---|---|
void |
ExprPlugInSingleRowNode.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
protected static CodegenExpression |
ExprCaseNodeForgeEvalSyntax1.codegenToType(ExprCaseNodeForge forge,
ExprNode node,
CodegenMethod methodNode,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope) |
boolean |
ExprTypeofNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprPropertyExistsNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprPlugInSingleRowNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprMinMaxRowNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprIStreamNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprInstanceofNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprEventIdentityEqualsNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprCoalesceNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprCastNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprCaseNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
void |
ExprPlugInSingleRowNode.replaceUnlistedChildNode(ExprNode nodeToReplace,
ExprNode newNode) |
Constructor and Description |
---|
CaseAnalysis(List<UniformPair<ExprNode>> whenThenNodeList,
ExprNode optionalCompareExprNode,
ExprNode optionalElseExprNode) |
Constructor and Description |
---|
CaseAnalysis(List<UniformPair<ExprNode>> whenThenNodeList,
ExprNode optionalCompareExprNode,
ExprNode optionalElseExprNode) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprAndNode
Represents an And-condition.
|
interface |
ExprBetweenNode
Represents the between-clause function in an expression tree.
|
interface |
ExprEqualsNode
Represents an equals (=, !=, <>, is, is not) comparator in a filter expressiun tree.
|
interface |
ExprInNode
Represents the in-clause (set check) function in an expression tree.
|
interface |
ExprRelationalOpNode
Represents a lesser or greater then (</<=/>/>=) expression in a filter expression tree.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprAndNodeImpl
Represents an And-condition.
|
class |
ExprArrayNode
Represents an array in a filter expressiun tree.
|
class |
ExprBetweenNodeImpl
Represents the between-clause function in an expression tree.
|
class |
ExprBitWiseNode
Represents the bit-wise operators in an expression tree.
|
class |
ExprConcatNode
Represents a string concatenation.
|
class |
ExprEqualsAllAnyNode
Represents an equals-for-group (= ANY/ALL/SOME (expression list)) comparator in a expression tree.
|
class |
ExprEqualsNodeImpl
Represents an equals (=) comparator in a filter expressiun tree.
|
class |
ExprInNodeImpl
Represents the in-clause (set check) function in an expression tree.
|
class |
ExprLikeNode
Represents the like-clause in an expression tree.
|
class |
ExprMathNode
Represents a simple Math (+/-/divide/*) in a filter expression tree.
|
class |
ExprNewInstanceNode
Represents the "new Class(...)" operator in an expression tree.
|
class |
ExprNewStructNode
Represents the "new {...}" operator in an expression tree.
|
class |
ExprNotNode
Represents a NOT expression in an expression tree.
|
class |
ExprOrNode
Represents an OR expression in a filter expression tree.
|
class |
ExprRegexpNode
Represents the regexp-clause in an expression tree.
|
class |
ExprRelationalOpAllAnyNode
Represents a lesser or greater then (</<=/>/>=) expression in a filter expression tree.
|
class |
ExprRelationalOpNodeImpl
Represents a lesser or greater then (</<=/>/>=) expression in a filter expression tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprOrNode.getForgeRenderable() |
ExprNode |
ExprNotNode.getForgeRenderable() |
ExprNode |
ExprRelationalOpNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprRelationalOpAllAnyNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprRegexpNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprOrNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNotNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNewStructNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprNewInstanceNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprMathNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprLikeNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprInNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprEqualsNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprEqualsAllAnyNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprConcatNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprBitWiseNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprBetweenNodeImpl.validate(ExprValidationContext validationContext) |
ExprNode |
ExprArrayNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprAndNodeImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static CodegenExpression |
ExprBitWiseNodeForgeEval.codegen(ExprBitWiseNodeForge forge,
Class requiredType,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode lhs,
ExprNode rhs) |
static CodegenMethod |
ExprEqualsNodeForgeCoercionEval.codegen(ExprEqualsNodeForgeCoercion forge,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode lhs,
ExprNode rhs) |
static CodegenMethod |
ExprLikeNodeForgeConstEval.codegen(ExprLikeNodeForgeConst forge,
ExprNode lhs,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope) |
static CodegenMethod |
ExprLikeNodeFormNonconstEval.codegen(ExprLikeNodeForgeNonconst forge,
ExprNode lhs,
ExprNode pattern,
ExprNode optionalEscape,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope) |
static CodegenMethod |
ExprMathNodeForgeEval.codegen(ExprMathNodeForge forge,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope,
ExprNode lhs,
ExprNode rhs) |
static CodegenMethod |
ExprRegexpNodeForgeConstEval.codegen(ExprRegexpNodeForgeConst forge,
ExprNode lhs,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope) |
static CodegenMethod |
ExprRegexpNodeForgeNonconstEval.codegen(ExprRegexpNodeForgeNonconst forge,
ExprNode lhs,
ExprNode pattern,
CodegenMethodScope codegenMethodScope,
ExprForgeCodegenSymbol exprSymbol,
CodegenClassScope codegenClassScope) |
boolean |
ExprRelationalOpNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprRelationalOpAllAnyNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprRegexpNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprOrNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNotNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNewStructNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprNewInstanceNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprMathNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprLikeNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprInNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprEqualsNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprEqualsAllAnyNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprConcatNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprBitWiseNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprBetweenNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprArrayNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprAndNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Class and Description |
---|---|
class |
ExprPreviousMatchRecognizeNode
Represents the 'prev' previous event function in match-recognize "define" item.
|
class |
ExprPreviousNode
Represents the 'prev' previous event function in an expression node tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprPreviousNode.getForgeRenderable() |
ExprNode |
ExprPreviousMatchRecognizeNode.getForgeRenderable() |
ExprNode |
ExprPreviousNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprPreviousMatchRecognizeNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprPreviousNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprPreviousMatchRecognizeNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Class and Description |
---|---|
class |
ExprPriorNode
Represents the 'prior' prior event function in an expression node tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprPriorNode.getForgeRenderable() |
ExprNode |
ExprPriorNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprPriorNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Class and Description |
---|---|
class |
ExprSubselectAllSomeAnyNode
Represents a subselect in an expression tree.
|
class |
ExprSubselectExistsNode
Represents an exists-subselect in an expression tree.
|
class |
ExprSubselectInNode
Represents a subselect in an expression tree.
|
class |
ExprSubselectNode
Represents a subselect in an expression tree.
|
class |
ExprSubselectRowNode
Represents a subselect in an expression tree.
|
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
ExprSubselectNode.selectClause |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
ExprSubselectNode.getSelectClause()
Returns the select clause or null if none.
|
ExprNode |
ExprSubselectNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprSubselectNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
void |
ExprSubselectNode.setSelectClause(ExprNode[] selectClause)
Sets the validates select clause
|
Modifier and Type | Class and Description |
---|---|
class |
ExprTableAccessNode |
class |
ExprTableAccessNodeKeys |
class |
ExprTableAccessNodeSubprop |
class |
ExprTableAccessNodeTopLevel |
class |
ExprTableIdentNode |
class |
ExprTableResetRowAggNode |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprTableResetRowAggNode.getForgeRenderable() |
ExprNode |
ExprTableIdentNode.getForgeRenderable() |
ExprNode |
ExprTableResetRowAggNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprTableIdentNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprTableAccessNode.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprTableResetRowAggNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprTableIdentNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprTableAccessNode.equalsNode(ExprNode o,
boolean ignoreStreamPrefix) |
static void |
ExprTableNodeUtil.validateExpressions(String tableName,
Class[] providedTypes,
String providedName,
ExprNode[] providedExpr,
Class[] expectedTypes,
String expectedName) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExprTimePeriod
Expression representing a time period.
|
Modifier and Type | Class and Description |
---|---|
class |
ExprTimePeriodImpl
Expression representing a time period.
|
class |
ExprTimestampNode
Represents the CURRENT_TIMESTAMP() function or reserved keyword in an expression tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprTimestampNode.getForgeRenderable() |
ExprNode |
ExprTimestampNode.validate(ExprValidationContext validationContext) |
ExprNode |
ExprTimePeriodImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprTimestampNode.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
boolean |
ExprTimePeriodImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Class and Description |
---|---|
class |
ExprVariableNodeImpl
Represents a variable in an expression tree.
|
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprVariableNodeImpl.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExprVariableNodeImpl.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
ExprNodeViewResourceVisitor.getExprNodes()
Returns the list of expression nodes requiring view resources.
|
List<Pair<ExprNode,ExprIdentNode>> |
ExprNodeIdentifierCollectVisitorWContainer.getExprProperties()
Returns list of event property stream numbers and names that uniquely identify which
property is from whcih stream, and the name of each.
|
List<Pair<ExprNode,ExprGroupingIdNode>> |
ExprNodeGroupingVisitorWParent.getGroupingIdNodes() |
List<Pair<ExprNode,ExprGroupingNode>> |
ExprNodeGroupingVisitorWParent.getGroupingNodes() |
List<Pair<ExprNode,ExprIdentNode>> |
ExprNodeIdentVisitorWParent.getIdentNodes() |
List<Pair<ExprNode,ExprPreviousNode>> |
ExprNodePreviousVisitorWParent.getPrevious()
Returns the pair of previous nodes and their parent expression.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ExprNodeVisitorWithParent.isVisit(ExprNode exprNode)
Allows visitor to indicate whether to visit a given node.
|
boolean |
ExprNodeVisitor.isVisit(ExprNode exprNode)
Allows visitor to indicate whether to visit a given node.
|
boolean |
ExprNodeViewResourceVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeVariableVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeTableAccessVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeTableAccessFinderVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeSummaryVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeSubselectDeclaredNoTraverseVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeSubselectDeclaredDotVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeStreamUseCollectVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeStreamSelectVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeStreamRequiredVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodePreviousVisitorWParent.isVisit(ExprNode exprNode) |
boolean |
ExprNodeIdentVisitorWParent.isVisit(ExprNode exprNode) |
boolean |
ExprNodeIdentifierVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeIdentifierCollectVisitorWContainer.isVisit(ExprNode exprNode) |
boolean |
ExprNodeIdentifierCollectVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeIdentifierAndStreamRefVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeGroupingVisitorWParent.isVisit(ExprNode exprNode) |
boolean |
ExprNodeDeclaredVisitor.isVisit(ExprNode exprNode) |
boolean |
ExprNodeContextPropertiesVisitor.isVisit(ExprNode exprNode) |
void |
ExprNodeVisitor.visit(ExprNode exprNode)
Visit the given expression node.
|
void |
ExprNodeViewResourceVisitor.visit(ExprNode exprNode) |
void |
ExprNodeVariableVisitor.visit(ExprNode exprNode) |
void |
ExprNodeTableAccessVisitor.visit(ExprNode exprNode) |
void |
ExprNodeTableAccessFinderVisitor.visit(ExprNode exprNode) |
void |
ExprNodeSummaryVisitor.visit(ExprNode exprNode) |
void |
ExprNodeSubselectDeclaredDotVisitor.visit(ExprNode exprNode) |
void |
ExprNodeStreamUseCollectVisitor.visit(ExprNode exprNode) |
void |
ExprNodeStreamSelectVisitor.visit(ExprNode exprNode) |
void |
ExprNodeStreamRequiredVisitor.visit(ExprNode exprNode) |
void |
ExprNodeIdentifierVisitor.visit(ExprNode exprNode) |
void |
ExprNodeIdentifierCollectVisitor.visit(ExprNode exprNode) |
void |
ExprNodeIdentifierAndStreamRefVisitor.visit(ExprNode exprNode) |
void |
ExprNodeDeclaredVisitor.visit(ExprNode exprNode) |
void |
ExprNodeContextPropertiesVisitor.visit(ExprNode exprNode) |
void |
ExprNodeVisitorWithParent.visit(ExprNode exprNode,
ExprNode parentExprNode)
Visit the given expression node.
|
void |
ExprNodeSubselectDeclaredNoTraverseVisitor.visit(ExprNode exprNode,
ExprNode parentExprNode) |
void |
ExprNodePreviousVisitorWParent.visit(ExprNode exprNode,
ExprNode parentExprNode) |
void |
ExprNodeIdentVisitorWParent.visit(ExprNode exprNode,
ExprNode parentExprNode) |
void |
ExprNodeIdentifierCollectVisitorWContainer.visit(ExprNode exprNode,
ExprNode containerExprNode) |
void |
ExprNodeGroupingVisitorWParent.visit(ExprNode exprNode,
ExprNode parentExprNode) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
FAFQueryMethodIUDBaseForge.whereClause |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
FAFQueryMethodSelectDesc.getConsumerFilters() |
ExprNode |
FAFQueryMethodSelectDesc.getWhereClause() |
Constructor and Description |
---|
HistoricalIndexLookupStrategyInKeywordMultiForge(int lookupStream,
ExprNode evaluator) |
HistoricalIndexLookupStrategyInKeywordSingleForge(int lookupStream,
ExprNode[] evaluators) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
SettingsApplicationDotMethodBase.getLhs() |
ExprNode[] |
SettingsApplicationDotMethodBase.getRhs() |
ExprNode |
SettingsApplicationDotMethodBase.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
EventAdvancedIndexConfigStatementForge |
EventAdvancedIndexFactoryForgeQuadTreePointRegionFactory.toConfigStatement(ExprNode[] indexedExpr) |
EventAdvancedIndexConfigStatementForge |
EventAdvancedIndexFactoryForgeQuadTreeMXCIFFactory.toConfigStatement(ExprNode[] indexedExpr) |
protected ExprForge |
SettingsApplicationDotMethodRectangeIntersectsRectangle.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected ExprForge |
SettingsApplicationDotMethodRectangeIntersectsRectangle.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected ExprForge |
SettingsApplicationDotMethodPointInsideRectange.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected ExprForge |
SettingsApplicationDotMethodPointInsideRectange.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected abstract ExprForge |
SettingsApplicationDotMethodBase.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
protected abstract ExprForge |
SettingsApplicationDotMethodBase.validateAll(String lhsName,
ExprNode[] lhs,
String rhsName,
ExprNode[] rhs,
ExprValidationContext validationContext) |
AdvancedIndexConfigContextPartition |
AdvancedIndexFactoryProviderQuadTree.validateConfigureFilterIndex(String indexName,
String indexTypeName,
ExprNode[] parameters,
ExprValidationContext validationContext) |
EventAdvancedIndexProvisionCompileTime |
AdvancedIndexFactoryProviderPointRegionQuadTree.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
EventAdvancedIndexProvisionCompileTime |
AdvancedIndexFactoryProviderPointRegionQuadTree.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
EventAdvancedIndexProvisionCompileTime |
AdvancedIndexFactoryProviderMXCIFQuadTree.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
EventAdvancedIndexProvisionCompileTime |
AdvancedIndexFactoryProviderMXCIFQuadTree.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
protected static void |
AdvancedIndexFactoryProviderQuadTree.validateParameters(String indexTypeName,
ExprNode[] parameters) |
Modifier and Type | Method and Description |
---|---|
SubordTableLookupStrategyFactoryQuadTreeForge |
EventAdvancedIndexFactoryForgeQuadTreeForge.getSubordinateLookupStrategy(String operationName,
Map<Integer,ExprNode> positionalExpressions,
boolean isNWOnTrigger,
int numOuterstreams) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
EventAdvancedIndexProvisionRuntime.getIndexExpressionsOpt() |
ExprNode[] |
EventAdvancedIndexProvisionRuntime.getParameterExpressionsOpt() |
ExprNode[] |
EventAdvancedIndexProvisionCompileTime.getParameters() |
Modifier and Type | Method and Description |
---|---|
void |
EventAdvancedIndexProvisionRuntime.setIndexExpressionsOpt(ExprNode[] indexExpressionsOpt) |
void |
EventAdvancedIndexProvisionRuntime.setParameterExpressionsOpt(ExprNode[] parameterExpressionsOpt) |
static void |
AdvancedIndexValidationHelper.validateColumnReturnTypeNumber(String indexTypeName,
int colnum,
ExprNode expr,
String name) |
AdvancedIndexConfigContextPartition |
AdvancedIndexFactoryProvider.validateConfigureFilterIndex(String indexName,
String indexTypeName,
ExprNode[] parameters,
ExprValidationContext validationContext) |
EventAdvancedIndexProvisionCompileTime |
AdvancedIndexFactoryProvider.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
EventAdvancedIndexProvisionCompileTime |
AdvancedIndexFactoryProvider.validateEventIndex(String indexName,
String indexTypeName,
ExprNode[] columns,
ExprNode[] parameters) |
static void |
AdvancedIndexValidationHelper.validateParameterReturnType(Class expectedReturnType,
String indexTypeName,
int paramnum,
ExprNode expr,
String name) |
static void |
AdvancedIndexValidationHelper.validateParameterReturnTypeNumber(String indexTypeName,
int paramnum,
ExprNode expr,
String name) |
Constructor and Description |
---|
EventAdvancedIndexProvisionCompileTime(AdvancedIndexDescWExpr indexDesc,
ExprNode[] parameters,
EventAdvancedIndexFactoryForge factory,
EventAdvancedIndexConfigStatementForge configStatement) |
FilterExprAnalyzerAffectorIndexProvision(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> keyExpressions,
int streamNumIndex) |
Constructor and Description |
---|
FilterExprAnalyzerAffectorIndexProvision(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> keyExpressions,
int streamNumIndex) |
Modifier and Type | Method and Description |
---|---|
static void |
FilterExprAnalyzer.analyze(ExprNode topNode,
QueryGraphForge queryGraph,
boolean isOuterJoin)
Analyzes filter expression to build query graph model.
|
static void |
RangeFilterAnalyzer.apply(ExprNode target,
ExprNode start,
ExprNode end,
boolean includeStart,
boolean includeEnd,
boolean isNot,
QueryGraphForge queryGraph) |
static EligibilityDesc |
EligibilityUtil.verifyInputStream(ExprNode expression,
int indexedStream) |
Constructor and Description |
---|
JoinSetComposerPrototypeForge(EventType[] streamTypes,
ExprNode postJoinEvaluator,
boolean outerJoins) |
JoinSetComposerPrototypeGeneralForge(EventType[] streamTypes,
ExprNode postJoinEvaluator,
boolean outerJoins,
QueryPlanForge queryPlan,
StreamJoinAnalysisResultCompileTime streamJoinAnalysisResult,
String[] streamNames,
boolean joinRemoveStream,
boolean hasHistorical) |
JoinSetComposerPrototypeHistorical2StreamForge(EventType[] streamTypes,
ExprNode postJoinEvaluator,
boolean outerJoins,
int polledNum,
int streamNum,
ExprNode outerJoinEqualsEval,
HistoricalIndexLookupStrategyForge historicalIndexLookupStrategy,
PollResultIndexingStrategyForge pollResultIndexingStrategy,
boolean isAllHistoricalNoSubordinate,
boolean[] outerJoinPerStream) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExcludePlanHint.filter(int streamLookup,
int streamIndexed,
ExcludePlanFilterOperatorType opType,
ExprNode... exprNodes) |
static EventBean |
ExcludePlanHintExprUtil.toEvent(int fromStreamnum,
int toStreamnum,
String fromStreamname,
String toStreamname,
String opname,
ExprNode[] expressions) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
InKeywordTableLookupPlanSingleIdxForge.getExpressions() |
ExprNode |
InKeywordTableLookupPlanMultiIdxForge.getKeyExpr() |
Constructor and Description |
---|
InKeywordTableLookupPlanMultiIdxForge(int lookupStream,
int indexedStream,
boolean indexedStreamIsVDW,
EventType[] typesPerStream,
TableLookupIndexReqKey[] indexNum,
ExprNode keyExpr) |
InKeywordTableLookupPlanSingleIdxForge(int lookupStream,
int indexedStream,
boolean indexedStreamIsVDW,
EventType[] typesPerStream,
TableLookupIndexReqKey indexNum,
ExprNode[] expressions) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
QueryGraphValueEntryRangeInForge.getExprEnd() |
ExprNode |
QueryGraphValueEntryRangeRelOpForge.getExpression() |
ExprNode[] |
QueryGraphValueEntryRangeRelOpForge.getExpressions() |
ExprNode[] |
QueryGraphValueEntryRangeInForge.getExpressions() |
abstract ExprNode[] |
QueryGraphValueEntryRangeForge.getExpressions() |
ExprNode[] |
QueryGraphValueEntryCustomKeyForge.getExprNodes() |
ExprNode |
QueryGraphValueEntryRangeInForge.getExprStart() |
ExprNode[] |
QueryGraphValuePairInKWMultiIdx.getIndexed() |
ExprNode[] |
QueryGraphValueDescForge.getIndexExprs() |
ExprNode |
QueryGraphValueEntryInKeywordMultiIdxForge.getKeyExpr() |
ExprNode |
QueryGraphValueEntryHashKeyedForge.getKeyExpr() |
ExprNode[] |
QueryGraphValueEntryInKeywordSingleIdxForge.getKeyExprs() |
Modifier and Type | Method and Description |
---|---|
Map<Integer,ExprNode> |
QueryGraphValueEntryCustomOperationForge.getPositionalExpressions() |
Modifier and Type | Method and Description |
---|---|
void |
QueryGraphValueForge.addCustom(ExprNode[] indexExpressions,
String operationName,
int expressionPosition,
ExprNode expression) |
void |
QueryGraphValueForge.addCustom(ExprNode[] indexExpressions,
String operationName,
int expressionPosition,
ExprNode expression) |
void |
QueryGraphForge.addCustomIndex(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> streamKeys,
int streamValue) |
void |
QueryGraphValueForge.addInKeywordMultiIdx(ExprNode testPropExpr,
ExprNode[] setProps) |
void |
QueryGraphValueForge.addInKeywordMultiIdx(ExprNode testPropExpr,
ExprNode[] setProps) |
void |
QueryGraphValueForge.addInKeywordSingleIdx(ExprNode testPropIdent,
ExprNode[] setPropExpr) |
void |
QueryGraphValueForge.addInKeywordSingleIdx(ExprNode testPropIdent,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetMultiIndex(int testStreamNum,
ExprNode testPropExpr,
int setStreamNum,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetMultiIndex(int testStreamNum,
ExprNode testPropExpr,
int setStreamNum,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetMultiIndexUnkeyed(ExprNode testPropExpr,
int setStreamNum,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetMultiIndexUnkeyed(ExprNode testPropExpr,
int setStreamNum,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetSingleIndex(int testStreamNum,
ExprNode testPropExpr,
int setStreamNum,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetSingleIndex(int testStreamNum,
ExprNode testPropExpr,
int setStreamNum,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetSingleIndexUnkeyed(int testStreamNum,
ExprNode testPropExpr,
ExprNode[] setPropExpr) |
void |
QueryGraphForge.addInSetSingleIndexUnkeyed(int testStreamNum,
ExprNode testPropExpr,
ExprNode[] setPropExpr) |
void |
QueryGraphValueForge.addKeyedExpr(ExprIdentNode indexedPropIdent,
ExprNode exprNodeNoIdent) |
void |
QueryGraphForge.addKeyedExpression(int indexedStream,
ExprIdentNode indexedProp,
int keyExprStream,
ExprNode exprNodeNoIdent) |
void |
QueryGraphValueForge.addRange(QueryGraphRangeEnum rangeType,
ExprNode propertyStart,
ExprNode propertyEnd,
ExprIdentNode propertyValueIdent) |
void |
QueryGraphForge.addRangeExpr(int indexedStream,
ExprIdentNode indexedProp,
ExprNode startNode,
Integer optionalStartStreamNum,
ExprNode endNode,
Integer optionalEndStreamNum,
QueryGraphRangeEnum rangeOp) |
void |
QueryGraphForge.addRelationalOp(int indexedStream,
ExprIdentNode indexedProp,
Integer keyStreamNum,
ExprNode exprNodeNoIdent,
RelationalOpEnum relationalOpEnum) |
void |
QueryGraphValueForge.addRelOp(ExprNode propertyKey,
QueryGraphRangeEnum op,
ExprIdentNode propertyValueIdent,
boolean isBetweenOrIn) |
void |
QueryGraphValueForge.addUnkeyedExpr(ExprIdentNode indexedPropIdent,
ExprNode exprNodeNoIdent) |
void |
QueryGraphForge.addUnkeyedExpression(int indexedStream,
ExprIdentNode indexedProp,
ExprNode exprNodeNoIdent) |
Modifier and Type | Method and Description |
---|---|
void |
QueryGraphForge.addCustomIndex(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> streamKeys,
int streamValue) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
TableLookupKeyDesc.getHashExpressions() |
Modifier and Type | Method and Description |
---|---|
static Class |
CoercionUtil.getCoercionTypeRangeIn(Class valuePropType,
ExprNode exprStart,
ExprNode exprEnd) |
Modifier and Type | Method and Description |
---|---|
static SubordPropPlan |
QueryPlanIndexBuilder.getJoinProps(ExprNode filterExpr,
int outsideStreamCount,
EventType[] allStreamTypesZeroIndexed,
ExcludePlanHint excludePlanHint) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
SubordInKeywordMultiTableLookupStrategyFactoryForge.exprNode |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
AdvancedIndexDescWExpr.getIndexedExpressions() |
Modifier and Type | Method and Description |
---|---|
EventAdvancedIndexConfigStatementForge |
EventAdvancedIndexFactory.toConfigStatement(ExprNode[] indexedExpr) |
Modifier and Type | Method and Description |
---|---|
SubordTableLookupStrategyFactoryQuadTreeForge |
EventAdvancedIndexFactoryForge.getSubordinateLookupStrategy(String operationName,
Map<Integer,ExprNode> expressions,
boolean isNWOnTrigger,
int numOuterstreams) |
Constructor and Description |
---|
AdvancedIndexDescWExpr(String indexTypeName,
ExprNode[] indexedExpressions) |
SubordInKeywordMultiTableLookupStrategyFactoryForge(boolean isNWOnTrigger,
int streamCountOuter,
ExprNode exprNode) |
SubordInKeywordSingleTableLookupStrategyFactoryForge(boolean isNWOnTrigger,
int streamCountOuter,
ExprNode[] exprNodes) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
SubordPropInKeywordMultiIndex.getExpression() |
ExprNode[] |
SubordPropInKeywordSingleIndex.getExpressions() |
Modifier and Type | Method and Description |
---|---|
static SubordTableLookupStrategyFactoryForge |
SubordinateTableLookupStrategyUtil.getLookupStrategy(EventType[] outerStreamTypesZeroIndexed,
List<SubordPropHashKeyForge> hashKeys,
CoercionDesc hashKeyCoercionTypes,
MultiKeyClassRef hashMultikeyClasses,
List<SubordPropRangeKeyForge> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
ExprNode[] inKeywordSingleIdxKeys,
ExprNode inKeywordMultiIdxKey,
boolean isNWOnTrigger) |
static SubordTableLookupStrategyFactoryForge |
SubordinateTableLookupStrategyUtil.getLookupStrategy(EventType[] outerStreamTypesZeroIndexed,
List<SubordPropHashKeyForge> hashKeys,
CoercionDesc hashKeyCoercionTypes,
MultiKeyClassRef hashMultikeyClasses,
List<SubordPropRangeKeyForge> rangeKeys,
CoercionDesc rangeKeyCoercionTypes,
ExprNode[] inKeywordSingleIdxKeys,
ExprNode inKeywordMultiIdxKey,
boolean isNWOnTrigger) |
Constructor and Description |
---|
SubordPropInKeywordMultiIndex(String[] indexedProp,
Class coercionType,
ExprNode expression) |
SubordPropInKeywordSingleIndex(String indexedProp,
Class coercionType,
ExprNode[] expressions) |
Modifier and Type | Method and Description |
---|---|
static SubordinateWMatchExprQueryPlanResult |
SubordinateQueryPlanner.planOnExpression(ExprNode joinExpr,
EventType filterEventType,
IndexHint optionalIndexHint,
boolean isIndexShare,
int subqueryNumber,
ExcludePlanHint excludePlanHint,
boolean isVirtualDataWindow,
EventTableIndexMetadata indexMetadata,
EventType eventTypeIndexed,
Set<String> optionalUniqueKeyProps,
boolean onlyUseExistingIndexes,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
Constructor and Description |
---|
SubordWMatchExprLookupStrategyAllFilteredForge(ExprNode exprEvaluator) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
DotMethodFPProvidedParam.getExpression() |
Modifier and Type | Method and Description |
---|---|
static DotMethodFPProvided |
DotMethodUtil.getProvidedFootprint(List<ExprNode> parameters) |
Constructor and Description |
---|
DotMethodFPProvidedParam(int lambdaParamNum,
Class returnType,
ExprNode expression) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
InfraOnMergeActionForge.optionalFilter |
Constructor and Description |
---|
InfraOnMergeActionDelForge(ExprNode optionalFilter) |
InfraOnMergeActionForge(ExprNode optionalFilter) |
InfraOnMergeActionInsForge(ExprNode optionalFilter,
SelectExprProcessorForge insertHelper,
TableMetaData insertIntoTable,
boolean audit,
boolean route) |
InfraOnMergeActionUpdForge(ExprNode optionalFilter,
EventBeanUpdateHelperForge updateHelper,
TableMetaData table) |
InfraOnMergeMatchForge(ExprNode optionalCond,
List<InfraOnMergeActionForge> actions) |
Constructor and Description |
---|
OutputConditionExpressionForge(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> assignments,
ExprNode andWhenTerminatedExpr,
List<OnTriggerSetAssignment> afterTerminateAssignments,
boolean isStartConditionOnCreation,
StatementCompileTimeServices services) |
Constructor and Description |
---|
OutputConditionCrontabForge(List<ExprNode> scheduleSpecExpressionList,
boolean isStartConditionOnCreation,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Constructor and Description |
---|
OutputConditionPolledExpressionFactoryForge(ExprNode whenExpressionNode,
List<OnTriggerSetAssignment> assignments,
StatementCompileTimeServices services)
Ctor.
|
Constructor and Description |
---|
OutputConditionPolledCrontabFactoryForge(List<ExprNode> list,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
static CodegenExpression |
PatternDeltaComputeUtil.makePatternDeltaAnonymous(ExprNode parameter,
MatchedEventConvertorForge convertor,
TimeAbacus timeAbacus,
CodegenMethod method,
CodegenClassScope classScope) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
EvalEveryDistinctForgeNode.getDistinctExpressions()
Returns distinct expressions.
|
List<ExprNode> |
EvalEveryDistinctForgeNode.getExpressions()
Returns all expressions.
|
Modifier and Type | Method and Description |
---|---|
void |
EvalEveryDistinctForgeNode.setDistinctExpressions(List<ExprNode> distinctExpressions,
MultiKeyClassRef distincMultiKey,
TimePeriodComputeForge timePeriodComputeForge,
ExprNode expiryTimeExp) |
Modifier and Type | Method and Description |
---|---|
void |
EvalEveryDistinctForgeNode.setDistinctExpressions(List<ExprNode> distinctExpressions,
MultiKeyClassRef distincMultiKey,
TimePeriodComputeForge timePeriodComputeForge,
ExprNode expiryTimeExp) |
Constructor and Description |
---|
EvalEveryDistinctForgeNode(boolean attachPatternText,
List<ExprNode> expressions)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
EvalFollowedByForgeNode.getOptionalMaxExpressions() |
Modifier and Type | Method and Description |
---|---|
void |
EvalFollowedByForgeNode.setOptionalMaxExpressions(List<ExprNode> optionalMaxExpressions) |
Constructor and Description |
---|
EvalFollowedByForgeNode(boolean attachPatternText,
List<ExprNode> optionalMaxExpressions) |
Modifier and Type | Method and Description |
---|---|
void |
TimerWithinOrMaxCountGuardForge.setGuardParameters(List<ExprNode> parameters,
MatchedEventConvertorForge convertor,
StatementCompileTimeServices services) |
void |
TimerWithinGuardForge.setGuardParameters(List<ExprNode> parameters,
MatchedEventConvertorForge convertor,
StatementCompileTimeServices services) |
void |
GuardForge.setGuardParameters(List<ExprNode> guardParameters,
MatchedEventConvertorForge convertor,
StatementCompileTimeServices services)
Sets the guard object parameters.
|
void |
ExpressionGuardForge.setGuardParameters(List<ExprNode> parameters,
MatchedEventConvertorForge convertor,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
EvalMatchUntilForgeNode.getLowerBounds() |
ExprNode |
EvalMatchUntilForgeNode.getSingleBound() |
ExprNode |
EvalMatchUntilForgeNode.getUpperBounds() |
Modifier and Type | Method and Description |
---|---|
void |
EvalMatchUntilForgeNode.setLowerBounds(ExprNode lowerBounds) |
void |
EvalMatchUntilForgeNode.setSingleBound(ExprNode singleBound) |
void |
EvalMatchUntilForgeNode.setUpperBounds(ExprNode upperBounds) |
Constructor and Description |
---|
EvalMatchUntilForgeNode(boolean attachPatternText,
ExprNode lowerBounds,
ExprNode upperBounds,
ExprNode singleBound) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
TimerIntervalObserverForge.parameter |
Modifier and Type | Method and Description |
---|---|
void |
TimerScheduleObserverForge.setObserverParameters(List<ExprNode> parameters,
MatchedEventConvertorForge convertor,
ExprValidationContext validationContext) |
void |
TimerIntervalObserverForge.setObserverParameters(List<ExprNode> parameters,
MatchedEventConvertorForge convertor,
ExprValidationContext validationContext) |
void |
TimerAtObserverForge.setObserverParameters(List<ExprNode> parameters,
MatchedEventConvertorForge convertor,
ExprValidationContext validationContext) |
void |
ObserverForge.setObserverParameters(List<ExprNode> observerParameters,
MatchedEventConvertorForge convertor,
ExprValidationContext validationContext)
Sets the observer object parameters.
|
static void |
ObserverParameterUtil.validateNoNamedParameters(String name,
List<ExprNode> parameter) |
Constructor and Description |
---|
TimerScheduleSpecComputeFromExprForge(ExprNode dateNode,
ExprNode repetitionsNode,
ExprTimePeriod periodNode) |
TimerScheduleSpecComputeISOStringForge(ExprNode parameter) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
ResultSetProcessorAggregateGroupedForge.getGroupKeyNodeExpressions() |
Constructor and Description |
---|
ResultSetProcessorAggregateGroupedForge(EventType resultEventType,
ExprNode[] groupKeyNodeExpressions,
ExprForge optionalHavingNode,
boolean isSelectRStream,
boolean isUnidirectional,
OutputLimitSpec outputLimitSpec,
boolean isSorting,
boolean isHistoricalOnly,
ResultSetProcessorOutputConditionType outputConditionType,
OutputConditionPolledFactoryForge optionalOutputFirstConditionFactory,
EventType[] eventTypes,
MultiKeyClassRef multiKeyClassRef) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
GroupByRollupInfo.getExprNodes() |
ExprNode |
ResultSetSpec.getHavingClause() |
ExprNode |
ResultSetSpec.getWhereClause() |
static ExprNode |
ColumnNamedNodeSwapper.swap(ExprNode exprTree,
String columnName,
ExprNode fullExpr)
Replace all instances of the node representing the colum name with
the full expression.
|
Modifier and Type | Method and Description |
---|---|
static ExprNode |
ColumnNamedNodeSwapper.swap(ExprNode exprTree,
String columnName,
ExprNode fullExpr)
Replace all instances of the node representing the colum name with
the full expression.
|
Constructor and Description |
---|
GroupByRollupInfo(ExprNode[] exprNodes,
AggregationGroupByRollupDescForge rollupDesc,
List<StmtClassForgeableFactory> additionalForgeables,
MultiKeyClassRef optionalMultiKey) |
ResultSetSpec(SelectClauseStreamSelectorEnum selectClauseStreamSelector,
List<OrderByItem> orderByList,
SelectClauseSpecCompiled selectClauseSpec,
InsertIntoDesc insertIntoDesc,
GroupByClauseExpressions groupByClauseExpressions,
ExprNode whereClause,
ExprNode havingClause,
OutputLimitSpec optionalOutputLimitSpec,
RowLimitSpec rowLimitSpec,
String contextName,
ForClauseSpec forClauseSpec,
IntoTableSpec intoTableSpec,
StreamSpecCompiled[] streamSpecs,
Annotation[] annotations) |
Modifier and Type | Method and Description |
---|---|
static CodegenMethod |
ResultSetProcessorGroupedUtil.generateGroupKeySingleCodegen(ExprNode[] groupKeyExpressions,
MultiKeyClassRef optionalMultiKeyClasses,
CodegenClassScope classScope,
CodegenInstanceAux instance) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
OrderByElementForge.getExprNode() |
Constructor and Description |
---|
OrderByElementForge(ExprNode exprNode,
boolean isDescending) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
ResultSetProcessorRowPerGroupForge.getGroupKeyNodeExpressions() |
Constructor and Description |
---|
ResultSetProcessorRowPerGroupForge(EventType resultEventType,
EventType[] typesPerStream,
ExprNode[] groupKeyNodeExpressions,
ExprForge optionalHavingNode,
boolean isSelectRStream,
boolean isUnidirectional,
OutputLimitSpec outputLimitSpec,
boolean isSorting,
boolean isHistoricalOnly,
ResultSetProcessorOutputConditionType outputConditionType,
EventType[] eventTypes,
OutputConditionPolledFactoryForge optionalOutputFirstConditionFactory,
MultiKeyClassRef multiKeyClassRef,
boolean unboundedProcessor) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
ResultSetProcessorRowPerGroupRollupForge.getGroupKeyNodeExpressions() |
Constructor and Description |
---|
ResultSetProcessorRowPerGroupRollupForge(EventType resultEventType,
GroupByRollupPerLevelForge perLevelForges,
ExprNode[] groupKeyNodeExpressions,
boolean isSelectRStream,
boolean isUnidirectional,
OutputLimitSpec outputLimitSpec,
boolean isSorting,
boolean noDataWindowSingleStream,
AggregationGroupByRollupDescForge groupByRollupDesc,
boolean isJoin,
boolean isHistoricalOnly,
boolean iterateUnbounded,
ResultSetProcessorOutputConditionType outputConditionType,
OutputConditionPolledFactoryForge optionalOutputFirstConditionFactory,
EventType[] eventTypes,
MultiKeyClassRef multiKeyClassRef) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
SelectSubscriberDescriptor.getGroupDelivery() |
Modifier and Type | Method and Description |
---|---|
SelectExprProcessorForge |
SelectExprProcessorRepresentationFactory.makeRecast(EventType[] eventTypes,
SelectExprForgeContext selectExprForgeContext,
int streamNumber,
AvroSchemaEventType insertIntoTargetType,
ExprNode[] exprNodes,
String statementName) |
Constructor and Description |
---|
SelectSubscriberDescriptor(Class[] selectClauseTypes,
String[] selectClauseColumnNames,
boolean forClauseDelivery,
ExprNode[] groupDelivery,
MultiKeyClassRef groupDeliveryMultiKey) |
Modifier and Type | Method and Description |
---|---|
static SelectExprProcessorForge |
SelectEvalStreamWUndRecastObjectArrayFactory.make(EventType[] eventTypes,
SelectExprForgeContext selectExprForgeContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
ClasspathImportServiceCompileTime classpathImportService,
String statementName) |
static SelectExprProcessorForge |
SelectEvalStreamWUndRecastMapFactory.make(EventType[] eventTypes,
SelectExprForgeContext selectExprForgeContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
ClasspathImportServiceCompileTime classpathImportService,
String statementName) |
static SelectExprProcessorForge |
SelectEvalStreamWUndRecastJsonFactory.make(EventType[] eventTypes,
SelectExprForgeContext selectExprForgeContext,
int streamNumber,
EventType targetType,
ExprNode[] exprNodes,
ClasspathImportServiceCompileTime classpathImportService,
String statementName) |
Modifier and Type | Method and Description |
---|---|
protected static RowRecogNFAStrandResult |
RowRecogHelper.buildStartStates(RowRecogExprNode parent,
Map<String,ExprNode> variableDefinitions,
Map<String,Pair<Integer,Boolean>> variableStreams,
boolean[] exprRequiresMultimatchState)
Build a list of start states from the parent node.
|
void |
RowRecogNFAViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Constructor and Description |
---|
RowRecogDescForge(EventType parentEventType,
EventType rowEventType,
EventType compositeEventType,
EventType multimatchEventType,
int[] multimatchStreamNumToVariable,
int[] multimatchVariableToStreamNum,
ExprNode[] partitionBy,
MultiKeyClassRef partitionByMultiKey,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
boolean hasInterval,
boolean iterateOnly,
boolean unbound,
boolean orTerminated,
boolean collectMultimatches,
boolean defineAsksMultimatches,
int numEventsEventsPerStreamDefine,
String[] multimatchVariablesArray,
RowRecogNFAStateForge[] startStates,
RowRecogNFAStateForge[] allStates,
boolean allMatches,
MatchRecognizeSkipEnum skip,
ExprNode[] columnEvaluators,
String[] columnNames,
TimePeriodComputeForge intervalCompute,
int[] previousRandomAccessIndexes,
AggregationServiceForgeDesc[] aggregationServices) |
RowRecogDescForge(EventType parentEventType,
EventType rowEventType,
EventType compositeEventType,
EventType multimatchEventType,
int[] multimatchStreamNumToVariable,
int[] multimatchVariableToStreamNum,
ExprNode[] partitionBy,
MultiKeyClassRef partitionByMultiKey,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
boolean hasInterval,
boolean iterateOnly,
boolean unbound,
boolean orTerminated,
boolean collectMultimatches,
boolean defineAsksMultimatches,
int numEventsEventsPerStreamDefine,
String[] multimatchVariablesArray,
RowRecogNFAStateForge[] startStates,
RowRecogNFAStateForge[] allStates,
boolean allMatches,
MatchRecognizeSkipEnum skip,
ExprNode[] columnEvaluators,
String[] columnNames,
TimePeriodComputeForge intervalCompute,
int[] previousRandomAccessIndexes,
AggregationServiceForgeDesc[] aggregationServices) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
RowRecogExprRepeatDesc.getLower() |
ExprNode |
RowRecogExprRepeatDesc.getSingle() |
ExprNode |
RowRecogExprRepeatDesc.getUpper() |
Constructor and Description |
---|
RowRecogExprRepeatDesc(ExprNode lower,
ExprNode upper,
ExprNode single) |
Constructor and Description |
---|
RowRecogNFAStateFilterForge(String nodeNum,
String variableName,
int streamNum,
boolean multiple,
boolean exprRequiresMultimatchState,
ExprNode expression)
Ctor.
|
RowRecogNFAStateOneOptionalForge(String nodeNum,
String variableName,
int streamNum,
boolean multiple,
boolean isGreedy,
boolean exprRequiresMultimatchState,
ExprNode expression)
Ctor.
|
RowRecogNFAStateOneToManyForge(String nodeNum,
String variableName,
int streamNum,
boolean multiple,
boolean isGreedy,
boolean exprRequiresMultimatchState,
ExprNode expression)
Ctor.
|
RowRecogNFAStateZeroToManyForge(String nodeNum,
String variableName,
int streamNum,
boolean multiple,
boolean isGreedy,
boolean exprRequiresMultimatchState,
ExprNode expression) |
Modifier and Type | Class and Description |
---|---|
class |
ExprNodeScript |
Modifier and Type | Method and Description |
---|---|
ExprNode |
ExprNodeScript.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
ExprNodeScript.getAdditionalNodes() |
List<ExprNode> |
ExprNodeScript.getParameters() |
Modifier and Type | Method and Description |
---|---|
void |
ExprNodeScript.acceptChildnodes(ExprNodeVisitorWithParent visitor,
ExprNode parent) |
boolean |
ExprNodeScript.equalsNode(ExprNode node,
boolean ignoreStreamPrefix) |
Constructor and Description |
---|
ExprNodeScript(String defaultDialect,
ExpressionScriptProvided script,
List<ExprNode> parameters) |
Constructor and Description |
---|
SubSelectStrategyFactoryIndexShareForge(int subqueryNumber,
SubSelectActivationPlan subselectActivation,
EventType[] outerEventTypesSelect,
NamedWindowMetaData namedWindow,
TableMetaData table,
boolean fullTableScan,
IndexHint indexHint,
SubordPropPlan joinedPropPlan,
ExprForge filterExprEval,
ExprNode[] groupKeys,
AggregationServiceForgeDesc aggregationServiceForgeDesc,
StatementBaseInfo statement,
StatementCompileTimeServices services) |
SubSelectStrategyFactoryLocalViewPreloadedForge(List<ViewFactoryForge> viewForges,
ViewResourceDelegateDesc viewResourceDelegateDesc,
Pair<EventTableFactoryFactoryForge,SubordTableLookupStrategyFactoryForge> lookupStrategy,
ExprNode filterExprNode,
boolean correlatedSubquery,
AggregationServiceForgeDesc aggregationServiceForgeDesc,
int subqueryNumber,
ExprNode[] groupKeys,
NamedWindowMetaData namedWindow,
ExprNode namedWindowFilterExpr,
QueryGraphForge namedWindowFilterQueryGraph,
MultiKeyClassRef groupByMultiKeyClasses) |
SubSelectStrategyFactoryLocalViewPreloadedForge(List<ViewFactoryForge> viewForges,
ViewResourceDelegateDesc viewResourceDelegateDesc,
Pair<EventTableFactoryFactoryForge,SubordTableLookupStrategyFactoryForge> lookupStrategy,
ExprNode filterExprNode,
boolean correlatedSubquery,
AggregationServiceForgeDesc aggregationServiceForgeDesc,
int subqueryNumber,
ExprNode[] groupKeys,
NamedWindowMetaData namedWindow,
ExprNode namedWindowFilterExpr,
QueryGraphForge namedWindowFilterQueryGraph,
MultiKeyClassRef groupByMultiKeyClasses) |
Modifier and Type | Method and Description |
---|---|
static Pair<ExprNode,List<ExprChainedSpec>> |
TableCompileTimeUtil.getTableNodeChainable(StreamTypeService streamTypeService,
List<ExprChainedSpec> chainSpec,
boolean allowTableAggReset,
TableCompileTimeResolver tableCompileTimeResolver) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
TableColumnMethodPairForge.getAggregationNode() |
Constructor and Description |
---|
TableColumnMethodPairForge(ExprForge[] forges,
int column,
ExprNode aggregationNode) |
Modifier and Type | Method and Description |
---|---|
static ExprNode |
EPLValidationUtil.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
EventType optionalEventType,
boolean allowBindingConsumption,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
static List<ExprNode> |
StatementSpecRawWalkerExpr.collectExpressionsShallow(StatementSpecRaw raw) |
Modifier and Type | Method and Description |
---|---|
static QueryGraphForge |
EPLValidationUtil.validateFilterGetQueryGraphSafe(ExprNode filterExpression,
StreamTypeServiceImpl typeService,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
static void |
EPLValidationUtil.validateFilterWQueryGraphSafe(QueryGraphForge queryGraph,
ExprNode filterExpression,
StreamTypeServiceImpl typeService,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
static void |
EPLValidationUtil.validateParametersTypePredefined(ExprNode[] expressions,
String invocableName,
String invocableCategory,
EPLExpressionParamType type) |
static void |
EPLValidationUtil.validateParameterType(String invocableName,
String invocableCategory,
boolean isFunction,
EPLExpressionParamType expectedTypeEnum,
Class[] expectedTypeClasses,
Class providedType,
int parameterNum,
ExprNode parameterExpression) |
static ExprNode |
EPLValidationUtil.validateSimpleGetSubtree(ExprNodeOrigin origin,
ExprNode expression,
EventType optionalEventType,
boolean allowBindingConsumption,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
void |
VirtualDWViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
static InstanceManufacturerFactory |
InstanceManufacturerFactoryFactory.getManufacturer(Class targetClass,
ClasspathImportServiceCompileTime classpathImportService,
ExprNode[] childNodes) |
Modifier and Type | Method and Description |
---|---|
ExprNode |
FilterSpecParamExprNodeForge.getExprNode()
Returns the expression node of the boolean expression this filter parameter represents.
|
ExprNode[] |
FilterSpecCompilerAdvIndexDesc.getIndexExpressions() |
ExprNode[] |
FilterSpecCompilerAdvIndexDesc.getKeyExpressions() |
Constructor and Description |
---|
FilterForEvalConstRuntimeExprForge(ExprNode runtimeConstant) |
FilterSpecCompilerAdvIndexDesc(ExprNode[] indexExpressions,
ExprNode[] keyExpressions,
AdvancedIndexConfigContextPartition indexSpec,
String indexType,
String indexName) |
FilterSpecCompilerAdvIndexDesc(ExprNode[] indexExpressions,
ExprNode[] keyExpressions,
AdvancedIndexConfigContextPartition indexSpec,
String indexType,
String indexName) |
FilterSpecParamExprNodeForge(ExprFilterSpecLookupableForge lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
boolean hasSubquery,
boolean hasTableAccess,
boolean hasVariable,
StatementCompileTimeServices compileTimeServices) |
Modifier and Type | Method and Description |
---|---|
static EPType |
EPTypeHelper.optionalFromEnumerationExpr(StatementRawInfo raw,
StatementCompileTimeServices services,
ExprNode exprNode) |
Modifier and Type | Method and Description |
---|---|
static ExprForge[] |
ScheduleExpressionUtil.crontabScheduleValidate(ExprNodeOrigin origin,
List<ExprNode> scheduleSpecExpressionList,
boolean allowBindingConsumption,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
SettingsApplicationDotMethod.getLhs() |
ExprNode[] |
SettingsApplicationDotMethod.getRhs() |
ExprNode |
ClasspathImportServiceCompileTimeImpl.resolveAggExtendedBuiltin(String name,
boolean isDistinct) |
ExprNode |
ClasspathImportServiceCompileTime.resolveAggExtendedBuiltin(String name,
boolean isDistinct) |
ExprNode |
ClasspathImportServiceCompileTimeImpl.resolveSingleRowExtendedBuiltin(String name) |
ExprNode |
ClasspathImportServiceCompileTime.resolveSingleRowExtendedBuiltin(String name) |
ExprNode |
SettingsApplicationDotMethod.validate(ExprValidationContext validationContext) |
Modifier and Type | Method and Description |
---|---|
static ExprNode |
EPStatementStartMethodHelperValidate.validateExprNoAgg(ExprNodeOrigin exprNodeOrigin,
ExprNode exprNode,
StreamTypeService streamTypeService,
String errorMsg,
boolean allowTableConsumption,
boolean allowTableAggReset,
StatementRawInfo raw,
StatementCompileTimeServices compileTimeServices) |
static ExprNode |
EPStatementStartMethodHelperValidate.validateNodes(StatementSpecRaw statementSpec,
StreamTypeService typeService,
ViewResourceDelegateExpr viewResourceDelegate,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
Modifier and Type | Method and Description |
---|---|
static ExprNode |
EPStatementStartMethodHelperValidate.validateExprNoAgg(ExprNodeOrigin exprNodeOrigin,
ExprNode exprNode,
StreamTypeService streamTypeService,
String errorMsg,
boolean allowTableConsumption,
boolean allowTableAggReset,
StatementRawInfo raw,
StatementCompileTimeServices compileTimeServices) |
static void |
EPStatementStartMethodHelperValidate.validateNoAggregations(ExprNode exprNode,
String errorMsg) |
static void |
EPStatementStartMethodHelperValidate.validateSubqueryExcludeOuterStream(ExprNode matchCondition) |
Modifier and Type | Method and Description |
---|---|
void |
ViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
CorrelationViewForge.expressionX |
protected ExprNode |
CorrelationViewForge.expressionY |
protected ExprNode |
UnivariateStatisticsViewForge.fieldExpression |
protected ExprNode |
WeightedAverageViewForge.fieldNameWeight |
protected ExprNode |
WeightedAverageViewForge.fieldNameX |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
StatViewAdditionalPropsForge.getAdditionalEvals() |
Modifier and Type | Method and Description |
---|---|
static StatViewAdditionalPropsForge |
StatViewAdditionalPropsForge.make(ExprNode[] validated,
int startIndex,
EventType parentEventType,
int streamNumber,
ViewForgeEnv viewForgeEnv) |
Modifier and Type | Method and Description |
---|---|
void |
WeightedAverageViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
UnivariateStatisticsViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
SizeViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
RegressionLinestViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
CorrelationViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Constructor and Description |
---|
StatViewAdditionalPropsForge(String[] additionalProps,
ExprNode[] additionalEvals,
Class[] additionalTypes,
DataInputOutputSerdeForge[] additionalSerdes) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
ExpressionViewForgeBase.expiryExpression |
Modifier and Type | Method and Description |
---|---|
void |
ExpressionWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
ExpressionBatchViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
ExternallyTimedBatchViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
ExternallyTimedWindowViewForge.timestampExpression |
Modifier and Type | Method and Description |
---|---|
void |
ExternallyTimedWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
FirstEventViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
FirstLengthWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
FirstTimeViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
FirstUniqueByPropertyViewForge.criteriaExpressions |
Modifier and Type | Field and Description |
---|---|
protected List<ExprNode> |
FirstUniqueByPropertyViewForge.viewParameters |
Modifier and Type | Method and Description |
---|---|
void |
FirstUniqueByPropertyViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
GroupByViewFactoryForge.criteriaExpressions |
Modifier and Type | Field and Description |
---|---|
protected List<ExprNode> |
GroupByViewFactoryForge.viewParameters |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
GroupByViewFactoryForge.getCriteriaExpressions() |
Modifier and Type | Method and Description |
---|---|
List<ExprNode> |
MergeViewFactoryForge.getViewParameters() |
List<ExprNode> |
GroupByViewFactoryForge.getViewParameters() |
Modifier and Type | Method and Description |
---|---|
void |
MergeViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
GroupByViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
IntersectViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
KeepAllViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
LastEventViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
LengthWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
LengthBatchViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
PriorEventViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
RankWindowViewForge.criteriaExpressions |
protected ExprNode[] |
RankWindowViewForge.sortCriteriaExpressions |
Modifier and Type | Method and Description |
---|---|
void |
RankWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
SortWindowViewForge.sortCriteriaExpressions |
Modifier and Type | Method and Description |
---|---|
void |
SortWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
TimeAccumViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
TimeBatchViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
TimeLengthBatchViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode |
TimeToLiveViewForge.timestampExpression |
Modifier and Type | Method and Description |
---|---|
void |
TimeToLiveViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
void |
TimeOrderViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
TimeWindowViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
void |
UnionViewFactoryForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Field and Description |
---|---|
protected ExprNode[] |
UniqueByPropertyViewForge.criteriaExpressions |
Modifier and Type | Field and Description |
---|---|
protected List<ExprNode> |
UniqueByPropertyViewForge.viewParameters |
Modifier and Type | Method and Description |
---|---|
ExprNode[] |
UniqueByPropertyViewForge.getCriteriaExpressions() |
Modifier and Type | Method and Description |
---|---|
void |
UniqueByPropertyViewForge.setViewParameters(List<ExprNode> parameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
static ExprNode[] |
ViewForgeSupport.validate(String viewName,
EventType eventType,
List<ExprNode> expressions,
boolean allowConstantResult,
ViewForgeEnv viewForgeEnv,
int streamNumber)
Validate the view parameter expressions and return the validated expression for later execution.
|
static ExprNode[] |
ViewForgeSupport.validate(String viewName,
List<ExprNode> expressions,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
static ExprNode |
ViewForgeSupport.validateExpr(String viewName,
ExprNode expression,
StreamTypeService streamTypeService,
ViewForgeEnv viewForgeEnv,
int expressionNumber,
int streamNumber) |
Modifier and Type | Method and Description |
---|---|
static void |
ViewForgeSupport.assertReturnsNonConstant(String viewName,
ExprNode expression,
int index)
Assert and throws an exception if the expression passed returns a non-constant value.
|
static void |
ViewMultiKeyHelper.assign(ExprNode[] criteriaExpressions,
MultiKeyClassRef multiKeyClassNames,
CodegenMethod method,
CodegenExpressionRef factory,
SAIFFInitializeSymbol symbols,
CodegenClassScope classScope) |
static Object |
ViewForgeSupport.evaluateAssertNoProperties(String viewName,
ExprNode expression,
int index) |
static Object |
ViewForgeSupport.validateAndEvaluate(String viewName,
ExprNode expression,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
static Object |
ViewForgeSupport.validateAndEvaluateExpr(String viewName,
ExprNode expression,
StreamTypeService streamTypeService,
ViewForgeEnv viewForgeEnv,
int expressionNumber,
int streamNumber) |
static TimePeriodComputeForge |
ViewFactoryTimePeriodHelper.validateAndEvaluateTimeDeltaFactory(String viewName,
ExprNode expression,
String expectedMessage,
int expressionNumber,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
static ExprNode |
ViewForgeSupport.validateExpr(String viewName,
ExprNode expression,
StreamTypeService streamTypeService,
ViewForgeEnv viewForgeEnv,
int expressionNumber,
int streamNumber) |
static void |
ViewForgeSupport.validateNoProperties(String viewName,
ExprNode expression,
int index) |
static ExprForge |
ViewForgeSupport.validateSizeParam(String viewName,
ExprNode sizeNode,
int expressionNumber) |
Modifier and Type | Method and Description |
---|---|
static ExprNode[] |
ViewForgeSupport.validate(String viewName,
EventType eventType,
List<ExprNode> expressions,
boolean allowConstantResult,
ViewForgeEnv viewForgeEnv,
int streamNumber)
Validate the view parameter expressions and return the validated expression for later execution.
|
static ExprNode[] |
ViewForgeSupport.validate(String viewName,
List<ExprNode> expressions,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
static void |
ViewForgeSupport.validateNoParameters(String viewName,
List<ExprNode> expressionParameters) |
static ExprForge |
ViewForgeSupport.validateSizeSingleParam(String viewName,
List<ExprNode> expressionParameters,
ViewForgeEnv viewForgeEnv,
int streamNumber) |
Copyright © 2005–2020. All rights reserved.