Documentation ¶
Index ¶
- Constants
- func GetKafkaProducer(ctx context.Context) (message.Producer, error)
- func GetPostgresqlSingleStateRepository(ctx context.Context) (stateful.SingleStateRepository, error)
- func GetPostgresqlUpsertRepository[T any](ctx context.Context) (materialise.UpsertRepository[T], error)
- func GetRetry(ctx context.Context) (*runtime_retry.Retry, error)
- func InjectedRuntimes() []runtime.Runtime
- func InjectorKafkaConsumerHandlerConfiguration(ctx context.Context) (runtime.Configuration[*runtime_sarama.Consumer], error)
- func InjectorKafkaConsumerKeyedHandler(ctx context.Context) (runtime_sarama.ConsumerLoop, error)
- func InjectorPostgresqlSingleStateRepository(ctx context.Context) (stateful.SingleStateRepository, error)
- func InjectorPostgresqlUpsertRepository[T any](ctx context.Context) (materialise.UpsertRepository[T], error)
- func InjectorRouteProducer(ctx context.Context) (runtime.Configuration[*runtime_bunrouter.Router], error)
- func InjectorRuntime(qualifier string) inverse.Injector[runtime.Runtime]
- func RegisterConsumer()
- func RegisterConsumerKeyedConfig(config []runtime.Configuration[*runtime_sarama.Consumer])
- func RegisterPostgresql(config []runtime.Configuration[*runtime_bun.PostgresqlConnection])
- func RegisterPostgresqlSingleState(tableName string)
- func RegisterPostgresqlUpsert[T any]()
- func RegisterProducer()
- func RegisterProducerConfig(config []runtime.Configuration[*runtime_sarama.Producer])
- func RegisterRetry(config []runtime.Configuration[*runtime_retry.Retry])
- func RegisterRoute(config []runtime.Configuration[*runtime_bunrouter.Router])
- type JoinPostgresqlFunctionConfiguration
- type Main
- type MaterialisePostgresqlFunctionConfiguration
- type MaterialisePostgresqlOneToOneFunctionConfiguration
- type RouterAdapterConfiguration
- type RouterConfiguration
- type RuntimeFacade
- type StatefulPostgresqlFunctionConfiguration
- type StatefulPostgresqlOneToOneFunctionConfiguration
- type StatefulPostgresqlOneToTwoFunctionConfiguration
- type StatelessOneToOneConfiguration
- type StatelessOneToOneExplodeConfiguration
- type StatelessOneToTwoConfiguration
- type StatelessSingleFunctionConfiguration
Constants ¶
View Source
const ( QualifierKafkaProducerConfiguration = "QualifierKafkaProducerConfiguration" QualifierKafkaProducer = "QualifierKafkaProducer" QualifierKafkaConsumerConfiguration = "QualifierKafkaConsumerConfiguration" QualifierKafkaConsumer = "QualifierKafkaConsumer" QualifierKafkaConsumerHandler = "QualifierKafkaConsumerHandler" QualifierKafkaConsumerSingleFunction = "QualifierKafkaConsumerSingleFunction" QualifierKafkaConsumerBatchFunction = "QualifierKafkaConsumerBatchFunction" QualifierKafkaConsumerKeyFunction = "QualifierKafkaConsumerKeyFunction" )
View Source
const ( QualifierPostgresqlConnectionConfiguration = "QualifierPostgresqlConnectionConfiguration" QualifierPostgresqlConnection = "QualifierPostgresqlConnection" QualifierPostgresqlSingleStateRepository = "QualifierPostgresqlSingleStateRepository" QualifierPostgresqlSingleStateRepositoryTableName = "QualifierPostgresqlSingleStateRepositoryTableName" QualifierPostgresqlUpsertRepository = "QualifierPostgresqlUpsertRepository" )
View Source
const ( QualifierRetryConfiguration = "QualifierRetryConfiguration" QualifierRetry = "QualifierRetry" )
View Source
const ( QualifierRouteConfiguration = "QualifierRouteConfiguration" QualifierRoute = "QualifierRoute" )
View Source
const (
QualifierRuntime = "QualifierRuntime"
)
Variables ¶
This section is empty.
Functions ¶
func GetKafkaProducer ¶ added in v0.0.20
func GetPostgresqlSingleStateRepository ¶ added in v0.0.20
func GetPostgresqlSingleStateRepository(ctx context.Context) (stateful.SingleStateRepository, error)
func GetPostgresqlUpsertRepository ¶ added in v0.0.20
func GetPostgresqlUpsertRepository[T any](ctx context.Context) (materialise.UpsertRepository[T], error)
func InjectedRuntimes ¶ added in v0.0.20
func InjectorKafkaConsumerHandlerConfiguration ¶ added in v0.1.0
func InjectorKafkaConsumerHandlerConfiguration(ctx context.Context) (runtime.Configuration[*runtime_sarama.Consumer], error)
func InjectorKafkaConsumerKeyedHandler ¶ added in v0.1.0
func InjectorKafkaConsumerKeyedHandler(ctx context.Context) (runtime_sarama.ConsumerLoop, error)
func InjectorPostgresqlSingleStateRepository ¶ added in v0.0.20
func InjectorPostgresqlSingleStateRepository(ctx context.Context) (stateful.SingleStateRepository, error)
func InjectorPostgresqlUpsertRepository ¶ added in v0.0.20
func InjectorPostgresqlUpsertRepository[T any](ctx context.Context) (materialise.UpsertRepository[T], error)
func InjectorRouteProducer ¶ added in v0.0.21
func InjectorRouteProducer(ctx context.Context) (runtime.Configuration[*runtime_bunrouter.Router], error)
func InjectorRuntime ¶ added in v0.0.20
func RegisterConsumerKeyedConfig ¶ added in v0.1.0
func RegisterConsumerKeyedConfig(config []runtime.Configuration[*runtime_sarama.Consumer])
func RegisterPostgresql ¶ added in v0.0.20
func RegisterPostgresql(config []runtime.Configuration[*runtime_bun.PostgresqlConnection])
Postgresql connection
func RegisterPostgresqlSingleState ¶ added in v0.0.20
func RegisterPostgresqlSingleState(tableName string)
Single state repository
func RegisterPostgresqlUpsert ¶ added in v0.0.20
func RegisterPostgresqlUpsert[T any]()
Upsert materialiser
func RegisterProducer ¶ added in v0.0.20
func RegisterProducer()
func RegisterProducerConfig ¶ added in v0.0.20
func RegisterProducerConfig(config []runtime.Configuration[*runtime_sarama.Producer])
Producer
func RegisterRetry ¶ added in v0.0.20
func RegisterRetry(config []runtime.Configuration[*runtime_retry.Retry])
Retry
func RegisterRoute ¶ added in v0.0.20
func RegisterRoute(config []runtime.Configuration[*runtime_bunrouter.Router])
Types ¶
type JoinPostgresqlFunctionConfiguration ¶
type JoinPostgresqlFunctionConfiguration struct { PostgresqlConfiguration []runtime.Configuration[*runtime_bun.PostgresqlConnection] KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] StatefulFunctions map[string]stateful.SingleFunction PersistenceIdFunctions map[string]stateful.PersistenceIdFunction[[]byte, []byte] IntermediateTopicName string PersistenceTableName string RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
func (JoinPostgresqlFunctionConfiguration) Runtime ¶
func (c JoinPostgresqlFunctionConfiguration) Runtime() runtime.Runtime
type MaterialisePostgresqlFunctionConfiguration ¶ added in v0.0.4
type MaterialisePostgresqlFunctionConfiguration[T any] struct { PostgresqlConfiguration []runtime.Configuration[*runtime_bun.PostgresqlConnection] KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] MaterialiseMapFunction materialise.MapFunction[message.Bytes, message.Bytes, T] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
func (MaterialisePostgresqlFunctionConfiguration[T]) Runtime ¶ added in v0.0.4
func (c MaterialisePostgresqlFunctionConfiguration[T]) Runtime() runtime.Runtime
type MaterialisePostgresqlOneToOneFunctionConfiguration ¶ added in v0.0.17
type MaterialisePostgresqlOneToOneFunctionConfiguration[S any, IK any, IV any] struct { Name string InputTopic topic.Topic[IK, IV] Function materialise.MapFunction[IK, IV, S] InputBroker string OutputBroker string HttpPort int PostgresConnectionString string PostgresqlConfiguration []runtime.Configuration[*runtime_bun.PostgresqlConnection] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (MaterialisePostgresqlOneToOneFunctionConfiguration[S, IK, IV]) Runtime ¶ added in v0.0.17
func (c MaterialisePostgresqlOneToOneFunctionConfiguration[S, IK, IV]) Runtime() runtime.Runtime
type RouterAdapterConfiguration ¶ added in v0.0.16
type RouterAdapterConfiguration[Request any, InputKey any, InputValue any] struct { Name string ProduceTopic topic.Topic[InputKey, InputValue] ProduceBroker string RequestBodyFormat format.Format[Request] RequestMapFunction stateless.OneToOneFunction[message.Bytes, Request, InputKey, InputValue] HttpPort int KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (RouterAdapterConfiguration[Request, InputKey, InputValue]) Runtime ¶ added in v0.0.16
func (c RouterAdapterConfiguration[Request, InputKey, InputValue]) Runtime() runtime.Runtime
type RouterConfiguration ¶ added in v0.0.6
type RouterConfiguration struct { KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (RouterConfiguration) Runtime ¶ added in v0.0.6
func (c RouterConfiguration) Runtime() runtime.Runtime
type RuntimeFacade ¶ added in v0.0.13
func (*RuntimeFacade) Start ¶ added in v0.0.13
func (r *RuntimeFacade) Start() error
func (*RuntimeFacade) Stop ¶ added in v0.0.13
func (r *RuntimeFacade) Stop()
type StatefulPostgresqlFunctionConfiguration ¶
type StatefulPostgresqlFunctionConfiguration struct { PostgresqlConfiguration []runtime.Configuration[*runtime_bun.PostgresqlConnection] KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] StatefulFunction stateful.SingleFunction PersistenceIdFunction stateful.PersistenceIdFunction[[]byte, []byte] PersistenceTableName string RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (StatefulPostgresqlFunctionConfiguration) Runtime ¶
func (c StatefulPostgresqlFunctionConfiguration) Runtime() runtime.Runtime
type StatefulPostgresqlOneToOneFunctionConfiguration ¶ added in v0.0.15
type StatefulPostgresqlOneToOneFunctionConfiguration[S any, IK any, IV any, OK any, OV any] struct { Name string InputTopic topic.Topic[IK, IV] OutputTopic topic.Topic[OK, OV] Function stateful.OneToOneFunction[S, IK, IV, OK, OV] InputBroker string OutputBroker string HttpPort int StateFormat format.Format[S] StateKeyFunction stateful.PersistenceIdFunction[IK, IV] PostgresTable string PostgresConnectionString string PostgresqlConfiguration []runtime.Configuration[*runtime_bun.PostgresqlConnection] KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (StatefulPostgresqlOneToOneFunctionConfiguration[S, IK, IV, OK, OV]) Runtime ¶ added in v0.0.15
func (c StatefulPostgresqlOneToOneFunctionConfiguration[S, IK, IV, OK, OV]) Runtime() runtime.Runtime
type StatefulPostgresqlOneToTwoFunctionConfiguration ¶ added in v0.0.15
type StatefulPostgresqlOneToTwoFunctionConfiguration[S any, IK any, IV any, OK1 any, OV1 any, OK2 any, OV2 any] struct { Name string InputTopic topic.Topic[IK, IV] OutputTopicOne topic.Topic[OK1, OV1] OutputTopicTwo topic.Topic[OK2, OV2] Function stateful.OneToTwoFunction[S, IK, IV, OK1, OV1, OK2, OV2] InputBroker string OutputBroker string HttpPort int StateFormat format.Format[S] StateKeyFunction stateful.PersistenceIdFunction[IK, IV] PostgresTable string PostgresConnectionString string PostgresqlConfiguration []runtime.Configuration[*runtime_bun.PostgresqlConnection] KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (StatefulPostgresqlOneToTwoFunctionConfiguration[S, IK, IV, OK1, OV1, OK2, OV2]) Runtime ¶ added in v0.0.15
func (c StatefulPostgresqlOneToTwoFunctionConfiguration[S, IK, IV, OK1, OV1, OK2, OV2]) Runtime() runtime.Runtime
type StatelessOneToOneConfiguration ¶ added in v0.0.15
type StatelessOneToOneConfiguration[IK any, IV any, OK any, OV any] struct { Name string InputTopic topic.Topic[IK, IV] OutputTopic topic.Topic[OK, OV] Function stateless.OneToOneFunction[IK, IV, OK, OV] InputBroker string OutputBroker string HttpPort int KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
func (StatelessOneToOneConfiguration[IK, IV, OK, OV]) Runtime ¶ added in v0.0.15
func (c StatelessOneToOneConfiguration[IK, IV, OK, OV]) Runtime() runtime.Runtime
type StatelessOneToOneExplodeConfiguration ¶ added in v0.0.15
type StatelessOneToOneExplodeConfiguration[IK any, IV any, OK any, OV any] struct { Name string InputTopic topic.Topic[IK, IV] OutputTopic topic.Topic[OK, OV] Function stateless.OneToOneExplodeFunction[IK, IV, OK, OV] InputBroker string OutputBroker string HttpPort int KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
func (StatelessOneToOneExplodeConfiguration[IK, IV, OK, OV]) Runtime ¶ added in v0.0.15
func (c StatelessOneToOneExplodeConfiguration[IK, IV, OK, OV]) Runtime() runtime.Runtime
type StatelessOneToTwoConfiguration ¶ added in v0.0.15
type StatelessOneToTwoConfiguration[IK any, IV any, OK1 any, OV1 any, OK2 any, OV2 any] struct { Name string InputTopic topic.Topic[IK, IV] OutputTopicOne topic.Topic[OK1, OV1] OutputTopicTwo topic.Topic[OK2, OV2] Function stateless.OneToTwoFunction[IK, IV, OK1, OV1, OK2, OV2] InputBroker string OutputBroker string HttpPort int KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
func (StatelessOneToTwoConfiguration[IK, IV, OK1, OV1, OK2, OV2]) Runtime ¶ added in v0.0.15
func (c StatelessOneToTwoConfiguration[IK, IV, OK1, OV1, OK2, OV2]) Runtime() runtime.Runtime
type StatelessSingleFunctionConfiguration ¶
type StatelessSingleFunctionConfiguration struct { KafkaProducerConfiguration []runtime.Configuration[*runtime_sarama.Producer] KafkaConsumerConfiguration []runtime.Configuration[*runtime_sarama.Consumer] RetryConfiguration []runtime.Configuration[*runtime_retry.Retry] StatelessFunction stateless.SingleFunction RouteConfiguration []runtime.Configuration[*runtime_bunrouter.Router] }
Wiring configuration
func (StatelessSingleFunctionConfiguration) Runtime ¶
func (c StatelessSingleFunctionConfiguration) Runtime() runtime.Runtime
Source Files ¶
- runtime_facade.go
- runtime_postgresql_join.go
- runtime_postgresql_materialise.go
- runtime_postgresql_materialise_one_to_one.go
- runtime_postgresql_stateful.go
- runtime_postgresql_stateful_one_to_one.go
- runtime_postgresql_stateful_one_to_two.go
- runtime_router.go
- runtime_router_adapter.go
- runtime_stateless.go
- runtime_stateless_one_to_one.go
- runtime_stateless_one_to_one_explode.go
- runtime_stateless_one_to_two.go
- runtime_switch.go
- util_kafka.go
- util_postgresql.go
- util_retry.go
- util_route.go
- util_runtime.go
Directories ¶
Path | Synopsis |
---|---|
Package mock is a generated GoMock package.
|
Package mock is a generated GoMock package. |
Click to show internal directories.
Click to hide internal directories.