Class ParDoStateUpdateFn<KeyT,ValueT,InputT extends KV<KeyT,ValueT>,OutputT>

java.lang.Object
scala.runtime.AbstractFunction3<ByteArray,scala.Option<byte[]>,org.apache.spark.streaming.State<StateAndTimers>,List<scala.Tuple2<TupleTag<?>,byte[]>>>
org.apache.beam.runners.spark.translation.streaming.ParDoStateUpdateFn<KeyT,ValueT,InputT,OutputT>
Type Parameters:
KeyT - The type of the key in the input KV pairs
ValueT - The type of the value in the input KV pairs
InputT - The input type, must be a KV of KeyT and ValueT
OutputT - The output type produced by the DoFn
All Implemented Interfaces:
Serializable, scala.Function3<ByteArray,scala.Option<byte[]>,org.apache.spark.streaming.State<StateAndTimers>,List<scala.Tuple2<TupleTag<?>,byte[]>>>

public class ParDoStateUpdateFn<KeyT,ValueT,InputT extends KV<KeyT,ValueT>,OutputT> extends scala.runtime.AbstractFunction3<ByteArray,scala.Option<byte[]>,org.apache.spark.streaming.State<StateAndTimers>,List<scala.Tuple2<TupleTag<?>,byte[]>>> implements Serializable
A function to handle stateful processing in Apache Beam's SparkRunner. This class processes stateful DoFn operations by managing state updates in a Spark streaming context.

Current Implementation Status:

See Also: