Class

pl.touk.nussknacker.engine.flink.api.state

TimestampedEvictableState

Related Doc: package state

Permalink

abstract class TimestampedEvictableState[T] extends TimestampedEvictableStateGeneric[T, ValueWithContext[Any]]

Annotations
@Deprecated
Linear Supertypes
TimestampedEvictableStateGeneric[T, ValueWithContext[Any]], RichEvictableStateGeneric[MultiMap[Long, T], ValueWithContext[Any]], EvictableState[InterpretationResult, ValueWithContext[Any]], Triggerable[String, String], OneInputStreamOperator[InterpretationResult, ValueWithContext[Any]], AbstractStreamOperator[ValueWithContext[Any]], CheckpointedStreamOperator, SetupableStreamOperator[ValueWithContext[Any]], StreamOperator[ValueWithContext[Any]], Serializable, Disposable, KeyContext, CheckpointListener, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. TimestampedEvictableState
  2. TimestampedEvictableStateGeneric
  3. RichEvictableStateGeneric
  4. EvictableState
  5. Triggerable
  6. OneInputStreamOperator
  7. AbstractStreamOperator
  8. CheckpointedStreamOperator
  9. SetupableStreamOperator
  10. StreamOperator
  11. Serializable
  12. Disposable
  13. KeyContext
  14. CheckpointListener
  15. AnyRef
  16. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new TimestampedEvictableState()

    Permalink

Abstract Value Members

  1. abstract def processElement(arg0: StreamRecord[InterpretationResult]): Unit

    Permalink
    Definition Classes
    OneInputStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  2. abstract def stateDescriptor: ValueStateDescriptor[MultiMap[Long, T]]

    Permalink
    Definition Classes
    RichEvictableStateGeneric

Concrete 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 clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate() @throws( ... )
  6. def close(): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  7. def dispose(): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator → Disposable
    Annotations
    @throws( classOf[java.lang.Exception] )
  8. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  10. def filterState(timeStamp: Long, lengthInMillis: Long): MultiMap[Long, T]

    Permalink
  11. final def getChainingStrategy(): ChainingStrategy

    Permalink
    Definition Classes
    AbstractStreamOperator → SetupableStreamOperator
  12. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
    Annotations
    @HotSpotIntrinsicCandidate()
  13. def getContainingTask(): StreamTask[_, _]

    Permalink
    Definition Classes
    AbstractStreamOperator
  14. def getCurrentKey(): AnyRef

    Permalink
    Definition Classes
    AbstractStreamOperator → KeyContext
  15. def getExecutionConfig(): ExecutionConfig

    Permalink
    Definition Classes
    AbstractStreamOperator
  16. def getInternalTimerService[K, N](arg0: String, arg1: TypeSerializer[N], arg2: Triggerable[K, N]): InternalTimerService[N]

    Permalink
    Definition Classes
    AbstractStreamOperator
  17. def getKeyedStateBackend[K](): KeyedStateBackend[K]

    Permalink
    Definition Classes
    AbstractStreamOperator
  18. def getKeyedStateStore(): KeyedStateStore

    Permalink
    Definition Classes
    AbstractStreamOperator
  19. def getMetricGroup(): MetricGroup

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
  20. def getOperatorConfig(): StreamConfig

    Permalink
    Definition Classes
    AbstractStreamOperator
  21. def getOperatorID(): OperatorID

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
  22. def getOperatorName(): String

    Permalink
    Attributes
    protected[org.apache.flink.streaming.api.operators]
    Definition Classes
    AbstractStreamOperator
  23. def getOperatorStateBackend(): OperatorStateBackend

    Permalink
    Definition Classes
    AbstractStreamOperator
  24. def getOrCreateKeyedState[N, S <: State, T](arg0: TypeSerializer[N], arg1: StateDescriptor[S, T]): S

    Permalink
    Attributes
    protected[org.apache.flink.streaming.api.operators]
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  25. def getPartitionedState[S <: State, N](arg0: N, arg1: TypeSerializer[N], arg2: StateDescriptor[S, _]): S

    Permalink
    Attributes
    protected[org.apache.flink.streaming.api.operators]
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  26. def getPartitionedState[S <: State](arg0: StateDescriptor[S, _]): S

    Permalink
    Attributes
    protected[org.apache.flink.streaming.api.operators]
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  27. def getProcessingTimeService(): ProcessingTimeService

    Permalink
    Definition Classes
    AbstractStreamOperator
  28. def getRuntimeContext(): StreamingRuntimeContext

    Permalink
    Definition Classes
    AbstractStreamOperator
  29. def getState: ValueState[MultiMap[Long, T]]

    Permalink
  30. def getTimeServiceManager(): Optional[InternalTimeServiceManager[_]]

    Permalink
    Attributes
    protected[org.apache.flink.streaming.api.operators]
    Definition Classes
    AbstractStreamOperator
  31. def getUserCodeClassloader(): ClassLoader

    Permalink
    Definition Classes
    AbstractStreamOperator
  32. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
    Annotations
    @HotSpotIntrinsicCandidate()
  33. def initializeState(arg0: StateInitializationContext): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → CheckpointedStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  34. final def initializeState(arg0: StreamTaskStateInitializer): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  35. var internalTimerService: InternalTimerService[String]

    Permalink
    Definition Classes
    EvictableState
  36. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  37. var lastEventTimeForKey: ValueState[Long]

    Permalink
    Definition Classes
    EvictableState
  38. final def ne(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate()
  40. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate()
  41. def notifyCheckpointAborted(arg0: Long): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → CheckpointListener
    Annotations
    @throws( classOf[java.lang.Exception] )
  42. def notifyCheckpointComplete(arg0: Long): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → CheckpointListener
    Annotations
    @throws( classOf[java.lang.Exception] )
  43. def numEventTimeTimers(): Int

    Permalink
    Definition Classes
    AbstractStreamOperator
  44. def numProcessingTimeTimers(): Int

    Permalink
    Definition Classes
    AbstractStreamOperator
  45. def onEventTime(timer: InternalTimer[String, String]): Unit

    Permalink
    Definition Classes
    EvictableState → Triggerable
  46. def onProcessingTime(timer: InternalTimer[String, String]): Unit

    Permalink
    Definition Classes
    EvictableState → Triggerable
  47. def open(): Unit

    Permalink
    Definition Classes
    RichEvictableStateGenericEvictableState → AbstractStreamOperator → StreamOperator
  48. def prepareSnapshotPreBarrier(arg0: Long): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  49. def processLatencyMarker(arg0: LatencyMarker): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  50. def processLatencyMarker1(arg0: LatencyMarker): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  51. def processLatencyMarker2(arg0: LatencyMarker): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  52. def processWatermark(mark: Watermark): Unit

    Permalink
    Definition Classes
    TimestampedEvictableStateGeneric → OneInputStreamOperator → AbstractStreamOperator
  53. def processWatermark1(arg0: Watermark): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  54. def processWatermark2(arg0: Watermark): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  55. def reportOrForwardLatencyMarker(arg0: LatencyMarker): Unit

    Permalink
    Attributes
    protected[org.apache.flink.streaming.api.operators]
    Definition Classes
    AbstractStreamOperator
  56. final def setChainingStrategy(arg0: ChainingStrategy): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → SetupableStreamOperator
  57. def setCurrentKey(arg0: Any): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → KeyContext
  58. final def setEvictionTimeForCurrentKey(time: Long): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    EvictableState
  59. def setKeyContextElement1(arg0: StreamRecord): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  60. def setKeyContextElement2(arg0: StreamRecord): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  61. def setup(arg0: StreamTask[_, _], arg1: StreamConfig, arg2: Output[StreamRecord[ValueWithContext[Any]]]): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → SetupableStreamOperator
  62. def snapshotState(arg0: StateSnapshotContext): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator → CheckpointedStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  63. final def snapshotState(arg0: Long, arg1: Long, arg2: CheckpointOptions, arg3: CheckpointStreamFactory): OperatorSnapshotFutures

    Permalink
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  64. var state: ValueState[MultiMap[Long, T]]

    Permalink
    Definition Classes
    RichEvictableStateGeneric
  65. def stateValue: MultiMap[Long, T]

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

    Permalink
    Definition Classes
    AnyRef
  67. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  68. final def wait(arg0: Long, arg1: Int): Unit

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  70. final def wait(): Unit

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

Deprecated Value Members

  1. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @Deprecated @deprecated @throws( classOf[java.lang.Throwable] )
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

  2. def setProcessingTimeService(arg0: ProcessingTimeService): Unit

    Permalink
    Definition Classes
    AbstractStreamOperator
    Annotations
    @Deprecated @deprecated
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

Inherited from TimestampedEvictableStateGeneric[T, ValueWithContext[Any]]

Inherited from RichEvictableStateGeneric[MultiMap[Long, T], ValueWithContext[Any]]

Inherited from EvictableState[InterpretationResult, ValueWithContext[Any]]

Inherited from Triggerable[String, String]

Inherited from OneInputStreamOperator[InterpretationResult, ValueWithContext[Any]]

Inherited from AbstractStreamOperator[ValueWithContext[Any]]

Inherited from CheckpointedStreamOperator

Inherited from SetupableStreamOperator[ValueWithContext[Any]]

Inherited from StreamOperator[ValueWithContext[Any]]

Inherited from Serializable

Inherited from Disposable

Inherited from KeyContext

Inherited from CheckpointListener

Inherited from AnyRef

Inherited from Any

Ungrouped