Class

org.apache.spark.sql.execution.Hokusai

TimeAndItemAggregation

Related Doc: package Hokusai

Permalink

class TimeAndItemAggregation extends AnyRef

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. TimeAndItemAggregation
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new TimeAndItemAggregation(taList: MutableList[CountMinSketch[T]], itemList: MutableList[CountMinSketch[T]], intervalTracker: IntervalTracker)

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def basicQuery(tIntervalsToQuery: Range, key: T, taIntervalWithInstant: Int, totalComputedIntervalLength: Int): Approximate

    Permalink

    tIntervalsToQuery

    the tIntervals range to query as per the time aggregates. That is the interval range is the intervals in the past relative to most recent interval Note that time aggregates are from right to left, that is most recent interval is at the 0th position , while item aggregates are from left to right, that is most recent interval is at the end

  6. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  7. def convertIntervalBySwappingEnds(intervalNumber: Long): Long

    Permalink

    Converts the last n th interval to interval from begining For example, the most recent interval is say 8th.

    Converts the last n th interval to interval from begining For example, the most recent interval is say 8th. 8, 7, 6 , 5 , 4 , 3 , 2 ,1 last 3rd interval will be converted to 6th interval from the begining The starting interval is 1 based.

    or Converts the n th interval from 1st interal onwards to interval number from the end i.e lastNth interval from the most recent interval; For example, the most recent interval is say 8th. 8, 7, 6 , 5 , 4 , 3 , 2 ,1 3rd interval will be converted to 6th interval from the end that is 6th most recent interval The starting interval is 1 based.

  8. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  9. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  10. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  11. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  12. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  13. val ia: ItemAggregation

    Permalink
  14. def increment(mBar: CountMinSketch[T], t: Long): Unit

    Permalink
  15. val intervalTracker: IntervalTracker

    Permalink
  16. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  17. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  18. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  19. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  20. def queryAtInterval(lastNthInterval: Int, key: T): Option[Approximate]

    Permalink
  21. def queryBetweenIntervals(later: Int, earlier: Int, key: T): Option[Approximate]

    Permalink
  22. def queryBySummingTimeAggregates(item: T, sumUpTo: Int): Approximate

    Permalink
  23. def queryLastNIntervals[B](lastNIntervals: Int, queryTillLastN_Case1: () ⇒ B, queryTillLastN_Case2: (Int) ⇒ B, queryTillLastN_Case3: (Int, Int, Int, Int) ⇒ B, queryTillLastN_Case4: (Int, Int, Int, Int) ⇒ B): B

    Permalink
  24. def queryTimeAggregateForInterval(item: T, interval: Long): Approximate

    Permalink
  25. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  26. val ta: TimeAggregation

    Permalink
  27. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  28. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  29. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  30. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from AnyRef

Inherited from Any

Ungrouped