Packages

abstract class MakeStateQueryableTransformer[A <: ChangedState, B] extends AbstractStreamOperator[ValueWithContext[B]] with OneInputStreamOperator[Either[A, ValueWithContext[B]], ValueWithContext[B]] with LazyLogging

Linear Supertypes
LazyLogging, OneInputStreamOperator[Either[A, ValueWithContext[B]], ValueWithContext[B]], Input[Either[A, ValueWithContext[B]]], AbstractStreamOperator[ValueWithContext[B]], CheckpointedStreamOperator, SetupableStreamOperator[ValueWithContext[B]], StreamOperator[ValueWithContext[B]], Serializable, KeyContext, CheckpointListener, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. MakeStateQueryableTransformer
  2. LazyLogging
  3. OneInputStreamOperator
  4. Input
  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 MakeStateQueryableTransformer(queryName: String, mapToJson: (A) ⇒ Json)

Type Members

  1. case class QueriedState(key: String, jsonValue: Json, changeTimestamp: Long) extends Product with Serializable

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

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 LazyLogging

Inherited from OneInputStreamOperator[Either[A, ValueWithContext[B]], ValueWithContext[B]]

Inherited from Input[Either[A, ValueWithContext[B]]]

Inherited from AbstractStreamOperator[ValueWithContext[B]]

Inherited from CheckpointedStreamOperator

Inherited from SetupableStreamOperator[ValueWithContext[B]]

Inherited from StreamOperator[ValueWithContext[B]]

Inherited from Serializable

Inherited from KeyContext

Inherited from CheckpointListener

Inherited from AnyRef

Inherited from Any

Ungrouped