Uses of Class
com.espertech.esper.collection.Pair

Packages that use Pair
com.espertech.esper.client This package and its sub-packages defines the central Esper Client APIs. 
com.espertech.esper.collection Internal collection classes 
com.espertech.esper.core.context.mgr Context management. 
com.espertech.esper.core.context.subselect Subselect implementation. 
com.espertech.esper.core.start Classes related to start and stop of statements 
com.espertech.esper.epl.agg.service Aggregation services. 
com.espertech.esper.epl.core Contains EPL statement specification classes define the constructs that make up an EPL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
com.espertech.esper.epl.db Database SQL polling views and caches 
com.espertech.esper.epl.expression.core Core expression classes. 
com.espertech.esper.epl.expression.visitor Expression visitors. 
com.espertech.esper.epl.join.base Join process interfaces and glue code 
com.espertech.esper.epl.join.plan Inner join and outer join query planning 
com.espertech.esper.epl.join.table Indexes for views 
com.espertech.esper.epl.lookup Subquery execution strategies and lookup indexes 
com.espertech.esper.epl.parse Parsers and AST tree walkers and helper classes transforming AST into business objects 
com.espertech.esper.epl.spec Contains EPL statement specification classes define the constructs that make up an EPL statement, such as the list of items in the select clause, the insert-into stream name and property names etc. 
com.espertech.esper.epl.table.mgmt Table-related services and metadata. 
com.espertech.esper.epl.variable Variable service and variable collections 
com.espertech.esper.epl.virtualdw Virtual data window. 
com.espertech.esper.event This package defines the internal event APIs. 
com.espertech.esper.event.arr Object-array event type. 
com.espertech.esper.event.bean JavaBean and legacy Java underlying event classes are here. 
com.espertech.esper.event.map Map-underlying event classes are here. 
com.espertech.esper.filter Main switchboard filtering and routing of incoming events to interested statements is performed in this package. 
com.espertech.esper.metrics.instrumentation EPL instrumentation helpers. 
com.espertech.esper.pattern Pattern expression tree and pattern state objects, the later resembles pattern expression state for each active pattern instance 
com.espertech.esper.rowregex Match-recognize expression tree and state objects. 
com.espertech.esper.type Internal primitive, enum and other type representations 
com.espertech.esper.util Utility classes that center around Java type handling, printing, reflection, debugging 
com.espertech.esper.view View infrastructure concerned with view creation and destroy, cloning and hooking views trees into filtering. 
com.espertech.esper.view.stream View to event stream relationship service 
 

Uses of Pair in com.espertech.esper.client
 

Methods in com.espertech.esper.client that return types with arguments of type Pair
 java.util.List<Pair<StringPatternSet,java.lang.Boolean>> ConfigurationMetricsReporting.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.collection
 

Methods in com.espertech.esper.collection that return Pair
static
<K,V> Pair<K,V>
Pair.createPair(K key, V value)
           
 

Uses of Pair in com.espertech.esper.core.context.mgr
 

Constructors in com.espertech.esper.core.context.mgr with parameters of type Pair
ContextControllerHashedGetterSingleRow(java.lang.String statementName, java.lang.String functionName, Pair<java.lang.Class,EngineImportSingleRowDesc> func, java.util.List<ExprNode> parameters, int granularity, MethodResolutionService methodResolutionService, EventType eventType, EventAdapterService eventAdapterService, java.lang.String statementId, TableService tableService)
           
 

Uses of Pair in com.espertech.esper.core.context.subselect
 

Constructors in com.espertech.esper.core.context.subselect with parameters of type Pair
SubSelectStrategyFactoryLocalViewPreloaded(int subqueryNumber, SubSelectActivationHolder subSelectHolder, Pair<EventTableFactory,SubordTableLookupStrategyFactory> pair, ExprNode filterExprNode, ExprEvaluator filterExprEval, boolean correlatedSubquery, AggregationServiceFactoryDesc aggregationServiceFactory, ViewResourceDelegateVerified viewResourceDelegate, ExprEvaluator[] groupKeys)
           
 

Uses of Pair in com.espertech.esper.core.start
 

Methods in com.espertech.esper.core.start that return Pair
static Pair<ResultSetProcessor,AggregationService> EPStatementStartMethodHelperUtil.startResultSetAndAggregation(ResultSetProcessorFactoryDesc resultSetProcessorPrototype, AgentInstanceContext agentInstanceContext)
           
 

Uses of Pair in com.espertech.esper.epl.agg.service
 

Fields in com.espertech.esper.epl.agg.service with type parameters of type Pair
protected  java.util.List<Pair<java.lang.Integer,java.lang.Object>> AggSvcGroupLocalGroupByBase.removedKeys
           
 

Methods in com.espertech.esper.epl.agg.service that return types with arguments of type Pair
 java.util.List<Pair<java.lang.Integer,java.lang.Object>> AggSvcGroupLocalGroupByBase.getRemovedKeys()
           
 

Methods in com.espertech.esper.epl.agg.service with parameters of type Pair
 void AggSvcGroupLocalGroupByBase.internalHandleGroupRemove(Pair<java.lang.Integer,java.lang.Object> groupByKey)
           
 

Method parameters in com.espertech.esper.epl.agg.service with type arguments of type Pair
 void AggSvcGroupLocalGroupByBase.setRemovedKeys(java.util.List<Pair<java.lang.Integer,java.lang.Object>> removedKeys)
           
 

Uses of Pair in com.espertech.esper.epl.core
 

Methods in com.espertech.esper.epl.core that return Pair
 Pair<java.lang.Integer,java.lang.String> StreamTypesException.getOptionalSuggestion()
          Returns the optional suggestion for a matching name.
 Pair<java.lang.Class,EngineImportSingleRowDesc> MethodResolutionServiceImpl.resolveSingleRow(java.lang.String functionName)
           
 Pair<java.lang.Class,EngineImportSingleRowDesc> MethodResolutionService.resolveSingleRow(java.lang.String functionName)
          Used at statement compile-time to try and resolve a given function name into an single-row function.
 Pair<java.lang.Class,EngineImportSingleRowDesc> EngineImportServiceImpl.resolveSingleRow(java.lang.String name)
           
 Pair<java.lang.Class,EngineImportSingleRowDesc> EngineImportService.resolveSingleRow(java.lang.String functionName)
          Used at statement compile-time to try and resolve a given function name into an single-row function.
 

Constructors in com.espertech.esper.epl.core with parameters of type Pair
PropertyNotFoundException(java.lang.String msg, Pair<java.lang.Integer,java.lang.String> nearestMatchSuggestion)
          Ctor.
StreamNotFoundException(java.lang.String msg, Pair<java.lang.Integer,java.lang.String> suggestion)
          Ctor.
StreamTypesException(java.lang.String message, Pair<java.lang.Integer,java.lang.String> suggestion)
          Ctor.
 

Constructor parameters in com.espertech.esper.epl.core with type arguments of type Pair
StreamTypeServiceImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> namesAndTypes, java.lang.String engineURI, boolean isStreamZeroUnambigous, boolean requireStreamNames)
          Ctor.
 

Uses of Pair in com.espertech.esper.epl.db
 

Methods in com.espertech.esper.epl.db that return Pair
 Pair<java.sql.Connection,java.sql.PreparedStatement> ConnectionNoCacheImpl.getConnection()
           
 Pair<java.sql.Connection,java.sql.PreparedStatement> ConnectionCacheImpl.getConnection()
           
abstract  Pair<java.sql.Connection,java.sql.PreparedStatement> ConnectionCache.getConnection()
          Returns a cached or new connection and statement pair.
protected  Pair<java.sql.Connection,java.sql.PreparedStatement> ConnectionCache.makeNew()
          Make a new pair of resources.
 

Methods in com.espertech.esper.epl.db with parameters of type Pair
protected static void ConnectionCache.close(Pair<java.sql.Connection,java.sql.PreparedStatement> pair)
          Close resources.
 void ConnectionNoCacheImpl.doneWith(Pair<java.sql.Connection,java.sql.PreparedStatement> pair)
           
 void ConnectionCacheImpl.doneWith(Pair<java.sql.Connection,java.sql.PreparedStatement> pair)
           
abstract  void ConnectionCache.doneWith(Pair<java.sql.Connection,java.sql.PreparedStatement> pair)
          Indicate to return the connection and statement pair after use.
 

Uses of Pair in com.espertech.esper.epl.expression.core
 

Methods in com.espertech.esper.epl.expression.core that return Pair
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToProp(ExprNode node)
           
static Pair<java.lang.String,ExprNode> ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node)
           
static Pair<PropertyResolutionDescriptor,java.lang.String> ExprIdentNodeUtil.getTypeFromStream(StreamTypeService streamTypeService, java.lang.String propertyNameNestable, boolean explicitPropertiesOnly, boolean obtainFragment)
           
protected static Pair<PropertyResolutionDescriptor,java.lang.String> ExprIdentNodeUtil.getTypeFromStream(StreamTypeService streamTypeService, java.lang.String unresolvedPropertyName, java.lang.String streamOrPropertyName, boolean obtainFragment)
          Determine stream id and property type given an unresolved property name and a stream name that may also be part of the property name.
protected static Pair<PropertyResolutionDescriptor,java.lang.String> ExprIdentNodeUtil.getTypeFromStreamExplicitProperties(StreamTypeService streamTypeService, java.lang.String unresolvedPropertyName, java.lang.String streamOrPropertyName, boolean obtainFragment)
          This method only resolves against explicitly-listed properties (for use with XML or other types that allow any name as a property name).
 

Methods in com.espertech.esper.epl.expression.core that return types with arguments of type Pair
static java.util.List<Pair<ExprNode,ExprNode>> ExprNodeUtility.findExpression(ExprNode selectExpression, ExprNode searchExpression)
           
static java.util.List<Pair<java.lang.Integer,java.lang.String>> ExprNodeUtility.getExpressionProperties(ExprNode exprNode, boolean visitAggregateNodes)
          Walk expression returning properties used.
 

Uses of Pair in com.espertech.esper.epl.expression.visitor
 

Methods in com.espertech.esper.epl.expression.visitor that return types with arguments of type Pair
 java.util.List<Pair<java.lang.Integer,java.lang.String>> 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.
 java.util.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.
 java.util.List<Pair<ExprNode,ExprGroupingIdNode>> ExprNodeGroupingVisitorWParent.getGroupingIdNodes()
           
 java.util.List<Pair<ExprNode,ExprGroupingNode>> ExprNodeGroupingVisitorWParent.getGroupingNodes()
           
 java.util.List<Pair<ExprNode,ExprIdentNode>> ExprNodeIdentVisitorWParent.getIdentNodes()
           
 java.util.List<Pair<ExprNode,ExprPreviousNode>> ExprNodePreviousVisitorWParent.getPrevious()
          Returns the pair of previous nodes and their parent expression.
 

Uses of Pair in com.espertech.esper.epl.join.base
 

Methods in com.espertech.esper.epl.join.base that return Pair
static Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> JoinSetComposerPrototypeFactory.determineIndexing(QueryGraph queryGraph, EventType polledViewType, EventType streamViewType, int polledViewStreamNum, int streamViewStreamNum)
          Constructs indexing and lookup strategy for a given relationship that a historical stream may have with another stream (historical or not) that looks up into results of a poll of a historical stream.
 

Constructors in com.espertech.esper.epl.join.base with parameters of type Pair
JoinSetComposerPrototypeHistorical2StreamImpl(ExprNode optionalFilterNode, EventType[] streamTypes, ExprEvaluatorContext exprEvaluatorContext, int polledViewNum, int streamViewNum, boolean outerJoin, ExprNode outerJoinEqualsNode, Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> indexStrategies, boolean allHistoricalNoSubordinate, OuterJoinDesc[] outerJoinDescList)
           
 

Uses of Pair in com.espertech.esper.epl.join.plan
 

Methods in com.espertech.esper.epl.join.plan that return Pair
protected  Pair<TableLookupIndexReqKey,int[]> QueryPlanIndex.getIndexNum(java.lang.String[] indexProps, java.lang.String[] rangeProps)
          Find a matching index for the property names supplied.
 

Uses of Pair in com.espertech.esper.epl.join.table
 

Methods in com.espertech.esper.epl.join.table that return Pair
 Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> HistoricalStreamIndexList.getStrategy(int streamViewStreamNum)
          Get the strategies to use for polling from a given stream.
 

Uses of Pair in com.espertech.esper.epl.lookup
 

Methods in com.espertech.esper.epl.lookup that return Pair
 Pair<IndexMultiKey,EventTableAndNamePair> EventTableIndexRepository.addExplicitIndexOrReuse(boolean unique, java.util.List<IndexedPropDesc> hashProps, java.util.List<IndexedPropDesc> btreeProps, java.lang.Iterable<EventBean> prefilledEvents, EventType indexedType, java.lang.String indexName)
           
static Pair<IndexMultiKey,EventTableIndexEntryBase> EventTableIndexUtil.findIndexBestAvailable(java.util.Map<IndexMultiKey,? extends EventTableIndexEntryBase> tablesAvailable, java.util.Set<java.lang.String> keyPropertyNames, java.util.Set<java.lang.String> rangePropertyNames, java.util.List<IndexHintInstruction> optionalIndexHintInstructions)
           
 Pair<IndexMultiKey,EventTableAndNamePair> EventTableIndexRepository.findTable(java.util.Set<java.lang.String> keyPropertyNames, java.util.Set<java.lang.String> rangePropertyNames, java.util.List<IndexHintInstruction> optionalIndexHintInstructions)
           
 

Uses of Pair in com.espertech.esper.epl.parse
 

Methods in com.espertech.esper.epl.parse that return Pair
static Pair<ExprTableAccessNode,ExprDotNode> ASTTableExprHelper.checkTableNameGetExprForSubproperty(TableService tableService, java.lang.String tableName, java.lang.String subproperty)
          Resolve "table.property", not chainable
static Pair<ExprTableAccessNode,java.util.List<ExprChainedSpec>> ASTTableExprHelper.checkTableNameGetLibFunc(TableService tableService, EngineImportService engineImportService, LazyAllocatedMap<ConfigurationPlugInAggregationMultiFunction,PlugInAggregationMultiFunctionFactory> plugInAggregations, java.lang.String engineURI, java.lang.String classIdent, java.util.List<ExprChainedSpec> chain)
           
static Pair<ExprTableAccessNode,java.util.List<ExprChainedSpec>> ASTTableExprHelper.getTableExprChainable(EngineImportService engineImportService, LazyAllocatedMap<ConfigurationPlugInAggregationMultiFunction,PlugInAggregationMultiFunctionFactory> plugInAggregations, java.lang.String engineURI, java.lang.String tableName, java.util.List<ExprChainedSpec> chain)
          Handle "variable[...].xxxxx......"
static Pair<ExpressionDeclItem,ExpressionScriptProvided> ASTExpressionDeclHelper.walkExpressionDecl(EsperEPL2GrammarParser.ExpressionDeclContext ctx, java.util.List<java.lang.String> scriptBodies, java.util.Map<org.antlr.v4.runtime.tree.Tree,ExprNode> astExprNodeMap, org.antlr.v4.runtime.CommonTokenStream tokenStream)
           
 

Uses of Pair in com.espertech.esper.epl.spec
 

Methods in com.espertech.esper.epl.spec that return Pair
 Pair<java.lang.Class,PluggableObjectEntry> PluggableObjectRegistryImpl.lookup(java.lang.String nameSpace, java.lang.String name)
           
 Pair<java.lang.Class,PluggableObjectEntry> PluggableObjectRegistry.lookup(java.lang.String nameSpace, java.lang.String name)
           
 

Methods in com.espertech.esper.epl.spec that return types with arguments of type Pair
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> PatternStreamSpecCompiled.getArrayEventTypes()
          Returns event types tagged in the pattern expression under a repeat-operator.
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> MatchEventSpec.getArrayEventTypes()
           
 java.util.List<Pair<java.lang.String,java.lang.Object>> AnnotationDesc.getAttributes()
          Returns annotation attributes.
 java.util.Map<java.lang.String,java.util.Map<java.lang.String,Pair<java.lang.Class,PluggableObjectEntry>>> PluggableObjectCollection.getPluggables()
          Returns the underlying nested map of namespace keys and name-to-object maps.
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> PatternStreamSpecCompiled.getTaggedEventTypes()
          Returns event types tagged in the pattern expression.
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> MatchEventSpec.getTaggedEventTypes()
           
 

Constructors in com.espertech.esper.epl.spec with parameters of type Pair
CreateExpressionDesc(Pair<ExpressionDeclItem,ExpressionScriptProvided> pair)
           
 

Constructor parameters in com.espertech.esper.epl.spec with type arguments of type Pair
AnnotationDesc(java.lang.String name, java.util.List<Pair<java.lang.String,java.lang.Object>> attributes)
          Ctor.
MatchEventSpec(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
           
MatchEventSpec(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
           
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, java.util.LinkedHashSet<java.lang.String> allTags, ViewSpec[] viewSpecs, java.lang.String optionalStreamName, StreamSpecOptions streamSpecOptions, boolean suppressSameEventMatches, boolean discardPartialsOnMatch)
          Ctor.
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, java.util.LinkedHashSet<java.lang.String> allTags, ViewSpec[] viewSpecs, java.lang.String optionalStreamName, StreamSpecOptions streamSpecOptions, boolean suppressSameEventMatches, boolean discardPartialsOnMatch)
          Ctor.
 

Uses of Pair in com.espertech.esper.epl.table.mgmt
 

Methods in com.espertech.esper.epl.table.mgmt that return Pair
static Pair<int[],IndexMultiKey> TableServiceUtil.getIndexMultikeyForKeys(java.util.Map<java.lang.String,TableMetadataColumn> items, ObjectArrayEventType eventType)
           
 Pair<ExprNode,java.util.List<ExprChainedSpec>> TableServiceImpl.getTableNodeChainable(StreamTypeService streamTypeService, java.util.List<ExprChainedSpec> chainSpec, EngineImportService engineImportService)
           
 Pair<ExprNode,java.util.List<ExprChainedSpec>> TableService.getTableNodeChainable(StreamTypeService streamTypeService, java.util.List<ExprChainedSpec> chainSpec, EngineImportService engineImportService)
           
 

Uses of Pair in com.espertech.esper.epl.variable
 

Methods in com.espertech.esper.epl.variable that return Pair
 Pair<java.lang.Boolean,java.lang.Object> VariableStateHandler.getHasState(java.lang.String variableName, int variableNumber, int agentInstanceId, java.lang.Class type, EventType eventType, StatementExtensionSvcContext statementExtContext)
          Returns the current variable state plus Boolean.TRUE if there is a current state since the variable may have the value of null; returns Boolean.FALSE and null if there is no current state
 

Methods in com.espertech.esper.epl.variable that return types with arguments of type Pair
 java.util.Map<java.lang.Integer,Pair<java.lang.Integer,java.lang.Object>> VariableVersionThreadEntry.getUncommitted()
          Returns a map of variable number and uncommitted value, or empty map or null if none exist
 

Method parameters in com.espertech.esper.epl.variable with type arguments of type Pair
 void VariableVersionThreadEntry.setUncommitted(java.util.Map<java.lang.Integer,Pair<java.lang.Integer,java.lang.Object>> uncommitted)
          Sets a map of variable number and uncommitted value, or empty map or null if none exist
 

Constructor parameters in com.espertech.esper.epl.variable with type arguments of type Pair
VariableVersionThreadEntry(int version, java.util.Map<java.lang.Integer,Pair<java.lang.Integer,java.lang.Object>> uncommitted)
          Ctor.
 

Uses of Pair in com.espertech.esper.epl.virtualdw
 

Methods in com.espertech.esper.epl.virtualdw that return Pair
 Pair<IndexMultiKey,EventTable> VirtualDWViewImpl.getFireAndForgetDesc(java.util.Set<java.lang.String> keysAvailable, java.util.Set<java.lang.String> rangesAvailable)
           
 Pair<IndexMultiKey,EventTable> VirtualDWView.getFireAndForgetDesc(java.util.Set<java.lang.String> keysAvailable, java.util.Set<java.lang.String> rangesAvailable)
           
 Pair<IndexMultiKey,EventTable> VirtualDWViewImpl.getSubordinateQueryDesc(boolean unique, java.util.List<IndexedPropDesc> hashedProps, java.util.List<IndexedPropDesc> btreeProps)
           
 Pair<IndexMultiKey,EventTable> VirtualDWView.getSubordinateQueryDesc(boolean unique, java.util.List<IndexedPropDesc> hashedProps, java.util.List<IndexedPropDesc> btreeProps)
           
 

Uses of Pair in com.espertech.esper.event
 

Methods in com.espertech.esper.event that return types with arguments of type Pair
 java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> TaggedCompositeEventType.getTaggedEventTypes()
          Returns the event types for each composing event.
 

Method parameters in com.espertech.esper.event with type arguments of type Pair
 EventType EventAdapterServiceImpl.createSemiAnonymousMapType(java.lang.String typeName, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, boolean isUsedByChildViews)
           
 EventType EventAdapterServiceImpl.createSemiAnonymousMapType(java.lang.String typeName, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, boolean isUsedByChildViews)
           
 EventType EventAdapterService.createSemiAnonymousMapType(java.lang.String typeName, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, boolean isUsedByChildViews)
          Creates an anonymous map that has no name, however in a fail-over scenario events of this type may be recoverable and therefore the type is only semi-anonymous, identified by the tags and event type names used.
 EventType EventAdapterService.createSemiAnonymousMapType(java.lang.String typeName, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, boolean isUsedByChildViews)
          Creates an anonymous map that has no name, however in a fail-over scenario events of this type may be recoverable and therefore the type is only semi-anonymous, identified by the tags and event type names used.
 

Uses of Pair in com.espertech.esper.event.arr
 

Fields in com.espertech.esper.event.arr with type parameters of type Pair
protected  java.util.Map<java.lang.String,Pair<EventPropertyDescriptor,ObjectArrayEventBeanPropertyWriter>> ObjectArrayEventType.propertyWriters
           
 

Uses of Pair in com.espertech.esper.event.bean
 

Methods in com.espertech.esper.event.bean that return Pair
static Pair<net.sf.cglib.reflect.FastConstructor,ExprEvaluator[]> InstanceManufacturerUtil.getManufacturer(java.lang.Class targetClass, EngineImportService engineImportService, ExprEvaluator[] exprEvaluators, java.lang.Object[] expressionReturnTypes)
           
 

Uses of Pair in com.espertech.esper.event.map
 

Fields in com.espertech.esper.event.map with type parameters of type Pair
protected  java.util.Map<java.lang.String,Pair<EventPropertyDescriptor,MapEventBeanPropertyWriter>> MapEventType.propertyWriters
           
 

Uses of Pair in com.espertech.esper.filter
 

Fields in com.espertech.esper.filter with type parameters of type Pair
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> FilterSpecCompilerArgs.arrayEventTypes
           
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> FilterSpecCompilerArgs.taggedEventTypes
           
 

Methods in com.espertech.esper.filter that return Pair
static Pair<FilterValueSetParam,FilterParamIndexBase> IndexHelper.findIndex(java.util.ArrayDeque<FilterValueSetParam> parameters, java.util.List<FilterParamIndexBase> indizes)
          Find an index that matches one of the filter parameters passed.
 

Methods in com.espertech.esper.filter that return types with arguments of type Pair
 java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> FilterSpecParamExprNode.getTaggedEventTypes()
          Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)
 

Method parameters in com.espertech.esper.filter with type arguments of type Pair
static FilterSpecCompiled FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext stmtContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
           
static FilterSpecCompiled FilterSpecCompiler.build(java.util.List<ExprNode> validatedNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext stmtContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
           
static FilterSpecCompiled FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementId, java.lang.String statementName, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ConfigurationInformation configurationInformation, NamedWindowService namedWindowService)
           
static FilterSpecCompiled FilterSpecCompiler.buildNoStmtCtx(java.util.List<ExprNode> validatedFilterNodes, EventType eventType, java.lang.String eventTypeName, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, java.util.Collection<java.lang.Integer> assignedTypeNumberStack, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementId, java.lang.String statementName, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, MethodResolutionService methodResolutionService, EventAdapterService eventAdapterService, TimeProvider timeProvider, VariableService variableService, TableService tableService, ConfigurationInformation configurationInformation, NamedWindowService namedWindowService)
           
protected static FilterSpecParam FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementName)
          For a given expression determine if this is optimizable and create the filter parameter representing the expression, or null if not optimizable.
static FilterSpecCompiled FilterSpecCompiler.makeFilterSpec(EventType eventType, java.lang.String eventTypeName, java.util.List<ExprNode> filterExpessions, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext statementContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
          Factory method for compiling filter expressions into a filter specification for use with filter service.
static FilterSpecCompiled FilterSpecCompiler.makeFilterSpec(EventType eventType, java.lang.String eventTypeName, java.util.List<ExprNode> filterExpessions, PropertyEvalSpec optionalPropertyEvalSpec, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, StreamTypeService streamTypeService, java.lang.String optionalStreamName, StatementContext statementContext, java.util.Collection<java.lang.Integer> assignedTypeNumberStack)
          Factory method for compiling filter expressions into a filter specification for use with filter service.
static java.util.List<ExprNode> FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin, java.util.List<ExprNode> exprNodes, StreamTypeService streamTypeService, StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
          Validates expression nodes and returns a list of validated nodes.
static java.util.List<ExprNode> FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin, java.util.List<ExprNode> exprNodes, StreamTypeService streamTypeService, StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes)
          Validates expression nodes and returns a list of validated nodes.
 

Constructor parameters in com.espertech.esper.filter with type arguments of type Pair
FilterSpecCompilerArgs(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementName, java.lang.String statementId, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, EventAdapterService eventAdapterService, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, ConfigurationInformation configurationInformation)
           
FilterSpecCompilerArgs(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, ExprEvaluatorContext exprEvaluatorContext, java.lang.String statementName, java.lang.String statementId, StreamTypeService streamTypeService, MethodResolutionService methodResolutionService, TimeProvider timeProvider, VariableService variableService, TableService tableService, EventAdapterService eventAdapterService, java.lang.annotation.Annotation[] annotations, ContextDescriptor contextDescriptor, ConfigurationInformation configurationInformation)
           
FilterSpecParamExprNode(FilterSpecLookupable lookupable, FilterOperator filterOperator, ExprNode exprNode, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, VariableService variableService, TableService tableService, EventAdapterService eventAdapterService, ConfigurationInformation configurationInformation, java.lang.String statementName, boolean hasSubquery, boolean hasTableAccess)
          Ctor.
FilterSpecParamExprNode(FilterSpecLookupable lookupable, FilterOperator filterOperator, ExprNode exprNode, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> taggedEventTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, VariableService variableService, TableService tableService, EventAdapterService eventAdapterService, ConfigurationInformation configurationInformation, java.lang.String statementName, boolean hasSubquery, boolean hasTableAccess)
          Ctor.
 

Uses of Pair in com.espertech.esper.metrics.instrumentation
 

Method parameters in com.espertech.esper.metrics.instrumentation with type arguments of type Pair
 void InstrumentationDefault.aRegExState(java.util.List<RegexNFAStateEntry> next, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable)
           
 void Instrumentation.aRegExState(java.util.List<RegexNFAStateEntry> next, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable)
           
 void InstrumentationDefault.qRegExState(RegexNFAStateEntry currentState, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable)
           
 void Instrumentation.qRegExState(RegexNFAStateEntry currentState, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable)
           
 void InstrumentationDefault.qRegIntervalState(RegexNFAStateEntry endState, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable, long engineTime)
           
 void Instrumentation.qRegIntervalState(RegexNFAStateEntry endState, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable, long engineTime)
           
 void InstrumentationDefault.qRegMeasure(RegexNFAStateEntry endState, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable)
           
 void Instrumentation.qRegMeasure(RegexNFAStateEntry endState, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, int[] multimatchStreamNumToVariable)
           
 

Uses of Pair in com.espertech.esper.pattern
 

Constructor parameters in com.espertech.esper.pattern with type arguments of type Pair
MatchedEventConvertorImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> filterTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, java.util.LinkedHashSet<java.lang.String> allTags, EventAdapterService eventAdapterService)
          Ctor.
MatchedEventConvertorImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> filterTypes, java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> arrayEventTypes, java.util.LinkedHashSet<java.lang.String> allTags, EventAdapterService eventAdapterService)
          Ctor.
 

Uses of Pair in com.espertech.esper.rowregex
 

Methods in com.espertech.esper.rowregex that return types with arguments of type Pair
 java.util.List<Pair<RowRegexExprNodeAtom,RowRegexExprNode>> RowRegexExprNodeVisitorRepeat.getAtoms()
           
 

Method parameters in com.espertech.esper.rowregex with type arguments of type Pair
static StreamTypeService EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, MatchRecognizeDefineItem defineItem, java.util.Map<java.lang.String,java.util.Set<java.lang.String>> visibilityByIdentifier, EventType parentViewType)
           
static ObjectArrayBackedEventBean EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, EventType parentViewType)
           
protected static RegexNFAStrandResult EventRowRegexHelper.recursiveBuildStartStates(RowRegexExprNode parent, java.util.Map<java.lang.String,ExprNode> variableDefinitions, java.util.Map<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, boolean[] exprRequiresMultimatchState)
          Build a list of start states from the parent node.
 

Constructor parameters in com.espertech.esper.rowregex with type arguments of type Pair
EventRowRegexNFAView(EventRowRegexNFAViewFactory factory, ObjectArrayEventType compositeEventType, EventType rowEventType, MatchRecognizeSpec matchRecognizeSpec, java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams, java.util.Map<java.lang.Integer,java.lang.String> streamsVariables, java.util.Set<java.lang.String> variablesSingle, AgentInstanceContext agentInstanceContext, java.util.TreeMap<java.lang.Integer,java.util.List<ExprPreviousMatchRecognizeNode>> callbacksPerIndex, AggregationServiceMatchRecognize aggregationService, boolean isDefineAsksMultimatches, ObjectArrayBackedEventBean defineMultimatchEventBean, boolean[] isExprRequiresMultimatchState, boolean isUnbound, boolean isIterateOnly, boolean isCollectMultimatches, RowRegexExprNode expandedPatternNode)
          Ctor.
 

Uses of Pair in com.espertech.esper.type
 

Method parameters in com.espertech.esper.type with type arguments of type Pair
static java.lang.Boolean StringPatternSetUtil.evaluate(boolean defaultValue, java.util.List<Pair<StringPatternSet,java.lang.Boolean>> patterns, java.lang.String literal)
          Executes a seriers of include/exclude patterns against a match string, returning the last pattern match result as boolean in/out.
 

Uses of Pair in com.espertech.esper.util
 

Methods in com.espertech.esper.util that return Pair
static Pair<java.lang.String,java.lang.Boolean> JavaClassHelper.isGetArrayType(java.lang.String type)
           
 

Uses of Pair in com.espertech.esper.view
 

Methods in com.espertech.esper.view that return Pair
protected static Pair<Viewable,java.util.List<View>> ViewServiceHelper.matchExistingViews(Viewable rootViewable, java.util.List<ViewFactory> viewFactories)
          Match the views under the stream to the list of view specications passed in.
 

Uses of Pair in com.espertech.esper.view.stream
 

Methods in com.espertech.esper.view.stream that return Pair
 Pair<EventStream,StatementAgentInstanceLock> StreamFactorySvcImpl.createStream(java.lang.String statementId, FilterSpecCompiled filterSpec, FilterService filterService, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, boolean isJoin, ExprEvaluatorContext exprEvaluatorContext, boolean hasOrderBy, boolean filterWithSameTypeSubselect, java.lang.annotation.Annotation[] annotations, boolean stateless, int streamNum, boolean isCanIterateUnbound)
          See the method of the same name in StreamFactoryService.
 Pair<EventStream,StatementAgentInstanceLock> StreamFactoryService.createStream(java.lang.String statementId, FilterSpecCompiled filterSpec, FilterService filterService, EPStatementAgentInstanceHandle epStatementAgentInstanceHandle, boolean isJoin, ExprEvaluatorContext exprEvaluatorContext, boolean hasOrderBy, boolean filterWithSameTypeSubselect, java.lang.annotation.Annotation[] annotations, boolean stateless, int streamNum, boolean isCanIterateUnbound)
          Create or reuse existing EventStream instance representing that event filter.
 


© 2006-2015 EsperTech Inc.
All rights reserved.
Visit us at espertech.com