Uses of Class
com.espertech.esper.epl.table.mgmt.TableMetadata

Packages that use TableMetadata
com.espertech.esper.core.context.activator Activation of streams for statement start. 
com.espertech.esper.core.context.factory Statement agent instance factories. 
com.espertech.esper.core.context.subselect Subselect implementation. 
com.espertech.esper.core.service Implementation of client package interfaces, glue code 
com.espertech.esper.core.start Classes related to start and stop of statements 
com.espertech.esper.epl.agg.access State multifunction aggregation methods 
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.core.eval Select expression evaluators. 
com.espertech.esper.epl.enummethod.dot Enumeration method utility classes and input data sources. 
com.espertech.esper.epl.expression.core Core expression classes. 
com.espertech.esper.epl.expression.subquery Subselect expressions. 
com.espertech.esper.epl.expression.table Table access and identifiers expressions. 
com.espertech.esper.epl.join.plan Inner join and outer join query planning 
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.merge Table on-merge handlers. 
com.espertech.esper.epl.table.mgmt Table-related services and metadata. 
com.espertech.esper.epl.table.onaction Table on-action handlers. 
com.espertech.esper.epl.table.strategy Table access evaluators. 
com.espertech.esper.epl.table.upd Table update strategies. 
 

Uses of TableMetadata in com.espertech.esper.core.context.activator
 

Constructors in com.espertech.esper.core.context.activator with parameters of type TableMetadata
ViewableActivatorTable(TableMetadata tableMetadata, ExprEvaluator[] optionalTableFilters)
           
 

Uses of TableMetadata in com.espertech.esper.core.context.factory
 

Constructors in com.espertech.esper.core.context.factory with parameters of type TableMetadata
StatementAgentInstanceFactoryCreateTable(TableMetadata tableMetadata)
           
StatementAgentInstanceFactoryOnTriggerTable(StatementContext statementContext, StatementSpecCompiled statementSpec, EPServicesContext services, ViewableActivator activator, SubSelectStrategyCollection subSelectStrategyCollection, ResultSetProcessorFactoryDesc resultSetProcessorPrototype, ExprNode validatedJoin, TableOnViewFactory onExprFactory, EventType activatorResultEventType, TableMetadata tableMetadata, ResultSetProcessorFactoryDesc outputResultSetProcessorPrototype, OutputProcessViewFactory outputProcessViewFactory)
           
 

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

Constructors in com.espertech.esper.core.context.subselect with parameters of type TableMetadata
SubSelectStrategyFactoryIndexShare(java.lang.String statementName, java.lang.String statementId, int subqueryNum, EventType[] outerEventTypesSelect, NamedWindowProcessor optionalNamedWindowProcessor, TableMetadata optionalTableMetadata, boolean fullTableScan, IndexHint optionalIndexHint, SubordPropPlan joinedPropPlan, ExprEvaluator filterExprEval, AggregationServiceFactoryDesc aggregationServiceFactory, ExprEvaluator[] groupByKeys, TableService tableService, java.lang.annotation.Annotation[] annotations, StatementStopService statementStopService)
           
 

Uses of TableMetadata in com.espertech.esper.core.service
 

Methods in com.espertech.esper.core.service that return TableMetadata
 TableMetadata[] StreamJoinAnalysisResult.getTablesPerStream()
           
 

Methods in com.espertech.esper.core.service with parameters of type TableMetadata
 void StreamJoinAnalysisResult.setTablesForStream(int streamNum, TableMetadata metadata)
           
 

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

Methods in com.espertech.esper.core.start that return TableMetadata
 TableMetadata FireAndForgetProcessorTable.getTableMetadata()
           
 

Constructors in com.espertech.esper.core.start with parameters of type TableMetadata
EPStatementDestroyCallbackTableIdxRef(TableService tableService, TableMetadata tableMetadata, java.lang.String statementName)
           
EPStatementDestroyCallbackTableUpdStr(TableService tableService, TableMetadata tableMetadata, java.lang.String statementName)
           
FireAndForgetProcessorTable(TableService tableService, TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.agg.access
 

Constructors in com.espertech.esper.epl.agg.access with parameters of type TableMetadata
AggregationAccessorMinMaxByTable(boolean max, TableMetadata tableMetadata)
           
AggregationAccessorSortedTable(boolean max, java.lang.Class componentType, TableMetadata tableMetadata)
           
 

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

Fields in com.espertech.esper.epl.agg.service declared as TableMetadata
protected  TableMetadata AggSvcGroupByWTableBase.tableMetadata
           
 

Methods in com.espertech.esper.epl.agg.service with parameters of type TableMetadata
 AggregationServiceFactory AggregationServiceFactoryServiceImpl.getGroupWBinding(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessorPairs, boolean join, IntoTableSpec bindings, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
 AggregationServiceFactory AggregationServiceFactoryService.getGroupWBinding(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessorPairs, boolean join, IntoTableSpec bindings, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
 

Constructors in com.espertech.esper.epl.agg.service with parameters of type TableMetadata
AggSvcGroupByWTableBase(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
AggSvcGroupByWTableFactory(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
AggSvcGroupByWTableImpl(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
AggSvcGroupByWTableRollupMultiKeyImpl(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents, AggregationGroupByRollupDesc groupByRollupDesc)
           
AggSvcGroupByWTableRollupSingleKeyImpl(TableMetadata tableMetadata, TableColumnMethodPair[] methodPairs, AggregationAccessorSlotPair[] accessors, boolean join, TableStateInstanceGroupBy tableStateInstance, int[] targetStates, ExprNode[] accessStateExpr, AggregationAgent[] agents)
           
 

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

Constructors in com.espertech.esper.epl.core with parameters of type TableMetadata
BindProcessorEvaluatorStreamTable(int streamNum, java.lang.Class returnType, TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.core.eval
 

Constructors in com.espertech.esper.epl.core.eval with parameters of type TableMetadata
EvalSelectStreamWUnderlying(SelectExprContext selectExprContext, EventType resultEventType, java.util.List<SelectClauseStreamCompiledSpec> namedStreams, boolean usingWildcard, java.util.List<SelectExprStreamDesc> unnamedStreams, boolean singleStreamWrapper, boolean underlyingIsFragmentEvent, int underlyingStreamNumber, EventPropertyGetter underlyingPropertyEventGetter, ExprEvaluator underlyingExprEvaluator, TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.enummethod.dot
 

Constructors in com.espertech.esper.epl.enummethod.dot with parameters of type TableMetadata
ExprDotEvalUnpackBeanTable(EventType lambdaType, TableMetadata tableMetadata)
           
ExprDotEvalUnpackCollEventBeanTable(EventType type, TableMetadata tableMetadata)
           
 

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

Methods in com.espertech.esper.epl.expression.core with parameters of type TableMetadata
static ExprEvaluator ExprNodeUtility.makeUnderlyingEvaluator(int streamNum, java.lang.Class resultType, TableMetadata tableMetadata)
           
 

Constructors in com.espertech.esper.epl.expression.core with parameters of type TableMetadata
ExprNodeUtilExprEvalStreamNumEventTable(int streamNum, TableMetadata tableMetadata)
           
ExprNodeUtilUnderlyingEvaluatorTable(int streamNum, java.lang.Class resultType, TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.expression.subquery
 

Constructors in com.espertech.esper.epl.expression.subquery with parameters of type TableMetadata
ExprSubselectRowEvalStrategyFilteredUnselectedTable(TableMetadata tableMetadata)
           
ExprSubselectRowEvalStrategyUnfilteredUnselectedTable(TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.expression.table
 

Methods in com.espertech.esper.epl.expression.table with parameters of type TableMetadata
protected  void ExprTableAccessNodeTopLevel.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNodeSubpropAccessor.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNodeSubprop.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNodeKeys.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected abstract  void ExprTableAccessNode.validateBindingInternal(ExprValidationContext validationContext, TableMetadata tableMetadata)
           
protected  void ExprTableAccessNode.validateGroupKeys(TableMetadata metadata)
           
protected  TableMetadataColumn ExprTableAccessNode.validateSubpropertyGetCol(TableMetadata tableMetadata, java.lang.String subpropName)
           
 

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

Methods in com.espertech.esper.epl.join.plan with parameters of type TableMetadata
static QueryPlan TwoStreamQueryPlanBuilder.build(EventType[] typesPerStream, QueryGraph queryGraph, OuterJoinType optionalOuterJoinType, java.lang.String[][][] uniqueIndexProps, TableMetadata[] tablesPerStream)
          Build query plan.
protected static QueryPlan NStreamQueryPlanBuilder.build(QueryGraph queryGraph, EventType[] typesPerStream, HistoricalViewableDesc historicalViewableDesc, DependencyGraph dependencyGraph, HistoricalStreamIndexList[] historicalStreamIndexLists, boolean hasForceNestedIter, java.lang.String[][][] indexedStreamsUniqueProps, TableMetadata[] tablesPerStream)
          Build a query plan based on the stream property relationships indicated in queryGraph.
protected static QueryPlan NStreamOuterQueryPlanBuilder.build(QueryGraph queryGraph, OuterJoinDesc[] outerJoinDescList, java.lang.String[] streamNames, EventType[] typesPerStream, HistoricalViewableDesc historicalViewableDesc, DependencyGraph dependencyGraph, HistoricalStreamIndexList[] historicalStreamIndexLists, ExprEvaluatorContext exprEvaluatorContext, java.lang.String[][][] indexedStreamsUniqueProps, TableMetadata[] tablesPerStream)
          Build a query plan based on the stream property relationships indicated in queryGraph.
static TableLookupPlan NStreamQueryPlanBuilder.createLookupPlan(QueryGraph queryGraph, int currentLookupStream, int indexedStream, QueryPlanIndex indexSpecs, EventType[] typesPerStream, TableMetadata indexedStreamTableMeta)
          Create the table lookup plan for a from-stream to look up in an indexed stream using the columns supplied in the query graph and looking at the actual indexes available and their index number.
protected static QueryPlanNode NStreamQueryPlanBuilder.createStreamPlan(int lookupStream, int[] bestChain, QueryGraph queryGraph, QueryPlanIndex[] indexSpecsPerStream, EventType[] typesPerStream, boolean[] isHistorical, HistoricalStreamIndexList[] historicalStreamIndexLists, TableMetadata[] tablesPerStream)
          Walks the chain of lookups and constructs lookup strategy and plan specification based on the index specifications.
 

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

Methods in com.espertech.esper.epl.spec that return TableMetadata
 TableMetadata SelectClauseStreamCompiledSpec.getTableMetadata()
           
 

Methods in com.espertech.esper.epl.spec with parameters of type TableMetadata
 void SelectClauseStreamCompiledSpec.setTableMetadata(TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.table.merge
 

Constructors in com.espertech.esper.epl.table.merge with parameters of type TableMetadata
TableOnMergeHelper(StatementContext statementContext, OnTriggerMergeDesc onTriggerDesc, EventType triggeringEventType, java.lang.String triggeringStreamName, InternalEventRouter internalEventRouter, TableMetadata tableMetadata)
           
 

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

Fields in com.espertech.esper.epl.table.mgmt declared as TableMetadata
protected  TableMetadata TableStateInstance.tableMetadata
           
 

Methods in com.espertech.esper.epl.table.mgmt that return TableMetadata
 TableMetadata TableServiceImpl.addTable(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory tableStateRowFactory, int numberMethodAggregations, StatementContext statementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 TableMetadata TableService.addTable(java.lang.String tableName, java.lang.String eplExpression, java.lang.String statementName, java.lang.Class[] keyTypes, java.util.Map<java.lang.String,TableMetadataColumn> tableColumns, TableStateRowFactory tableStateRowFactory, int numberMethodAggregations, StatementContext statementContext, ObjectArrayEventType internalEventType, ObjectArrayEventType publicEventType, TableMetadataInternalEventToPublic eventToPublic, boolean queryPlanLogging)
           
 TableMetadata TableStateInstance.getTableMetadata()
           
 TableMetadata TableServiceImpl.getTableMetadata(java.lang.String tableName)
           
 TableMetadata TableService.getTableMetadata(java.lang.String tableName)
           
 TableMetadata TableServiceImpl.getTableMetadataFromEventType(EventType type)
           
 TableMetadata TableService.getTableMetadataFromEventType(EventType type)
           
 

Methods in com.espertech.esper.epl.table.mgmt with parameters of type TableMetadata
 void TableServiceImpl.addTableUpdateStrategyReceiver(TableMetadata tableMetadata, java.lang.String statementName, TableUpdateStrategyReceiver receiver, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 void TableService.addTableUpdateStrategyReceiver(TableMetadata tableMetadata, java.lang.String statementName, TableUpdateStrategyReceiver receiver, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 TableUpdateStrategy TableServiceImpl.getTableUpdateStrategy(TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 TableUpdateStrategy TableService.getTableUpdateStrategy(TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 void TableServiceImpl.removeIndexReferencesStmtMayRemoveIndex(java.lang.String statementName, TableMetadata tableMetadata)
           
 void TableService.removeIndexReferencesStmtMayRemoveIndex(java.lang.String statementName, TableMetadata tableMetadata)
           
 void TableServiceImpl.removeTableUpdateStrategyReceivers(TableMetadata tableMetadata, java.lang.String statementName)
           
 void TableService.removeTableUpdateStrategyReceivers(TableMetadata tableMetadata, java.lang.String statementName)
           
 void TableServiceImpl.validateAddIndex(java.lang.String createIndexStatementName, TableMetadata tableMetadata, java.lang.String indexName, IndexMultiKey imk)
           
 void TableService.validateAddIndex(java.lang.String createIndexStatementName, TableMetadata tableMetadata, java.lang.String indexName, IndexMultiKey imk)
           
 

Constructors in com.espertech.esper.epl.table.mgmt with parameters of type TableMetadata
TableStateInstance(TableMetadata tableMetadata, AgentInstanceContext agentInstanceContext)
           
TableStateInstanceGroupBy(TableMetadata tableMetadata, AgentInstanceContext agentInstanceContext)
           
TableStateInstanceUngrouped(TableMetadata tableMetadata, AgentInstanceContext agentInstanceContext)
           
TableStateViewableInternal(TableMetadata tableMetadata, TableStateInstance tableStateInstance, ExprEvaluator[] optionalTableFilters)
           
TableStateViewablePublic(TableMetadata tableMetadata, TableStateInstance tableStateInstance)
           
 

Uses of TableMetadata in com.espertech.esper.epl.table.onaction
 

Fields in com.espertech.esper.epl.table.onaction declared as TableMetadata
protected  TableMetadata TableOnViewBase.metadata
           
 

Methods in com.espertech.esper.epl.table.onaction that return TableMetadata
 TableMetadata TableOnUpdateViewFactory.getTableMetadata()
           
 TableMetadata TableOnMergeViewFactory.getTableMetadata()
           
 TableMetadata TableOnDeleteViewFactory.getTableMetadata()
           
 

Methods in com.espertech.esper.epl.table.onaction with parameters of type TableMetadata
static TableOnViewFactory TableOnViewFactoryFactory.make(TableMetadata tableMetadata, OnTriggerDesc onTriggerDesc, EventType filterEventType, java.lang.String filterStreamName, StatementContext statementContext, StatementMetricHandle metricsHandle, boolean isDistinct, InternalEventRouter internalEventRouter)
           
static EventBean[] TableOnViewUtil.toPublic(EventBean[] matching, TableMetadata tableMetadata, EventBean[] triggers, boolean isNewData, ExprEvaluatorContext context)
           
 

Constructors in com.espertech.esper.epl.table.onaction with parameters of type TableMetadata
TableOnDeleteView(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance rootView, ExprEvaluatorContext exprEvaluatorContext, TableMetadata metadata, TableOnDeleteViewFactory parent)
           
TableOnDeleteViewFactory(StatementResultService statementResultService, TableMetadata tableMetadata)
           
TableOnMergeView(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance rootView, ExprEvaluatorContext exprEvaluatorContext, TableMetadata metadata, TableOnMergeViewFactory parent)
           
TableOnMergeViewChangeHandler(TableMetadata tableMetadata)
           
TableOnMergeViewFactory(TableMetadata tableMetadata, TableOnMergeHelper onMergeHelper, StatementResultService statementResultService, StatementMetricHandle metricsHandle, MetricReportingServiceSPI metricReportingService)
           
TableOnSelectView(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance rootView, ExprEvaluatorContext exprEvaluatorContext, TableMetadata metadata, TableOnSelectViewFactory parent, ResultSetProcessor resultSetProcessor, boolean audit, boolean deleteAndSelect)
           
TableOnSelectViewFactory(TableMetadata tableMetadata, InternalEventRouter internalEventRouter, EPStatementHandle statementHandle, EventBeanReader eventBeanReader, boolean distinct, StatementResultService statementResultService, InternalEventRouteDest internalEventRouteDest, boolean deleteAndSelect)
           
TableOnUpdateView(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance rootView, ExprEvaluatorContext exprEvaluatorContext, TableMetadata metadata, TableOnUpdateViewFactory parent)
           
TableOnUpdateViewFactory(StatementResultService statementResultService, TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, TableUpdateStrategy tableUpdateStrategy)
           
TableOnViewBase(SubordWMatchExprLookupStrategy lookupStrategy, TableStateInstance tableStateInstance, ExprEvaluatorContext exprEvaluatorContext, TableMetadata metadata, boolean acquireWriteLock)
           
 

Uses of TableMetadata in com.espertech.esper.epl.table.strategy
 

Methods in com.espertech.esper.epl.table.strategy with parameters of type TableMetadata
static ExprTableAccessEvalStrategy ExprTableEvalStrategyFactory.getTableAccessEvalStrategy(boolean writesToTables, ExprTableAccessNode tableNode, TableStateInstance state, TableMetadata tableMetadata)
           
 

Uses of TableMetadata in com.espertech.esper.epl.table.upd
 

Methods in com.espertech.esper.epl.table.upd with parameters of type TableMetadata
static TableUpdateStrategy TableUpdateStrategyFactory.validateGetTableUpdateStrategy(TableMetadata tableMetadata, EventBeanUpdateHelper updateHelper, boolean isOnMerge)
           
 


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