Package

px.kinesis.stream

consumer

Permalink

package consumer

Visibility
  1. Public
  2. All

Type Members

  1. 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
  2. case class Record(key: String, data: ByteString, sequenceNumber: String, subSequenceNumber: Long, shardId: String, approximateArrivalTimestamp: Instant, markProcessed: () ⇒ Future[Done]) extends Product with Serializable

    Permalink
  3. class RecordProcessorFactoryImpl extends ShardRecordProcessorFactory

    Permalink
  4. class RecordProcessorImpl extends ShardRecordProcessor

    Permalink
  5. 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

  6. class StreamScheduler extends AnyRef

    Permalink
  7. class WorkerStateChangeListenerImpl extends WorkerStateChangeListener

    Permalink

Value Members

  1. object Consumer

    Permalink
  2. object ConsumerConfig extends Serializable

    Permalink
  3. object Record extends Serializable

    Permalink
  4. object SchedulerExecutionContext

    Permalink
  5. object StreamScheduler

    Permalink
  6. package checkpoint

    Permalink

Ungrouped