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.groupbylocal |
Aggregation services - local-grouping
|
com.espertech.esper.epl.core.engineimport |
Engine import handling
|
com.espertech.esper.epl.core.streamtype |
Stream-type management
|
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 |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> Pair<K,V> |
Pair.createPair(K key,
V value) |
Constructor and Description |
---|
ContextControllerHashedGetterSingleRow(java.lang.String statementName,
java.lang.String functionName,
Pair<java.lang.Class,EngineImportSingleRowDesc> func,
java.util.List<ExprNode> parameters,
int granularity,
EngineImportService engineImportService,
EventType eventType,
EventAdapterService eventAdapterService,
int statementId,
TableService tableService,
java.lang.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,
java.lang.Integer subqueryNumber) |
Modifier and Type | Field and Description |
---|---|
protected java.util.List<Pair<java.lang.Integer,java.lang.Object>> |
AggSvcGroupLocalGroupByBase.removedKeys |
Modifier and Type | Method and Description |
---|---|
java.util.List<Pair<java.lang.Integer,java.lang.Object>> |
AggSvcGroupLocalGroupByBase.getRemovedKeys() |
Modifier and Type | Method and Description |
---|---|
void |
AggSvcGroupLocalGroupByBase.internalHandleGroupRemove(Pair<java.lang.Integer,java.lang.Object> groupByKey) |
Modifier and Type | Method and Description |
---|---|
void |
AggSvcGroupLocalGroupByBase.setRemovedKeys(java.util.List<Pair<java.lang.Integer,java.lang.Object>> removedKeys) |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
protected static Pair<java.lang.Integer,java.lang.String> |
StreamTypeServiceUtil.findLevMatch(EventType[] eventTypes,
java.lang.String propertyName) |
protected static Pair<java.lang.Integer,java.lang.String> |
StreamTypeServiceUtil.findLevMatch(java.lang.String propertyName,
EventType eventType) |
Pair<java.lang.Integer,java.lang.String> |
StreamTypesException.getOptionalSuggestion()
Returns the optional suggestion for a matching name.
|
Pair<java.lang.Integer,java.lang.String> |
StreamTypesExceptionSuggestionGen.getSuggestion() |
Constructor and Description |
---|
StreamTypeServiceImpl(java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> namesAndTypes,
java.lang.String engineURI,
boolean isStreamZeroUnambigous,
boolean requireStreamNames)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
java.util.List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTIntervalAffector.getKeyExpressions() |
java.util.List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTBetweenAffector.getKeyExpressions() |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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 streamOrPropertyNameMayEscaped,
boolean obtainFragment) |
protected static Pair<PropertyResolutionDescriptor,java.lang.String> |
ExprIdentNodeUtil.getTypeFromStreamExplicitProperties(StreamTypeService streamTypeService,
java.lang.String unresolvedPropertyName,
java.lang.String streamOrPropertyName,
boolean obtainFragment) |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static java.lang.Boolean |
ExprInstanceofNodeForgeEval.instanceofCacheCheckOrAdd(java.lang.Class[] classes,
java.util.concurrent.CopyOnWriteArrayList<Pair<java.lang.Class,java.lang.Boolean>> resultCache,
java.lang.Object result)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
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.
|
Constructor and Description |
---|
FilterExprAnalyzerAffectorIndexProvision(java.lang.String operationName,
ExprNode[] indexExpressions,
java.util.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(java.lang.String[] indexProps,
java.lang.String[] rangeProps)
Find a matching index for the property names supplied.
|
Modifier and Type | Method and Description |
---|---|
void |
QueryGraph.addCustomIndex(java.lang.String operationName,
ExprNode[] indexExpressions,
java.util.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,
java.util.List<IndexedPropDesc> hashProps,
java.util.List<IndexedPropDesc> btreeProps,
EventAdvancedIndexProvisionDesc advancedIndexProvisionDesc,
java.lang.Iterable<EventBean> prefilledEvents,
EventType indexedType,
java.lang.String indexName,
AgentInstanceContext agentInstanceContext,
java.lang.Object optionalSerde) |
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) |
Modifier and Type | Method and Description |
---|---|
static Pair<ExprTableAccessNode,ExprDotNode> |
ASTTableExprHelper.checkTableNameGetExprForSubproperty(TableService tableService,
java.lang.String tableName,
java.lang.String subproperty) |
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) |
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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() |
Constructor and Description |
---|
CreateExpressionDesc(Pair<ExpressionDeclItem,ExpressionScriptProvided> pair) |
Constructor and Description |
---|
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) |
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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,
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 |
---|---|
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
|
Modifier and Type | Method and Description |
---|---|
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 and Description |
---|
VariableVersionThreadEntry(int version,
java.util.Map<java.lang.Integer,Pair<java.lang.Integer,java.lang.Object>> uncommitted)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
static Pair<EventType[],java.util.Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(ConfigurationEventTypeWithSupertype optionalConfig,
EventUnderlyingType representation,
java.util.Map<java.lang.String,? extends EventType> nameToTypeMap) |
static Pair<EventType[],java.util.Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(java.util.Set<java.lang.String> superTypesSet,
EventUnderlyingType representation,
java.util.Map<java.lang.String,? extends EventType> nameToTypeMap) |
Modifier and Type | Method and Description |
---|---|
java.util.Map<java.lang.String,Pair<EventType,java.lang.String>> |
TaggedCompositeEventType.getTaggedEventTypes()
Returns the event types for each composing event.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Field and Description |
---|---|
protected java.util.Map<java.lang.String,Pair<EventPropertyDescriptor,ObjectArrayEventBeanPropertyWriter>> |
ObjectArrayEventType.propertyWriters |
Modifier and Type | Method and Description |
---|---|
static Pair<net.sf.cglib.reflect.FastConstructor,ExprForge[]> |
InstanceManufacturerUtil.getManufacturer(java.lang.Class targetClass,
EngineImportService engineImportService,
ExprForge[] exprForges,
java.lang.Object[] expressionReturnTypes) |
Modifier and Type | Field and Description |
---|---|
protected java.util.Map<java.lang.String,Pair<EventPropertyDescriptor,MapEventBeanPropertyWriter>> |
MapEventType.propertyWriters |
Modifier and Type | Field and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
java.util.LinkedHashMap<java.lang.String,Pair<EventType,java.lang.String>> |
FilterSpecParamExprNode.getArrayEventTypes() |
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)
|
Modifier and Type | Method and Description |
---|---|
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,
int statementId,
java.lang.String statementName,
java.lang.annotation.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(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,
int statementId,
java.lang.String statementName,
java.lang.annotation.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,
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 and Description |
---|
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,
int statementId,
StreamTypeService streamTypeService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation,
StatementExtensionSvcContext statementExtensionSvcContext) |
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,
int statementId,
StreamTypeService streamTypeService,
EngineImportService engineImportService,
TimeProvider timeProvider,
VariableService variableService,
TableService tableService,
EventAdapterService eventAdapterService,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
java.lang.annotation.Annotation[] annotations,
ContextDescriptor contextDescriptor,
ConfigurationInformation configurationInformation,
StatementExtensionSvcContext statementExtensionSvcContext) |
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,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
ConfigurationInformation configurationInformation,
boolean hasSubquery,
boolean hasTableAccess) |
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,
FilterBooleanExpressionFactory filterBooleanExpressionFactory,
ConfigurationInformation configurationInformation,
boolean hasSubquery,
boolean hasTableAccess) |
Modifier and Type | Method and Description |
---|---|
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.aRegExStateStart(java.util.List<RegexNFAStateEntry> nextStates,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.aRegExStateStart(java.util.List<RegexNFAStateEntry> nextStates,
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.qRegExStateStart(RegexNFAState startState,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
Instrumentation.qRegExStateStart(RegexNFAState startState,
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) |
Constructor and Description |
---|
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) |
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) |
Modifier and Type | Field and Description |
---|---|
protected java.util.HashMap<java.lang.String,Pair<ExprNode,ExprEvaluator>> |
EventRowRegexNFAViewFactory.variableDefinitions |
protected java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> |
EventRowRegexNFAViewFactory.variableStreams |
Modifier and Type | Method and Description |
---|---|
java.util.List<Pair<RowRegexExprNodeAtom,RowRegexExprNode>> |
RowRegexExprNodeVisitorRepeat.getAtoms() |
Modifier and Type | Method and Description |
---|---|
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 java.lang.String |
EventRowRegexNFAViewUtil.printStates(java.util.List<RegexNFAStateEntry> states,
java.util.Map<java.lang.Integer,java.lang.String> streamsVariables,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
protected static RegexNFAStrandResult |
EventRowRegexHelper.recursiveBuildStartStates(RowRegexExprNode parent,
java.util.Map<java.lang.String,Pair<ExprNode,ExprEvaluator>> 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.
|
protected static RegexNFAStrandResult |
EventRowRegexHelper.recursiveBuildStartStates(RowRegexExprNode parent,
java.util.Map<java.lang.String,Pair<ExprNode,ExprEvaluator>> 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 and Description |
---|
RegexNFAStateFilter(java.lang.String nodeNum,
java.lang.String variableName,
int streamNum,
boolean multiple,
Pair<ExprNode,ExprEvaluator> expression,
boolean exprRequiresMultimatchState)
Ctor.
|
Constructor and Description |
---|
RegexPartitionTerminationStateComparator(int[] multimatchStreamNumToVariable,
java.util.LinkedHashMap<java.lang.String,Pair<java.lang.Integer,java.lang.Boolean>> variableStreams) |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static Pair<ExprNode,java.lang.String> |
StatementSelectionUtil.compileValidateStatementFilterExpr(EPServiceProviderSPI engine,
java.lang.String filterExpression) |
static Pair<java.lang.String,java.lang.Boolean> |
JavaClassHelper.isGetArrayType(java.lang.String type) |
Modifier and Type | Method and Description |
---|---|
static java.lang.Object |
SimpleTypeCasterAnyType.simpleTypeCasterCast(java.lang.Object object,
java.lang.Class typeToCastTo,
java.util.concurrent.CopyOnWriteArraySet<Pair<java.lang.Class,java.lang.Boolean>> pairs)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
protected static Pair<Viewable,java.util.List<View>> |
ViewServiceHelper.matchExistingViews(Viewable rootViewable,
java.util.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,
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(int statementId,
FilterSpecCompiled filterSpec,
FilterService filterService,
EPStatementAgentInstanceHandle epStatementAgentInstanceHandle,
boolean isJoin,
AgentInstanceContext agentInstanceContext,
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.
|