1818package org .apache .spark .sql .streaming
1919
2020import org .apache .spark .annotation .{Experimental , InterfaceStability }
21- import org .apache .spark .sql .{ Encoder , KeyValueGroupedDataset }
21+ import org .apache .spark .sql .KeyValueGroupedDataset
2222import org .apache .spark .sql .catalyst .plans .logical .LogicalGroupState
2323
2424/**
2525 * :: Experimental ::
2626 *
2727 * Wrapper class for interacting with per-group state data in `mapGroupsWithState` and
28- * `flatMapGroupsWithState` operations on [[ KeyValueGroupedDataset ]] .
28+ * `flatMapGroupsWithState` operations on ` KeyValueGroupedDataset` .
2929 *
3030 * Detail description on `[map/flatMap]GroupsWithState` operation
3131 * --------------------------------------------------------------
32- * Both, `mapGroupsWithState` and `flatMapGroupsWithState` in [[ KeyValueGroupedDataset ]]
32+ * Both, `mapGroupsWithState` and `flatMapGroupsWithState` in ` KeyValueGroupedDataset`
3333 * will invoke the user-given function on each group (defined by the grouping function in
3434 * `Dataset.groupByKey()`) while maintaining user-defined per-group state between invocations.
3535 * For a static batch Dataset, the function will be invoked once per group. For a streaming
@@ -70,8 +70,8 @@ import org.apache.spark.sql.catalyst.plans.logical.LogicalGroupState
7070 * `[map|flatMap]GroupsWithState`, but the exact timeout duration/timestamp is configurable per
7171 * group by calling `setTimeout...()` in `GroupState`.
7272 * - Timeouts can be either based on processing time (i.e.
73- * [[ GroupStateTimeout.ProcessingTimeTimeout ]] ) or event time (i.e.
74- * [[ GroupStateTimeout.EventTimeTimeout ]] ).
73+ * ` GroupStateTimeout.ProcessingTimeTimeout` ) or event time (i.e.
74+ * ` GroupStateTimeout.EventTimeTimeout` ).
7575 * - With `ProcessingTimeTimeout`, the timeout duration can be set by calling
7676 * `GroupState.setTimeoutDuration`. The timeout will occur when the clock has advanced by the set
7777 * duration. Guarantees provided by this timeout with a duration of D ms are as follows:
@@ -177,7 +177,7 @@ import org.apache.spark.sql.catalyst.plans.logical.LogicalGroupState
177177 * }}}
178178 *
179179 * @tparam S User-defined type of the state to be stored for each group. Must be encodable into
180- * Spark SQL types (see [[ Encoder ]] for more details).
180+ * Spark SQL types (see ` Encoder` for more details).
181181 * @since 2.2.0
182182 */
183183@ Experimental
@@ -224,7 +224,7 @@ trait GroupState[S] extends LogicalGroupState[S] {
224224 /**
225225 * Set the timeout duration for this key as a string. For example, "1 hour", "2 days", etc.
226226 *
227- * @note , ProcessingTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
227+ * @note ProcessingTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
228228 */
229229 @ throws[IllegalArgumentException ](" if 'duration' is not a valid duration" )
230230 @ throws[IllegalStateException ](" when state is either not initialized, or already removed" )
@@ -240,7 +240,7 @@ trait GroupState[S] extends LogicalGroupState[S] {
240240 * Set the timeout timestamp for this key as milliseconds in epoch time.
241241 * This timestamp cannot be older than the current watermark.
242242 *
243- * @note , EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
243+ * @note EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
244244 */
245245 def setTimeoutTimestamp (timestampMs : Long ): Unit
246246
@@ -254,7 +254,7 @@ trait GroupState[S] extends LogicalGroupState[S] {
254254 * The final timestamp (including the additional duration) cannot be older than the
255255 * current watermark.
256256 *
257- * @note , EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
257+ * @note EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
258258 */
259259 def setTimeoutTimestamp (timestampMs : Long , additionalDuration : String ): Unit
260260
@@ -265,7 +265,7 @@ trait GroupState[S] extends LogicalGroupState[S] {
265265 * Set the timeout timestamp for this key as a java.sql.Date.
266266 * This timestamp cannot be older than the current watermark.
267267 *
268- * @note , EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
268+ * @note EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
269269 */
270270 def setTimeoutTimestamp (timestamp : java.sql.Date ): Unit
271271
@@ -279,7 +279,7 @@ trait GroupState[S] extends LogicalGroupState[S] {
279279 * The final timestamp (including the additional duration) cannot be older than the
280280 * current watermark.
281281 *
282- * @note , EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
282+ * @note EventTimeTimeout must be enabled in `[map/flatmap]GroupsWithStates`.
283283 */
284284 def setTimeoutTimestamp (timestamp : java.sql.Date , additionalDuration : String ): Unit
285285}
0 commit comments