Constructor and Description |
---|
StmtClassForgeableAIFactoryProviderCreateContext(String className,
CodegenPackageScope packageScope,
String contextName,
ContextControllerFactoryForge[] forges,
EventType eventTypeContextProperties,
StatementAgentInstanceFactoryCreateContextForge forge,
StateMgmtSetting partitionIdSvcStateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
ContextDefinition.getPartitionIdSvcStateMgmtSettings() |
Modifier and Type | Method and Description |
---|---|
void |
ContextDefinition.setPartitionIdSvcStateMgmtSettings(StateMgmtSetting partitionIdSvcStateMgmtSettings) |
Constructor and Description |
---|
AggregationServiceGroupByForge(AggGroupByDesc aggGroupByDesc,
TimeAbacus timeAbacus,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
AggSvcLocalGroupByForge(boolean hasGroupBy,
AggregationLocalGroupByPlanForge localGroupByPlan,
AggregationUseFlags useFlags,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
AggSvcGroupByRollupForge(AggregationRowStateForgeDesc rowStateForgeDesc,
AggregationGroupByRollupDescForge rollupDesc,
ExprNode[] groupByNodes,
StateMgmtSetting stateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
EventTableFactory |
EventTableIndexServiceImpl.createHashedOnly(int indexedStreamNum,
EventType eventType,
String[] indexProps,
MultiKeyFromObjectArray transformFireAndForget,
DataInputOutputSerde<Object> keySerde,
boolean unique,
String optionalIndexName,
EventPropertyValueGetter getter,
DataInputOutputSerde<Object> optionalValueSerde,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexService.createHashedOnly(int indexedStreamNum,
EventType eventType,
String[] indexProps,
MultiKeyFromObjectArray transformFireAndForget,
DataInputOutputSerde<Object> keySerde,
boolean unique,
String optionalIndexName,
EventPropertyValueGetter getter,
DataInputOutputSerde<Object> optionalValueSerde,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexServiceImpl.createInArray(int streamNum,
EventType eventType,
String[] propertyNames,
EPTypeClass[] indexTypes,
DataInputOutputSerde<Object>[] indexSerdes,
boolean unique,
EventPropertyValueGetter[] getters,
boolean isFireAndForget,
EventTableFactoryFactoryContext eventTableFactoryContext,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexService.createInArray(int streamNum,
EventType eventType,
String[] propertyNames,
EPTypeClass[] indexTypes,
DataInputOutputSerde<Object>[] indexSerdes,
boolean unique,
EventPropertyValueGetter[] getters,
boolean isFireAndForget,
EventTableFactoryFactoryContext eventTableFactoryContext,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexServiceImpl.createSorted(int indexedStreamNum,
EventType eventType,
String indexedProp,
EPTypeClass indexType,
EventPropertyValueGetter getter,
DataInputOutputSerde<Object> serde,
DataInputOutputSerde<Object> optionalValueSerde,
boolean isFireAndForget,
EventTableFactoryFactoryContext eventTableFactoryContext,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexService.createSorted(int indexedStreamNum,
EventType eventType,
String indexedProp,
EPTypeClass indexType,
EventPropertyValueGetter getter,
DataInputOutputSerde<Object> serde,
DataInputOutputSerde<Object> optionalValueSerde,
boolean isFireAndForget,
EventTableFactoryFactoryContext eventTableFactoryContext,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexServiceImpl.createUnindexed(int indexedStreamNum,
EventType eventType,
DataInputOutputSerde<Object> optionalValueSerde,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
EventTableFactory |
EventTableIndexService.createUnindexed(int indexedStreamNum,
EventType eventType,
DataInputOutputSerde<Object> optionalValueSerde,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
PropertyHashedFactoryFactory(int indexedStreamNum,
Integer subqueryNum,
boolean isFireAndForget,
String[] indexProps,
boolean unique,
EventPropertyValueGetter valueGetter,
MultiKeyFromObjectArray transformFireAndForget,
DataInputOutputSerde<Object> keySerde,
StateMgmtSetting stateMgmtSettings) |
PropertyHashedFactoryFactoryForge(int indexedStreamNum,
Integer subqueryNum,
boolean isFireAndForget,
String[] indexedProps,
EventType eventType,
boolean unique,
CoercionDesc hashCoercionDesc,
MultiKeyClassRef multiKeyClassRef,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
PropertyHashedArrayFactoryFactory(int streamNum,
String[] propertyNames,
EPTypeClass[] propertyTypes,
DataInputOutputSerde<Object>[] propertySerdes,
boolean unique,
EventPropertyValueGetter[] propertyGetters,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
PropertyHashedArrayFactoryFactoryForge(int streamNum,
EventType eventType,
String[] propertyNames,
EPType[] propertyTypes,
DataInputOutputSerdeForge[] serdes,
boolean unique,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
PropertySortedFactoryFactory(int indexedStreamNum,
Integer subqueryNum,
boolean isFireAndForget,
String indexProp,
EPTypeClass indexType,
EventPropertyValueGetter valueGetter,
DataInputOutputSerde<Object> indexSerde,
StateMgmtSetting stateMgmtSettings) |
PropertySortedFactoryFactoryForge(int indexedStreamNum,
Integer subqueryNum,
boolean isFireAndForget,
String indexedProp,
EventType eventType,
CoercionDesc coercionDesc,
DataInputOutputSerdeForge serde,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
UnindexedEventTableFactoryFactory(int indexedStreamNum,
Integer subqueryNum,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
UnindexedEventTableFactoryFactoryForge(int indexedStreamNum,
Integer subqueryNum,
boolean isFireAndForget,
StateMgmtSetting stateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
QueryPlanIndexItem.getStateMgmtSettings() |
Constructor and Description |
---|
QueryPlanIndexItem(String[] hashProps,
EPTypeClass[] hashPropTypes,
EventPropertyValueGetter hashGetter,
MultiKeyFromObjectArray transformFireAndForget,
DataInputOutputSerde<Object> hashKeySerde,
String[] rangeProps,
EPTypeClass[] rangePropTypes,
EventPropertyValueGetter[] rangeGetters,
DataInputOutputSerde<Object>[] rangeKeySerdes,
boolean unique,
EventAdvancedIndexProvisionRuntime advancedIndexProvisionDesc,
StateMgmtSetting stateMgmtSettings) |
Constructor and Description |
---|
OutputProcessViewConditionDefaultPostProcess(ResultSetProcessor resultSetProcessor,
Long afterConditionTime,
Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
OutputStrategyPostProcess postProcessor,
EventType[] eventTypes,
StateMgmtSetting stateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
OutputProcessViewConditionSpec.getChangeSetStateMgmtSettings() |
Modifier and Type | Method and Description |
---|---|
void |
OutputProcessViewConditionSpec.setChangeSetStateMgmtSettings(StateMgmtSetting changeSetStateMgmtSettings) |
Constructor and Description |
---|
OutputProcessViewConditionDefault(ResultSetProcessor resultSetProcessor,
Long afterConditionTime,
Integer afterConditionNumberOfEvents,
boolean afterConditionSatisfied,
OutputProcessViewConditionFactory parent,
AgentInstanceContext agentInstanceContext,
EventType[] eventTypes,
StateMgmtSetting stateMgmtSettings) |
OutputProcessViewConditionForge(OutputStrategyPostProcessForge outputStrategyPostProcessForge,
boolean isDistinct,
MultiKeyClassRef distinctMultiKey,
ExprTimePeriod afterTimePeriodExpr,
Integer afterNumberOfEvents,
OutputConditionFactoryForge outputConditionFactoryForge,
int streamCount,
ResultSetProcessorOutputConditionType conditionType,
boolean terminable,
boolean hasAfter,
boolean unaggregatedUngrouped,
SelectClauseStreamSelectorEnum selectClauseStreamSelector,
EventType[] eventTypes,
EventType resultEventType,
StateMgmtSetting changeSetStateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
EvalAndFactoryNode |
PatternFactoryServiceImpl.and(StateMgmtSetting stateMgmtSettings) |
EvalAndFactoryNode |
PatternFactoryService.and(StateMgmtSetting stateMgmtSettings) |
EvalEveryFactoryNode |
PatternFactoryServiceImpl.every(StateMgmtSetting stateMgmtSettings) |
EvalEveryFactoryNode |
PatternFactoryService.every(StateMgmtSetting stateMgmtSettings) |
EvalEveryDistinctFactoryNode |
PatternFactoryServiceImpl.everyDistinct(StateMgmtSetting stateMgmtSettings) |
EvalEveryDistinctFactoryNode |
PatternFactoryService.everyDistinct(StateMgmtSetting stateMgmtSettings) |
EvalFilterFactoryNode |
PatternFactoryServiceImpl.filter(StateMgmtSetting stateMgmtSettings) |
EvalFilterFactoryNode |
PatternFactoryService.filter(StateMgmtSetting stateMgmtSettings) |
EvalFollowedByFactoryNode |
PatternFactoryServiceImpl.followedby(StateMgmtSetting stateMgmtSettings) |
EvalFollowedByFactoryNode |
PatternFactoryService.followedby(StateMgmtSetting stateMgmtSettings) |
EvalGuardFactoryNode |
PatternFactoryServiceImpl.guard(StateMgmtSetting stateMgmtSettings) |
EvalGuardFactoryNode |
PatternFactoryService.guard(StateMgmtSetting stateMgmtSettings) |
EvalMatchUntilFactoryNode |
PatternFactoryServiceImpl.matchUntil(StateMgmtSetting stateMgmtSettings) |
EvalMatchUntilFactoryNode |
PatternFactoryService.matchUntil(StateMgmtSetting stateMgmtSettings) |
EvalNotFactoryNode |
PatternFactoryServiceImpl.not(StateMgmtSetting stateMgmtSettings) |
EvalNotFactoryNode |
PatternFactoryService.not(StateMgmtSetting stateMgmtSettings) |
EvalObserverFactoryNode |
PatternFactoryServiceImpl.observer(StateMgmtSetting stateMgmtSettings) |
EvalObserverFactoryNode |
PatternFactoryService.observer(StateMgmtSetting stateMgmtSettings) |
EvalOrFactoryNode |
PatternFactoryServiceImpl.or(StateMgmtSetting stateMgmtSettings) |
EvalOrFactoryNode |
PatternFactoryService.or(StateMgmtSetting stateMgmtSettings) |
EvalRootFactoryNode |
PatternFactoryServiceImpl.root(StateMgmtSetting stateMgmtSettings) |
EvalRootFactoryNode |
PatternFactoryService.root(StateMgmtSetting stateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
Supplier<StateMgmtSetting> |
ResultSetProcessorAggregateGroupedForge.getOutputAllHelperSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorAggregateGroupedForge.getOutputAllOptSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorAggregateGroupedForge.getOutputFirstHelperSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorAggregateGroupedForge.getOutputLastOptSettings() |
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,
Supplier<StateMgmtSetting> outputFirstHelperSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptSettings,
Supplier<StateMgmtSetting> outputLastOptSettings) |
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,
Supplier<StateMgmtSetting> outputFirstHelperSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptSettings,
Supplier<StateMgmtSetting> outputLastOptSettings) |
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,
Supplier<StateMgmtSetting> outputFirstHelperSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptSettings,
Supplier<StateMgmtSetting> outputLastOptSettings) |
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,
Supplier<StateMgmtSetting> outputFirstHelperSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptSettings,
Supplier<StateMgmtSetting> outputLastOptSettings) |
Modifier and Type | Method and Description |
---|---|
Supplier<StateMgmtSetting> |
ResultSetProcessorRowForAllForge.getOutputAllHelperSettings() |
Constructor and Description |
---|
ResultSetProcessorRowForAllForge(EventType resultEventType,
ExprForge optionalHavingNode,
boolean isSelectRStream,
boolean isUnidirectional,
boolean isHistoricalOnly,
OutputLimitSpec outputLimitSpec,
boolean hasOrderBy,
Supplier<StateMgmtSetting> outputAllHelperSettings) |
Modifier and Type | Method and Description |
---|---|
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerEventForge.getOutputAllHelperSettings() |
Constructor and Description |
---|
ResultSetProcessorRowPerEventForge(EventType resultEventType,
ExprForge optionalHavingNode,
boolean isSelectRStream,
boolean isUnidirectional,
boolean isHistoricalOnly,
OutputLimitSpec outputLimitSpec,
boolean hasOrderBy,
Supplier<StateMgmtSetting> outputAllHelperSettings) |
Modifier and Type | Method and Description |
---|---|
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupForge.getOutputAllHelperSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupForge.getOutputAllOptHelperSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupForge.getOutputFirstSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupForge.getOutputLastOptHelperSettings() |
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,
Supplier<StateMgmtSetting> unboundGroupRepSettings,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptHelperSettings,
Supplier<StateMgmtSetting> outputLastOptHelperSettings) |
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,
Supplier<StateMgmtSetting> unboundGroupRepSettings,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptHelperSettings,
Supplier<StateMgmtSetting> outputLastOptHelperSettings) |
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,
Supplier<StateMgmtSetting> unboundGroupRepSettings,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptHelperSettings,
Supplier<StateMgmtSetting> outputLastOptHelperSettings) |
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,
Supplier<StateMgmtSetting> unboundGroupRepSettings,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptHelperSettings,
Supplier<StateMgmtSetting> outputLastOptHelperSettings) |
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,
Supplier<StateMgmtSetting> unboundGroupRepSettings,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllHelperSettings,
Supplier<StateMgmtSetting> outputAllOptHelperSettings,
Supplier<StateMgmtSetting> outputLastOptHelperSettings) |
Modifier and Type | Method and Description |
---|---|
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupRollupForge.getOutputAllSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupRollupForge.getOutputFirstSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupRollupForge.getOutputLastSettings() |
Supplier<StateMgmtSetting> |
ResultSetProcessorRowPerGroupRollupForge.getOutputSnapshotSettings() |
Modifier and Type | Method and Description |
---|---|
static ResultSetProcessorGroupedOutputFirstHelper[] |
ResultSetProcessorRowPerGroupRollupUtil.initializeOutputFirstHelpers(ResultSetProcessorHelperFactory resultSetProcessorHelperFactory,
ExprEvaluatorContext exprEvaluatorContext,
EPType[] groupKeyTypes,
AggregationGroupByRollupDesc groupByRollupDesc,
OutputConditionPolledFactory outputConditionPolledFactory,
StateMgmtSetting outputLimitHelperSettings)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
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,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllSettings,
Supplier<StateMgmtSetting> outputLastSettings,
Supplier<StateMgmtSetting> outputSnapshotSettings) |
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,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllSettings,
Supplier<StateMgmtSetting> outputLastSettings,
Supplier<StateMgmtSetting> outputSnapshotSettings) |
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,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllSettings,
Supplier<StateMgmtSetting> outputLastSettings,
Supplier<StateMgmtSetting> outputSnapshotSettings) |
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,
Supplier<StateMgmtSetting> outputFirstSettings,
Supplier<StateMgmtSetting> outputAllSettings,
Supplier<StateMgmtSetting> outputLastSettings,
Supplier<StateMgmtSetting> outputSnapshotSettings) |
Modifier and Type | Method and Description |
---|---|
Supplier<StateMgmtSetting> |
ResultSetProcessorSimpleForge.getOutputAllHelperSettings() |
Constructor and Description |
---|
ResultSetProcessorSimpleForge(EventType resultEventType,
ExprForge optionalHavingNode,
boolean isSelectRStream,
OutputLimitSpec outputLimitSpec,
ResultSetProcessorOutputConditionType outputConditionType,
boolean isSorting,
EventType[] eventTypes,
Supplier<StateMgmtSetting> outputAllHelperSettings) |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
RowRecogDesc.getPartitionMgmtStateMgmtSettings() |
StateMgmtSetting |
RowRecogDesc.getScheduleMgmtStateMgmtSettings() |
Modifier and Type | Method and Description |
---|---|
void |
RowRecogDesc.setPartitionMgmtStateMgmtSettings(StateMgmtSetting partitionMgmtStateMgmtSettings) |
void |
RowRecogDesc.setScheduleMgmtStateMgmtSettings(StateMgmtSetting scheduleMgmtStateMgmtSettings) |
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,
StateMgmtSetting partitionMgmtStateMgmtSettings,
StateMgmtSetting scheduleMgmtStateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
RowRecogPartitionStateRepo |
RowRecogStateRepoFactoryDefault.makePartitioned(RowRecogPreviousStrategyImpl prevGetter,
RowRecogPartitionStateRepoGroupMeta stateRepoGroupMeta,
AgentInstanceContext agentInstanceContext,
RowRecogNFAView view,
boolean keepScheduleState,
RowRecogPartitionTerminationStateComparator terminationStateCompare,
StateMgmtSetting partitionMgmtStateMgmtSettings,
StateMgmtSetting scheduleMgmtStateMgmtSettings) |
RowRecogPartitionStateRepo |
RowRecogStateRepoFactory.makePartitioned(RowRecogPreviousStrategyImpl prevGetter,
RowRecogPartitionStateRepoGroupMeta stateRepoGroupMeta,
AgentInstanceContext agentInstanceContext,
RowRecogNFAView view,
boolean keepScheduleState,
RowRecogPartitionTerminationStateComparator terminationStateCompare,
StateMgmtSetting partitionMgmtStateMgmtSettings,
StateMgmtSetting scheduleMgmtStateMgmtSettings) |
RowRecogPartitionStateRepo |
RowRecogStateRepoFactoryDefault.makeSingle(RowRecogPreviousStrategyImpl prevGetter,
AgentInstanceContext agentInstanceContext,
RowRecogNFAView view,
boolean keepScheduleState,
RowRecogPartitionTerminationStateComparator terminationStateCompare,
StateMgmtSetting unpartitionedStateMgmtSettings,
StateMgmtSetting scheduleMgmtStateMgmtSettings) |
RowRecogPartitionStateRepo |
RowRecogStateRepoFactory.makeSingle(RowRecogPreviousStrategyImpl prevGetter,
AgentInstanceContext agentInstanceContext,
RowRecogNFAView view,
boolean keepScheduleState,
RowRecogPartitionTerminationStateComparator terminationStateCompare,
StateMgmtSetting unpartitionedStateMgmtSettings,
StateMgmtSetting scheduleMgmtStateMgmtSettings) |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
TableMetaData.getPrimaryKeyStateMgmtSettings() |
Modifier and Type | Method and Description |
---|---|
void |
TableMetaData.setPrimaryKeyStateMgmtSettings(StateMgmtSetting primaryKeyStateMgmtSettings) |
Constructor and Description |
---|
TableMetaData(String tableName,
String tableModuleName,
NameAccessModifier tableVisibility,
String optionalContextName,
NameAccessModifier optionalContextVisibility,
String optionalContextModule,
EventType internalEventType,
EventType publicEventType,
String[] keyColumns,
EPTypeClass[] keyTypes,
int[] keyColNums,
Map<String,TableMetadataColumn> columns,
int numMethodAggs,
StateMgmtSetting primaryKeyStateMgmtSettings) |
Modifier and Type | Class and Description |
---|---|
class |
StateMgmtSettingDefault |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
StateMgmtSettingsProxy.configure(StatementRawInfo raw,
AppliesTo appliesTo,
StateMgmtSetting setting) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getAggregation(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProvider.getAggregation(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getContext(StatementRawInfo raw,
String contextName,
AppliesTo contextCategory) |
StateMgmtSetting |
StateMgmtSettingsProvider.getContext(StatementRawInfo raw,
String contextName,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getIndex(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProvider.getIndex(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getPattern(StatementRawInfo raw,
int streamNum,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProvider.getPattern(StatementRawInfo raw,
int streamNum,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getResultSet(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProvider.getResultSet(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getRowRecog(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProvider.getRowRecog(StatementRawInfo raw,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProviderDefault.getView(StatementRawInfo raw,
int streamNumber,
boolean subquery,
boolean grouped,
AppliesTo appliesTo) |
StateMgmtSetting |
StateMgmtSettingsProvider.getView(StatementRawInfo raw,
int streamNumber,
boolean subquery,
boolean grouped,
AppliesTo appliesTo) |
Modifier and Type | Method and Description |
---|---|
StateMgmtSetting |
StateMgmtSettingsProxy.configure(StatementRawInfo raw,
AppliesTo appliesTo,
StateMgmtSetting setting) |
Modifier and Type | Field and Description |
---|---|
protected StateMgmtSetting |
ViewFactoryForgeBase.stateMgmtSettings |
Constructor and Description |
---|
PriorEventViewForge(boolean unbound,
EventType eventType,
StateMgmtSetting stateMgmtSettings) |
Copyright © 2005–2020. All rights reserved.