Uses of Class
com.espertech.esper.common.internal.collection.UniformPair
Package
Description
Test framework classes.
Internal collection classes
Result set processor for Aggregated and Grouped
Result set processor for Aggregated and Un-Grouped
Result set processor for Fully-Aggregated and Grouped
Result set processor for Rollup
This package defines the internal event APIs.
-
Uses of UniformPair in com.espertech.esper.common.client.scopetest
Modifier and TypeMethodDescriptionstatic void
EPAssertionUtil.assertProps
(UniformPair<EventBean> received, String[] propertyNames, Object[] expectedInsert, Object[] expectedRemoved) Assert that the property values of a new event and a removed event match the expected insert and removed values.static void
EPAssertionUtil.assertPropsPerRow
(UniformPair<EventBean[]> received, String[] propertyNames, Object[][] expectedInsert, Object[][] expectedRemoved) Assert that the property values of a new event and a removed event match the expected insert and removed values.static void
EPAssertionUtil.assertPropsPerRow
(UniformPair<EventBean[]> received, String propertyName, Object[] expectedInsert, Object[] expectedRemoved) Assert that the property values of the events (insert and remove pair) match the expected insert and removed values for a single property.static void
EPAssertionUtil.assertPropsPerRowAnyOrder
(UniformPair<EventBean[]> pair, String[] propertyNames, Object[][] expectedNew, Object[][] expectedOld) Compare property values for insert and remove stream pairstatic void
EPAssertionUtil.assertUnderlyingPerRow
(UniformPair<EventBean[]> received, Object[] expectedUnderlyingInsert, Object[] expectedUnderlyingRemove) Assert that the underlying objects of the events (insert and remove pair) match the expected insert and removed objects. -
Uses of UniformPair in com.espertech.esper.common.internal.collection
-
Uses of UniformPair in com.espertech.esper.common.internal.context.util
Modifier and TypeMethodDescriptionvoid
StatementResultService.indicate
(UniformPair<EventBean[]> results, StatementDispatchTLEntry dispatchTLEntry) void
ContextMergeView.newResult
(UniformPair<EventBean[]> result) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.expression.funcs
Modifier and TypeMethodDescriptionExprCaseNode.CaseAnalysis.getWhenThenNodeList()
ExprCaseNodeForge.getWhenThenNodeList()
ModifierConstructorDescriptionCaseAnalysis
(List<UniformPair<ExprNode>> whenThenNodeList, ExprNode optionalCompareExprNode, ExprNode optionalElseExprNode) ExprCaseNodeForgeEvalSyntax1
(ExprCaseNodeForge forge, List<UniformPair<ExprEvaluator>> whenThenNodeList, ExprEvaluator optionalElseExprNode) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.join.base
Modifier and TypeMethodDescriptionJoinSetComposer.join
(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream, ExprEvaluatorContext exprEvaluatorContext) Return join tuple result set from new data and old data for each stream.JoinSetComposerAllUnidirectionalOuter.join
(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream, ExprEvaluatorContext exprEvaluatorContext) JoinSetComposerFAFImpl.join
(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream, ExprEvaluatorContext exprEvaluatorContext) JoinSetComposerHistoricalImpl.join
(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream, ExprEvaluatorContext exprEvaluatorContext) JoinSetComposerImpl.join
(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream, ExprEvaluatorContext exprEvaluatorContext) JoinSetComposerStreamToWinImpl.join
(EventBean[][] newDataPerStream, EventBean[][] oldDataPerStream, ExprEvaluatorContext exprEvaluatorContext) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.join.querygraph
ModifierConstructorDescriptionQueryGraph
(Map<UniformPair<Integer>, QueryGraphValue> streamJoinMap) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.output.condition
Modifier and TypeMethodDescriptionvoid
OutputProcessViewConditionDefaultPostProcess.output
(boolean forceUpdate, UniformPair<EventBean[]> results) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.output.core
Modifier and TypeMethodDescriptionstatic void
OutputStrategyUtil.indicateEarlyReturn
(StatementContext statementContext, UniformPair<EventBean[]> newOldEvents) Indicate statement result.void
OutputProcessViewConditionLastAllUnordPostProcessAll.output
(boolean forceUpdate, UniformPair<EventBean[]> results) void
OutputProcessViewConditionSnapshot.output
(boolean forceUpdate, UniformPair<EventBean[]> results) static void
OutputStrategyUtil.output
(boolean forceUpdate, UniformPair<EventBean[]> result, UpdateDispatchView finalView) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.output.view
Modifier and TypeMethodDescriptionOutputProcessViewConditionDeltaSet.getJoinEventsSet()
OutputProcessViewConditionDeltaSetImpl.getJoinEventsSet()
List<UniformPair<EventBean[]>>
OutputProcessViewConditionDeltaSet.getViewEventsSet()
List<UniformPair<EventBean[]>>
OutputProcessViewConditionDeltaSetImpl.getViewEventsSet()
Modifier and TypeMethodDescriptionvoid
OutputProcessViewConditionDeltaSet.addJoin
(UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>> events) void
OutputProcessViewConditionDeltaSetImpl.addJoin
(UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>> setUniformPair) void
OutputProcessViewConditionDeltaSet.addView
(UniformPair<EventBean[]> events) void
OutputProcessViewConditionDeltaSetImpl.addView
(UniformPair<EventBean[]> uniformPair) boolean
OutputProcessViewBaseWAfter.checkAfterCondition
(UniformPair<EventBean[]> newOldEvents, StatementContext statementContext) Returns true if the after-condition is satisfied.boolean
OutputProcessViewAfterState.checkUpdateAfterCondition
(UniformPair<EventBean[]> newOldEvents, StatementContext statementContext) boolean
OutputProcessViewAfterStateImpl.checkUpdateAfterCondition
(UniformPair<EventBean[]> newOldEvents, StatementContext statementContext) Returns true if the after-condition is satisfied.boolean
OutputProcessViewAfterStateNone.checkUpdateAfterCondition
(UniformPair<EventBean[]> newOldEvents, StatementContext statementContext) protected void
OutputProcessViewConditionDefault.output
(boolean forceUpdate, UniformPair<EventBean[]> results) protected void
OutputProcessViewConditionFirst.output
(boolean forceUpdate, UniformPair<EventBean[]> results) void
OutputProcessViewConditionFirstPostProcess.output
(boolean forceUpdate, UniformPair<EventBean[]> results) protected void
OutputProcessViewConditionLastAllUnord.output
(boolean forceUpdate, UniformPair<EventBean[]> results) void
OutputProcessViewConditionSnapshotPostProcess.output
(boolean forceUpdate, UniformPair<EventBean[]> results) void
OutputStrategyPostProcess.output
(boolean forceUpdate, UniformPair<EventBean[]> result, UpdateDispatchView finalView) protected void
OutputProcessViewDirect.postProcess
(boolean force, UniformPair<EventBean[]> newOldEvents, UpdateDispatchView childView) protected void
OutputProcessViewDirectDistinctOrAfter.postProcess
(boolean force, UniformPair<EventBean[]> newOldEvents, UpdateDispatchView childView) protected void
OutputProcessViewDirectDistinctOrAfterPostProcess.postProcess
(boolean force, UniformPair<EventBean[]> newOldEvents, UpdateDispatchView childView) protected void
OutputProcessViewDirectPostProcess.postProcess
(boolean force, UniformPair<EventBean[]> newOldEvents, UpdateDispatchView childView) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.agggrouped
Modifier and TypeMethodDescriptionResultSetProcessorAggregateGroupedOutputAllHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputAllHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputLastHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputLastHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputAllHelper.outputView
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputAllHelperImpl.outputView
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputLastHelper.outputView
(boolean isSynthesize) ResultSetProcessorAggregateGroupedOutputLastHelperImpl.outputView
(boolean isSynthesize) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.core
Modifier and TypeMethodDescriptionResultSetProcessor.continueOutputLimitedLastAllNonBufferedJoin
(boolean isSynthesize) ResultSetProcessor.continueOutputLimitedLastAllNonBufferedView
(boolean isSynthesize) static UniformPair<EventBean[]>
ResultSetProcessorUtil.finalizeOutputMaySortMayRStream
(List<EventBean> newEvents, List<Object> newEventsSortKey, List<EventBean> oldEvents, List<Object> oldEventsSortKey, boolean selectRStream, OrderByProcessor orderByProcessor, ExprEvaluatorContext exprEvaluatorContext) NOTE: Code-generation-invoked method, method name and parameter order mattersResultSetProcessor.processJoinResult
(Set<MultiKeyArrayOfKeys<EventBean>> newEvents, Set<MultiKeyArrayOfKeys<EventBean>> oldEvents, boolean isSynthesize) For use by joins posting their result, process the event rows that are entered and removed (new and old events).ResultSetProcessor.processOutputLimitedJoin
(List<UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>> joinEventsSet, boolean generateSynthetic) Processes batched events in case of output-rate limiting.ResultSetProcessor.processOutputLimitedView
(List<UniformPair<EventBean[]>> viewEventsList, boolean generateSynthetic) Processes batched events in case of output-rate limiting.ResultSetProcessor.processViewResult
(EventBean[] newData, EventBean[] oldData, boolean isSynthesize) For use by views posting their result, process the event rows that are entered and removed (new and old events).static UniformPair<EventBean[]>
ResultSetProcessorUtil.toPairNullIfAllNull
(EventBean[] selectNewEvents, EventBean[] selectOldEvents) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic UniformPair<EventBean[]>
ResultSetProcessorUtil.toPairNullIfAllNullSingle
(EventBean istream, EventBean rstream) NOTE: Code-generation-invoked method, method name and parameter order mattersstatic UniformPair<EventBean[]>
ResultSetProcessorUtil.toPairNullIfNullIStream
(EventBean istream) NOTE: Code-generation-invoked method, method name and parameter order mattersModifier and TypeMethodDescriptionResultSetProcessor.processOutputLimitedJoin
(List<UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>> joinEventsSet, boolean generateSynthetic) Processes batched events in case of output-rate limiting.ResultSetProcessor.processOutputLimitedView
(List<UniformPair<EventBean[]>> viewEventsList, boolean generateSynthetic) Processes batched events in case of output-rate limiting. -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.handthru
Modifier and TypeMethodDescriptionResultSetProcessorHandThroughImpl.continueOutputLimitedLastAllNonBufferedJoin
(boolean isSynthesize) ResultSetProcessorHandThroughImpl.continueOutputLimitedLastAllNonBufferedView
(boolean isSynthesize) ResultSetProcessorHandThroughImpl.processJoinResult
(Set<MultiKeyArrayOfKeys<EventBean>> newEvents, Set<MultiKeyArrayOfKeys<EventBean>> oldEvents, boolean isSynthesize) ResultSetProcessorHandThroughImpl.processOutputLimitedJoin
(List<UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>> joinEventsSet, boolean generateSynthetic) ResultSetProcessorHandThroughImpl.processOutputLimitedView
(List<UniformPair<EventBean[]>> viewEventsList, boolean generateSynthetic) ResultSetProcessorHandThroughImpl.processViewResult
(EventBean[] newData, EventBean[] oldData, boolean isSynthesize) Modifier and TypeMethodDescriptionResultSetProcessorHandThroughImpl.processOutputLimitedJoin
(List<UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>> joinEventsSet, boolean generateSynthetic) ResultSetProcessorHandThroughImpl.processOutputLimitedView
(List<UniformPair<EventBean[]>> viewEventsList, boolean generateSynthetic) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.rowforall
Modifier and TypeMethodDescriptionResultSetProcessorRowForAllOutputAllHelper.outputJoin
(boolean isGenerateSynthetic) ResultSetProcessorRowForAllOutputAllHelperImpl.outputJoin
(boolean isGenerateSynthetic) ResultSetProcessorRowForAllOutputLastHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorRowForAllOutputLastHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorRowForAllOutputAllHelper.outputView
(boolean isGenerateSynthetic) ResultSetProcessorRowForAllOutputAllHelperImpl.outputView
(boolean isGenerateSynthetic) ResultSetProcessorRowForAllOutputLastHelper.outputView
(boolean isSynthesize) ResultSetProcessorRowForAllOutputLastHelperImpl.outputView
(boolean isSynthesize) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.rowperevent
-
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.rowpergroup
Modifier and TypeMethodDescriptionResultSetProcessorRowPerGroupOutputAllHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputAllHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputLastHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputLastHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputAllHelper.outputView
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputAllHelperImpl.outputView
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputLastHelper.outputView
(boolean isSynthesize) ResultSetProcessorRowPerGroupOutputLastHelperImpl.outputView
(boolean isSynthesize) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.rowpergrouprollup
Modifier and TypeMethodDescriptionResultSetProcessorRowPerGroupRollupOutputAllHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputAllHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputLastHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputLastHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputAllHelper.outputView
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputAllHelperImpl.outputView
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputLastHelper.outputView
(boolean isSynthesize) ResultSetProcessorRowPerGroupRollupOutputLastHelperImpl.outputView
(boolean isSynthesize) -
Uses of UniformPair in com.espertech.esper.common.internal.epl.resultset.simple
Modifier and TypeMethodDescriptionResultSetProcessorSimpleOutputAllHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorSimpleOutputAllHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorSimpleOutputLastHelper.outputJoin
(boolean isSynthesize) ResultSetProcessorSimpleOutputLastHelperImpl.outputJoin
(boolean isSynthesize) ResultSetProcessorSimpleOutputAllHelper.outputView
(boolean isSynthesize) ResultSetProcessorSimpleOutputAllHelperImpl.outputView
(boolean isSynthesize) ResultSetProcessorSimpleOutputLastHelper.outputView
(boolean isSynthesize) ResultSetProcessorSimpleOutputLastHelperImpl.outputView
(boolean isSynthesize) -
Uses of UniformPair in com.espertech.esper.common.internal.event.core
Modifier and TypeMethodDescriptionstatic UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>
EventBeanUtility.flattenBatchJoin
(List<UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>> joinPostings) NOTE: Code-generation-invoked method, method name and parameter order matters Flattens a list of pairs of join result sets.static UniformPair<EventBean[]>
EventBeanUtility.flattenBatchStream
(List<UniformPair<EventBean[]>> updateVector) NOTE: Code-generation-invoked method, method name and parameter order matters Flatten the vector of arrays to an array.static UniformPair<EventBean[]>
EventBeanUtility.flattenList
(ArrayDeque<UniformPair<EventBean[]>> eventVector) Flatten the vector of arrays to an array.Modifier and TypeMethodDescriptionstatic UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>
EventBeanUtility.flattenBatchJoin
(List<UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>>> joinPostings) NOTE: Code-generation-invoked method, method name and parameter order matters Flattens a list of pairs of join result sets.static UniformPair<EventBean[]>
EventBeanUtility.flattenBatchStream
(List<UniformPair<EventBean[]>> updateVector) NOTE: Code-generation-invoked method, method name and parameter order matters Flatten the vector of arrays to an array.static UniformPair<EventBean[]>
EventBeanUtility.flattenList
(ArrayDeque<UniformPair<EventBean[]>> eventVector) Flatten the vector of arrays to an array. -
Uses of UniformPair in com.espertech.esper.common.internal.metrics.instrumentation
Modifier and TypeMethodDescriptionvoid
InstrumentationCommon.aJoinExecStrategy
(UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>> joinSet) void
InstrumentationCommonDefault.aJoinExecStrategy
(UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>> joinSet) void
InstrumentationCommon.qJoinExecProcess
(UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>> joinSet) void
InstrumentationCommonDefault.qJoinExecProcess
(UniformPair<Set<MultiKeyArrayOfKeys<EventBean>>> joinSet) -
Uses of UniformPair in com.espertech.esper.common.internal.statement.dispatch
Modifier and TypeMethodDescriptionvoid
UpdateDispatchView.newResult
(UniformPair<EventBean[]> result) Convenience method that accepts a pair of new and old data as this is the most treated unit. -
Uses of UniformPair in com.espertech.esper.common.internal.statement.helper
Modifier and TypeMethodDescriptionprotected static UniformPair<Integer>
EPStatementStartMethodHelperValidate.validateOuterJoinPropertyPair
(ExprIdentNode leftNode, ExprIdentNode rightNode, int outerJoinCount, StreamTypeService typeService, ViewResourceDelegateExpr viewResourceDelegate, StatementRawInfo statementRawInfo, StatementCompileTimeServices compileTimeServices)