Package | Description |
---|---|
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.datetime.eval |
Date-Time methods and related utility classes.
|
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.funcs |
Function expressions.
|
com.espertech.esper.epl.expression.visitor |
Expression visitors.
|
com.espertech.esper.epl.index.service |
Advanced index provisioning
|
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
|
Modifier and Type | Method and Description |
---|---|
List<Pair<StringPatternSet,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.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> Pair<K,V> |
Pair.createPair(K key,
V value) |
Constructor and Description |
---|
ContextControllerHashedGetterSingleRow(String statementName,
String functionName,
Pair<Class,EngineImportSingleRowDesc> func,
List<ExprNode> parameters,
int granularity,
EngineImportService engineImportService,
EventType eventType,
EventAdapterService eventAdapterService,
int statementId,
TableService tableService,
String engineURI) |
Constructor and Description |
---|
SubSelectStrategyFactoryLocalViewPreloaded(int subqueryNumber,
SubSelectActivationHolder subSelectHolder,
Pair<EventTableFactory,SubordTableLookupStrategyFactory> pair,
ExprNode filterExprNode,
ExprEvaluator filterExprEval,
boolean correlatedSubquery,
AggregationServiceFactoryDesc aggregationServiceFactory,
ViewResourceDelegateVerified viewResourceDelegate,
ExprEvaluator[] groupKeys) |
Modifier and Type | Method and Description |
---|---|
static Pair<ResultSetProcessor,AggregationService> |
EPStatementStartMethodHelperUtil.startResultSetAndAggregation(ResultSetProcessorFactoryDesc resultSetProcessorPrototype,
AgentInstanceContext agentInstanceContext,
boolean isSubquery,
Integer subqueryNumber) |
Modifier and Type | Field and Description |
---|---|
protected List<Pair<Integer,Object>> |
AggSvcGroupLocalGroupByBase.removedKeys |
Modifier and Type | Method and Description |
---|---|
List<Pair<Integer,Object>> |
AggSvcGroupLocalGroupByBase.getRemovedKeys() |
Modifier and Type | Method and Description |
---|---|
void |
AggSvcGroupLocalGroupByBase.internalHandleGroupRemove(Pair<Integer,Object> groupByKey) |
Modifier and Type | Method and Description |
---|---|
void |
AggSvcGroupLocalGroupByBase.setRemovedKeys(List<Pair<Integer,Object>> removedKeys) |
Modifier and Type | Method and Description |
---|---|
protected static Pair<Integer,String> |
StreamTypeServiceUtil.findLevMatch(EventType[] eventTypes,
String propertyName) |
protected static Pair<Integer,String> |
StreamTypeServiceUtil.findLevMatch(String propertyName,
EventType eventType) |
Pair<Integer,String> |
StreamTypesException.getOptionalSuggestion()
Returns the optional suggestion for a matching name.
|
Pair<Integer,String> |
StreamTypesExceptionSuggestionGen.getSuggestion() |
Pair<Class,EngineImportSingleRowDesc> |
EngineImportServiceImpl.resolveSingleRow(String name) |
Pair<Class,EngineImportSingleRowDesc> |
EngineImportService.resolveSingleRow(String functionName)
Used at statement compile-time to try and resolve a given function name into an
single-row function.
|
Constructor and Description |
---|
StreamTypeServiceImpl(LinkedHashMap<String,Pair<EventType,String>> namesAndTypes,
String engineURI,
boolean isStreamZeroUnambigous,
boolean requireStreamNames)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTIntervalAffector.getKeyExpressions() |
List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTBetweenAffector.getKeyExpressions() |
Modifier and Type | Method and Description |
---|---|
Pair<Connection,PreparedStatement> |
ConnectionNoCacheImpl.getConnection() |
Pair<Connection,PreparedStatement> |
ConnectionCacheImpl.getConnection() |
abstract Pair<Connection,PreparedStatement> |
ConnectionCache.getConnection()
Returns a cached or new connection and statement pair.
|
protected Pair<Connection,PreparedStatement> |
ConnectionCache.makeNew()
Make a new pair of resources.
|
Modifier and Type | Method and Description |
---|---|
protected static void |
ConnectionCache.close(Pair<Connection,PreparedStatement> pair)
Close resources.
|
void |
ConnectionNoCacheImpl.doneWith(Pair<Connection,PreparedStatement> pair) |
void |
ConnectionCacheImpl.doneWith(Pair<Connection,PreparedStatement> pair) |
abstract void |
ConnectionCache.doneWith(Pair<Connection,PreparedStatement> pair)
Indicate to return the connection and statement pair after use.
|
Modifier and Type | Method and Description |
---|---|
static Pair<String,ExprNode> |
ExprNodeUtility.checkGetAssignmentToProp(ExprNode node) |
static Pair<String,ExprNode> |
ExprNodeUtility.checkGetAssignmentToVariableOrProp(ExprNode node) |
static Pair<PropertyResolutionDescriptor,String> |
ExprIdentNodeUtil.getTypeFromStream(StreamTypeService streamTypeService,
String propertyNameNestable,
boolean explicitPropertiesOnly,
boolean obtainFragment) |
protected static Pair<PropertyResolutionDescriptor,String> |
ExprIdentNodeUtil.getTypeFromStream(StreamTypeService streamTypeService,
String unresolvedPropertyName,
String streamOrPropertyName,
boolean obtainFragment) |
protected static Pair<PropertyResolutionDescriptor,String> |
ExprIdentNodeUtil.getTypeFromStreamExplicitProperties(StreamTypeService streamTypeService,
String unresolvedPropertyName,
String streamOrPropertyName,
boolean obtainFragment) |
Modifier and Type | Method and Description |
---|---|
static List<Pair<ExprNode,ExprNode>> |
ExprNodeUtility.findExpression(ExprNode selectExpression,
ExprNode searchExpression) |
static List<Pair<Integer,String>> |
ExprNodeUtility.getExpressionProperties(ExprNode exprNode,
boolean visitAggregateNodes)
Walk expression returning properties used.
|
Modifier and Type | Method and Description |
---|---|
static Boolean |
ExprInstanceofNodeForgeEval.instanceofCacheCheckOrAdd(Class[] classes,
CopyOnWriteArrayList<Pair<Class,Boolean>> resultCache,
Object result)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
List<Pair<Integer,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.
|
List<Pair<ExprNode,ExprIdentNode>> |
ExprNodeIdentifierCollectVisitorWContainer.getExprProperties()
Returns list of event property stream numbers and names that uniquely identify which
property is from whcih stream, and the name of each.
|
List<Pair<ExprNode,ExprGroupingIdNode>> |
ExprNodeGroupingVisitorWParent.getGroupingIdNodes() |
List<Pair<ExprNode,ExprGroupingNode>> |
ExprNodeGroupingVisitorWParent.getGroupingNodes() |
List<Pair<ExprNode,ExprIdentNode>> |
ExprNodeIdentVisitorWParent.getIdentNodes() |
List<Pair<ExprNode,ExprPreviousNode>> |
ExprNodePreviousVisitorWParent.getPrevious()
Returns the pair of previous nodes and their parent expression.
|
Constructor and Description |
---|
FilterExprAnalyzerAffectorIndexProvision(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> keyExpressions,
int streamNumIndex) |
Modifier and Type | Method and Description |
---|---|
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.
|
Constructor and Description |
---|
JoinSetComposerPrototypeHistorical2StreamImpl(ExprEvaluator optionalFilterEval,
EventType[] streamTypes,
ExprEvaluatorContext exprEvaluatorContext,
int polledViewNum,
int streamViewNum,
boolean outerJoin,
ExprEvaluator outerJoinEqualsEval,
Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> indexStrategies,
boolean allHistoricalNoSubordinate,
OuterJoinDesc[] outerJoinDescList,
boolean allowIndexInit) |
Modifier and Type | Method and Description |
---|---|
protected Pair<TableLookupIndexReqKey,int[]> |
QueryPlanIndex.getIndexNum(String[] indexProps,
String[] rangeProps)
Find a matching index for the property names supplied.
|
Modifier and Type | Method and Description |
---|---|
void |
QueryGraph.addCustomIndex(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> streamKeys,
int streamValue) |
Modifier and Type | Method and Description |
---|---|
Pair<HistoricalIndexLookupStrategy,PollResultIndexingStrategy> |
HistoricalStreamIndexList.getStrategy(int streamViewStreamNum)
Get the strategies to use for polling from a given stream.
|
Modifier and Type | Method and Description |
---|---|
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.addExplicitIndexOrReuse(boolean unique,
List<IndexedPropDesc> hashProps,
List<IndexedPropDesc> btreeProps,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc,
Iterable<EventBean> prefilledEvents,
EventType indexedType,
String indexName,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
static Pair<IndexMultiKey,EventTableIndexEntryBase> |
EventTableIndexUtil.findIndexBestAvailable(Map<IndexMultiKey,? extends EventTableIndexEntryBase> tablesAvailable,
Set<String> keyPropertyNames,
Set<String> rangePropertyNames,
List<IndexHintInstruction> optionalIndexHintInstructions) |
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.findTable(Set<String> keyPropertyNames,
Set<String> rangePropertyNames,
List<IndexHintInstruction> optionalIndexHintInstructions) |
Modifier and Type | Method and Description |
---|---|
Pair<Class,PluggableObjectEntry> |
PluggableObjectRegistryImpl.lookup(String nameSpace,
String name) |
Pair<Class,PluggableObjectEntry> |
PluggableObjectRegistry.lookup(String nameSpace,
String name) |
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
PatternStreamSpecCompiled.getArrayEventTypes()
Returns event types tagged in the pattern expression under a repeat-operator.
|
LinkedHashMap<String,Pair<EventType,String>> |
MatchEventSpec.getArrayEventTypes() |
List<Pair<String,Object>> |
AnnotationDesc.getAttributes()
Returns annotation attributes.
|
Map<String,Map<String,Pair<Class,PluggableObjectEntry>>> |
PluggableObjectCollection.getPluggables()
Returns the underlying nested map of namespace keys and name-to-object maps.
|
LinkedHashMap<String,Pair<EventType,String>> |
PatternStreamSpecCompiled.getTaggedEventTypes()
Returns event types tagged in the pattern expression.
|
LinkedHashMap<String,Pair<EventType,String>> |
MatchEventSpec.getTaggedEventTypes() |
Constructor and Description |
---|
CreateExpressionDesc(Pair<ExpressionDeclItem,ExpressionScriptProvided> pair) |
Constructor and Description |
---|
AnnotationDesc(String name,
List<Pair<String,Object>> attributes)
Ctor.
|
MatchEventSpec(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes) |
MatchEventSpec(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes) |
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode,
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) |
PatternStreamSpecCompiled(EvalFactoryNode evalFactoryNode,
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) |
Modifier and Type | Method and Description |
---|---|
static Pair<int[],IndexMultiKey> |
TableServiceUtil.getIndexMultikeyForKeys(Map<String,TableMetadataColumn> items,
ObjectArrayEventType eventType) |
Pair<ExprNode,List<ExprChainedSpec>> |
TableServiceImpl.getTableNodeChainable(StreamTypeService streamTypeService,
List<ExprChainedSpec> chainSpec,
EngineImportService engineImportService) |
Pair<ExprNode,List<ExprChainedSpec>> |
TableService.getTableNodeChainable(StreamTypeService streamTypeService,
List<ExprChainedSpec> chainSpec,
EngineImportService engineImportService) |
Modifier and Type | Method and Description |
---|---|
Pair<Boolean,Object> |
VariableStateHandler.getHasState(String variableName,
int variableNumber,
int agentInstanceId,
Class type,
EventType eventType,
StatementExtensionSvcContext statementExtContext,
boolean isConstant)
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
|
Modifier and Type | Method and Description |
---|---|
Map<Integer,Pair<Integer,Object>> |
VariableVersionThreadEntry.getUncommitted()
Returns a map of variable number and uncommitted value, or empty map or null if none exist
|
Modifier and Type | Method and Description |
---|---|
void |
VariableVersionThreadEntry.setUncommitted(Map<Integer,Pair<Integer,Object>> uncommitted)
Sets a map of variable number and uncommitted value, or empty map or null if none exist
|
Constructor and Description |
---|
VariableVersionThreadEntry(int version,
Map<Integer,Pair<Integer,Object>> uncommitted)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
Pair<IndexMultiKey,EventTable> |
VirtualDWViewImpl.getFireAndForgetDesc(Set<String> keysAvailable,
Set<String> rangesAvailable) |
Pair<IndexMultiKey,EventTable> |
VirtualDWView.getFireAndForgetDesc(Set<String> keysAvailable,
Set<String> rangesAvailable) |
Pair<IndexMultiKey,EventTable> |
VirtualDWViewImpl.getSubordinateQueryDesc(boolean unique,
List<IndexedPropDesc> hashedProps,
List<IndexedPropDesc> btreeProps) |
Pair<IndexMultiKey,EventTable> |
VirtualDWView.getSubordinateQueryDesc(boolean unique,
List<IndexedPropDesc> hashedProps,
List<IndexedPropDesc> btreeProps) |
Modifier and Type | Method and Description |
---|---|
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(ConfigurationEventTypeWithSupertype optionalConfig,
EventUnderlyingType representation,
Map<String,? extends EventType> nameToTypeMap) |
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(Set<String> superTypesSet,
EventUnderlyingType representation,
Map<String,? extends EventType> nameToTypeMap) |
Modifier and Type | Method and Description |
---|---|
Map<String,Pair<EventType,String>> |
TaggedCompositeEventType.getTaggedEventTypes()
Returns the event types for each composing event.
|
Modifier and Type | Method and Description |
---|---|
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews) |
EventType |
EventAdapterServiceImpl.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,String>> arrayEventTypes,
boolean isUsedByChildViews) |
EventType |
EventAdapterService.createSemiAnonymousMapType(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,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(String typeName,
Map<String,Pair<EventType,String>> taggedEventTypes,
Map<String,Pair<EventType,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.
|
Modifier and Type | Field and Description |
---|---|
protected Map<String,Pair<EventPropertyDescriptor,ObjectArrayEventBeanPropertyWriter>> |
ObjectArrayEventType.propertyWriters |
Modifier and Type | Method and Description |
---|---|
static Pair<net.sf.cglib.reflect.FastConstructor,ExprForge[]> |
InstanceManufacturerUtil.getManufacturer(Class targetClass,
EngineImportService engineImportService,
ExprForge[] exprForges,
Object[] expressionReturnTypes) |
Modifier and Type | Field and Description |
---|---|
protected Map<String,Pair<EventPropertyDescriptor,MapEventBeanPropertyWriter>> |
MapEventType.propertyWriters |
Modifier and Type | Field and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecCompilerArgs.arrayEventTypes |
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecCompilerArgs.taggedEventTypes |
Modifier and Type | Method and Description |
---|---|
static Pair<FilterValueSetParam,FilterParamIndexBase> |
IndexHelper.findIndex(ArrayDeque<FilterValueSetParam> parameters,
List<FilterParamIndexBase> indizes)
Find an index that matches one of the filter parameters passed.
|
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecParamExprNode.getArrayEventTypes() |
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecParamExprNode.getTaggedEventTypes()
Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)
|
Modifier and Type | Method and Description |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext stmtContext,
Collection<Integer> assignedTypeNumberStack) |
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext stmtContext,
Collection<Integer> assignedTypeNumberStack) |
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(List<ExprNode> validatedFilterNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
Collection<Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
int statementId,
String statementName,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
EngineImportService engineImportService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowMgmtService namedWindowMgmtService,
StatementExtensionSvcContext statementExtensionSvcContext) |
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(List<ExprNode> validatedFilterNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
Collection<Integer> assignedTypeNumberStack,
ExprEvaluatorContext exprEvaluatorContext,
int statementId,
String statementName,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
EngineImportService engineImportService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
ConfigurationInformation configurationInformation,
NamedWindowMgmtService namedWindowMgmtService,
StatementExtensionSvcContext statementExtensionSvcContext) |
protected static FilterSpecParam |
FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
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,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext statementContext,
Collection<Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementContext statementContext,
Collection<Integer> assignedTypeNumberStack)
Factory method for compiling filter expressions into a filter specification
for use with filter service.
|
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
StatementContext statementContext,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes)
Validates expression nodes and returns a list of validated nodes.
|
Constructor and Description |
---|
FilterSpecCompilerArgs(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
String statementName,
int statementId,
StreamTypeService streamTypeService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation,
StatementExtensionSvcContext statementExtensionSvcContext) |
FilterSpecCompilerArgs(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
ExprEvaluatorContext exprEvaluatorContext,
String statementName,
int statementId,
StreamTypeService streamTypeService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation,
StatementExtensionSvcContext statementExtensionSvcContext) |
FilterSpecParamExprNode(FilterSpecLookupable lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
ConfigurationInformation configurationInformation,
boolean hasSubquery,
boolean hasTableAccess) |
FilterSpecParamExprNode(FilterSpecLookupable lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
ConfigurationInformation configurationInformation,
boolean hasSubquery,
boolean hasTableAccess) |
Modifier and Type | Method and Description |
---|---|
void |
InstrumentationDefault.aRegExState(List<RegexNFAStateEntry> next,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.aRegExState(List<RegexNFAStateEntry> next,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationDefault.aRegExStateStart(List<RegexNFAStateEntry> nextStates,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.aRegExStateStart(List<RegexNFAStateEntry> nextStates,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationDefault.qRegExState(RegexNFAStateEntry currentState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.qRegExState(RegexNFAStateEntry currentState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationDefault.qRegExStateStart(RegexNFAState startState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.qRegExStateStart(RegexNFAState startState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationDefault.qRegIntervalState(RegexNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable,
long engineTime) |
void |
Instrumentation.qRegIntervalState(RegexNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable,
long engineTime) |
void |
InstrumentationDefault.qRegMeasure(RegexNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.qRegMeasure(RegexNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
Constructor and Description |
---|
MatchedEventConvertorImpl(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
EventAdapterService eventAdapterService) |
MatchedEventConvertorImpl(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags,
EventAdapterService eventAdapterService) |
Modifier and Type | Field and Description |
---|---|
protected HashMap<String,Pair<ExprNode,ExprEvaluator>> |
EventRowRegexNFAViewFactory.variableDefinitions |
protected LinkedHashMap<String,Pair<Integer,Boolean>> |
EventRowRegexNFAViewFactory.variableStreams |
Modifier and Type | Method and Description |
---|---|
List<Pair<RowRegexExprNodeAtom,RowRegexExprNode>> |
RowRegexExprNodeVisitorRepeat.getAtoms() |
Modifier and Type | Method and Description |
---|---|
static StreamTypeService |
EventRowRegexNFAViewFactoryHelper.buildDefineStreamTypeServiceDefine(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
MatchRecognizeDefineItem defineItem,
Map<String,Set<String>> visibilityByIdentifier,
EventType parentViewType) |
static ObjectArrayBackedEventBean |
EventRowRegexNFAViewFactoryHelper.getDefineMultimatchBean(StatementContext statementContext,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
EventType parentViewType) |
protected static String |
EventRowRegexNFAViewUtil.printStates(List<RegexNFAStateEntry> states,
Map<Integer,String> streamsVariables,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
protected static RegexNFAStrandResult |
EventRowRegexHelper.recursiveBuildStartStates(RowRegexExprNode parent,
Map<String,Pair<ExprNode,ExprEvaluator>> variableDefinitions,
Map<String,Pair<Integer,Boolean>> variableStreams,
boolean[] exprRequiresMultimatchState)
Build a list of start states from the parent node.
|
protected static RegexNFAStrandResult |
EventRowRegexHelper.recursiveBuildStartStates(RowRegexExprNode parent,
Map<String,Pair<ExprNode,ExprEvaluator>> variableDefinitions,
Map<String,Pair<Integer,Boolean>> variableStreams,
boolean[] exprRequiresMultimatchState)
Build a list of start states from the parent node.
|
Constructor and Description |
---|
RegexNFAStateFilter(String nodeNum,
String variableName,
int streamNum,
boolean multiple,
Pair<ExprNode,ExprEvaluator> expression,
boolean exprRequiresMultimatchState)
Ctor.
|
Constructor and Description |
---|
RegexPartitionTerminationStateComparator(int[] multimatchStreamNumToVariable,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams) |
Modifier and Type | Method and Description |
---|---|
static Boolean |
StringPatternSetUtil.evaluate(boolean defaultValue,
List<Pair<StringPatternSet,Boolean>> patterns,
String literal)
Executes a seriers of include/exclude patterns against a match string,
returning the last pattern match result as boolean in/out.
|
Modifier and Type | Method and Description |
---|---|
static Pair<ExprNode,String> |
StatementSelectionUtil.compileValidateStatementFilterExpr(EPServiceProviderSPI engine,
String filterExpression) |
static Pair<String,Boolean> |
JavaClassHelper.isGetArrayType(String type) |
Modifier and Type | Method and Description |
---|---|
static Object |
SimpleTypeCasterAnyType.simpleTypeCasterCast(Object object,
Class typeToCastTo,
CopyOnWriteArraySet<Pair<Class,Boolean>> pairs)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
protected static Pair<Viewable,List<View>> |
ViewServiceHelper.matchExistingViews(Viewable rootViewable,
List<ViewFactory> viewFactories,
AgentInstanceContext agentInstanceContext)
Match the views under the stream to the list of view specications passed in.
|
Modifier and Type | Method and Description |
---|---|
Pair<EventStream,StatementAgentInstanceLock> |
StreamFactorySvcImpl.createStream(int statementId,
FilterSpecCompiled filterSpec,
FilterService filterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
boolean isJoin,
AgentInstanceContext agentInstanceContext,
boolean hasOrderBy,
boolean filterWithSameTypeSubselect,
Annotation[] annotations,
boolean stateless,
int streamNum,
boolean isCanIterateUnbound)
See the method of the same name in
StreamFactoryService . |
Pair<EventStream,StatementAgentInstanceLock> |
StreamFactoryService.createStream(int statementId,
FilterSpecCompiled filterSpec,
FilterService filterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
boolean isJoin,
AgentInstanceContext agentInstanceContext,
boolean hasOrderBy,
boolean filterWithSameTypeSubselect,
Annotation[] annotations,
boolean stateless,
int streamNum,
boolean isCanIterateUnbound)
Create or reuse existing EventStream instance representing that event filter.
|