Object

com.weightwatchers.reactive.kinesis.consumer

ConsumerWorker

Related Doc: package consumer

Permalink

object ConsumerWorker

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ConsumerWorker
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. case class ConsumerShutdown(shardId: String) extends Product with Serializable

    Permalink

    Sent to the eventProcessor upon shutdown of this worker.

  2. final case class ConsumerWorkerConf(batchTimeout: FiniteDuration, failedMessageRetries: Int, failureTolerancePercentage: Double, shutdownHook: Boolean, shutdownTimeout: Timeout) extends Product with Serializable

    Permalink

    Configuration for the Consumer Worker.

    Configuration for the Consumer Worker.

    batchTimeout

    The total timeout for processing a single batch

    failedMessageRetries

    The number of times to retry failed batch messages

    failureTolerancePercentage

    The delay between notification messages sent to the parent to indicate we're ready to checkpoint.

    shutdownHook

    Whether we automatically attempt a graceful shutdown on shutdown of the service

    shutdownTimeout

    When gracefully shutting down, this is the timeout allowed checkpointing etc

  3. case class ConsumerWorkerFailure(failedEvents: Seq[ConsumerEvent], shardId: String) extends Product with Serializable

    Permalink

    Sent to the eventProcessor if batch processing fails (above the tolerance after retrying) before shutting down processing on this shard.

    Sent to the eventProcessor if batch processing fails (above the tolerance after retrying) before shutting down processing on this shard.

    failedEvents

    The events that failed processing within the time.

    shardId

    The shardId of the worker causing the failure.

  4. case class EventProcessed(compoundSeqNo: CompoundSequenceNumber, successful: Boolean = true) extends Product with Serializable

    Permalink

    Expected in response to a ProcessEvent message after processing is complete

    Expected in response to a ProcessEvent message after processing is complete

    compoundSeqNo

    This is a combination of the sequence and subsequence numbers

    successful

    Set this to false to skip this message.

  5. case class ProcessEvent(consumerEvent: ConsumerEvent) extends Product with Serializable

    Permalink

    Sent to the eventProcessor for each message in the batch.

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. object ConsumerWorkerConf extends Serializable

    Permalink
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  7. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  9. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  10. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  11. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  12. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  13. final def ne(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef
  15. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  16. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  18. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  19. final def wait(arg0: Long, arg1: Int): Unit

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

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

Inherited from AnyRef

Inherited from Any

Ungrouped