org.apache.spark.sql.execution.streaming.state
StreamingAggregationStateManager
Companion object StreamingAggregationStateManager
sealed trait StreamingAggregationStateManager extends Serializable
Base trait for state manager purposed to be used from streaming aggregations.
- Alphabetic
- By Inheritance
- StreamingAggregationStateManager
- Serializable
- Serializable
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Abstract Value Members
-
abstract
def
commit(store: StateStore): Long
Commit all the updates that have been made to the target state store, and return the new version.
-
abstract
def
get(store: ReadStateStore, key: UnsafeRow): UnsafeRow
Get the current value of a non-null key from the target state store.
-
abstract
def
getKey(row: UnsafeRow): UnsafeRow
Extract columns consisting key from input row, and return the new row for key columns.
-
abstract
def
getStateValueSchema: StructType
Calculate schema for the value of state.
Calculate schema for the value of state. The schema is mainly passed to the StateStoreRDD.
-
abstract
def
iterator(store: ReadStateStore): Iterator[UnsafeRowPair]
Return an iterator containing all the key-value pairs in target state store.
-
abstract
def
keys(store: ReadStateStore): Iterator[UnsafeRow]
Return an iterator containing all the keys in target state store.
-
abstract
def
put(store: StateStore, row: UnsafeRow): Unit
Put a new value for a non-null key to the target state store.
Put a new value for a non-null key to the target state store. Note that key will be extracted from the input row, and the key would be same as the result of getKey(inputRow).
-
abstract
def
remove(store: StateStore, key: UnsafeRow): Unit
Remove a single non-null key from the target state store.
-
abstract
def
values(store: ReadStateStore): Iterator[UnsafeRow]
Return an iterator containing all the values in target state store.
Concrete Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
##(): Int
- Definition Classes
- AnyRef → Any
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
def
finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
final
def
ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
final
def
notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()