Packages

abstract class PropertyStore extends AnyRef

A property store manages the execution of computations of properties related to concrete entities as well as artificial entities (for example, methods, fields and classes of a program, but, for another example, also the call graph or the project as such). These computations may require and provide information about other entities of the store and the property store implements the logic to handle the computations related to the dependencies between the entities. Furthermore, the property store may parallelize the computation of the properties as far as possible without requiring users to take care of it; users are also generally not required to think about the concurrency when implementing an analysis as long as the properties only use immutable data-structures and the analyses only use immutable data structures when interacting the property store. The most basic concepts are also described in the SOAP paper: "Lattice Based Modularization of Static Analyses" (https://conf.researchr.org/event/issta-2018/soap-2018-papers-lattice-based-modularization-of-static-analyses)

Usage

The correct strategy, when using the PropertyStore, is to always continue computing the property of an entity and to collect the dependencies on those elements that are (still) relevant. I.e., if some information is not or just not completely available, the analysis should still continue using the provided information and (internally) record the dependency, by storing the returned property extension. Later on, when the analysis has computed its (interim) result, it reports the same and informs the framework about its dependencies. Based on the later the framework will call back the analysis when a dependency is updated. In general, an analysis should always try to minimize the number of dependencies to the minimum set to enable the property store to suspend computations that are no longer required.

Core Requirements on Property Computation Functions (Modular Static Analyses)

The following requirements ensure correctness and determinism of the result.

  • At Most One Lazy Function per Property Kind A specific kind of property is always computed by only one registered lazy PropertyComputation function. No other analysis is (conceptually) allowed to derive a value for an E/PK pairing for which a lazy function is registered. It is also not allowed to schedule a computation eagerly if a lazy computation is also registered.
  • Thread-Safe PropertyComputation functions If a single instance of a property computation function (which is the standard case) is scheduled for computing the properties of multiple entities, that function has to be thread safe. I.e., the function may be executed concurrently for different entities. The OnUpdateContinuation functions are, however, executed sequentially w.r.t. one E/PK pair. This model generally does not require that users have to think about concurrent issues as long as the initial function is actually a pure function, which is usually a non-issue.
  • Non-Overlapping Results PropertyComputation functions that are invoked on different entities have to compute result sets that are disjoint unless a PartialResult is used. For example, an analysis that performs a computation on class files and that derives properties of a specific kind related to a class file's methods must ensure that two concurrent calls of the same analysis - running concurrently on two different class files - do not derive information about the same method. If results for a specific entity are collaboratively computed, then a PartialResult has to be used.
  • If some partial result potentially contributes to the property of an entity, the first partial result has to set the property to the default (typically "most precise") value.
  • Monoton a function which computes a property has to be monotonic.
Cyclic Dependencies

In general, it may happen that some analyses are mutually dependent and therefore no final value is directly computed. In this case the current extension (the most precise result) of the properties are committed as the final values when the phase end. If the analyses only computed a lower bound that one will be used.

Thread Safety

The sequential property store is not thread-safe; the parallelized implementation enables limited concurrent access:

Common Abbreviations

  • e = Entity
  • p = Property
  • pk = Property Key
  • pc = Property Computation
  • lpc = Lazy Property Computation
  • c = Continuation (The part of the analysis that factors in all properties of dependees)
  • EPK = Entity and a PropertyKey
  • EPS = Entity, Property and the State (final or intermediate)
  • EP = Entity and some (final or intermediate) Property
  • EOptionP = Entity and either a PropertyKey or (if available) a Property
  • ps = Property Store

Exceptions

In general, exceptions are only thrown if debugging is turned on due to the costs of checking for the respective violations. That is, if debugging is turned off, many potential errors leading to "incomprehensible" results will not be reported. Hence, after debugging an analysis turn debugging (and assertions!) off to get the best performance.

We will throw IllegalArgumentException's iff a parameter is in itself invalid. E.g., the lower bound is above the upper bound. In all other cases IllegalStateExceptions are thrown. All exceptions are either thrown immediately or eventually, when PropertyStore#waitOnPhaseCompletion is called. In the latter case, the exceptions are accumulated in the first thrown exception using suppressed exceptions.

Source
PropertyStore.scala
Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. PropertyStore
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new PropertyStore()

Abstract Value Members

  1. abstract def MaxEvaluationDepth: Int
  2. abstract val ctx: Map[Class[_], AnyRef]

    Immutable map which stores the context objects given at initialization time.

  3. abstract def doApply[E <: Entity, P <: Property](epk: EPK[E, P], e: E, pkId: Int): EOptionP[E, P]
    Attributes
    protected[this]
  4. abstract def doPreInitialize[E <: Entity, P <: Property](e: E, pk: PropertyKey[P])(pc: (EOptionP[E, P]) => InterimEP[E, P]): Unit
    Attributes
    protected[this]
  5. abstract def doRegisterTriggeredComputation[E <: Entity, P <: Property](pk: PropertyKey[P], pc: PropertyComputation[E]): Unit
    Attributes
    protected[this]
  6. abstract def doScheduleEagerComputationForEntity[E <: Entity](e: E)(pc: PropertyComputation[E]): Unit
    Attributes
    protected[this]
  7. abstract def doSet(e: Entity, p: Property): Unit
    Attributes
    protected[this]
  8. abstract def entities(propertyFilter: (SomeEPS) => Boolean): Iterator[Entity]

    The set of all entities which have an entity property state that passes the given filter.

    The set of all entities which have an entity property state that passes the given filter.

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  9. abstract def entities[P <: Property](lb: P, ub: P): Iterator[Entity]

    Returns all entities that currently have the given property bounds based on an "==" (equals) comparison.

    Returns all entities that currently have the given property bounds based on an "==" (equals) comparison. (In case of final properties the bounds are equal.) If some analysis only computes an upper or a lower bound and no final results exists, that entity will be ignored.

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  10. abstract def entities[P <: Property](pk: PropertyKey[P]): Iterator[EPS[Entity, P]]

    Returns all entities which have a property of the respective kind.

    Returns all entities which have a property of the respective kind. The result is undefined if this method is called while the property store still performs (concurrent) computations.

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  11. abstract def entitiesWithLB[P <: Property](lb: P): Iterator[Entity]

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  12. abstract def entitiesWithUB[P <: Property](ub: P): Iterator[Entity]

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  13. abstract def execute(f: => Unit): Unit

    Executes the given function at some point between now and the return of a subsequent call of waitOnPhaseCompletion.

  14. abstract def fallbacksUsedForComputedPropertiesCount: Int

    The number of times a fallback property was computed for an entity though an (eager) analysis was actually scheduled.

  15. abstract def force[E <: Entity, P <: Property](e: E, pk: PropertyKey[P]): Unit

    Enforce the evaluation of the specified property kind for the given entity, even if the property is computed lazily and no "eager computation" requires the results (anymore).

    Enforce the evaluation of the specified property kind for the given entity, even if the property is computed lazily and no "eager computation" requires the results (anymore). Using force is in particular necessary in cases where a specific analysis should be scheduled lazily because the computed information is not necessary for all entities, but strictly required for some elements. E.g., if you want to compute a property for some piece of code, but not for those elements of the used library that are strictly necessary. For example, if we want to compute the purity of the methods of a specific application, we may have to compute the property for some entities of the libraries, but we don't want to compute them for all.

    Note

    Triggers lazy evaluations.

  16. abstract def get[E <: Entity, P <: Property](epk: EPK[E, P]): Option[EOptionP[E, P]]

    Returns the property of the respective property kind pk currently associated with the given element e.

    Returns the property of the respective property kind pk currently associated with the given element e. Does not trigger any computations.

  17. abstract def get[E <: Entity, P <: Property](e: E, pk: PropertyKey[P]): Option[EOptionP[E, P]]

    See also

    get(epk:EPK) for details.

  18. abstract def handleResult(r: PropertyComputationResult): Unit

    Processes the result eventually; generally, not directly called by analyses.

    Processes the result eventually; generally, not directly called by analyses. If this function is directly called, the caller has to ensure that we don't have overlapping results and that the given result is a meaningful update of the previous property associated with the respective entity - if any!

    Exceptions thrown

    IllegalStateException If the result cannot be applied.

    Note

    If any computation resulted in an exception, then handleResult will fail and the exception related to the failing computation will be thrown again.

  19. abstract def hasProperty(e: Entity, pk: PropertyKind): Boolean

    See hasProperty(SomeEPK) for details.

    See hasProperty(SomeEPK) for details. *

  20. abstract def isIdle: Boolean

    Returns true if the store does not perform any computations at the time of this method call.

    Returns true if the store does not perform any computations at the time of this method call.

    This method is only intended to support bug detection.

  21. abstract def isKnown(e: Entity): Boolean

    Returns true if the given entity is known to the property store.

    Returns true if the given entity is known to the property store. Here, isKnown can mean

    • that we actually have a property, or
    • a computation is scheduled/running to compute some property, or
    • an analysis has a dependency on some (not yet finally computed) property, or
    • that the store just eagerly created the data structures necessary to associate properties with the entity because the entity was queried.
  22. implicit abstract val logContext: LogContext
  23. abstract def properties[E <: Entity](e: E): Iterator[EPS[E, Property]]

    Returns an iterator of the different properties associated with the given entity.

    Returns an iterator of the different properties associated with the given entity.

    This method is the preferred way to get a snapshot of all properties of an entity and should be used if you know that all properties are already computed.

    e

    An entity stored in the property store.

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  24. abstract def quiescenceCount: Int

    The number of times the property store reached quiescence.

  25. abstract def scheduledOnUpdateComputationsCount: Int

    The number of (OnUpdateContinuations) that were executed in response to an updated property.

  26. abstract def scheduledTasksCount: Int

    Simple counter of the number of tasks that were executed to perform an initial computation of a property for some entity.

  27. abstract def shutdown(): Unit

    Should be called when a PropertyStore is no longer going to be used to schedule computations.

    Should be called when a PropertyStore is no longer going to be used to schedule computations.

    Properties can still be queried after shutdown.

  28. abstract def toString(printProperties: Boolean): String

    Returns a consistent snapshot of the stored properties.

    Returns a consistent snapshot of the stored properties.

    printProperties

    If true prints the properties of all entities.

    Note

    Some computations may still be running.

  29. abstract def waitOnPhaseCompletion(): Unit

    Awaits the completion of all property computations which were previously scheduled.

    Awaits the completion of all property computations which were previously scheduled. As soon as all initial computations have finished, dependencies on E/P pairs for which no value was computed, will be identified and the fallback value will be used. After that, the remaining intermediate values will be made final.

    Note

    If a computation fails with an exception, the property store will stop in due time and return the thrown exception. No strong guarantees are given which exception is returned in case of concurrent execution with multiple exceptions.

    ,

    In case of an exception, the analyses are aborted as fast as possible and the store is no longer usable.

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def alreadyComputedPropertyKindIds: IntIterator
  5. def apply[E <: Entity, P <: Property](epk: EPK[E, P]): EOptionP[E, P]

    Returns the property of the respective property kind pk currently associated with the given element e.

    Returns the property of the respective property kind pk currently associated with the given element e.

    This is the most basic method to get some property and it is the preferred way if (a) you know that the property is already available – e.g., because some property computation function was strictly run before the current one – or if (b) the property is computed using a lazy property computation - or if (c) it may be possible to compute a final answer even if the property of the entity is not yet available.

    epk

    An entity/property key pair.

    returns

    EPK(e,pk) if information about the respective property is not (yet) available. Final|InterimP(e,Property) otherwise.

    Exceptions thrown

    IllegalStateException If setup phase was not called or a previous computation result contained an epk which was not queried. (Both state are ALWAYS illegal, but are only explicitly checked for if debug is turned on!)

    Note

    In general, the returned value may change over time but only such that it is strictly more precise.

    ,

    Querying a property may trigger the (lazy) computation of the property.

    ,

    setupPhase has to be called before calling apply!

    ,

    After all computations has finished one of the "pure" query methods (e.g., entities or get should be used.)

  6. final def apply[E <: Entity, P <: Property](e: E, pk: PropertyKey[P]): EOptionP[E, P]

    See also

    apply(epk:EPK) for details.

  7. final def apply[E <: Entity, P <: Property](es: Iterable[E], pmi: PropertyMetaInformation { type Self <: P }): Iterable[EOptionP[E, P]]

    Returns a snapshot of the properties with the given kind associated with the given entities.

    Returns a snapshot of the properties with the given kind associated with the given entities.

    Note

    Querying the properties of the given entities will trigger lazy computations.

    ,

    The returned collection can be used to create an InterimResult.

    See also

    apply(epk:EPK) for details.

  8. final def apply[E <: Entity, P <: Property](es: Iterable[E], pk: PropertyKey[P]): Iterable[EOptionP[E, P]]

    Returns a snapshot of the properties with the given kind associated with the given entities.

    Returns a snapshot of the properties with the given kind associated with the given entities.

    Note

    Querying the properties of the given entities will trigger lazy computations.

    ,

    The returned collection can be used to create an InterimResult.

    See also

    apply(epk:EPK) for details.

  9. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  10. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native() @IntrinsicCandidate()
  11. def collectAndThrowException(t: Throwable): Nothing
    Attributes
    protected[fpcf]
    Annotations
    @inline()
  12. def collectException(t: Throwable): Unit
    Attributes
    protected[fpcf]
  13. def computeFallback[E <: Entity, P <: Property](e: E, pkId: Int): FinalEP[E, P]
    Attributes
    protected[this]
  14. final def context[T](key: Class[T]): T

    Looks up the context object of the given type.

    Looks up the context object of the given type. This is a comparatively expensive operation; the result should be cached.

  15. final val debug: Boolean

    If "debug" is true and we have an update related to an ordered property, we will then check if the update is correct!

  16. var doTerminate: Boolean

    If set to true no new computations will be scheduled and running computations will be terminated.

    If set to true no new computations will be scheduled and running computations will be terminated. Afterwards, the store can be queried, but no new computations can be started.

  17. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  18. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  19. var exception: Throwable
    Attributes
    protected[this]
  20. def finalEntities[P <: Property](p: P): Iterator[Entity]

    Returns all final entities with the given property.

    Returns all final entities with the given property.

    Note

    Only to be called when the store is quiescent.

    ,

    Does not trigger lazy property computations.

  21. final def getAndClearInformation[T <: AnyRef](key: AnyRef): Option[T]

    Returns the information stored in the store and removes the key, if any.

    Returns the information stored in the store and removes the key, if any.

    This method is thread-safe. However, the client which adds information to the store has to ensure that the overall process of adding/querying/removing is well defined and the ordered is ensured.

  22. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @IntrinsicCandidate()
  23. final def getInformation[T <: AnyRef](key: AnyRef): Option[T]

    Returns the information stored in the store, if any.

    Returns the information stored in the store, if any.

    This method is thread-safe. However, the client which adds information to the store has to ensure that the overall process of adding/querying/removing is well defined and the ordered is ensured.

  24. final def getOrCreateInformation[T <: AnyRef](key: AnyRef, f: => T): T

    Attaches or returns some information associated with the property store using a key object.

    Attaches or returns some information associated with the property store using a key object.

    This method is thread-safe. However, the client which adds information to the store has to ensure that the overall process of adding/querying/removing is well defined and the ordered is ensured.

  25. def handleExceptions[U](f: => U): U
    Annotations
    @inline()
  26. final def hasProperty(epk: SomeEPK): Boolean

    Tests if we have some (lb, ub or final) property for the entity with the respective kind.

    Tests if we have some (lb, ub or final) property for the entity with the respective kind. If hasProperty returns true a subsequent apply will return an EPS (not an EPK).

  27. final val hasSuppressedDependers: Array[Boolean]

    true if entities with a specific property kind (EP) may have dependers with suppressed notifications.

    true if entities with a specific property kind (EP) may have dependers with suppressed notifications. (I.e., suppressInteriumUpdates("depender")("EP") is true.)

    Attributes
    protected[this]
  28. var hasSuppressedNotifications: Boolean
    Attributes
    protected[this]
  29. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @IntrinsicCandidate()
  30. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  31. final val lazyComputations: Array[SomeProperPropertyComputation]

    The set of computations that will only be scheduled if the result is required.

    The set of computations that will only be scheduled if the result is required.

    Attributes
    protected[this]
  32. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  33. def newPhaseInitialized(propertyKindsComputedInThisPhase: Set[PropertyKind], propertyKindsComputedInLaterPhase: Set[PropertyKind], suppressInterimUpdates: Map[PropertyKind, Set[PropertyKind]], finalizationOrder: List[List[PropertyKind]]): Unit

    Called when a new phase was initialized.

    Called when a new phase was initialized. Intended to be overridden by subclasses if special handling is required.

    Attributes
    protected[this]
  34. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @IntrinsicCandidate()
  35. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @IntrinsicCandidate()
  36. def onFirstException(t: Throwable): Unit

    Called when the first top-level exception occurs.

    Called when the first top-level exception occurs. Intended to be overridden by subclasses.

    Attributes
    protected[this]
  37. final def preInitialize[E <: Entity, P <: Property](e: E, pk: PropertyKey[P])(pc: (EOptionP[E, P]) => InterimEP[E, P]): Unit

    Associates the given entity with the newly computed intermediate property P.

    Associates the given entity with the newly computed intermediate property P.

    Calling this method is only supported before any analysis is scheduled!

    pc

    A function which is given the current property of kind pk associated with e and which has to compute the new intermediate property p.

  38. final val propertyKindsComputedInEarlierPhase: Array[Boolean]

    If a property is queried for which we have no value, then this information is used to determine which kind of fallback is required.

    If a property is queried for which we have no value, then this information is used to determine which kind of fallback is required.

    Attributes
    protected[this]
  39. final val propertyKindsComputedInLaterPhase: Array[Boolean]

    Used to identify situations where a property is queried, which is only going to be computed in the future - in this case, the specification of an analysis is broken!

    Used to identify situations where a property is queried, which is only going to be computed in the future - in this case, the specification of an analysis is broken!

    Attributes
    protected[this]
  40. final val propertyKindsComputedInThisPhase: Array[Boolean]
    Attributes
    protected[this]
  41. final def registerLazyPropertyComputation[E <: Entity, P <: Property](pk: PropertyKey[P], pc: ProperPropertyComputation[E]): Unit

    Registers a function that lazily computes a property for an element of the store if the property of the respective kind is requested.

    Registers a function that lazily computes a property for an element of the store if the property of the respective kind is requested. Hence, a first request of such a property will always first return no result.

    The computation is triggered by a(n in)direct call of this store's apply method.

    This store ensures that the property computation function pc is never invoked more than once for the same element at the same time. If pc is invoked again for a specific element then only because a dependee has changed!

    In general, the result can't be an IncrementalResult, a PartialResult or a NoResult.

    A lazy computation must never return a NoResult; if the entity cannot be processed an exception has to be thrown or the bottom value – if defined – has to be returned.

    Calling registerLazyPropertyComputation is only supported as long as the store is not queried and no computations are already running. In general, this requires that lazy property computations are scheduled before any eager analysis that potentially reads the value.

  42. final def registerTransformer[SourceP <: Property, TargetP <: Property, E <: Entity](sourcePK: PropertyKey[SourceP], targetPK: PropertyKey[TargetP])(pc: (E, SourceP) => FinalEP[E, TargetP]): Unit

    Registers a total function that takes a given final property and computes a new final property of a different kind; the function must not query the property store.

    Registers a total function that takes a given final property and computes a new final property of a different kind; the function must not query the property store. Furthermore, setupPhase must specify that notifications about interim updates have to be suppressed. A transformer is conceptually a special kind of lazy analysis.

  43. final def registerTriggeredComputation[E <: Entity, P <: Property](pk: PropertyKey[P], pc: PropertyComputation[E]): Unit

    Registers a property computation that is eagerly triggered when a property of the given kind is derived for some entity for the first time.

    Registers a property computation that is eagerly triggered when a property of the given kind is derived for some entity for the first time. Note, that the property computation function – as usual – has to be thread safe (only on-update continuation functions are guaranteed to be executed sequentially per E/PK pair). The primary use case is to kick-start the computation of some e/pk as soon as an entity "becomes relevant".

    In general, it also possible to have a standard analysis that just queries the properties of the respective entities and which maintains the list of dependees. However, if the list of dependees becomes larger and (at least initially) encompasses a significant fraction or even all entities of a specific kind, the overhead that is generated in the framework becomes very huge. In this case, it is way more efficient to register a triggered computation.

    For example, if you want to do some processing (kick-start further computations) related to methods that are reached, it is more efficient to register a property computation that is triggered when a method's Caller property is set. Please note, that the property computation is allowed to query and depend on the property that initially kicked-off the computation in the first place. Querying the property store may in particular be required to identify the reason why the property was set. For example, if the Caller property was set to the fallback due to a depending computation, it may be necessary to distinguish between the case "no callers" and "unknown callers"; in case of the final property "no callers" the result may very well be NoResult.

    pk

    The property key.

    pc

    The computation that is (potentially concurrently) called to kick-start a computation related to the given entity.

    Note

    A computation is guaranteed to be triggered exactly once for every e/pk pair that has a concrete property - even if the value was already associated with the e/pk pair before the registration is done.

  44. final def scheduleEagerComputationForEntity[E <: Entity](e: E)(pc: PropertyComputation[E]): Unit

    Schedules the execution of the given PropertyComputation function for the given entity.

    Schedules the execution of the given PropertyComputation function for the given entity. This is of particular interest to start an incremental computation (cf. IncrementalResult) which, e.g., processes the class hierarchy in a top-down manner.

    Note

    It is NOT possible to use scheduleEagerComputationForEntity for properties which are also computed by a lazy property computation; use force instead!

    ,

    If any computation resulted in an exception, then the scheduling will fail and the exception related to the failing computation will be thrown again.

  45. final def scheduleEagerComputationsForEntities[E <: Entity](es: IterableOnce[E])(c: PropertyComputation[E]): Unit

    Will call the given function c for all elements of es in parallel.

    Will call the given function c for all elements of es in parallel.

    See also

    scheduleEagerComputationForEntity for details.

  46. final def set(e: Entity, p: Property): Unit

    Associates the given property p, which has property kind pk, with the given entity e iff e has no property of the respective kind.

    Associates the given property p, which has property kind pk, with the given entity e iff e has no property of the respective kind. The set property is always final.

    Calling this method is only supported before any analysis is scheduled!

    One use case is an analysis that does use the property store while executing the analysis, but which wants to store the results in the store. Such an analysis must be executed before any other analysis is scheduled. A second use case are (eager or lazy) analyses, which want to store some pre-configured information in the property store; e.g., properties of natives methods which were derived beforehand.

    Note

    This method must not be used if there might be a computation (in the future) that computes the property kind pk for the given e.

  47. final def setupPhase(propertyKindsComputedInThisPhase: Set[PropertyKind], propertyKindsComputedInLaterPhase: Set[PropertyKind] = Set.empty, suppressInterimUpdates: Map[PropertyKind, Set[PropertyKind]] = Map.empty, finalizationOrder: List[List[PropertyKind]] = List.empty): Unit

    Needs to be called before an analysis is scheduled to inform the property store which properties will be computed now and which are computed in a later phase.

    Needs to be called before an analysis is scheduled to inform the property store which properties will be computed now and which are computed in a later phase. The information is used to decide when we use a fallback and which kind of fallback.

    propertyKindsComputedInThisPhase

    The kinds of properties for which we will schedule computations.

    propertyKindsComputedInLaterPhase

    The set of property kinds which will be computed in a later phase.

    suppressInterimUpdates

    Specifies which interim updates should not be passed to which kind of dependers. A depender will only be informed about the final update. The key of the map identifies the target of a notification about an update (the depender) and the value specifies which dependee updates should be ignored unless it is a final update. This is an optimization related to lazy computations, but also enables the implementation of transformers and the scheduling of analyses which compute different kinds of bounds unless the analyses have cyclic dependencies.

    Note

    setupPhase even needs to be called if just fallback values should be computed; in this case propertyKindsComputedInThisPhase and propertyKindsComputedInLaterPhase have to be empty, but finalizationOrder have to contain the respective property kind.

  48. final def setupPhase(configuration: PropertyKindsConfiguration): Unit
  49. def statistics: LinkedHashMap[String, Int]

    Reports core statistics; this method is only guaranteed to report final results if it is called while the store is quiescent.

  50. final var subPhaseFinalizationOrder: Array[List[PropertyKind]]

    The order in which the property kinds will be finalized; the last phase is considered the clean-up phase and will contain all remaining properties that were not explicitly finalized previously.

    The order in which the property kinds will be finalized; the last phase is considered the clean-up phase and will contain all remaining properties that were not explicitly finalized previously.

    Attributes
    protected[this]
  51. var subPhaseId: Int
    Attributes
    protected[this]
  52. final val suppressInterimUpdates: Array[Array[Boolean]]
    Attributes
    protected[this]
  53. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  54. def toString(): String

    Returns a short string representation of the property store showing core figures.

    Returns a short string representation of the property store showing core figures.

    Definition Classes
    PropertyStore → AnyRef → Any
  55. final val traceFallbacks: Boolean
  56. final val traceSuppressedNotifications: Boolean
  57. final val transformersBySourcePK: Array[(PropertyKey[Property], (Entity, Property) => FinalEP[Entity, Property])]
    Attributes
    protected[this]
  58. final val transformersByTargetPK: Array[(PropertyKey[Property], (Entity, Property) => FinalEP[Entity, Property])]

    The set of transformers that will only be executed when required.

    The set of transformers that will only be executed when required.

    Attributes
    protected[this]
  59. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  60. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  61. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

Inherited from AnyRef

Inherited from Any

Ungrouped