Package

px.kinesis.stream

consumer

Permalink

package consumer

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. consumer
  2. CommitGraphStages
  3. Consumer
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. trait CommitGraphStages extends AnyRef

    Permalink
  2. trait Consumer extends AnyRef

    Permalink
  3. case class ConsumerConfig(streamName: String, appName: String, workerId: String, checkpointConfig: CheckpointConfig, kinesisClient: KinesisAsyncClient, dynamoClient: DynamoDbAsyncClient, cloudwatchClient: CloudWatchAsyncClient, initialPositionInStreamExtended: InitialPositionInStreamExtended = ..., coordinatorConfig: Option[CoordinatorConfig] = None, leaseManagementConfig: Option[LeaseManagementConfig] = None, metricsConfig: Option[MetricsConfig] = None) extends Product with Serializable

    Permalink
  4. case class Record(key: String, data: ByteString, sequenceNumber: String, subSequenceNumber: Long, shardId: String, approximateArrivalTimestamp: Instant, markProcessed: () ⇒ Future[Done]) extends Product with Serializable

    Permalink
  5. class RecordProcessorFactoryImpl extends ShardRecordProcessorFactory

    Permalink
  6. class RecordProcessorImpl extends ShardRecordProcessor

    Permalink
  7. class ShardShutdownListener extends TaskExecutionListener

    Permalink

    Used to detect when ShardRecordProcessors are shut down (due to shard end, lease lost..

    Used to detect when ShardRecordProcessors are shut down (due to shard end, lease lost.. etc) When this occurs, we can clean up the corresponding consumer.checkpoint tracker associated with the shard

  8. class StreamScheduler extends AnyRef

    Permalink
  9. class WorkerStateChangeListenerImpl extends WorkerStateChangeListener

    Permalink

Value Members

  1. object ConsumerConfig extends Serializable

    Permalink
  2. object Record extends Serializable

    Permalink
  3. object SchedulerExecutionContext

    Permalink
  4. object StreamScheduler

    Permalink
  5. package checkpoint

    Permalink
  6. def commitFlow(parallelism: Int = 1)(implicit ec: ExecutionContext): Flow[Record, Record, NotUsed]

    Permalink

    A flow which transparently marks every record as processed

    A flow which transparently marks every record as processed

    Definition Classes
    CommitGraphStages
  7. def source(streamName: String, appName: String)(implicit am: ActorMaterializer, system: ActorSystem, ec: ExecutionContext): Source[Record, Future[Done]]

    Permalink
    Definition Classes
    Consumer
  8. def source(config: ConsumerConfig)(implicit am: ActorMaterializer, system: ActorSystem, ec: ExecutionContext): Source[Record, Future[Done]]

    Permalink

    Returns a Source which emits checkpointable Records from the Kinesis stream.

    Returns a Source which emits checkpointable Records from the Kinesis stream. The stream will contain messages from all shard assignments for the KCL worker A KCL worker is started upon stream materialization and shut down upon stream completin/termination

    Definition Classes
    Consumer

Inherited from CommitGraphStages

Inherited from Consumer

Inherited from AnyRef

Inherited from Any

Ungrouped