org.apache.spark.sql.execution.streaming.state

StateStore

trait StateStore extends AnyRef

Base trait for a versioned key-value store used for streaming aggregations

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. StateStore
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Abstract Value Members

  1. abstract def abort(): Unit

    Abort all the updates that have been made to the store.

  2. abstract def commit(): Long

    Commit all the updates that have been made to the store, and return the new version.

  3. abstract def filter(condition: (UnsafeRow, UnsafeRow) ⇒ Boolean): Iterator[(UnsafeRow, UnsafeRow)]

    Return an iterator of key-value pairs that satisfy a certain condition.

    Return an iterator of key-value pairs that satisfy a certain condition. Note that the iterator must be fail-safe towards modification to the store, that is, it must be based on the snapshot of store the time of this call, and any change made to the store while iterating through iterator should not cause the iterator to fail or have any affect on the values in the iterator.

  4. abstract def get(key: UnsafeRow): Option[UnsafeRow]

    Get the current value of a key.

  5. abstract def id: StateStoreId

    Unique identifier of the store

  6. abstract def iterator(): Iterator[(UnsafeRow, UnsafeRow)]

    Iterator of store data after a set of updates have been committed.

    Iterator of store data after a set of updates have been committed. This can be called only after committing all the updates made in the current thread.

  7. abstract def numKeys(): Long

    Number of keys in the state store

  8. abstract def put(key: UnsafeRow, value: UnsafeRow): Unit

    Put a new value for a key.

  9. abstract def remove(key: UnsafeRow): Unit

    Remove a single key.

  10. abstract def remove(condition: (UnsafeRow) ⇒ Boolean): Unit

    Remove keys that match the following condition.

  11. abstract def updates(): Iterator[StoreUpdate]

    Iterator of the updates that have been committed.

    Iterator of the updates that have been committed. This can be called only after committing all the updates made in the current thread.

  12. abstract def version: Long

    Version of the data in this store before committing updates.

Concrete Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

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

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  8. final def eq(arg0: AnyRef): Boolean

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

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

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

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

    Definition Classes
    AnyRef → Any
  13. final def isInstanceOf[T0]: Boolean

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

    Definition Classes
    AnyRef
  15. final def notify(): Unit

    Definition Classes
    AnyRef
  16. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  17. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  18. def toString(): String

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from AnyRef

Inherited from Any

Ungrouped