Uses of Class
com.espertech.esper.common.internal.collection.Pair
Package
Description
Configuration classes for the runtime section, which is only relevant to the runtime
Internal collection classes
Contains EPL statement specification classes define the constructs that make up an EPL statement,
such as the list of items in the select clause, the insert-into stream name and property names etc.
Date-Time methods and related utility classes.
Advanced index provisioning
Match-recognize core.
Match-recognize indexExpressions.
Stream-type management
Object-array event type.
This package defines the internal event APIs.
Map-underlying event classes are here.
Internal primitive, enum and other type representations
Utility classes that center around Java type handling, printing, reflection, debugging
-
Uses of Pair in com.espertech.esper.common.client.configuration.runtime
Modifier and TypeMethodDescriptionConfigurationRuntimeMetricsReporting.StmtGroupMetrics.getPatterns()
Returns a list of patterns that indicate whether a statement, by the statement name matching or not matching each pattern, falls within the statement group. -
Uses of Pair in com.espertech.esper.common.internal.collection
Modifier and TypeMethodDescriptionstatic <K,
V> Pair<K, V> Pair.createPair
(K key, V value) PathModuleEntry.getAnyModuleExpectSingle
(String entityName, PathRegistryObjectType objectType, Set<String> moduleNames) PathRegistry.getAnyModuleExpectSingle
(K entityKey, Set<String> moduleUses) -
Uses of Pair in com.espertech.esper.common.internal.compile.stage1.spec
Modifier and TypeMethodDescriptionModifier and TypeMethodDescriptionMatchEventSpec.getArrayEventTypes()
PatternStreamSpecCompiled.getArrayEventTypes()
Returns event types tagged in the pattern expression under a repeat-operator.AnnotationDesc.getAttributes()
Returns annotation attributes.PluggableObjectCollection.getPluggables()
Returns the underlying nested map of namespace keys and name-to-object maps.MatchEventSpec.getTaggedEventTypes()
PatternStreamSpecCompiled.getTaggedEventTypes()
Returns event types tagged in the pattern expression.ModifierConstructorDescriptionModifierConstructorDescriptionCtor.MatchEventSpec
(LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes) PatternStreamSpecCompiled
(EvalRootForgeNode root, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTags, ViewSpec[] viewSpecs, String optionalStreamName, StreamSpecOptions streamSpecOptions, boolean suppressSameEventMatches, boolean discardPartialsOnMatch) -
Uses of Pair in com.espertech.esper.common.internal.compile.stage2
Modifier and TypeFieldDescriptionfinal LinkedHashMap<String,
Pair<EventType, String>> FilterSpecCompilerArgs.arrayEventTypes
final LinkedHashMap<String,
Pair<EventType, String>> FilterSpecCompilerArgs.taggedEventTypes
Modifier and TypeMethodDescriptionFilterSpecCompilerIndexPlannerHelper.getStreamIndex
(String resolvedPropertyName) Modifier and TypeMethodDescriptionstatic FilterSpecCompiledDesc
FilterSpecCompiler.build
(FilterSpecValidatedDesc validatedDesc, EventType eventType, String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, StreamTypeService streamTypeService, String optionalStreamName, StatementRawInfo statementRawInfo, StatementCompileTimeServices compileTimeServices) static FilterSpecCompiled
FilterSpecCompiler.buildNoStmtCtx
(List<ExprNode> validatedNodes, EventType eventType, String eventTypeName, String optionalStreamName, PropertyEvalSpec optionalPropertyEvalSpec, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, StreamTypeService streamTypeService, StatementRawInfo statementRawInfo, StatementCompileTimeServices compileTimeServices) protected static EventType
FilterSpecCompilerIndexPlannerHelper.getArrayInnerEventType
(LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, String streamName) protected static FilterSpecParamFilterForEvalDoubleForge
FilterSpecCompilerIndexPlannerHelper.getIdentNodeDoubleEval
(ExprIdentNode node, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, String statementName) protected static MatchedEventConvertorForge
FilterSpecCompilerIndexPlannerHelper.getMatchEventConvertor
(ExprNode value, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered) protected static FilterSpecParamForge
FilterSpecCompilerIndexPlannerAdvancedIndex.handleAdvancedIndexDescProvider
(FilterSpecCompilerAdvIndexDescProvider provider, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, String statementName) protected static FilterSpecParamForge
FilterSpecCompilerIndexPlannerBooleanLimited.handleBooleanLimited
(ExprNode constituent, Function<String, Boolean> limitedExprExists, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, StreamTypeService streamTypeService, StatementRawInfo raw, StatementCompileTimeServices services) protected static FilterSpecParamForge
FilterSpecCompilerIndexPlannerEquals.handleEqualsAndRelOp
(ExprNode constituent, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, String statementName, StatementRawInfo raw, StatementCompileTimeServices services) protected static FilterSpecParamForge
FilterSpecCompilerIndexPlannerInSetOfValues.handleInSetNode
(ExprInNode constituent, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, StatementRawInfo raw, StatementCompileTimeServices services) static FilterSpecParamForge
FilterSpecCompilerIndexPlannerRange.handleRangeNode
(ExprBetweenNode betweenNode, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, String statementName, StatementRawInfo raw, StatementCompileTimeServices services) protected static FilterSpecPlanPathTripletForge
FilterSpecCompilerIndexPlannerConstituent.makeFilterParam
(ExprNode constituent, boolean performConditionPlanning, Function<String, Boolean> limitedExprExists, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, String statementName, StreamTypeService streamTypeService, StatementRawInfo raw, StatementCompileTimeServices services) For a given expression determine if this is optimizable and create the filter parameter representing the expression, or null if not optimizable.static FilterSpecCompiledDesc
FilterSpecCompiler.makeFilterSpec
(EventType eventType, String eventTypeName, List<ExprNode> filterExpessions, PropertyEvalSpec optionalPropertyEvalSpec, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, StreamTypeService streamTypeService, String optionalStreamName, StatementRawInfo statementRawInfo, StatementCompileTimeServices services) static FilterSpecValidatedDesc
FilterSpecCompiler.validateAllowSubquery
(ExprNodeOrigin exprNodeOrigin, List<ExprNode> exprNodes, StreamTypeService streamTypeService, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, StatementRawInfo statementRawInfo, StatementCompileTimeServices services) ModifierConstructorDescriptionFilterSpecCompilerArgs
(LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTagNamesOrdered, StreamTypeService streamTypeService, ContextCompileTimeDescriptor contextDescriptor, StatementRawInfo statementRawInfo, StatementCompileTimeServices compileTimeServices) -
Uses of Pair in com.espertech.esper.common.internal.context.aifactory.core
Modifier and TypeMethodDescriptionstatic Pair<ResultSetProcessor,
AggregationService> StatementAgentInstanceFactoryUtil.startResultSetAndAggregation
(ResultSetProcessorFactoryProvider resultSetProcessorPrototype, ExprEvaluatorContext exprEvaluatorContext, boolean isSubquery, Integer subqueryNumber) -
Uses of Pair in com.espertech.esper.common.internal.context.controller.hash
ModifierConstructorDescriptionContextControllerHashedGetterSingleRowForge
(Pair<Class, ClasspathImportSingleRowDesc> func, List<ExprNode> parameters, int granularity, EventType eventType, StatementRawInfo statementRawInfo, StatementCompileTimeServices services) -
Uses of Pair in com.espertech.esper.common.internal.epl.classprovided.compiletime
Modifier and TypeMethodDescriptionClassProvidedClasspathExtensionImpl.resolveAggregationMultiFunction
(String name) ClassProvidedCompileTimeResolver.resolveAggregationMultiFunction
(String name) ClassProvidedCompileTimeResolverEmpty.resolveAggregationMultiFunction
(String name) ClassProvidedCompileTimeResolverImpl.resolveAggregationMultiFunction
(String name) ClassProvidedClasspathExtensionImpl.resolveSingleRow
(String name) ClassProvidedCompileTimeResolver.resolveSingleRow
(String name) ClassProvidedCompileTimeResolverEmpty.resolveSingleRow
(String name) ClassProvidedCompileTimeResolverImpl.resolveSingleRow
(String name) -
Uses of Pair in com.espertech.esper.common.internal.epl.datetime.eval
Modifier and TypeMethodDescriptionFilterExprAnalyzerDTBetweenAffector.getKeyExpressions()
FilterExprAnalyzerDTIntervalAffector.getKeyExpressions()
-
Uses of Pair in com.espertech.esper.common.internal.epl.expression.core
Modifier and TypeMethodDescriptionstatic Pair<PropertyResolutionDescriptor,
String> ExprIdentNodeUtil.getTypeFromStream
(StreamTypeService streamTypeService, String propertyNameNestable, boolean explicitPropertiesOnly, boolean obtainFragment, TableCompileTimeResolver tableCompileTimeResolver) protected static Pair<PropertyResolutionDescriptor,
String> ExprIdentNodeUtil.getTypeFromStream
(StreamTypeService streamTypeService, String unresolvedPropertyName, String streamOrPropertyNameMayEscaped, boolean obtainFragment, TableCompileTimeResolver tableCompileTimeResolver) protected static Pair<PropertyResolutionDescriptor,
String> ExprIdentNodeUtil.getTypeFromStreamExplicitProperties
(StreamTypeService streamTypeService, String unresolvedPropertyName, String streamOrPropertyName, boolean obtainFragment) -
Uses of Pair in com.espertech.esper.common.internal.epl.expression.declared.compiletime
Modifier and TypeMethodDescriptionExprDeclaredHelper.getExistsDeclaredExpr
(String name, List<ExprNode> parameters, Collection<ExpressionDeclItem> stmtLocalExpressions, ContextCompileTimeDescriptor contextCompileTimeDescriptor, StatementSpecMapEnv mapEnv, LazyAllocatedMap<HashableMultiKey, AggregationMultiFunctionForge> plugInAggregations, List<ExpressionScriptProvided> scripts) -
Uses of Pair in com.espertech.esper.common.internal.epl.expression.funcs
Modifier and TypeMethodDescriptionstatic Boolean
ExprInstanceofNodeForgeEval.instanceofCacheCheckOrAdd
(Class[] classes, CopyOnWriteArrayList<Pair<Class, Boolean>> resultCache, Object result) NOTE: Code-generation-invoked method, method name and parameter order matters -
Uses of Pair in com.espertech.esper.common.internal.epl.expression.visitor
Modifier and TypeMethodDescriptionExprNodeIdentifierCollectVisitorWContainer.getExprProperties()
Returns list of event property stream numbers and names that uniquely identify which property is from whcih stream, and the name of each.ExprNodeIdentifierVisitor.getExprProperties()
Returns list of event property stream numbers and names that uniquely identify which property is from whcih stream, and the name of each.ExprNodeGroupingVisitorWParent.getGroupingIdNodes()
ExprNodeGroupingVisitorWParent.getGroupingNodes()
ExprNodeIdentVisitorWParent.getIdentNodes()
ExprNodePreviousVisitorWParent.getPrevious()
Returns the pair of previous nodes and their parent expression. -
Uses of Pair in com.espertech.esper.common.internal.epl.historical.database.core
Modifier and TypeMethodDescriptionabstract Pair<Connection,
PreparedStatement> ConnectionCache.getConnection()
Returns a cached or new connection and statement pair.ConnectionCacheImpl.getConnection()
ConnectionCacheNoCacheImpl.getConnection()
protected Pair<Connection,
PreparedStatement> ConnectionCache.makeNew()
Make a new pair of resources.Modifier and TypeMethodDescriptionprotected static void
ConnectionCache.close
(Pair<Connection, PreparedStatement> pair) Close resources.abstract void
ConnectionCache.doneWith
(Pair<Connection, PreparedStatement> pair) Indicate to return the connection and statement pair after use.void
ConnectionCacheImpl.doneWith
(Pair<Connection, PreparedStatement> pair) void
ConnectionCacheNoCacheImpl.doneWith
(Pair<Connection, PreparedStatement> pair) -
Uses of Pair in com.espertech.esper.common.internal.epl.historical.method.core
Modifier and TypeMethodDescriptionPollExecStrategyPlanner.plan
(MethodPollingViewableMeta metadata, Method targetMethod, EventType eventType) -
Uses of Pair in com.espertech.esper.common.internal.epl.index.advanced.index.service
-
Uses of Pair in com.espertech.esper.common.internal.epl.join.querygraph
-
Uses of Pair in com.espertech.esper.common.internal.epl.join.queryplan
Modifier and TypeMethodDescriptionPair<TableLookupIndexReqKey,
int[]> QueryPlanIndexForge.getIndexNum
(String[] indexProps, String[] rangeProps) Find a matching index for the property names supplied. -
Uses of Pair in com.espertech.esper.common.internal.epl.lookupplansubord
Modifier and TypeMethodDescriptionEventTableIndexRepository.addExplicitIndexOrReuse
(QueryPlanIndexItem desc, Iterable<EventBean> prefilledEvents, EventType indexedType, String indexName, String indexModuleName, AgentInstanceContext agentInstanceContext, DataInputOutputSerde optionalValueSerde) EventTableIndexUtil.findIndexBestAvailable
(Map<IndexMultiKey, ? extends EventTableIndexEntryBase> tablesAvailable, Set<String> keyPropertyNames, Set<String> rangePropertyNames, List<IndexHintInstruction> optionalIndexHintInstructions) EventTableIndexRepository.findTable
(Set<String> keyPropertyNames, Set<String> rangePropertyNames, List<IndexHintInstruction> optionalIndexHintInstructions) -
Uses of Pair in com.espertech.esper.common.internal.epl.pattern.core
ModifierConstructorDescriptionMatchedEventConvertorForge
(LinkedHashMap<String, Pair<EventType, String>> filterTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, LinkedHashSet<String> allTags, Set<Integer> streamsUsedCanNull, boolean baseStreamIndexOne) -
Uses of Pair in com.espertech.esper.common.internal.epl.rowrecog.core
Modifier and TypeMethodDescriptionRowRecogDesc.getNextStatesPerState()
RowRecogDesc.getVariableStreams()
RowRecogDescForge.getVariableStreams()
Modifier and TypeMethodDescriptionprotected static String
RowRecogNFAViewUtil.printStates
(List<RowRecogNFAStateEntry> states, Map<Integer, String> streamsVariables, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
RowRecogDesc.setNextStatesPerState
(List<Pair<Integer, int[]>> nextStatesPerState) void
RowRecogDesc.setVariableStreams
(LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams) ModifierConstructorDescriptionRowRecogDescForge
(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, boolean isTargetHA) RowRecogPartitionTerminationStateComparator
(int[] multimatchStreamNumToVariable, Map<String, Pair<Integer, Boolean>> variableStreams) -
Uses of Pair in com.espertech.esper.common.internal.epl.rowrecog.expr
-
Uses of Pair in com.espertech.esper.common.internal.epl.streamtype
Modifier and TypeMethodDescriptionStreamTypeServiceUtil.findLevMatch
(EventType[] eventTypes, String propertyName) StreamTypeServiceUtil.findLevMatch
(String propertyName, EventType eventType) StreamTypesException.getOptionalSuggestion()
Returns the optional suggestion for a matching name.StreamTypesExceptionSuggestionGen.getSuggestion()
ModifierConstructorDescriptionStreamTypeServiceImpl
(LinkedHashMap<String, Pair<EventType, String>> namesAndTypes, boolean isStreamZeroUnambigous, boolean requireStreamNames) Ctor. -
Uses of Pair in com.espertech.esper.common.internal.epl.subselect
Modifier and TypeMethodDescriptionstatic List<StmtClassForgeableFactory>
SubSelectHelperFilters.handleSubselectSelectClauses
(ExprSubselectNode subselect, EventType outerEventType, String outerEventTypeName, String outerStreamName, LinkedHashMap<String, Pair<EventType, String>> taggedEventTypes, LinkedHashMap<String, Pair<EventType, String>> arrayEventTypes, StatementRawInfo statementRawInfo, StatementCompileTimeServices services) ModifierConstructorDescriptionSubSelectStrategyFactoryLocalViewPreloadedForge
(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, boolean isTargetHA) -
Uses of Pair in com.espertech.esper.common.internal.epl.table.compiletime
Modifier and TypeMethodDescriptionTableCompileTimeUtil.getTableNodeChainable
(StreamTypeService streamTypeService, List<Chainable> chainSpec, boolean allowTableAggReset, TableCompileTimeResolver tableCompileTimeResolver) static Pair<ExprTableAccessNode,
List<Chainable>> TableCompileTimeUtil.handleTableAccessNode
(LazyAllocatedMap<ConfigurationCompilerPlugInAggregationMultiFunction, AggregationMultiFunctionForge> plugInAggregations, String tableName, String sub, List<Chainable> chain) static Pair<ExprTableAccessNode,
ExprDotNode> TableCompileTimeUtil.mapPropertyToTableNested
(TableCompileTimeResolver resolver, String stream, String subproperty) -
Uses of Pair in com.espertech.esper.common.internal.epl.variable.core
Modifier and TypeMethodDescriptionVariableVersionThreadEntry.getUncommitted()
Returns a map of variable number and uncommitted value, or empty map or null if none existModifier and TypeMethodDescriptionvoid
Sets a map of variable number and uncommitted value, or empty map or null if none exist -
Uses of Pair in com.espertech.esper.common.internal.epl.virtualdw
Modifier and TypeMethodDescriptionstatic Pair<IndexMultiKey,
EventTable> VirtualDWQueryPlanUtil.getFireAndForgetDesc
(EventType eventType, Set<String> keysAvailable, Set<String> rangesAvailable) static Pair<IndexMultiKey,
VirtualDWEventTable> VirtualDWQueryPlanUtil.getSubordinateQueryDesc
(boolean unique, IndexedPropDesc[] hashedProps, IndexedPropDesc[] btreeProps) -
Uses of Pair in com.espertech.esper.common.internal.event.arr
-
Uses of Pair in com.espertech.esper.common.internal.event.bean.manufacturer
Modifier and TypeMethodDescriptionstatic Pair<Constructor,
ExprForge[]> InstanceManufacturerUtil.getManufacturer
(EPTypeClass targetClass, ClasspathImportServiceCompileTime classpathImportService, ExprForge[] exprForges, Object[] expressionReturnTypes) -
Uses of Pair in com.espertech.esper.common.internal.event.core
Modifier and TypeMethodDescriptionEventTypeUtility.getSuperTypesDepthFirst
(String[] superTypesSet, EventUnderlyingType representation, EventTypeNameResolver eventTypeNameResolver) EventTypeUtility.getSuperTypesDepthFirst
(Set<String> superTypesSet, EventUnderlyingType representation, EventTypeNameResolver eventTypeNameResolver) -
Uses of Pair in com.espertech.esper.common.internal.event.json.compiletime
Modifier and TypeMethodDescriptionstatic EventTypeForgablesPair
JsonEventTypeUtility.makeJsonTypeCompileTimeNewType
(EventTypeMetadata metadata, Map<String, Object> compiledTyping, Pair<EventType[], Set<EventType>> superTypes, ConfigurationCommonEventTypeWithSupertype config, StatementRawInfo raw, StatementCompileTimeServices services) -
Uses of Pair in com.espertech.esper.common.internal.event.json.core
Modifier and TypeFieldDescriptionprotected Map<String,
Pair<EventPropertyDescriptor, JsonEventBeanPropertyWriter>> JsonEventType.propertyWriters
-
Uses of Pair in com.espertech.esper.common.internal.event.map
Modifier and TypeFieldDescriptionprotected Map<String,
Pair<EventPropertyDescriptor, MapEventBeanPropertyWriter>> MapEventType.propertyWriters
-
Uses of Pair in com.espertech.esper.common.internal.filterspec
Modifier and TypeMethodDescriptionFilterSpecParamExprNodeForge.getTaggedEventTypes()
Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)ModifierConstructorDescriptionFilterSpecParamExprNodeForge
(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) -
Uses of Pair in com.espertech.esper.common.internal.metrics.instrumentation
Modifier and TypeMethodDescriptionvoid
InstrumentationCommon.aRegExState
(List<RowRecogNFAStateEntry> next, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommonDefault.aRegExState
(List<RowRecogNFAStateEntry> next, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommon.aRegExStateStart
(List<RowRecogNFAStateEntry> nextStates, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommonDefault.aRegExStateStart
(List<RowRecogNFAStateEntry> nextStates, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommon.qRegExState
(RowRecogNFAStateEntry currentState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommonDefault.qRegExState
(RowRecogNFAStateEntry currentState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommon.qRegExStateStart
(RowRecogNFAState startState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommonDefault.qRegExStateStart
(RowRecogNFAState startState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommon.qRegIntervalState
(RowRecogNFAStateEntry endState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable, long runtimeTime) void
InstrumentationCommonDefault.qRegIntervalState
(RowRecogNFAStateEntry endState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable, long runtimeTime) void
InstrumentationCommon.qRegMeasure
(RowRecogNFAStateEntry endState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) void
InstrumentationCommonDefault.qRegMeasure
(RowRecogNFAStateEntry endState, LinkedHashMap<String, Pair<Integer, Boolean>> variableStreams, int[] multimatchStreamNumToVariable) -
Uses of Pair in com.espertech.esper.common.internal.settings
Modifier and TypeMethodDescriptionClasspathExtensionAggregationMultiFunction.resolveAggregationMultiFunction
(String name) ClasspathImportServiceCompileTime.resolveAggregationMultiFunction
(String name, ClasspathExtensionAggregationMultiFunction classpathExtensionAggregationMultiFunction) ClasspathImportServiceCompileTimeImpl.resolveAggregationMultiFunction
(String name, ClasspathExtensionAggregationMultiFunction extension) ClasspathExtensionSingleRow.resolveSingleRow
(String name) ClasspathImportServiceCompileTime.resolveSingleRow
(String name, ClasspathExtensionSingleRow classpathExtensionSingleRow) ClasspathImportServiceCompileTimeImpl.resolveSingleRow
(String name, ClasspathExtensionSingleRow classpathExtensionSingleRow) -
Uses of Pair in com.espertech.esper.common.internal.type
-
Uses of Pair in com.espertech.esper.common.internal.util
Modifier and TypeMethodDescriptionstatic Object
SimpleTypeCasterAnyType.simpleTypeCasterCast
(Object object, EPTypeClass typeToCastTo, CopyOnWriteArraySet<Pair<Class, Boolean>> pairs) NOTE: Code-generation-invoked method, method name and parameter order matters