Packages

class LockStreamFunction extends AbstractStreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]] with TwoInputStreamOperator[ValueWithContext[String], SampleProcessSignal, Either[LockOutputStateChanged, ValueWithContext[LockOutput]]] with LazyLogging with SignalHandler

Linear Supertypes
SignalHandler, LazyLogging, TwoInputStreamOperator[ValueWithContext[String], SampleProcessSignal, Either[LockOutputStateChanged, ValueWithContext[LockOutput]]], AbstractStreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]], CheckpointedStreamOperator, SetupableStreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]], StreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]], Serializable, KeyContext, CheckpointListener, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. LockStreamFunction
  2. SignalHandler
  3. LazyLogging
  4. TwoInputStreamOperator
  5. AbstractStreamOperator
  6. CheckpointedStreamOperator
  7. SetupableStreamOperator
  8. StreamOperator
  9. Serializable
  10. KeyContext
  11. CheckpointListener
  12. AnyRef
  13. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new LockStreamFunction(metaData: MetaData)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def changeState(newValue: Boolean): Unit
  6. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native() @HotSpotIntrinsicCandidate()
  7. def close(): Unit
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  8. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  9. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  10. def finish(): Unit
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  11. final def getChainingStrategy(): ChainingStrategy
    Definition Classes
    AbstractStreamOperator → SetupableStreamOperator
  12. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  13. def getContainingTask(): StreamTask[_, _]
    Definition Classes
    AbstractStreamOperator
  14. def getCurrentKey(): AnyRef
    Definition Classes
    AbstractStreamOperator → KeyContext
  15. def getExecutionConfig(): ExecutionConfig
    Definition Classes
    AbstractStreamOperator
  16. def getInternalTimerService[K, N](arg0: String, arg1: TypeSerializer[N], arg2: Triggerable[K, N]): InternalTimerService[N]
    Definition Classes
    AbstractStreamOperator
  17. def getKeyedStateBackend[K](): KeyedStateBackend[K]
    Definition Classes
    AbstractStreamOperator
  18. def getKeyedStateStore(): KeyedStateStore
    Definition Classes
    AbstractStreamOperator
  19. def getMetricGroup(): OperatorMetricGroup
    Definition Classes
    AbstractStreamOperator → StreamOperator
  20. def getOperatorConfig(): StreamConfig
    Definition Classes
    AbstractStreamOperator
  21. def getOperatorID(): OperatorID
    Definition Classes
    AbstractStreamOperator → StreamOperator
  22. def getOperatorName(): String
    Attributes
    protected[operators]
    Definition Classes
    AbstractStreamOperator
  23. def getOperatorStateBackend(): OperatorStateBackend
    Definition Classes
    AbstractStreamOperator
  24. def getOrCreateKeyedState[N, S <: State, T](arg0: TypeSerializer[N], arg1: StateDescriptor[S, T]): S
    Attributes
    protected[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
    Attributes
    protected[operators]
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  26. def getPartitionedState[S <: State](arg0: StateDescriptor[S, _]): S
    Attributes
    protected[operators]
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  27. def getProcessingTimeService(): ProcessingTimeService
    Definition Classes
    AbstractStreamOperator
  28. def getRuntimeContext(): StreamingRuntimeContext
    Definition Classes
    AbstractStreamOperator
  29. def getTimeServiceManager(): Optional[InternalTimeServiceManager[_]]
    Attributes
    protected[operators]
    Definition Classes
    AbstractStreamOperator
  30. def getUserCodeClassloader(): ClassLoader
    Definition Classes
    AbstractStreamOperator
  31. def handleIfSignalForThisProcess(signal: SampleProcessSignal)(handle: (SampleProcessSignal) ⇒ Unit): Unit
    Definition Classes
    SignalHandler
  32. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  33. def initializeState(arg0: StateInitializationContext): Unit
    Definition Classes
    AbstractStreamOperator → CheckpointedStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  34. final def initializeState(arg0: StreamTaskStateInitializer): Unit
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  35. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  36. def isUsingCustomRawKeyedState(): Boolean
    Attributes
    protected[operators]
    Definition Classes
    AbstractStreamOperator
  37. var lockEnabledState: ValueState[Boolean]
  38. lazy val logger: Logger
    Attributes
    protected
    Definition Classes
    LazyLogging
    Annotations
    @transient()
  39. val metaData: MetaData
    Definition Classes
    LockStreamFunctionSignalHandler
  40. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  41. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  42. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  43. def notifyCheckpointAborted(arg0: Long): Unit
    Definition Classes
    AbstractStreamOperator → CheckpointListener
    Annotations
    @throws( classOf[java.lang.Exception] )
  44. def notifyCheckpointComplete(arg0: Long): Unit
    Definition Classes
    AbstractStreamOperator → CheckpointListener
    Annotations
    @throws( classOf[java.lang.Exception] )
  45. def open(): Unit
    Definition Classes
    LockStreamFunction → AbstractStreamOperator → StreamOperator
  46. def prepareSnapshotPreBarrier(arg0: Long): Unit
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  47. def processElement1(element: StreamRecord[ValueWithContext[String]]): Unit
    Definition Classes
    LockStreamFunction → TwoInputStreamOperator
  48. def processElement2(element: StreamRecord[SampleProcessSignal]): Unit
    Definition Classes
    LockStreamFunction → TwoInputStreamOperator
  49. def processLatencyMarker(arg0: LatencyMarker): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  50. def processLatencyMarker1(arg0: LatencyMarker): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  51. def processLatencyMarker2(arg0: LatencyMarker): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  52. def processWatermark(arg0: Watermark): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  53. def processWatermark1(arg0: Watermark): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  54. def processWatermark2(arg0: Watermark): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  55. def processWatermarkStatus(arg0: WatermarkStatus): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  56. final def processWatermarkStatus1(arg0: WatermarkStatus): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  57. final def processWatermarkStatus2(arg0: WatermarkStatus): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  58. def reportOrForwardLatencyMarker(arg0: LatencyMarker): Unit
    Attributes
    protected[operators]
    Definition Classes
    AbstractStreamOperator
  59. final def setChainingStrategy(arg0: ChainingStrategy): Unit
    Definition Classes
    AbstractStreamOperator → SetupableStreamOperator
  60. def setCurrentKey(arg0: Any): Unit
    Definition Classes
    AbstractStreamOperator → KeyContext
  61. def setKeyContextElement1(arg0: StreamRecord[_]): Unit
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  62. def setKeyContextElement2(arg0: StreamRecord[_]): Unit
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  63. def setup(arg0: StreamTask[_, _], arg1: StreamConfig, arg2: Output[StreamRecord[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]]]): Unit
    Definition Classes
    AbstractStreamOperator → SetupableStreamOperator
  64. def snapshotState(arg0: StateSnapshotContext): Unit
    Definition Classes
    AbstractStreamOperator → CheckpointedStreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  65. final def snapshotState(arg0: Long, arg1: Long, arg2: CheckpointOptions, arg3: CheckpointStreamFactory): OperatorSnapshotFutures
    Definition Classes
    AbstractStreamOperator → StreamOperator
    Annotations
    @throws( classOf[java.lang.Exception] )
  66. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  67. def toString(): String
    Definition Classes
    AnyRef → Any
  68. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  69. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  70. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] ) @Deprecated @deprecated
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

  2. def setProcessingTimeService(arg0: ProcessingTimeService): Unit
    Definition Classes
    AbstractStreamOperator
    Annotations
    @Deprecated @deprecated
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

Inherited from SignalHandler

Inherited from LazyLogging

Inherited from TwoInputStreamOperator[ValueWithContext[String], SampleProcessSignal, Either[LockOutputStateChanged, ValueWithContext[LockOutput]]]

Inherited from AbstractStreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]]

Inherited from CheckpointedStreamOperator

Inherited from SetupableStreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]]

Inherited from StreamOperator[Either[LockOutputStateChanged, ValueWithContext[LockOutput]]]

Inherited from Serializable

Inherited from KeyContext

Inherited from CheckpointListener

Inherited from AnyRef

Inherited from Any

Ungrouped