mirror of
https://github.com/zitadel/zitadel.git
synced 2025-06-12 03:38:32 +00:00
reduce milestone pushed
This commit is contained in:
parent
51a9a54cfd
commit
a14871ce46
@ -49,7 +49,7 @@ Projections:
|
||||
NotificationsQuotas:
|
||||
# RequeueEvery: 1s
|
||||
Telemetry:
|
||||
RequeueEvery: 10s
|
||||
# RequeueEvery: 1s
|
||||
|
||||
DefaultInstance:
|
||||
LoginPolicy:
|
||||
|
@ -6,11 +6,11 @@ import (
|
||||
"github.com/zitadel/zitadel/internal/repository/milestone"
|
||||
)
|
||||
|
||||
// MilestonePushed writes a new event with a new milestone.Aggregate to the eventstore
|
||||
// MilestonePushed writes a new milestone.PushedEvent with a new milestone.Aggregate to the eventstore
|
||||
func (c *Commands) MilestonePushed(
|
||||
ctx context.Context,
|
||||
instanceID string,
|
||||
eventType milestone.PushedEventType,
|
||||
msType milestone.Type,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) error {
|
||||
@ -18,10 +18,6 @@ func (c *Commands) MilestonePushed(
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
pushedEvent, err := milestone.NewPushedEventByType(ctx, eventType, milestone.NewAggregate(id, instanceID, instanceID), endpoints, primaryDomain)
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
_, err = c.eventstore.Push(ctx, pushedEvent)
|
||||
_, err = c.eventstore.Push(ctx, milestone.NewPushedEvent(ctx, milestone.NewAggregate(id, instanceID, instanceID), msType, endpoints, primaryDomain))
|
||||
return err
|
||||
}
|
||||
|
@ -52,7 +52,7 @@ type StatementHandler struct {
|
||||
|
||||
bulkLimit uint64
|
||||
|
||||
subscribe bool
|
||||
reduceScheduledPseudoEvent bool
|
||||
}
|
||||
|
||||
func NewStatementHandler(
|
||||
@ -61,37 +61,40 @@ func NewStatementHandler(
|
||||
) StatementHandler {
|
||||
aggregateTypes := make([]eventstore.AggregateType, 0, len(config.Reducers))
|
||||
reduces := make(map[eventstore.EventType]handler.Reduce, len(config.Reducers))
|
||||
subscribe := true
|
||||
reduceScheduledPseudoEvent := false
|
||||
for _, aggReducer := range config.Reducers {
|
||||
aggregateTypes = append(aggregateTypes, aggReducer.Aggregate)
|
||||
if aggReducer.Aggregate == pseudo.AggregateType {
|
||||
subscribe = false
|
||||
reduceScheduledPseudoEvent = true
|
||||
if len(config.Reducers) != 1 ||
|
||||
len(aggReducer.EventRedusers) != 1 ||
|
||||
aggReducer.EventRedusers[0].Event != pseudo.ScheduledEventType {
|
||||
panic("if a pseudo.AggregateType is reduced, exactly one event reducer for pseudo.ScheduledEventType is supported and no other aggregate can be reduced")
|
||||
}
|
||||
}
|
||||
for _, eventReducer := range aggReducer.EventRedusers {
|
||||
if eventReducer.Event == pseudo.TimestampEventType {
|
||||
subscribe = false
|
||||
}
|
||||
reduces[eventReducer.Event] = eventReducer.Reduce
|
||||
}
|
||||
}
|
||||
|
||||
h := StatementHandler{
|
||||
client: config.Client,
|
||||
sequenceTable: config.SequenceTable,
|
||||
maxFailureCount: config.MaxFailureCount,
|
||||
currentSequenceStmt: fmt.Sprintf(currentSequenceStmtFormat, config.SequenceTable),
|
||||
updateSequencesBaseStmt: fmt.Sprintf(updateCurrentSequencesStmtFormat, config.SequenceTable),
|
||||
failureCountStmt: fmt.Sprintf(failureCountStmtFormat, config.FailedEventsTable),
|
||||
setFailureCountStmt: fmt.Sprintf(setFailureCountStmtFormat, config.FailedEventsTable),
|
||||
aggregates: aggregateTypes,
|
||||
reduces: reduces,
|
||||
bulkLimit: config.BulkLimit,
|
||||
Locker: NewLocker(config.Client.DB, config.LockTable, config.ProjectionName),
|
||||
initCheck: config.InitCheck,
|
||||
initialized: make(chan bool),
|
||||
client: config.Client,
|
||||
sequenceTable: config.SequenceTable,
|
||||
maxFailureCount: config.MaxFailureCount,
|
||||
currentSequenceStmt: fmt.Sprintf(currentSequenceStmtFormat, config.SequenceTable),
|
||||
updateSequencesBaseStmt: fmt.Sprintf(updateCurrentSequencesStmtFormat, config.SequenceTable),
|
||||
failureCountStmt: fmt.Sprintf(failureCountStmtFormat, config.FailedEventsTable),
|
||||
setFailureCountStmt: fmt.Sprintf(setFailureCountStmtFormat, config.FailedEventsTable),
|
||||
aggregates: aggregateTypes,
|
||||
reduces: reduces,
|
||||
bulkLimit: config.BulkLimit,
|
||||
Locker: NewLocker(config.Client.DB, config.LockTable, config.ProjectionName),
|
||||
initCheck: config.InitCheck,
|
||||
initialized: make(chan bool),
|
||||
reduceScheduledPseudoEvent: reduceScheduledPseudoEvent,
|
||||
}
|
||||
|
||||
h.ProjectionHandler = handler.NewProjectionHandler(ctx, config.ProjectionHandlerConfig, h.reduce, h.Update, h.SearchQuery, h.Lock, h.Unlock, h.initialized, subscribe)
|
||||
h.ProjectionHandler = handler.NewProjectionHandler(ctx, config.ProjectionHandlerConfig, h.reduce, h.Update, h.SearchQuery, h.Lock, h.Unlock, h.initialized, reduceScheduledPseudoEvent)
|
||||
|
||||
return h
|
||||
}
|
||||
@ -99,10 +102,9 @@ func NewStatementHandler(
|
||||
func (h *StatementHandler) Start() {
|
||||
h.initialized <- true
|
||||
close(h.initialized)
|
||||
if !h.subscribe {
|
||||
return
|
||||
if h.reduceScheduledPseudoEvent {
|
||||
h.Subscribe(h.aggregates...)
|
||||
}
|
||||
h.Subscribe(h.aggregates...)
|
||||
}
|
||||
|
||||
func (h *StatementHandler) SearchQuery(ctx context.Context, instanceIDs []string) (*eventstore.SearchQueryBuilder, uint64, error) {
|
||||
@ -111,7 +113,12 @@ func (h *StatementHandler) SearchQuery(ctx context.Context, instanceIDs []string
|
||||
return nil, 0, err
|
||||
}
|
||||
|
||||
queryBuilder := eventstore.NewSearchQueryBuilder(eventstore.ColumnsEvent).Limit(h.bulkLimit).AllowTimeTravel()
|
||||
bulkLimit := h.bulkLimit
|
||||
if h.reduceScheduledPseudoEvent {
|
||||
bulkLimit = 1
|
||||
}
|
||||
|
||||
queryBuilder := eventstore.NewSearchQueryBuilder(eventstore.ColumnsEvent).Limit(bulkLimit).AllowTimeTravel()
|
||||
|
||||
for _, aggregateType := range h.aggregates {
|
||||
for _, instanceID := range instanceIDs {
|
||||
@ -124,13 +131,18 @@ func (h *StatementHandler) SearchQuery(ctx context.Context, instanceIDs []string
|
||||
}
|
||||
queryBuilder.
|
||||
AddQuery().
|
||||
AggregateTypes(aggregateType).
|
||||
SequenceGreater(seq).
|
||||
InstanceID(instanceID)
|
||||
|
||||
if !h.reduceScheduledPseudoEvent {
|
||||
queryBuilder.
|
||||
AddQuery().
|
||||
AggregateTypes(aggregateType)
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
return queryBuilder, h.bulkLimit, nil
|
||||
return queryBuilder, bulkLimit, nil
|
||||
}
|
||||
|
||||
// Update implements handler.Update
|
||||
|
@ -51,19 +51,20 @@ type NowFunc func() time.Time
|
||||
|
||||
type ProjectionHandler struct {
|
||||
Handler
|
||||
ProjectionName string
|
||||
reduce Reduce
|
||||
update Update
|
||||
searchQuery SearchQuery
|
||||
triggerProjection *time.Timer
|
||||
lock Lock
|
||||
unlock Unlock
|
||||
requeueAfter time.Duration
|
||||
retryFailedAfter time.Duration
|
||||
retries int
|
||||
concurrentInstances int
|
||||
handleActiveInstances time.Duration
|
||||
nowFunc NowFunc
|
||||
ProjectionName string
|
||||
reduce Reduce
|
||||
update Update
|
||||
searchQuery SearchQuery
|
||||
triggerProjection *time.Timer
|
||||
lock Lock
|
||||
unlock Unlock
|
||||
requeueAfter time.Duration
|
||||
retryFailedAfter time.Duration
|
||||
retries int
|
||||
concurrentInstances int
|
||||
handleActiveInstances time.Duration
|
||||
nowFunc NowFunc
|
||||
reduceScheduledPseudoEvent bool
|
||||
}
|
||||
|
||||
func NewProjectionHandler(
|
||||
@ -75,32 +76,33 @@ func NewProjectionHandler(
|
||||
lock Lock,
|
||||
unlock Unlock,
|
||||
initialized <-chan bool,
|
||||
subscribe bool,
|
||||
reduceScheduledPseudoEvent bool,
|
||||
) *ProjectionHandler {
|
||||
concurrentInstances := int(config.ConcurrentInstances)
|
||||
if concurrentInstances < 1 {
|
||||
concurrentInstances = 1
|
||||
}
|
||||
h := &ProjectionHandler{
|
||||
Handler: NewHandler(config.HandlerConfig),
|
||||
ProjectionName: config.ProjectionName,
|
||||
reduce: reduce,
|
||||
update: update,
|
||||
searchQuery: query,
|
||||
lock: lock,
|
||||
unlock: unlock,
|
||||
requeueAfter: config.RequeueEvery,
|
||||
triggerProjection: time.NewTimer(0), // first trigger is instant on startup
|
||||
retryFailedAfter: config.RetryFailedAfter,
|
||||
retries: int(config.Retries),
|
||||
concurrentInstances: concurrentInstances,
|
||||
handleActiveInstances: config.HandleActiveInstances,
|
||||
nowFunc: time.Now,
|
||||
Handler: NewHandler(config.HandlerConfig),
|
||||
ProjectionName: config.ProjectionName,
|
||||
reduce: reduce,
|
||||
update: update,
|
||||
searchQuery: query,
|
||||
lock: lock,
|
||||
unlock: unlock,
|
||||
requeueAfter: config.RequeueEvery,
|
||||
triggerProjection: time.NewTimer(0), // first trigger is instant on startup
|
||||
retryFailedAfter: config.RetryFailedAfter,
|
||||
retries: int(config.Retries),
|
||||
concurrentInstances: concurrentInstances,
|
||||
handleActiveInstances: config.HandleActiveInstances,
|
||||
nowFunc: time.Now,
|
||||
reduceScheduledPseudoEvent: reduceScheduledPseudoEvent,
|
||||
}
|
||||
|
||||
go func() {
|
||||
<-initialized
|
||||
if subscribe {
|
||||
if h.reduceScheduledPseudoEvent {
|
||||
go h.subscribe(ctx)
|
||||
}
|
||||
go h.schedule(ctx)
|
||||
@ -116,9 +118,6 @@ func (h *ProjectionHandler) Trigger(ctx context.Context, instances ...string) er
|
||||
if len(instances) > 0 {
|
||||
ids = instances
|
||||
}
|
||||
if h.searchQuery == nil {
|
||||
return h.processTimestamp(ctx, ids...)
|
||||
}
|
||||
return h.processEvents(ctx, ids...)
|
||||
}
|
||||
|
||||
@ -141,11 +140,6 @@ func (h *ProjectionHandler) processEvents(ctx context.Context, ids ...string) er
|
||||
}
|
||||
}
|
||||
|
||||
func (h *ProjectionHandler) processTimestamp(ctx context.Context, instances ...string) error {
|
||||
_, err := h.Process(ctx, pseudo.NewTimestampEvent(h.nowFunc(), instances...))
|
||||
return err
|
||||
}
|
||||
|
||||
// Process handles multiple events by reducing them to statements and updating the projection
|
||||
func (h *ProjectionHandler) Process(ctx context.Context, events ...eventstore.Event) (index int, err error) {
|
||||
if len(events) == 0 {
|
||||
@ -182,6 +176,9 @@ func (h *ProjectionHandler) FetchEvents(ctx context.Context, instances ...string
|
||||
if err != nil {
|
||||
return nil, false, err
|
||||
}
|
||||
if h.reduceScheduledPseudoEvent {
|
||||
events[0] = pseudo.NewScheduledEvent(ctx, time.Now(), instances...)
|
||||
}
|
||||
return events, int(eventsLimit) == len(events), err
|
||||
}
|
||||
|
||||
|
@ -72,7 +72,7 @@ func (t *telemetryPusher) reducers() []handler.AggregateReducer {
|
||||
return []handler.AggregateReducer{{
|
||||
Aggregate: pseudo.AggregateType,
|
||||
EventRedusers: []handler.EventReducer{{
|
||||
Event: pseudo.TimestampEventType,
|
||||
Event: pseudo.ScheduledEventType,
|
||||
Reduce: t.pushMilestones,
|
||||
}},
|
||||
}}
|
||||
@ -80,7 +80,7 @@ func (t *telemetryPusher) reducers() []handler.AggregateReducer {
|
||||
|
||||
func (t *telemetryPusher) pushMilestones(event eventstore.Event) (*handler.Statement, error) {
|
||||
ctx := call.WithTimestamp(context.Background())
|
||||
timestampEvent, ok := event.(pseudo.TimestampEvent)
|
||||
scheduledEvent, ok := event.(*pseudo.ScheduledEvent)
|
||||
if !ok {
|
||||
return nil, errors.ThrowInvalidArgumentf(nil, "HANDL-lDTs5", "reduce.wrong.event.type %s", event.Type())
|
||||
}
|
||||
@ -97,9 +97,9 @@ func (t *telemetryPusher) pushMilestones(event eventstore.Event) (*handler.State
|
||||
if err != nil {
|
||||
return nil, err
|
||||
}
|
||||
unpushedMilestones, err := t.queries.Queries.SearchMilestones(ctx, timestampEvent.InstanceIDs, &query.MilestonesSearchQueries{
|
||||
unpushedMilestones, err := t.queries.Queries.SearchMilestones(ctx, scheduledEvent.InstanceIDs, &query.MilestonesSearchQueries{
|
||||
SearchRequest: query.SearchRequest{
|
||||
Offset: 100,
|
||||
Limit: 100,
|
||||
SortingColumn: query.MilestoneReachedDateColID,
|
||||
Asc: true,
|
||||
},
|
||||
@ -110,7 +110,7 @@ func (t *telemetryPusher) pushMilestones(event eventstore.Event) (*handler.State
|
||||
}
|
||||
var errs int
|
||||
for _, ms := range unpushedMilestones.Milestones {
|
||||
if err = t.pushMilestone(ctx, ms); err != nil {
|
||||
if err = t.pushMilestone(ctx, scheduledEvent, ms); err != nil {
|
||||
errs++
|
||||
logging.Warnf("pushing milestone %+v failed: %s", *ms, err.Error())
|
||||
}
|
||||
@ -119,10 +119,10 @@ func (t *telemetryPusher) pushMilestones(event eventstore.Event) (*handler.State
|
||||
return nil, fmt.Errorf("pushing %d of %d milestones failed", errs, unpushedMilestones.Count)
|
||||
}
|
||||
|
||||
return crdb.NewNoOpStatement(timestampEvent), nil
|
||||
return crdb.NewNoOpStatement(scheduledEvent), nil
|
||||
}
|
||||
|
||||
func (t *telemetryPusher) pushMilestone(ctx context.Context, ms *query.Milestone) error {
|
||||
func (t *telemetryPusher) pushMilestone(ctx context.Context, event *pseudo.ScheduledEvent, ms *query.Milestone) error {
|
||||
for _, endpoint := range t.endpoints {
|
||||
if err := types.SendJSON(
|
||||
ctx,
|
||||
@ -133,12 +133,12 @@ func (t *telemetryPusher) pushMilestone(ctx context.Context, ms *query.Milestone
|
||||
t.queries.GetFileSystemProvider,
|
||||
t.queries.GetLogProvider,
|
||||
ms,
|
||||
nil,
|
||||
event,
|
||||
t.metricSuccessfulDeliveriesJSON,
|
||||
t.metricFailedDeliveriesJSON,
|
||||
).WithoutTemplate(); err != nil {
|
||||
return err
|
||||
}
|
||||
}
|
||||
return t.commands.MilestonePushed(ctx, ms.InstanceID, ms.MilestoneType, t.endpoints, ms.PrimaryDomain)
|
||||
return t.commands.MilestonePushed(ctx, ms.InstanceID, ms.Type, t.endpoints, ms.PrimaryDomain)
|
||||
}
|
||||
|
@ -26,7 +26,7 @@ type Milestones struct {
|
||||
|
||||
type Milestone struct {
|
||||
InstanceID string
|
||||
MilestoneType milestone.PushedEventType
|
||||
Type milestone.Type
|
||||
ReachedDate time.Time
|
||||
PushedDate time.Time
|
||||
PrimaryDomain string
|
||||
@ -55,7 +55,7 @@ var (
|
||||
table: milestonesTable,
|
||||
}
|
||||
MilestoneTypeColID = Column{
|
||||
name: projection.MilestoneColumnMilestoneType,
|
||||
name: projection.MilestoneColumnType,
|
||||
table: milestonesTable,
|
||||
}
|
||||
MilestonePrimaryDomainColID = Column{
|
||||
@ -80,10 +80,14 @@ func (q *Queries) SearchMilestones(ctx context.Context, instanceIDs []string, qu
|
||||
if len(instanceIDs) == 0 {
|
||||
instanceIDs = []string{authz.GetInstance(ctx).InstanceID()}
|
||||
}
|
||||
stmt, args, err := queries.toQuery(query).
|
||||
Where(sq.Eq{
|
||||
MilestoneInstanceIDColID.identifier(): fmt.Sprintf("IN (%s)", strings.Join(instanceIDs, ",")),
|
||||
}).ToSql()
|
||||
instanceIDParams := make([]string, len(instanceIDs))
|
||||
instanceIDArgs := make([]interface{}, len(instanceIDs))
|
||||
for idx := range instanceIDs {
|
||||
instanceIDParams[idx] = fmt.Sprintf("$%d", idx+1)
|
||||
instanceIDArgs[idx] = instanceIDs[idx]
|
||||
}
|
||||
expr := fmt.Sprintf("%s IN (%s)", MilestoneInstanceIDColID.name, strings.Join(instanceIDParams, ","))
|
||||
stmt, args, err := queries.toQuery(query).Where(sq.Expr(expr, instanceIDArgs...)).ToSql()
|
||||
if err != nil {
|
||||
return nil, errors.ThrowInternal(err, "QUERY-A9i5k", "Errors.Query.SQLStatement")
|
||||
}
|
||||
@ -102,28 +106,37 @@ func (q *Queries) SearchMilestones(ctx context.Context, instanceIDs []string, qu
|
||||
|
||||
func prepareMilestonesQuery(ctx context.Context, db prepareDatabase) (sq.SelectBuilder, func(*sql.Rows) (*Milestones, error)) {
|
||||
return sq.Select(
|
||||
MilestoneInstanceIDColID.identifier(),
|
||||
MilestonePrimaryDomainColID.identifier(),
|
||||
MilestoneReachedDateColID.identifier(),
|
||||
MilestonePushedDateColID.identifier(),
|
||||
MilestoneTypeColID.identifier(),
|
||||
countColumn.identifier(),
|
||||
).
|
||||
From(notificationPolicyTable.identifier() + db.Timetravel(call.Took(ctx))).
|
||||
From(milestonesTable.identifier() + db.Timetravel(call.Took(ctx))).
|
||||
PlaceholderFormat(sq.Dollar),
|
||||
func(rows *sql.Rows) (*Milestones, error) {
|
||||
milestones := make([]*Milestone, 0)
|
||||
var count uint64
|
||||
for rows.Next() {
|
||||
m := new(Milestone)
|
||||
reachedDate := sql.NullTime{}
|
||||
pushedDate := sql.NullTime{}
|
||||
primaryDomain := sql.NullString{}
|
||||
err := rows.Scan(
|
||||
&m.PrimaryDomain,
|
||||
&m.ReachedDate,
|
||||
&m.MilestoneType,
|
||||
&m.InstanceID,
|
||||
&primaryDomain,
|
||||
&reachedDate,
|
||||
&pushedDate,
|
||||
&m.Type,
|
||||
&count,
|
||||
)
|
||||
if err != nil {
|
||||
return nil, err
|
||||
}
|
||||
m.PrimaryDomain = primaryDomain.String
|
||||
m.ReachedDate = reachedDate.Time
|
||||
m.ReachedDate = pushedDate.Time
|
||||
milestones = append(milestones, m)
|
||||
}
|
||||
if err := rows.Close(); err != nil {
|
||||
|
@ -21,7 +21,7 @@ const (
|
||||
MilestonesProjectionTable = "projections.milestones"
|
||||
|
||||
MilestoneColumnInstanceID = "instance_id"
|
||||
MilestoneColumnMilestoneType = "milestone_type"
|
||||
MilestoneColumnType = "type"
|
||||
MilestoneColumnPrimaryDomain = "primary_domain"
|
||||
MilestoneColumnReachedDate = "reached_date"
|
||||
MilestoneColumnPushedDate = "pushed_date"
|
||||
@ -38,12 +38,12 @@ func newMilestoneProjection(ctx context.Context, config crdb.StatementHandlerCon
|
||||
config.InitCheck = crdb.NewMultiTableCheck(
|
||||
crdb.NewTable([]*crdb.Column{
|
||||
crdb.NewColumn(MilestoneColumnInstanceID, crdb.ColumnTypeText),
|
||||
crdb.NewColumn(MilestoneColumnMilestoneType, crdb.ColumnTypeText),
|
||||
crdb.NewColumn(MilestoneColumnType, crdb.ColumnTypeEnum),
|
||||
crdb.NewColumn(MilestoneColumnReachedDate, crdb.ColumnTypeTimestamp, crdb.Nullable()),
|
||||
crdb.NewColumn(MilestoneColumnPushedDate, crdb.ColumnTypeTimestamp, crdb.Nullable()),
|
||||
crdb.NewColumn(MilestoneColumnPrimaryDomain, crdb.ColumnTypeText, crdb.Nullable()),
|
||||
},
|
||||
crdb.NewPrimaryKey(MilestoneColumnInstanceID, MilestoneColumnMilestoneType),
|
||||
crdb.NewPrimaryKey(MilestoneColumnInstanceID, MilestoneColumnType),
|
||||
),
|
||||
)
|
||||
p.StatementHandler = crdb.NewStatementHandler(ctx, config)
|
||||
@ -65,7 +65,7 @@ func (p *milestoneProjection) reducers() []handler.AggregateReducer {
|
||||
},
|
||||
{
|
||||
Event: instance.InstanceRemovedEventType,
|
||||
Reduce: p.milestoneReached(milestone.PushedInstanceDeletedEventType),
|
||||
Reduce: p.milestoneReached(milestone.InstanceDeleted),
|
||||
},
|
||||
},
|
||||
},
|
||||
@ -74,11 +74,11 @@ func (p *milestoneProjection) reducers() []handler.AggregateReducer {
|
||||
EventRedusers: []handler.EventReducer{
|
||||
{
|
||||
Event: project.ProjectAddedType,
|
||||
Reduce: p.milestoneReached(milestone.PushedProjectCreatedEventType),
|
||||
Reduce: p.milestoneReached(milestone.ProjectCreated),
|
||||
},
|
||||
{
|
||||
Event: project.ApplicationAddedType,
|
||||
Reduce: p.milestoneReached(milestone.PushedApplicationCreatedEventType),
|
||||
Reduce: p.milestoneReached(milestone.ApplicationCreated),
|
||||
},
|
||||
},
|
||||
},
|
||||
@ -91,23 +91,31 @@ func (p *milestoneProjection) reducers() []handler.AggregateReducer {
|
||||
},
|
||||
},
|
||||
},
|
||||
{
|
||||
Aggregate: milestone.AggregateType,
|
||||
EventRedusers: []handler.EventReducer{
|
||||
{
|
||||
Event: milestone.PushedEventType,
|
||||
Reduce: p.reducePushed,
|
||||
},
|
||||
},
|
||||
},
|
||||
}
|
||||
}
|
||||
|
||||
func (p *milestoneProjection) reduceInstanceAdded(event eventstore.Event) (*handler.Statement, error) {
|
||||
printEvent(event)
|
||||
e, ok := event.(*instance.InstanceAddedEvent)
|
||||
if !ok {
|
||||
return nil, errors.ThrowInvalidArgumentf(nil, "HANDL-JbHGS", "reduce.wrong.event.type %s", instance.InstanceAddedEventType)
|
||||
}
|
||||
allTypes := milestone.PushedEventTypes()
|
||||
allTypes := milestone.AllTypes()
|
||||
statements := make([]func(eventstore.Event) crdb.Exec, 0, len(allTypes))
|
||||
for _, ms := range allTypes {
|
||||
for _, msType := range allTypes {
|
||||
createColumns := []handler.Column{
|
||||
handler.NewCol(MilestoneColumnInstanceID, e.Aggregate().InstanceID),
|
||||
handler.NewCol(MilestoneColumnMilestoneType, ms),
|
||||
handler.NewCol(MilestoneColumnType, msType),
|
||||
}
|
||||
if ms == milestone.PushedInstanceCreatedEventType {
|
||||
if msType == milestone.InstanceCreated {
|
||||
createColumns = append(createColumns, handler.NewCol(MilestoneColumnReachedDate, event.CreationDate()))
|
||||
}
|
||||
statements = append(statements, crdb.AddCreateStatement(createColumns))
|
||||
@ -116,21 +124,20 @@ func (p *milestoneProjection) reduceInstanceAdded(event eventstore.Event) (*hand
|
||||
}
|
||||
|
||||
func (p *milestoneProjection) reduceInstanceDomainPrimarySet(event eventstore.Event) (*handler.Statement, error) {
|
||||
printEvent(event)
|
||||
e, ok := event.(*instance.DomainPrimarySetEvent)
|
||||
if !ok {
|
||||
return nil, errors.ThrowInvalidArgumentf(nil, "HANDL-Sfrgf", "reduce.wrong.event.type %s", instance.InstanceDomainPrimarySetEventType)
|
||||
}
|
||||
allTypes := milestone.PushedEventTypes()
|
||||
allTypes := milestone.AllTypes()
|
||||
statements := make([]func(eventstore.Event) crdb.Exec, 0, len(allTypes))
|
||||
for _, ms := range allTypes {
|
||||
for _, msType := range allTypes {
|
||||
statements = append(statements, crdb.AddUpdateStatement(
|
||||
[]handler.Column{
|
||||
handler.NewCol(MilestoneColumnPrimaryDomain, e.Domain),
|
||||
},
|
||||
[]handler.Condition{
|
||||
handler.NewCond(MilestoneColumnInstanceID, e.Aggregate().InstanceID),
|
||||
handler.NewCond(MilestoneColumnMilestoneType, ms),
|
||||
handler.NewCond(MilestoneColumnType, msType),
|
||||
crdb.NewIsNullCond(MilestoneColumnPushedDate),
|
||||
},
|
||||
))
|
||||
@ -138,9 +145,8 @@ func (p *milestoneProjection) reduceInstanceDomainPrimarySet(event eventstore.Ev
|
||||
return crdb.NewMultiStatement(e, statements...), nil
|
||||
}
|
||||
|
||||
func (p *milestoneProjection) milestoneReached(eventType milestone.PushedEventType) func(event eventstore.Event) (*handler.Statement, error) {
|
||||
func (p *milestoneProjection) milestoneReached(msType milestone.Type) func(event eventstore.Event) (*handler.Statement, error) {
|
||||
return func(event eventstore.Event) (*handler.Statement, error) {
|
||||
printEvent(event)
|
||||
if event.EditorUser() == "" || event.EditorService() == "" {
|
||||
return crdb.NewNoOpStatement(event), nil
|
||||
}
|
||||
@ -151,7 +157,7 @@ func (p *milestoneProjection) milestoneReached(eventType milestone.PushedEventTy
|
||||
},
|
||||
[]handler.Condition{
|
||||
handler.NewCond(MilestoneColumnInstanceID, event.Aggregate().InstanceID),
|
||||
handler.NewCond(MilestoneColumnMilestoneType, eventType),
|
||||
handler.NewCond(MilestoneColumnType, msType),
|
||||
crdb.NewIsNullCond(MilestoneColumnReachedDate),
|
||||
crdb.NewIsNullCond(MilestoneColumnPushedDate),
|
||||
},
|
||||
@ -159,13 +165,25 @@ func (p *milestoneProjection) milestoneReached(eventType milestone.PushedEventTy
|
||||
}
|
||||
}
|
||||
|
||||
func (p *milestoneProjection) reduceUserTokenAdded(event eventstore.Event) (*handler.Statement, error) {
|
||||
func (p *milestoneProjection) reducePushed(event eventstore.Event) (*handler.Statement, error) {
|
||||
printEvent(event)
|
||||
return crdb.NewNoOpStatement(event), nil
|
||||
e, ok := event.(*milestone.PushedEvent)
|
||||
if !ok {
|
||||
return nil, errors.ThrowInvalidArgumentf(nil, "HANDL-XJGXK", "reduce.wrong.event.type %s", milestone.PushedEventType)
|
||||
}
|
||||
return crdb.NewUpdateStatement(
|
||||
event,
|
||||
[]handler.Column{
|
||||
handler.NewCol(MilestoneColumnPushedDate, event.CreationDate()),
|
||||
},
|
||||
[]handler.Condition{
|
||||
handler.NewCond(MilestoneColumnInstanceID, event.Aggregate().InstanceID),
|
||||
handler.NewCond(MilestoneColumnType, e.MilestoneType),
|
||||
},
|
||||
), nil
|
||||
}
|
||||
|
||||
func (p *milestoneProjection) reduceInstanceRemoved(event eventstore.Event) (*handler.Statement, error) {
|
||||
printEvent(event)
|
||||
func (p *milestoneProjection) reduceUserTokenAdded(event eventstore.Event) (*handler.Statement, error) {
|
||||
return crdb.NewNoOpStatement(event), nil
|
||||
}
|
||||
|
||||
|
@ -2,215 +2,49 @@ package milestone
|
||||
|
||||
import (
|
||||
"context"
|
||||
"fmt"
|
||||
|
||||
"github.com/zitadel/zitadel/internal/eventstore"
|
||||
)
|
||||
|
||||
type PushedEventType eventstore.EventType
|
||||
|
||||
const (
|
||||
eventTypePrefix = PushedEventType("milestone.pushed.")
|
||||
PushedInstanceCreatedEventType = eventTypePrefix + "instance.created"
|
||||
PushedAuthenticationSucceededOnInstanceEventType = eventTypePrefix + "instance.authentication.succeeded"
|
||||
PushedProjectCreatedEventType = eventTypePrefix + "project.created"
|
||||
PushedApplicationCreatedEventType = eventTypePrefix + "application.created"
|
||||
PushedAuthenticationSucceededOnApplicationEventType = eventTypePrefix + "application.authentication.succeeded"
|
||||
PushedInstanceDeletedEventType = eventTypePrefix + "instance.deleted"
|
||||
eventTypePrefix = eventstore.EventType("milestone.")
|
||||
PushedEventType = eventTypePrefix + "pushed"
|
||||
)
|
||||
|
||||
func PushedEventTypes() []PushedEventType {
|
||||
return []PushedEventType{
|
||||
PushedInstanceCreatedEventType,
|
||||
PushedAuthenticationSucceededOnInstanceEventType,
|
||||
PushedProjectCreatedEventType,
|
||||
PushedApplicationCreatedEventType,
|
||||
PushedAuthenticationSucceededOnApplicationEventType,
|
||||
PushedInstanceDeletedEventType,
|
||||
}
|
||||
type PushedEvent struct {
|
||||
*eventstore.BaseEvent `json:"-"`
|
||||
MilestoneType Type `json:"type"`
|
||||
PrimaryDomain string `json:"primaryDomain"`
|
||||
Endpoints []string `json:"endpoints"`
|
||||
}
|
||||
|
||||
type PushedEvent interface {
|
||||
eventstore.Command
|
||||
IsMilestoneEvent()
|
||||
func (p *PushedEvent) Data() interface{} {
|
||||
return p
|
||||
}
|
||||
|
||||
type basePushedEvent struct {
|
||||
eventstore.BaseEvent `json:"-"`
|
||||
PrimaryDomain string `json:"primaryDomain"`
|
||||
Endpoints []string `json:"endpoints"`
|
||||
}
|
||||
|
||||
func (b *basePushedEvent) Data() interface{} {
|
||||
return b
|
||||
}
|
||||
|
||||
func (b *basePushedEvent) UniqueConstraints() []*eventstore.EventUniqueConstraint {
|
||||
func (p *PushedEvent) UniqueConstraints() []*eventstore.EventUniqueConstraint {
|
||||
return nil
|
||||
}
|
||||
|
||||
func (b *basePushedEvent) SetBaseEvent(base *eventstore.BaseEvent) {
|
||||
b.BaseEvent = *base
|
||||
func (p *PushedEvent) SetBaseEvent(b *eventstore.BaseEvent) {
|
||||
p.BaseEvent = b
|
||||
}
|
||||
|
||||
func NewPushedEventByType(
|
||||
ctx context.Context,
|
||||
eventType PushedEventType,
|
||||
aggregate *Aggregate,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) (PushedEvent, error) {
|
||||
switch eventType {
|
||||
case PushedInstanceCreatedEventType:
|
||||
return NewInstanceCreatedPushedEvent(ctx, aggregate, endpoints, primaryDomain), nil
|
||||
case PushedAuthenticationSucceededOnInstanceEventType:
|
||||
return NewAuthenticationSucceededOnInstancePushedEvent(ctx, aggregate, endpoints, primaryDomain), nil
|
||||
case PushedProjectCreatedEventType:
|
||||
return NewProjectCreatedPushedEvent(ctx, aggregate, endpoints, primaryDomain), nil
|
||||
case PushedApplicationCreatedEventType:
|
||||
return NewApplicationCreatedPushedEvent(ctx, aggregate, endpoints, primaryDomain), nil
|
||||
case PushedAuthenticationSucceededOnApplicationEventType:
|
||||
return NewAuthenticationSucceededOnApplicationPushedEvent(ctx, aggregate, endpoints, primaryDomain), nil
|
||||
case PushedInstanceDeletedEventType:
|
||||
return NewInstanceDeletedPushedEvent(ctx, aggregate, endpoints, primaryDomain), nil
|
||||
}
|
||||
return nil, fmt.Errorf("unknown event type %s", eventType)
|
||||
}
|
||||
|
||||
type InstanceCreatedPushedEvent struct{ basePushedEvent }
|
||||
|
||||
func (e *InstanceCreatedPushedEvent) IsMilestoneEvent() {}
|
||||
|
||||
func NewInstanceCreatedPushedEvent(
|
||||
func NewPushedEvent(
|
||||
ctx context.Context,
|
||||
aggregate *Aggregate,
|
||||
msType Type,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) *InstanceCreatedPushedEvent {
|
||||
return &InstanceCreatedPushedEvent{
|
||||
basePushedEvent: basePushedEvent{
|
||||
BaseEvent: *eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
eventstore.EventType(PushedInstanceCreatedEventType),
|
||||
),
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
},
|
||||
}
|
||||
}
|
||||
|
||||
type AuthenticationSucceededOnInstancePushedEvent struct{ basePushedEvent }
|
||||
|
||||
func (e *AuthenticationSucceededOnInstancePushedEvent) IsMilestoneEvent() {}
|
||||
|
||||
func NewAuthenticationSucceededOnInstancePushedEvent(
|
||||
ctx context.Context,
|
||||
aggregate *Aggregate,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) *AuthenticationSucceededOnInstancePushedEvent {
|
||||
return &AuthenticationSucceededOnInstancePushedEvent{
|
||||
basePushedEvent: basePushedEvent{
|
||||
BaseEvent: *eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
eventstore.EventType(PushedAuthenticationSucceededOnInstanceEventType),
|
||||
),
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
},
|
||||
}
|
||||
}
|
||||
|
||||
type ProjectCreatedPushedEvent struct{ basePushedEvent }
|
||||
|
||||
func (e *ProjectCreatedPushedEvent) IsMilestoneEvent() {}
|
||||
|
||||
func NewProjectCreatedPushedEvent(
|
||||
ctx context.Context,
|
||||
aggregate *Aggregate,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) *ProjectCreatedPushedEvent {
|
||||
return &ProjectCreatedPushedEvent{
|
||||
basePushedEvent: basePushedEvent{
|
||||
BaseEvent: *eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
eventstore.EventType(PushedProjectCreatedEventType),
|
||||
),
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
},
|
||||
}
|
||||
}
|
||||
|
||||
type ApplicationCreatedPushedEvent struct{ basePushedEvent }
|
||||
|
||||
func (e *ApplicationCreatedPushedEvent) IsMilestoneEvent() {}
|
||||
|
||||
func NewApplicationCreatedPushedEvent(
|
||||
ctx context.Context,
|
||||
aggregate *Aggregate,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) *ApplicationCreatedPushedEvent {
|
||||
return &ApplicationCreatedPushedEvent{
|
||||
basePushedEvent: basePushedEvent{
|
||||
BaseEvent: *eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
eventstore.EventType(PushedApplicationCreatedEventType),
|
||||
),
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
},
|
||||
}
|
||||
}
|
||||
|
||||
type AuthenticationSucceededOnApplicationPushedEvent struct{ basePushedEvent }
|
||||
|
||||
func (e *AuthenticationSucceededOnApplicationPushedEvent) IsMilestoneEvent() {}
|
||||
|
||||
func NewAuthenticationSucceededOnApplicationPushedEvent(
|
||||
ctx context.Context,
|
||||
aggregate *Aggregate,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) *AuthenticationSucceededOnApplicationPushedEvent {
|
||||
return &AuthenticationSucceededOnApplicationPushedEvent{
|
||||
basePushedEvent: basePushedEvent{
|
||||
BaseEvent: *eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
eventstore.EventType(PushedAuthenticationSucceededOnApplicationEventType),
|
||||
),
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
},
|
||||
}
|
||||
}
|
||||
|
||||
type InstanceDeletedPushedEvent struct{ basePushedEvent }
|
||||
|
||||
func (e *InstanceDeletedPushedEvent) IsMilestoneEvent() {}
|
||||
|
||||
func NewInstanceDeletedPushedEvent(
|
||||
ctx context.Context,
|
||||
aggregate *Aggregate,
|
||||
endpoints []string,
|
||||
primaryDomain string,
|
||||
) *InstanceDeletedPushedEvent {
|
||||
return &InstanceDeletedPushedEvent{
|
||||
basePushedEvent: basePushedEvent{
|
||||
BaseEvent: *eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
eventstore.EventType(PushedInstanceDeletedEventType),
|
||||
),
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
},
|
||||
) *PushedEvent {
|
||||
return &PushedEvent{
|
||||
BaseEvent: eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&aggregate.Aggregate,
|
||||
PushedEventType,
|
||||
),
|
||||
MilestoneType: msType,
|
||||
Endpoints: endpoints,
|
||||
PrimaryDomain: primaryDomain,
|
||||
}
|
||||
}
|
||||
|
@ -5,10 +5,5 @@ import (
|
||||
)
|
||||
|
||||
func RegisterEventMappers(es *eventstore.Eventstore) {
|
||||
es.RegisterFilterEventMapper(AggregateType, eventstore.EventType(PushedProjectCreatedEventType), eventstore.GenericEventMapper[InstanceCreatedPushedEvent]).
|
||||
RegisterFilterEventMapper(AggregateType, eventstore.EventType(PushedAuthenticationSucceededOnInstanceEventType), eventstore.GenericEventMapper[AuthenticationSucceededOnInstancePushedEvent]).
|
||||
RegisterFilterEventMapper(AggregateType, eventstore.EventType(PushedProjectCreatedEventType), eventstore.GenericEventMapper[ProjectCreatedPushedEvent]).
|
||||
RegisterFilterEventMapper(AggregateType, eventstore.EventType(PushedApplicationCreatedEventType), eventstore.GenericEventMapper[ApplicationCreatedPushedEvent]).
|
||||
RegisterFilterEventMapper(AggregateType, eventstore.EventType(PushedAuthenticationSucceededOnApplicationEventType), eventstore.GenericEventMapper[AuthenticationSucceededOnApplicationPushedEvent]).
|
||||
RegisterFilterEventMapper(AggregateType, eventstore.EventType(PushedInstanceDeletedEventType), eventstore.GenericEventMapper[InstanceDeletedPushedEvent])
|
||||
es.RegisterFilterEventMapper(AggregateType, PushedEventType, eventstore.GenericEventMapper[PushedEvent])
|
||||
}
|
||||
|
26
internal/repository/milestone/type.go
Normal file
26
internal/repository/milestone/type.go
Normal file
@ -0,0 +1,26 @@
|
||||
//go:generate stringer -type Type
|
||||
|
||||
package milestone
|
||||
|
||||
type Type int
|
||||
|
||||
const (
|
||||
unknown Type = iota
|
||||
|
||||
InstanceCreated
|
||||
AuthenticationSucceededOnInstance
|
||||
ProjectCreated
|
||||
ApplicationCreated
|
||||
AuthenticationSucceededOnApplication
|
||||
InstanceDeleted
|
||||
|
||||
typesCount
|
||||
)
|
||||
|
||||
func AllTypes() []Type {
|
||||
types := make([]Type, typesCount-1)
|
||||
for i := Type(1); i < typesCount; i++ {
|
||||
types[i-1] = i
|
||||
}
|
||||
return types
|
||||
}
|
30
internal/repository/milestone/type_string.go
Normal file
30
internal/repository/milestone/type_string.go
Normal file
@ -0,0 +1,30 @@
|
||||
// Code generated by "stringer -type Type"; DO NOT EDIT.
|
||||
|
||||
package milestone
|
||||
|
||||
import "strconv"
|
||||
|
||||
func _() {
|
||||
// An "invalid array index" compiler error signifies that the constant values have changed.
|
||||
// Re-run the stringer command to generate them again.
|
||||
var x [1]struct{}
|
||||
_ = x[unknown-0]
|
||||
_ = x[InstanceCreated-1]
|
||||
_ = x[AuthenticationSucceededOnInstance-2]
|
||||
_ = x[ProjectCreated-3]
|
||||
_ = x[ApplicationCreated-4]
|
||||
_ = x[AuthenticationSucceededOnApplication-5]
|
||||
_ = x[InstanceDeleted-6]
|
||||
_ = x[typesCount-7]
|
||||
}
|
||||
|
||||
const _Type_name = "unknownInstanceCreatedAuthenticationSucceededOnInstanceProjectCreatedApplicationCreatedAuthenticationSucceededOnApplicationInstanceDeletedtypesCount"
|
||||
|
||||
var _Type_index = [...]uint8{0, 7, 22, 55, 69, 87, 123, 138, 148}
|
||||
|
||||
func (i Type) String() string {
|
||||
if i < 0 || i >= Type(len(_Type_index)-1) {
|
||||
return "Type(" + strconv.FormatInt(int64(i), 10) + ")"
|
||||
}
|
||||
return _Type_name[_Type_index[i]:_Type_index[i+1]]
|
||||
}
|
@ -1,5 +1,21 @@
|
||||
package pseudo
|
||||
|
||||
import "github.com/zitadel/zitadel/internal/eventstore"
|
||||
|
||||
const (
|
||||
AggregateType = "pseudo"
|
||||
AggregateType = "pseudo"
|
||||
AggregateVersion = "v1"
|
||||
)
|
||||
|
||||
type Aggregate struct {
|
||||
eventstore.Aggregate
|
||||
}
|
||||
|
||||
func NewAggregate() *Aggregate {
|
||||
return &Aggregate{
|
||||
Aggregate: eventstore.Aggregate{
|
||||
Type: AggregateType,
|
||||
Version: AggregateVersion,
|
||||
},
|
||||
}
|
||||
}
|
||||
|
@ -1,6 +1,7 @@
|
||||
package pseudo
|
||||
|
||||
import (
|
||||
"context"
|
||||
"time"
|
||||
|
||||
"github.com/zitadel/zitadel/internal/eventstore"
|
||||
@ -8,57 +9,28 @@ import (
|
||||
|
||||
const (
|
||||
eventTypePrefix = eventstore.EventType("pseudo.")
|
||||
TimestampEventType = eventTypePrefix + "timestamp"
|
||||
ScheduledEventType = eventTypePrefix + "timestamp"
|
||||
)
|
||||
|
||||
var _ eventstore.Event = (*TimestampEvent)(nil)
|
||||
var _ eventstore.Event = (*ScheduledEvent)(nil)
|
||||
|
||||
type TimestampEvent struct {
|
||||
Timestamp time.Time
|
||||
InstanceIDs []string
|
||||
type ScheduledEvent struct {
|
||||
*eventstore.BaseEvent `json:"-"`
|
||||
Timestamp time.Time `json:"-"`
|
||||
InstanceIDs []string `json:"-"`
|
||||
}
|
||||
|
||||
func (t TimestampEvent) Aggregate() eventstore.Aggregate {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) EditorService() string {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) EditorUser() string {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) Type() eventstore.EventType {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) Sequence() uint64 {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) CreationDate() time.Time {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) PreviousAggregateSequence() uint64 {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) PreviousAggregateTypeSequence() uint64 {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func (t TimestampEvent) DataAsBytes() []byte {
|
||||
panic("TimestampEvent is not a real event")
|
||||
}
|
||||
|
||||
func NewTimestampEvent(
|
||||
func NewScheduledEvent(
|
||||
ctx context.Context,
|
||||
timestamp time.Time,
|
||||
instanceIDs ...string,
|
||||
) *TimestampEvent {
|
||||
return &TimestampEvent{
|
||||
) *ScheduledEvent {
|
||||
return &ScheduledEvent{
|
||||
BaseEvent: eventstore.NewBaseEventForPush(
|
||||
ctx,
|
||||
&NewAggregate().Aggregate,
|
||||
ScheduledEventType,
|
||||
),
|
||||
Timestamp: timestamp,
|
||||
InstanceIDs: instanceIDs,
|
||||
}
|
||||
|
Loading…
x
Reference in New Issue
Block a user