publisher

object publisher

fs2 Streams for publishing data to AWS Kinesis streams

class Object
trait Matchable
class Any

Value members

Concrete methods

def write[F[_]](streamName: String, producer: KinesisProducerClient[F])(using evidence$1: Sync[F]): (F, (String, ByteBuffer)) => ListenableFuture[UserRecordResult]
def writeAndForgetObjectToKinesis[F[_], I](streamName: String, parallelism: Int, producer: KinesisProducerClient[F])(using evidence$6: Sync[F], encoder: I => ByteBuffer): (F, (String, I)) => I

Writes the (partitionKey, payload) to a Kinesis stream via a Pipe

Writes the (partitionKey, payload) to a Kinesis stream via a Pipe

Type parameters:
F

effect type of the stream

I

type of payload

Value parameters:
encoder

implicit I => ByteBuffer encoder

parallelism

number of concurrent writes to race simultaneously

producer

kinesis producer client to use

streamName

the name of the Kinesis stream to write to

Returns:

a Pipe that accepts a tuple consisting of the partition key string and an entity and returns original entity

def writeAndForgetToKinesis[F[_]](streamName: String, parallelism: Int, producer: KinesisProducerClient[F])(using evidence$4: Sync[F]): (F, (String, ByteBuffer)) => Unit

Writes the (partitionKey, ByteBuffer) to a Kinesis stream via a Pipe

Writes the (partitionKey, ByteBuffer) to a Kinesis stream via a Pipe

Type parameters:
F

effect type of the stream

Value parameters:
parallelism

number of concurrent writes to race simultaneously

producer

kinesis producer client to use

streamName

the name of the Kinesis stream to write to

Returns:

a Pipe that accepts a tuple consisting of the partition key string and a ByteBuffer of data and returns Unit this is most fast versKinesisConsumerSpecion of producer, since we do not care about the result of kinesis right, hence we don't wait for it to publish next message

def writeObjectAndBypass[F[_], I](streamName: String, producer: KinesisProducerClient[F], encoder: I => ByteBuffer)(using evidence$2: Sync[F]): (F, (String, I)) => (I, ListenableFuture[UserRecordResult])
def writeObjectToKinesis[F[_], I](streamName: String, parallelism: Int, producer: KinesisProducerClient[F])(using evidence$5: Async[F], ec: ExecutionContext, encoder: I => ByteBuffer): (F, (String, I)) => (I, UserRecordResult)

Writes the (partitionKey, payload) to a Kinesis stream via a Pipe

Writes the (partitionKey, payload) to a Kinesis stream via a Pipe

Type parameters:
F

effect type of the stream

I

type of payload

Value parameters:
encoder

implicit I => ByteBuffer encoder

parallelism

number of concurrent writes to race simultaneously

producer

kinesis producer client to use

streamName

the name of the Kinesis stream to write to

Returns:

a Pipe that accepts a tuple consisting of the partition key string and a ByteBuffer of data and returns UserRecordResults

def writeToKinesis[F[_]](streamName: String, parallelism: Int, producer: KinesisProducerClient[F])(using evidence$3: Async[F], ec: ExecutionContext): (F, (String, ByteBuffer)) => UserRecordResult

Writes the (partitionKey, ByteBuffer) to a Kinesis stream via a Pipe

Writes the (partitionKey, ByteBuffer) to a Kinesis stream via a Pipe

Type parameters:
F

effect type of the stream

Value parameters:
parallelism

number of concurrent writes to race simultaneously

producer

kinesis producer client to use

streamName

the name of the Kinesis stream to write to

Returns:

a Pipe that accepts a tuple consisting of the partition key string and a ByteBuffer of data and returns UserRecordResults

def writeToKinesis_[F[_]](streamName: String, parallelism: Int, producer: KinesisProducerClient[F])(using evidence$7: Async[F], ec: ExecutionContext): (F, (String, ByteBuffer)) => Unit

Writes the bytestream to a Kinesis stream via a Sink

Writes the bytestream to a Kinesis stream via a Sink

Type parameters:
F

effect type of the stream

Value parameters:
parallelism

the max number of writes to race concurrently

producer

kinesis producer client to use

streamName

the name of the Kinesis stream to write to

Returns:

a Sink that accepts a stream of bytes