Documentation ¶
Index ¶
- func MakeFactory(ctor Ctor, unstructured bool, logger *zap.SugaredLogger) Factory
- func MarkAddedToChannel(s *v1alpha1.Subscription)
- func MarkReferencesResolved(s *v1alpha1.Subscription)
- func MarkSubscriptionReady(s *v1alpha1.Subscription)
- func NewApiServerSource(name, namespace string, o ...ApiServerSourceOption) *v1alpha1.ApiServerSource
- func NewBroker(name, namespace string, o ...BrokerOption) *v1alpha1.Broker
- func NewChannel(name, namespace string, o ...ChannelOption) *v1alpha1.Channel
- func NewConfigMap(name, namespace string, o ...ConfigMapOption) *v1.ConfigMap
- func NewConfigMapPropagation(name, namespace string, o ...ConfigMapPropagationOption) *v1alpha1.ConfigMapPropagation
- func NewContainerSource(name, namespace string, o ...ContainerSourceOption) *legacysourcesv1alpha1.ContainerSource
- func NewCronJobSource(name, namespace string, o ...CronJobSourceOption) *v1alpha1.CronJobSource
- func NewCustomResourceDefinition(name string, o ...CustomResourceDefinitionOption) *apiextensionsv1beta1.CustomResourceDefinition
- func NewDeployment(name, namespace string, do ...DeploymentOption) *appsv1.Deployment
- func NewEventType(name, namespace string, o ...EventTypeOption) *v1alpha1.EventType
- func NewFlowsParallel(name, namespace string, popt ...FlowsParallelOption) *v1alpha1.Parallel
- func NewFlowsSequence(name, namespace string, popt ...FlowsSequenceOption) *v1alpha1.Sequence
- func NewInMemoryChannel(name, namespace string, imcopt ...InMemoryChannelOption) *v1alpha1.InMemoryChannel
- func NewLegacyApiServerSource(name, namespace string, o ...LegacyApiServerSourceOption) *v1alpha1.ApiServerSource
- func NewLegacySinkBinding(name, namespace string, o ...LegacySinkBindingOption) *legacysourcesv1alpha1.SinkBinding
- func NewNamespace(name string, o ...NamespaceOption) *corev1.Namespace
- func NewPingSourceV1Alpha1(name, namespace string, o ...PingSourceOption) *v1alpha1.PingSource
- func NewPingSourceV1Alpha2(name, namespace string, o ...PingSourceV1A2Option) *v1alpha2.PingSource
- func NewScheme() *runtime.Scheme
- func NewService(name, namespace string, so ...ServiceOption) *corev1.Service
- func NewSinkBindingV1Alpha1(name, namespace string, o ...SinkBindingV1Alpha1Option) *sourcesv1alpha1.SinkBinding
- func NewSinkBindingV1Alpha2(name, namespace string, o ...SinkBindingV1Alpha2Option) *sourcesv1alpha2.SinkBinding
- func NewSubscription(name, namespace string, so ...SubscriptionOption) *v1alpha1.Subscription
- func NewSubscriptionWithoutNamespace(name string, so ...SubscriptionOption) *v1alpha1.Subscription
- func NewTrigger(name, namespace, broker string, to ...TriggerOption) *v1alpha1.Trigger
- func NewUnstructured(gvk metav1.GroupVersionKind, name, namespace string, uo ...UnstructuredOption) *unstructured.Unstructured
- func ToUnstructured(t *testing.T, objs []runtime.Object) (us []runtime.Object)
- func WithApiServerSourceDeleted(c *v1alpha1.ApiServerSource)
- func WithApiServerSourceDeployed(s *v1alpha1.ApiServerSource)
- func WithApiServerSourceDeploymentUnavailable(s *v1alpha1.ApiServerSource)
- func WithApiServerSourceEventTypes(s *v1alpha1.ApiServerSource)
- func WithApiServerSourceNoSufficientPermissions(s *v1alpha1.ApiServerSource)
- func WithApiServerSourceSinkNotFound(s *v1alpha1.ApiServerSource)
- func WithApiServerSourceSufficientPermissions(s *v1alpha1.ApiServerSource)
- func WithBackingChannelReady(c *v1alpha1.Channel)
- func WithBrokerDeletionTimestamp(b *v1alpha1.Broker)
- func WithBrokerReady(b *v1alpha1.Broker)
- func WithChannelDeleted(c *v1alpha1.Channel)
- func WithConfigMapPropagationDeletionTimestamp(cmp *v1alpha1.ConfigMapPropagation)
- func WithConfigMapPropagationNotPropagated(cmp *v1alpha1.ConfigMapPropagation)
- func WithConfigMapPropagationPropagated(cmp *v1alpha1.ConfigMapPropagation)
- func WithContainerSourceDeleted(c *legacysourcesv1alpha1.ContainerSource)
- func WithContainerSourceDeployed(s *legacysourcesv1alpha1.ContainerSource)
- func WithCronJobSourceDeleted(c *v1alpha1.CronJobSource)
- func WithCronJobSourceDeployed(s *v1alpha1.CronJobSource)
- func WithCronJobSourceEventType(s *v1alpha1.CronJobSource)
- func WithCronJobSourceSinkNotFound(s *v1alpha1.CronJobSource)
- func WithEventTypeBrokerDoesNotExist(et *v1alpha1.EventType)
- func WithEventTypeBrokerExists(et *v1alpha1.EventType)
- func WithEventTypeBrokerReady(et *v1alpha1.EventType)
- func WithEventTypeDeletionTimestamp(et *v1alpha1.EventType)
- func WithFlowsParallelDeleted(p *v1alpha1.Parallel)
- func WithFlowsSequenceDeleted(p *v1alpha1.Sequence)
- func WithInMemoryChannelDeleted(imc *v1alpha1.InMemoryChannel)
- func WithInitApiServerSourceConditions(s *v1alpha1.ApiServerSource)
- func WithInitBrokerConditions(b *v1alpha1.Broker)
- func WithInitChannelConditions(c *v1alpha1.Channel)
- func WithInitConfigMapPropagationConditions(cmp *v1alpha1.ConfigMapPropagation)
- func WithInitContainerSourceConditions(s *legacysourcesv1alpha1.ContainerSource)
- func WithInitCronJobSourceConditions(s *v1alpha1.CronJobSource)
- func WithInitEventTypeConditions(et *v1alpha1.EventType)
- func WithInitFlowsParallelConditions(p *v1alpha1.Parallel)
- func WithInitFlowsSequenceConditions(p *v1alpha1.Sequence)
- func WithInitInMemoryChannelConditions(imc *v1alpha1.InMemoryChannel)
- func WithInitLegacyApiServerSourceConditions(s *v1alpha1.ApiServerSource)
- func WithInitPingSourceConditions(s *v1alpha1.PingSource)
- func WithInitSubscriptionConditions(s *v1alpha1.Subscription)
- func WithInitTriggerConditions(t *v1alpha1.Trigger)
- func WithInvalidCronJobSourceSchedule(s *v1alpha1.CronJobSource)
- func WithInvalidPingSourceSchedule(s *v1alpha1.PingSource)
- func WithLegacyApiServerSourceDeleted(c *v1alpha1.ApiServerSource)
- func WithLegacyApiServerSourceDeployed(s *v1alpha1.ApiServerSource)
- func WithLegacyApiServerSourceDeploymentUnavailable(s *v1alpha1.ApiServerSource)
- func WithLegacyApiServerSourceEventTypes(s *v1alpha1.ApiServerSource)
- func WithLegacyApiServerSourceNoSufficientPermissions(s *v1alpha1.ApiServerSource)
- func WithLegacyApiServerSourceSinkNotFound(s *v1alpha1.ApiServerSource)
- func WithLegacyApiServerSourceSufficientPermissions(s *v1alpha1.ApiServerSource)
- func WithNamespaceDeleted(n *corev1.Namespace)
- func WithPingSourceDeleted(c *v1alpha1.PingSource)
- func WithPingSourceDeployed(s *v1alpha1.PingSource)
- func WithPingSourceEventType(s *v1alpha1.PingSource)
- func WithPingSourceSinkNotFound(s *v1alpha1.PingSource)
- func WithSubscriptionDeleted(s *v1alpha1.Subscription)
- func WithSubscriptionReady(s *v1alpha1.Subscription)
- func WithTriggerDeleted(t *v1alpha1.Trigger)
- func WithValidCronJobSourceResources(s *v1alpha1.CronJobSource)
- func WithValidCronJobSourceSchedule(s *v1alpha1.CronJobSource)
- func WithValidPingSourceResources(s *v1alpha1.PingSource)
- func WithValidPingSourceSchedule(s *v1alpha1.PingSource)
- type ApiServerSourceOption
- func WithApiServerSourceObjectMetaGeneration(generation int64) ApiServerSourceOption
- func WithApiServerSourceSink(uri string) ApiServerSourceOption
- func WithApiServerSourceSinkDepRef(uri string) ApiServerSourceOption
- func WithApiServerSourceSpec(spec v1alpha1.ApiServerSourceSpec) ApiServerSourceOption
- func WithApiServerSourceStatusObservedGeneration(generation int64) ApiServerSourceOption
- func WithApiServerSourceUID(uid string) ApiServerSourceOption
- type BrokerOption
- func WithBrokerAddress(address string) BrokerOption
- func WithBrokerChannel(crdType metav1.TypeMeta) BrokerOption
- func WithBrokerFinalizers(finalizers ...string) BrokerOption
- func WithBrokerGeneration(gen int64) BrokerOption
- func WithBrokerResourceVersion(rv string) BrokerOption
- func WithBrokerStatusObservedGeneration(gen int64) BrokerOption
- func WithBrokerTriggerChannel(c *corev1.ObjectReference) BrokerOption
- func WithFilterDeploymentAvailable() BrokerOption
- func WithFilterFailed(reason, msg string) BrokerOption
- func WithIngressDeploymentAvailable() BrokerOption
- func WithIngressFailed(reason, msg string) BrokerOption
- func WithTriggerChannelFailed(reason, msg string) BrokerOption
- func WithTriggerChannelReady() BrokerOption
- type Buildable
- type ChannelOption
- func WithBackingChannelFailed(reason, msg string) ChannelOption
- func WithBackingChannelObjRef(objRef *v1.ObjectReference) ChannelOption
- func WithBackingChannelUnknown(reason, msg string) ChannelOption
- func WithChannelAddress(hostname string) ChannelOption
- func WithChannelGeneration(gen int64) ChannelOption
- func WithChannelNoAddress() ChannelOption
- func WithChannelObservedGeneration(gen int64) ChannelOption
- func WithChannelReadySubscriber(uid string) ChannelOption
- func WithChannelReadySubscriberAndGeneration(uid string, observedGeneration int64) ChannelOption
- func WithChannelSubscriberStatuses(subscriberStatuses []eventingduckv1alpha1.SubscriberStatus) ChannelOption
- func WithChannelTemplate(typeMeta metav1.TypeMeta) ChannelOption
- type ConfigMapOption
- type ConfigMapPropagationOption
- func WithConfigMapPropagationGeneration(gen int64) ConfigMapPropagationOption
- func WithConfigMapPropagationSelector(selector metav1.LabelSelector) ConfigMapPropagationOption
- func WithConfigMapPropagationStatusObservedGeneration(gen int64) ConfigMapPropagationOption
- func WithConfigMapPropagationUID(uid string) ConfigMapPropagationOption
- func WithCopyConfigMapStatus(name, source, operation, ready, reason string) ConfigMapPropagationOption
- func WithInitConfigMapStatus() ConfigMapPropagationOption
- type ContainerSourceOption
- func WithContainerSourceAnnotations(annotations map[string]string) ContainerSourceOption
- func WithContainerSourceDeployFailed(msg string) ContainerSourceOption
- func WithContainerSourceDeploying(msg string) ContainerSourceOption
- func WithContainerSourceLabels(labels map[string]string) ContainerSourceOption
- func WithContainerSourceObjectMetaGeneration(generation int64) ContainerSourceOption
- func WithContainerSourceSink(uri string) ContainerSourceOption
- func WithContainerSourceSinkMissing(msg string) ContainerSourceOption
- func WithContainerSourceSinkNotFound(msg string) ContainerSourceOption
- func WithContainerSourceSpec(spec legacysourcesv1alpha1.ContainerSourceSpec) ContainerSourceOption
- func WithContainerSourceStatusObservedGeneration(generation int64) ContainerSourceOption
- func WithContainerSourceUID(uid types.UID) ContainerSourceOption
- type CronJobSourceOption
- func WithCronJobApiVersion(apiVersion string) CronJobSourceOption
- func WithCronJobSourceObjectMetaGeneration(generation int64) CronJobSourceOption
- func WithCronJobSourceSink(uri string) CronJobSourceOption
- func WithCronJobSourceSpec(spec v1alpha1.CronJobSourceSpec) CronJobSourceOption
- func WithCronJobSourceStatusObservedGeneration(generation int64) CronJobSourceOption
- func WithCronJobSourceUID(uid string) CronJobSourceOption
- type Ctor
- type CustomResourceDefinitionOption
- type DeploymentOption
- func WithDeploymentAnnotations(annotations map[string]string) DeploymentOption
- func WithDeploymentAvailable() DeploymentOption
- func WithDeploymentContainer(name, image string, liveness *corev1.Probe, readiness *corev1.Probe, ...) DeploymentOption
- func WithDeploymentLabels(labels map[string]string) DeploymentOption
- func WithDeploymentOwnerReferences(ownerReferences []metav1.OwnerReference) DeploymentOption
- func WithDeploymentServiceAccount(serviceAccountName string) DeploymentOption
- type DynamicMocks
- type EventTypeOption
- func WithEventTypeBroker(broker string) EventTypeOption
- func WithEventTypeBrokerFailed(reason, message string) EventTypeOption
- func WithEventTypeBrokerUnknown(reason, message string) EventTypeOption
- func WithEventTypeDescription(description string) EventTypeOption
- func WithEventTypeLabels(labels map[string]string) EventTypeOption
- func WithEventTypeOwnerReference(ownerRef metav1.OwnerReference) EventTypeOption
- func WithEventTypeSource(source string) EventTypeOption
- func WithEventTypeType(t string) EventTypeOption
- type FlowsParallelOption
- func WithFlowsParallelAddressableNotReady(reason, message string) FlowsParallelOption
- func WithFlowsParallelBranchStatuses(branchStatuses []v1alpha1.ParallelBranchStatus) FlowsParallelOption
- func WithFlowsParallelBranches(branches []v1alpha1.ParallelBranch) FlowsParallelOption
- func WithFlowsParallelChannelTemplateSpec(cts *messagingvbeta1.ChannelTemplateSpec) FlowsParallelOption
- func WithFlowsParallelChannelsNotReady(reason, message string) FlowsParallelOption
- func WithFlowsParallelGeneration(gen int64) FlowsParallelOption
- func WithFlowsParallelIngressChannelStatus(status v1alpha1.ParallelChannelStatus) FlowsParallelOption
- func WithFlowsParallelReply(reply *duckv1.Destination) FlowsParallelOption
- func WithFlowsParallelStatusObservedGeneration(gen int64) FlowsParallelOption
- func WithFlowsParallelSubscriptionsNotReady(reason, message string) FlowsParallelOption
- type FlowsSequenceOption
- func WithFlowsSequenceAddressableNotReady(reason, message string) FlowsSequenceOption
- func WithFlowsSequenceChannelStatuses(channelStatuses []v1alpha1.SequenceChannelStatus) FlowsSequenceOption
- func WithFlowsSequenceChannelTemplateSpec(cts *messagingv1beta1.ChannelTemplateSpec) FlowsSequenceOption
- func WithFlowsSequenceChannelsNotReady(reason, message string) FlowsSequenceOption
- func WithFlowsSequenceGeneration(gen int64) FlowsSequenceOption
- func WithFlowsSequenceReply(reply *duckv1.Destination) FlowsSequenceOption
- func WithFlowsSequenceStatusObservedGeneration(gen int64) FlowsSequenceOption
- func WithFlowsSequenceSteps(steps []v1alpha1.SequenceStep) FlowsSequenceOption
- func WithFlowsSequenceSubscriptionStatuses(subscriptionStatuses []v1alpha1.SequenceSubscriptionStatus) FlowsSequenceOption
- func WithFlowsSequenceSubscriptionsNotReady(reason, message string) FlowsSequenceOption
- type InMemoryChannelOption
- func WithInMemoryChannelAddress(a string) InMemoryChannelOption
- func WithInMemoryChannelChannelServiceNotReady(reason, message string) InMemoryChannelOption
- func WithInMemoryChannelChannelServiceReady() InMemoryChannelOption
- func WithInMemoryChannelDeploymentFailed(reason, message string) InMemoryChannelOption
- func WithInMemoryChannelDeploymentReady() InMemoryChannelOption
- func WithInMemoryChannelDeploymentUnknown(reason, message string) InMemoryChannelOption
- func WithInMemoryChannelEndpointsNotReady(reason, message string) InMemoryChannelOption
- func WithInMemoryChannelEndpointsReady() InMemoryChannelOption
- func WithInMemoryChannelGeneration(gen int64) InMemoryChannelOption
- func WithInMemoryChannelReady(host string) InMemoryChannelOption
- func WithInMemoryChannelReadySubscriber(uid string) InMemoryChannelOption
- func WithInMemoryChannelReadySubscriberAndGeneration(uid string, observedGeneration int64) InMemoryChannelOption
- func WithInMemoryChannelServiceReady() InMemoryChannelOption
- func WithInMemoryChannelServicetNotReady(reason, message string) InMemoryChannelOption
- func WithInMemoryChannelStatusObservedGeneration(gen int64) InMemoryChannelOption
- func WithInMemoryChannelStatusSubscribers(subscriberStatuses []duckv1alpha1.SubscriberStatus) InMemoryChannelOption
- func WithInMemoryChannelSubscribers(subscribers []duckv1alpha1.SubscriberSpec) InMemoryChannelOption
- func WithInMemoryScopeAnnotation(value string) InMemoryChannelOption
- type LegacyApiServerSourceOption
- func WithLegacyApiServerSourceObjectMetaGeneration(generation int64) LegacyApiServerSourceOption
- func WithLegacyApiServerSourceSink(uri string) LegacyApiServerSourceOption
- func WithLegacyApiServerSourceSinkDepRef(uri string) LegacyApiServerSourceOption
- func WithLegacyApiServerSourceSpec(spec v1alpha1.ApiServerSourceSpec) LegacyApiServerSourceOption
- func WithLegacyApiServerSourceStatusObservedGeneration(generation int64) LegacyApiServerSourceOption
- func WithLegacyApiServerSourceUID(uid string) LegacyApiServerSourceOption
- type LegacySinkBindingOption
- type Listers
- func (l *Listers) GetAllObjects() []runtime.Object
- func (l *Listers) GetApiServerSourceLister() sourcelisters.ApiServerSourceLister
- func (l *Listers) GetBrokerLister() eventinglisters.BrokerLister
- func (l *Listers) GetConfigMapLister() corev1listers.ConfigMapLister
- func (l *Listers) GetConfigMapPropagationLister() configslisters.ConfigMapPropagationLister
- func (l *Listers) GetCustomResourceDefinitionLister() apiextensionsv1beta1listers.CustomResourceDefinitionLister
- func (l *Listers) GetDeploymentLister() appsv1listers.DeploymentLister
- func (l *Listers) GetEndpointsLister() corev1listers.EndpointsLister
- func (l *Listers) GetEventTypeLister() eventinglisters.EventTypeLister
- func (l *Listers) GetEventingObjects() []runtime.Object
- func (l *Listers) GetFlowsParallelLister() flowslisters.ParallelLister
- func (l *Listers) GetFlowsSequenceLister() flowslisters.SequenceLister
- func (l *Listers) GetInMemoryChannelLister() messaginglisters.InMemoryChannelLister
- func (l *Listers) GetK8sServiceLister() corev1listers.ServiceLister
- func (l *Listers) GetKubeObjects() []runtime.Object
- func (l *Listers) GetLegacyApiServerSourceLister() legacysourcelisters.ApiServerSourceLister
- func (l *Listers) GetLegacyContainerSourceLister() legacysourcelisters.ContainerSourceLister
- func (l *Listers) GetLegacyCronJobSourceLister() legacysourcelisters.CronJobSourceLister
- func (l *Listers) GetLegacyObjects() []runtime.Object
- func (l *Listers) GetMessagingChannelLister() messaginglisters.ChannelLister
- func (l *Listers) GetNamespaceLister() corev1listers.NamespaceLister
- func (l *Listers) GetPingSourceLister() sourcelisters.PingSourceLister
- func (l *Listers) GetRoleBindingLister() rbacv1listers.RoleBindingLister
- func (l *Listers) GetServiceAccountLister() corev1listers.ServiceAccountLister
- func (l *Listers) GetServiceLister() corev1listers.ServiceLister
- func (l *Listers) GetSubscriberObjects() []runtime.Object
- func (l *Listers) GetSubscriptionLister() messaginglisters.SubscriptionLister
- func (l *Listers) GetTriggerLister() eventinglisters.TriggerLister
- type MockDynamicContext
- type MockDynamicCreate
- type MockDynamicDelete
- type MockDynamicDeleteCollection
- type MockDynamicGet
- type MockDynamicInterface
- type MockDynamicList
- type MockDynamicPatch
- type MockDynamicResource
- type MockDynamicUpdate
- type MockDynamicUpdateStatus
- type MockDynamicWatch
- type MockEventRecorder
- func (m *MockEventRecorder) AnnotatedEventf(object runtime.Object, annotations map[string]string, ...)
- func (m *MockEventRecorder) Event(object runtime.Object, eventtype, reason, message string)
- func (m *MockEventRecorder) Eventf(object runtime.Object, eventtype, reason, messageFmt string, ...)
- func (m *MockEventRecorder) PastEventf(object runtime.Object, timestamp metav1.Time, ...)
- type MockHandled
- type NamespaceOption
- type PingSourceOption
- func WithPingSourceApiVersion(apiVersion string) PingSourceOption
- func WithPingSourceObjectMetaGeneration(generation int64) PingSourceOption
- func WithPingSourceSink(uri *apis.URL) PingSourceOption
- func WithPingSourceSpec(spec v1alpha1.PingSourceSpec) PingSourceOption
- func WithPingSourceStatusObservedGeneration(generation int64) PingSourceOption
- func WithPingSourceUID(uid string) PingSourceOption
- type PingSourceV1A2Option
- type ServiceOption
- type SinkBindingV1Alpha1Option
- type SinkBindingV1Alpha2Option
- type SubscriptionOption
- func MarkNotAddedToChannel(reason, msg string) SubscriptionOption
- func WithSubscriptionChannel(gvk metav1.GroupVersionKind, name string) SubscriptionOption
- func WithSubscriptionDeadLetterSinkURI(uri *apis.URL) SubscriptionOption
- func WithSubscriptionDeliveryRef(gvk metav1.GroupVersionKind, name, namespace string) SubscriptionOption
- func WithSubscriptionFinalizers(finalizers ...string) SubscriptionOption
- func WithSubscriptionGenerateName(generateName string) SubscriptionOption
- func WithSubscriptionGeneration(gen int64) SubscriptionOption
- func WithSubscriptionLabels(labels map[string]string) SubscriptionOption
- func WithSubscriptionOwnerReferences(ownerReferences []metav1.OwnerReference) SubscriptionOption
- func WithSubscriptionPhysicalSubscriptionReply(uri *apis.URL) SubscriptionOption
- func WithSubscriptionPhysicalSubscriptionSubscriber(uri *apis.URL) SubscriptionOption
- func WithSubscriptionReferencesNotResolved(reason, msg string) SubscriptionOption
- func WithSubscriptionReferencesResolvedUnknown(reason, msg string) SubscriptionOption
- func WithSubscriptionReply(gvk metav1.GroupVersionKind, name, namespace string) SubscriptionOption
- func WithSubscriptionStatusObservedGeneration(gen int64) SubscriptionOption
- func WithSubscriptionSubscriberRef(gvk metav1.GroupVersionKind, name, namespace string) SubscriptionOption
- func WithSubscriptionUID(uid types.UID) SubscriptionOption
- type TriggerOption
- func WithDependencyAnnotation(dependencyAnnotation string) TriggerOption
- func WithInjectionAnnotation(injectionAnnotation string) TriggerOption
- func WithTriggerBrokerFailed(reason, message string) TriggerOption
- func WithTriggerBrokerReady() TriggerOption
- func WithTriggerBrokerUnknown(reason, message string) TriggerOption
- func WithTriggerDependencyFailed(reason, message string) TriggerOption
- func WithTriggerDependencyReady() TriggerOption
- func WithTriggerDependencyUnknown(reason, message string) TriggerOption
- func WithTriggerGeneration(gen int64) TriggerOption
- func WithTriggerNotSubscribed(reason, message string) TriggerOption
- func WithTriggerStatusObservedGeneration(gen int64) TriggerOption
- func WithTriggerStatusSubscriberURI(uri string) TriggerOption
- func WithTriggerSubscribed() TriggerOption
- func WithTriggerSubscribedUnknown(reason, message string) TriggerOption
- func WithTriggerSubscriberRef(gvk metav1.GroupVersionKind, name, namespace string) TriggerOption
- func WithTriggerSubscriberRefAndURIReference(gvk metav1.GroupVersionKind, name, namespace string, rawuri string) TriggerOption
- func WithTriggerSubscriberResolvedFailed(reason, message string) TriggerOption
- func WithTriggerSubscriberResolvedSucceeded() TriggerOption
- func WithTriggerSubscriberResolvedUnknown(reason, message string) TriggerOption
- func WithTriggerSubscriberURI(rawurl string) TriggerOption
- func WithTriggerSubscriptionNotConfigured() TriggerOption
- func WithTriggerUID(uid string) TriggerOption
- func WithUnmarshalFailedDependencyAnnotation() TriggerOption
- type UnstructuredOption
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func MakeFactory ¶ added in v0.6.0
func MakeFactory(ctor Ctor, unstructured bool, logger *zap.SugaredLogger) Factory
MakeFactory creates a reconciler factory with fake clients and controller created by `ctor`.
func MarkAddedToChannel ¶ added in v0.13.0
func MarkAddedToChannel(s *v1alpha1.Subscription)
func MarkReferencesResolved ¶ added in v0.13.0
func MarkReferencesResolved(s *v1alpha1.Subscription)
func MarkSubscriptionReady ¶ added in v0.6.0
func MarkSubscriptionReady(s *v1alpha1.Subscription)
func NewApiServerSource ¶ added in v0.6.0
func NewApiServerSource(name, namespace string, o ...ApiServerSourceOption) *v1alpha1.ApiServerSource
NewApiServerSource creates a ApiServer with ApiServerOptions
func NewBroker ¶ added in v0.6.0
func NewBroker(name, namespace string, o ...BrokerOption) *v1alpha1.Broker
NewBroker creates a Broker with BrokerOptions.
func NewChannel ¶ added in v0.6.0
func NewChannel(name, namespace string, o ...ChannelOption) *v1alpha1.Channel
NewChannel creates a Channel with ChannelOptions
func NewConfigMap ¶ added in v0.13.0
func NewConfigMap(name, namespace string, o ...ConfigMapOption) *v1.ConfigMap
NewConfigMap creates a new ConfigMap.
func NewConfigMapPropagation ¶ added in v0.13.0
func NewConfigMapPropagation(name, namespace string, o ...ConfigMapPropagationOption) *v1alpha1.ConfigMapPropagation
NewConfigMapPropagation creates a ConfigMapPropagation.
func NewContainerSource ¶ added in v0.6.0
func NewContainerSource(name, namespace string, o ...ContainerSourceOption) *legacysourcesv1alpha1.ContainerSource
NewContainerSource creates a ContainerSource with ContainerSourceOptions
func NewCronJobSource ¶ added in v0.8.0
func NewCronJobSource(name, namespace string, o ...CronJobSourceOption) *v1alpha1.CronJobSource
NewCronJobSource creates a CronJobSource with CronJobOptions.
func NewCustomResourceDefinition ¶ added in v0.7.0
func NewCustomResourceDefinition(name string, o ...CustomResourceDefinitionOption) *apiextensionsv1beta1.CustomResourceDefinition
NewCustomResourceDefinition creates a CustomResourceDefinition with CustomResourceDefinitionOption.
func NewDeployment ¶ added in v0.6.0
func NewDeployment(name, namespace string, do ...DeploymentOption) *appsv1.Deployment
NewDeployment creates a Deployment with DeploymentOptions.
func NewEventType ¶ added in v0.6.0
func NewEventType(name, namespace string, o ...EventTypeOption) *v1alpha1.EventType
NewEventType creates a EventType with EventTypeOptions.
func NewFlowsParallel ¶ added in v0.11.0
func NewFlowsParallel(name, namespace string, popt ...FlowsParallelOption) *v1alpha1.Parallel
NewFlowsParallel creates an Parallel with ParallelOptions.
func NewFlowsSequence ¶ added in v0.11.0
func NewFlowsSequence(name, namespace string, popt ...FlowsSequenceOption) *v1alpha1.Sequence
NewSequence creates an Sequence with SequenceOptions.
func NewInMemoryChannel ¶ added in v0.7.0
func NewInMemoryChannel(name, namespace string, imcopt ...InMemoryChannelOption) *v1alpha1.InMemoryChannel
NewInMemoryChannel creates an InMemoryChannel with InMemoryChannelOptions.
func NewLegacyApiServerSource ¶ added in v0.12.0
func NewLegacyApiServerSource(name, namespace string, o ...LegacyApiServerSourceOption) *v1alpha1.ApiServerSource
NewLegacyApiServerSource creates a ApiServer with ApiServerOptions
func NewLegacySinkBinding ¶ added in v0.12.0
func NewLegacySinkBinding(name, namespace string, o ...LegacySinkBindingOption) *legacysourcesv1alpha1.SinkBinding
NewLegacySinkBinding creates a SinkBinding with SinkBindingOptions
func NewNamespace ¶ added in v0.6.0
func NewNamespace(name string, o ...NamespaceOption) *corev1.Namespace
NewNamespace creates a Namespace with NamespaceOptions
func NewPingSourceV1Alpha1 ¶ added in v0.13.0
func NewPingSourceV1Alpha1(name, namespace string, o ...PingSourceOption) *v1alpha1.PingSource
NewPingSourceV1Alpha1 creates a PingSource with PingSourceOption.
func NewPingSourceV1Alpha2 ¶ added in v0.13.0
func NewPingSourceV1Alpha2(name, namespace string, o ...PingSourceV1A2Option) *v1alpha2.PingSource
NewPingSourceV1Alpha2 creates a PingSource with PingSourceOption.
func NewService ¶ added in v0.6.0
func NewService(name, namespace string, so ...ServiceOption) *corev1.Service
NewService creates a Service with ServiceOptions
func NewSinkBindingV1Alpha1 ¶ added in v0.13.0
func NewSinkBindingV1Alpha1(name, namespace string, o ...SinkBindingV1Alpha1Option) *sourcesv1alpha1.SinkBinding
NewSinkBindingV1Alpha1 creates a SinkBinding with SinkBindingOptions
func NewSinkBindingV1Alpha2 ¶ added in v0.13.0
func NewSinkBindingV1Alpha2(name, namespace string, o ...SinkBindingV1Alpha2Option) *sourcesv1alpha2.SinkBinding
NewSinkBindingV1Alpha2 creates a SinkBinding with SinkBindingOptions
func NewSubscription ¶ added in v0.6.0
func NewSubscription(name, namespace string, so ...SubscriptionOption) *v1alpha1.Subscription
NewSubscription creates a Subscription with SubscriptionOptions
func NewSubscriptionWithoutNamespace ¶ added in v0.6.0
func NewSubscriptionWithoutNamespace(name string, so ...SubscriptionOption) *v1alpha1.Subscription
NewSubscriptionWithoutNamespace creates a Subscription with SubscriptionOptions but without a specific namespace
func NewTrigger ¶ added in v0.6.0
func NewTrigger(name, namespace, broker string, to ...TriggerOption) *v1alpha1.Trigger
NewTrigger creates a Trigger with TriggerOptions.
func NewUnstructured ¶ added in v0.6.0
func NewUnstructured(gvk metav1.GroupVersionKind, name, namespace string, uo ...UnstructuredOption) *unstructured.Unstructured
NewUnstructured creates a unstructured.Unstructured with UnstructuredOption
func ToUnstructured ¶ added in v0.6.0
ToUnstructured takes a list of k8s resources and converts them to Unstructured objects. We must pass objects as Unstructured to the dynamic client fake, or it won't handle them properly.
func WithApiServerSourceDeleted ¶ added in v0.6.0
func WithApiServerSourceDeleted(c *v1alpha1.ApiServerSource)
func WithApiServerSourceDeployed ¶ added in v0.6.0
func WithApiServerSourceDeployed(s *v1alpha1.ApiServerSource)
func WithApiServerSourceDeploymentUnavailable ¶ added in v0.8.0
func WithApiServerSourceDeploymentUnavailable(s *v1alpha1.ApiServerSource)
func WithApiServerSourceEventTypes ¶ added in v0.6.0
func WithApiServerSourceEventTypes(s *v1alpha1.ApiServerSource)
func WithApiServerSourceNoSufficientPermissions ¶ added in v0.11.0
func WithApiServerSourceNoSufficientPermissions(s *v1alpha1.ApiServerSource)
func WithApiServerSourceSinkNotFound ¶ added in v0.6.0
func WithApiServerSourceSinkNotFound(s *v1alpha1.ApiServerSource)
func WithApiServerSourceSufficientPermissions ¶ added in v0.11.0
func WithApiServerSourceSufficientPermissions(s *v1alpha1.ApiServerSource)
func WithBackingChannelReady ¶ added in v0.8.0
func WithBrokerDeletionTimestamp ¶ added in v0.6.0
func WithBrokerReady ¶ added in v0.6.0
WithBrokerReady sets .Status to ready.
func WithChannelDeleted ¶ added in v0.6.0
func WithConfigMapPropagationDeletionTimestamp ¶ added in v0.13.0
func WithConfigMapPropagationDeletionTimestamp(cmp *v1alpha1.ConfigMapPropagation)
func WithConfigMapPropagationNotPropagated ¶ added in v0.13.0
func WithConfigMapPropagationNotPropagated(cmp *v1alpha1.ConfigMapPropagation)
WithConfigMapPropagationNotPropagated calls .Status.MarkConfigMapPropagationNotPropagated on the ConfigMapPropagation.
func WithConfigMapPropagationPropagated ¶ added in v0.13.0
func WithConfigMapPropagationPropagated(cmp *v1alpha1.ConfigMapPropagation)
WithConfigMapPropagationPropagated calls .Status.MarkConfigMapPropagationPropagated on the ConfigMapPropagation.
func WithContainerSourceDeleted ¶ added in v0.6.0
func WithContainerSourceDeleted(c *legacysourcesv1alpha1.ContainerSource)
func WithContainerSourceDeployed ¶ added in v0.6.0
func WithContainerSourceDeployed(s *legacysourcesv1alpha1.ContainerSource)
func WithCronJobSourceDeleted ¶ added in v0.6.0
func WithCronJobSourceDeleted(c *v1alpha1.CronJobSource)
func WithCronJobSourceDeployed ¶ added in v0.6.0
func WithCronJobSourceDeployed(s *v1alpha1.CronJobSource)
func WithCronJobSourceEventType ¶ added in v0.6.0
func WithCronJobSourceEventType(s *v1alpha1.CronJobSource)
func WithCronJobSourceSinkNotFound ¶ added in v0.6.0
func WithCronJobSourceSinkNotFound(s *v1alpha1.CronJobSource)
func WithEventTypeBrokerDoesNotExist ¶ added in v0.6.0
WithEventTypeBrokerNotFound calls .Status.MarkFilterFailed on the EventType.
func WithEventTypeBrokerExists ¶ added in v0.6.0
WithEventTypeBrokerExists calls .Status.MarkBrokerExists on the EventType.
func WithEventTypeBrokerReady ¶ added in v0.6.0
WithEventTypeBrokerReady calls .Status.MarkBrokerReady on the EventType.
func WithEventTypeDeletionTimestamp ¶ added in v0.6.0
func WithFlowsParallelDeleted ¶ added in v0.11.0
func WithFlowsSequenceDeleted ¶ added in v0.11.0
func WithInMemoryChannelDeleted ¶ added in v0.7.0
func WithInMemoryChannelDeleted(imc *v1alpha1.InMemoryChannel)
func WithInitApiServerSourceConditions ¶ added in v0.6.0
func WithInitApiServerSourceConditions(s *v1alpha1.ApiServerSource)
WithInitApiServerSourceConditions initializes the ApiServerSource's conditions.
func WithInitBrokerConditions ¶ added in v0.6.0
WithInitBrokerConditions initializes the Broker's conditions.
func WithInitChannelConditions ¶ added in v0.6.0
WithInitChannelConditions initializes the Channel's conditions.
func WithInitConfigMapPropagationConditions ¶ added in v0.13.0
func WithInitConfigMapPropagationConditions(cmp *v1alpha1.ConfigMapPropagation)
WithInitConfigMapPropagationConditions initializes the ConfigMapPropagation's conditions.
func WithInitContainerSourceConditions ¶ added in v0.6.0
func WithInitContainerSourceConditions(s *legacysourcesv1alpha1.ContainerSource)
WithInitContainerSourceConditions initializes the ContainerSource's conditions.
func WithInitCronJobSourceConditions ¶ added in v0.6.0
func WithInitCronJobSourceConditions(s *v1alpha1.CronJobSource)
WithInitCronJobSourceConditions initializes the CronJobSource's conditions.
func WithInitEventTypeConditions ¶ added in v0.6.0
WithInitEventTypeConditions initializes the EventType's conditions.
func WithInitFlowsParallelConditions ¶ added in v0.11.0
func WithInitFlowsSequenceConditions ¶ added in v0.11.0
func WithInitInMemoryChannelConditions ¶ added in v0.7.0
func WithInitInMemoryChannelConditions(imc *v1alpha1.InMemoryChannel)
func WithInitLegacyApiServerSourceConditions ¶ added in v0.12.0
func WithInitLegacyApiServerSourceConditions(s *v1alpha1.ApiServerSource)
WithInitApiServerSourceConditions initializes the ApiServerSource's conditions.
func WithInitPingSourceConditions ¶ added in v0.13.0
func WithInitPingSourceConditions(s *v1alpha1.PingSource)
WithInitPingSourceConditions initializes the PingSource's conditions.
func WithInitSubscriptionConditions ¶ added in v0.6.0
func WithInitSubscriptionConditions(s *v1alpha1.Subscription)
WithInitSubscriptionConditions initializes the Subscriptions's conditions.
func WithInitTriggerConditions ¶ added in v0.6.0
WithInitTriggerConditions initializes the Triggers's conditions.
func WithInvalidCronJobSourceSchedule ¶ added in v0.6.0
func WithInvalidCronJobSourceSchedule(s *v1alpha1.CronJobSource)
func WithInvalidPingSourceSchedule ¶ added in v0.13.0
func WithInvalidPingSourceSchedule(s *v1alpha1.PingSource)
func WithLegacyApiServerSourceDeleted ¶ added in v0.12.0
func WithLegacyApiServerSourceDeleted(c *v1alpha1.ApiServerSource)
func WithLegacyApiServerSourceDeployed ¶ added in v0.12.0
func WithLegacyApiServerSourceDeployed(s *v1alpha1.ApiServerSource)
func WithLegacyApiServerSourceDeploymentUnavailable ¶ added in v0.12.0
func WithLegacyApiServerSourceDeploymentUnavailable(s *v1alpha1.ApiServerSource)
func WithLegacyApiServerSourceEventTypes ¶ added in v0.12.0
func WithLegacyApiServerSourceEventTypes(s *v1alpha1.ApiServerSource)
func WithLegacyApiServerSourceNoSufficientPermissions ¶ added in v0.12.0
func WithLegacyApiServerSourceNoSufficientPermissions(s *v1alpha1.ApiServerSource)
func WithLegacyApiServerSourceSinkNotFound ¶ added in v0.12.0
func WithLegacyApiServerSourceSinkNotFound(s *v1alpha1.ApiServerSource)
func WithLegacyApiServerSourceSufficientPermissions ¶ added in v0.12.0
func WithLegacyApiServerSourceSufficientPermissions(s *v1alpha1.ApiServerSource)
func WithNamespaceDeleted ¶ added in v0.6.0
func WithPingSourceDeleted ¶ added in v0.13.0
func WithPingSourceDeleted(c *v1alpha1.PingSource)
func WithPingSourceDeployed ¶ added in v0.13.0
func WithPingSourceDeployed(s *v1alpha1.PingSource)
func WithPingSourceEventType ¶ added in v0.13.0
func WithPingSourceEventType(s *v1alpha1.PingSource)
func WithPingSourceSinkNotFound ¶ added in v0.13.0
func WithPingSourceSinkNotFound(s *v1alpha1.PingSource)
func WithSubscriptionDeleted ¶ added in v0.6.0
func WithSubscriptionDeleted(s *v1alpha1.Subscription)
TODO: this can be a runtime object
func WithSubscriptionReady ¶ added in v0.6.0
func WithSubscriptionReady(s *v1alpha1.Subscription)
func WithTriggerDeleted ¶ added in v0.6.0
TODO: this can be a runtime object
func WithValidCronJobSourceResources ¶ added in v0.7.0
func WithValidCronJobSourceResources(s *v1alpha1.CronJobSource)
func WithValidCronJobSourceSchedule ¶ added in v0.6.0
func WithValidCronJobSourceSchedule(s *v1alpha1.CronJobSource)
func WithValidPingSourceResources ¶ added in v0.13.0
func WithValidPingSourceResources(s *v1alpha1.PingSource)
func WithValidPingSourceSchedule ¶ added in v0.13.0
func WithValidPingSourceSchedule(s *v1alpha1.PingSource)
Types ¶
type ApiServerSourceOption ¶ added in v0.6.0
type ApiServerSourceOption func(*v1alpha1.ApiServerSource)
ApiServerSourceOption enables further configuration of a ApiServer.
func WithApiServerSourceObjectMetaGeneration ¶ added in v0.9.0
func WithApiServerSourceObjectMetaGeneration(generation int64) ApiServerSourceOption
func WithApiServerSourceSink ¶ added in v0.6.0
func WithApiServerSourceSink(uri string) ApiServerSourceOption
func WithApiServerSourceSinkDepRef ¶ added in v0.10.0
func WithApiServerSourceSinkDepRef(uri string) ApiServerSourceOption
func WithApiServerSourceSpec ¶ added in v0.6.0
func WithApiServerSourceSpec(spec v1alpha1.ApiServerSourceSpec) ApiServerSourceOption
func WithApiServerSourceStatusObservedGeneration ¶ added in v0.9.0
func WithApiServerSourceStatusObservedGeneration(generation int64) ApiServerSourceOption
func WithApiServerSourceUID ¶ added in v0.9.0
func WithApiServerSourceUID(uid string) ApiServerSourceOption
type BrokerOption ¶ added in v0.6.0
BrokerOption enables further configuration of a Broker.
func WithBrokerAddress ¶ added in v0.6.0
func WithBrokerAddress(address string) BrokerOption
WithBrokerAddress sets the Broker's address.
func WithBrokerChannel ¶ added in v0.10.0
func WithBrokerChannel(crdType metav1.TypeMeta) BrokerOption
WithBrokerChannel sets the Broker's ChannelTemplateSpec to the specified CRD.
func WithBrokerFinalizers ¶ added in v0.13.0
func WithBrokerFinalizers(finalizers ...string) BrokerOption
func WithBrokerGeneration ¶ added in v0.12.0
func WithBrokerGeneration(gen int64) BrokerOption
func WithBrokerResourceVersion ¶ added in v0.13.0
func WithBrokerResourceVersion(rv string) BrokerOption
func WithBrokerStatusObservedGeneration ¶ added in v0.12.0
func WithBrokerStatusObservedGeneration(gen int64) BrokerOption
func WithBrokerTriggerChannel ¶ added in v0.7.0
func WithBrokerTriggerChannel(c *corev1.ObjectReference) BrokerOption
func WithFilterDeploymentAvailable ¶ added in v0.6.0
func WithFilterDeploymentAvailable() BrokerOption
func WithFilterFailed ¶ added in v0.6.0
func WithFilterFailed(reason, msg string) BrokerOption
WithFilterFailed calls .Status.MarkFilterFailed on the Broker.
func WithIngressDeploymentAvailable ¶ added in v0.6.0
func WithIngressDeploymentAvailable() BrokerOption
func WithIngressFailed ¶ added in v0.6.0
func WithIngressFailed(reason, msg string) BrokerOption
WithIngressFailed calls .Status.MarkIngressFailed on the Broker.
func WithTriggerChannelFailed ¶ added in v0.6.0
func WithTriggerChannelFailed(reason, msg string) BrokerOption
WithTriggerChannelFailed calls .Status.MarkTriggerChannelFailed on the Broker.
func WithTriggerChannelReady ¶ added in v0.6.0
func WithTriggerChannelReady() BrokerOption
WithTriggerChannelReady calls .Status.PropagateTriggerChannelReadiness on the Broker.
type Buildable ¶
Buildable allows test fixtures to use the builder pattern. The table test runner will call Build() on any Buildable objects and use the result as the test fixture.
type ChannelOption ¶ added in v0.6.0
ChannelOption enables further configuration of a Channel.
func WithBackingChannelFailed ¶ added in v0.8.0
func WithBackingChannelFailed(reason, msg string) ChannelOption
func WithBackingChannelObjRef ¶ added in v0.8.0
func WithBackingChannelObjRef(objRef *v1.ObjectReference) ChannelOption
func WithBackingChannelUnknown ¶ added in v0.13.0
func WithBackingChannelUnknown(reason, msg string) ChannelOption
func WithChannelAddress ¶ added in v0.6.0
func WithChannelAddress(hostname string) ChannelOption
func WithChannelGeneration ¶ added in v0.13.0
func WithChannelGeneration(gen int64) ChannelOption
func WithChannelNoAddress ¶ added in v0.13.0
func WithChannelNoAddress() ChannelOption
func WithChannelObservedGeneration ¶ added in v0.13.0
func WithChannelObservedGeneration(gen int64) ChannelOption
func WithChannelReadySubscriber ¶ added in v0.9.0
func WithChannelReadySubscriber(uid string) ChannelOption
func WithChannelReadySubscriberAndGeneration ¶ added in v0.9.0
func WithChannelReadySubscriberAndGeneration(uid string, observedGeneration int64) ChannelOption
func WithChannelSubscriberStatuses ¶ added in v0.9.0
func WithChannelSubscriberStatuses(subscriberStatuses []eventingduckv1alpha1.SubscriberStatus) ChannelOption
func WithChannelTemplate ¶ added in v0.9.0
func WithChannelTemplate(typeMeta metav1.TypeMeta) ChannelOption
type ConfigMapOption ¶ added in v0.13.0
ConfigMapOption enables further configuration of a ConfigMap.
func WithConfigMapData ¶ added in v0.13.0
func WithConfigMapData(data map[string]string) ConfigMapOption
func WithConfigMapLabels ¶ added in v0.13.0
func WithConfigMapLabels(labels metav1.LabelSelector) ConfigMapOption
func WithConfigMapOwnerReference ¶ added in v0.13.0
func WithConfigMapOwnerReference(ConfigMapPropagation *v1alpha1.ConfigMapPropagation) ConfigMapOption
type ConfigMapPropagationOption ¶ added in v0.13.0
type ConfigMapPropagationOption func(*v1alpha1.ConfigMapPropagation)
ConfigMapPropagationOption enables further configuration of a ConfigMapPropagation.
func WithConfigMapPropagationGeneration ¶ added in v0.13.0
func WithConfigMapPropagationGeneration(gen int64) ConfigMapPropagationOption
func WithConfigMapPropagationSelector ¶ added in v0.13.0
func WithConfigMapPropagationSelector(selector metav1.LabelSelector) ConfigMapPropagationOption
func WithConfigMapPropagationStatusObservedGeneration ¶ added in v0.13.0
func WithConfigMapPropagationStatusObservedGeneration(gen int64) ConfigMapPropagationOption
func WithConfigMapPropagationUID ¶ added in v0.13.0
func WithConfigMapPropagationUID(uid string) ConfigMapPropagationOption
func WithCopyConfigMapStatus ¶ added in v0.13.0
func WithCopyConfigMapStatus(name, source, operation, ready, reason string) ConfigMapPropagationOption
func WithInitConfigMapStatus ¶ added in v0.13.0
func WithInitConfigMapStatus() ConfigMapPropagationOption
type ContainerSourceOption ¶ added in v0.6.0
type ContainerSourceOption func(*legacysourcesv1alpha1.ContainerSource)
ContainerSourceOption enables further configuration of a ContainerSource.
func WithContainerSourceAnnotations ¶ added in v0.6.0
func WithContainerSourceAnnotations(annotations map[string]string) ContainerSourceOption
func WithContainerSourceDeployFailed ¶ added in v0.6.0
func WithContainerSourceDeployFailed(msg string) ContainerSourceOption
func WithContainerSourceDeploying ¶ added in v0.6.0
func WithContainerSourceDeploying(msg string) ContainerSourceOption
func WithContainerSourceLabels ¶ added in v0.6.0
func WithContainerSourceLabels(labels map[string]string) ContainerSourceOption
func WithContainerSourceObjectMetaGeneration ¶ added in v0.9.0
func WithContainerSourceObjectMetaGeneration(generation int64) ContainerSourceOption
func WithContainerSourceSink ¶ added in v0.6.0
func WithContainerSourceSink(uri string) ContainerSourceOption
func WithContainerSourceSinkMissing ¶ added in v0.6.0
func WithContainerSourceSinkMissing(msg string) ContainerSourceOption
func WithContainerSourceSinkNotFound ¶ added in v0.6.0
func WithContainerSourceSinkNotFound(msg string) ContainerSourceOption
func WithContainerSourceSpec ¶ added in v0.6.0
func WithContainerSourceSpec(spec legacysourcesv1alpha1.ContainerSourceSpec) ContainerSourceOption
func WithContainerSourceStatusObservedGeneration ¶ added in v0.9.0
func WithContainerSourceStatusObservedGeneration(generation int64) ContainerSourceOption
func WithContainerSourceUID ¶ added in v0.6.0
func WithContainerSourceUID(uid types.UID) ContainerSourceOption
type CronJobSourceOption ¶ added in v0.6.0
type CronJobSourceOption func(*v1alpha1.CronJobSource)
CronJobSourceOption enables further configuration of a CronJob.
func WithCronJobApiVersion ¶ added in v0.9.0
func WithCronJobApiVersion(apiVersion string) CronJobSourceOption
func WithCronJobSourceObjectMetaGeneration ¶ added in v0.9.0
func WithCronJobSourceObjectMetaGeneration(generation int64) CronJobSourceOption
func WithCronJobSourceSink ¶ added in v0.6.0
func WithCronJobSourceSink(uri string) CronJobSourceOption
func WithCronJobSourceSpec ¶ added in v0.6.0
func WithCronJobSourceSpec(spec v1alpha1.CronJobSourceSpec) CronJobSourceOption
func WithCronJobSourceStatusObservedGeneration ¶ added in v0.9.0
func WithCronJobSourceStatusObservedGeneration(generation int64) CronJobSourceOption
func WithCronJobSourceUID ¶ added in v0.9.0
func WithCronJobSourceUID(uid string) CronJobSourceOption
type Ctor ¶ added in v0.6.0
type Ctor func(context.Context, *Listers, configmap.Watcher) controller.Reconciler
Ctor functions create a k8s controller with given params.
type CustomResourceDefinitionOption ¶ added in v0.7.0
type CustomResourceDefinitionOption func(*apiextensionsv1beta1.CustomResourceDefinition)
CustomResourceDefinitionOption enables further configuration of a CustomResourceDefinition.
func WithCustomResourceDefinitionLabels ¶ added in v0.7.0
func WithCustomResourceDefinitionLabels(labels map[string]string) CustomResourceDefinitionOption
WithCustomResourceDefinitionLabels sets the CRD's labels.
type DeploymentOption ¶ added in v0.6.0
type DeploymentOption func(*appsv1.Deployment)
DeploymentOption enables further configuration of a Deployment.
func WithDeploymentAnnotations ¶ added in v0.6.0
func WithDeploymentAnnotations(annotations map[string]string) DeploymentOption
func WithDeploymentAvailable ¶ added in v0.8.0
func WithDeploymentAvailable() DeploymentOption
WithDeploymentAvailable marks the Deployment as available.
func WithDeploymentContainer ¶ added in v0.6.0
func WithDeploymentContainer(name, image string, liveness *corev1.Probe, readiness *corev1.Probe, envVars []corev1.EnvVar, containerPorts []corev1.ContainerPort) DeploymentOption
func WithDeploymentLabels ¶ added in v0.6.0
func WithDeploymentLabels(labels map[string]string) DeploymentOption
func WithDeploymentOwnerReferences ¶ added in v0.6.0
func WithDeploymentOwnerReferences(ownerReferences []metav1.OwnerReference) DeploymentOption
func WithDeploymentServiceAccount ¶ added in v0.6.0
func WithDeploymentServiceAccount(serviceAccountName string) DeploymentOption
type DynamicMocks ¶ added in v0.5.0
type DynamicMocks struct { // MockResources corresponds to dynamic.Interface. MockResources []MockDynamicResource // All other fields correspond to their dynamic.ResourceInterface equivalents. MockCreates []MockDynamicCreate MockUpdates []MockDynamicUpdate MockUpdateStatuses []MockDynamicUpdateStatus MockDeletes []MockDynamicDelete MockDeleteCollections []MockDynamicDeleteCollection MockGets []MockDynamicGet MockLists []MockDynamicList MockWatches []MockDynamicWatch MockPatches []MockDynamicPatch }
The mocks to run on each function type. Each function will run through the mocks in its list until one responds with 'Handled'. If there is more than one mock in the list, then the one that responds 'Handled' will be removed and not run on subsequent calls to the function. If no mocks respond 'Handled', then the real underlying client is called.
type EventTypeOption ¶ added in v0.6.0
EventTypeOption enables further configuration of an EventType.
func WithEventTypeBroker ¶ added in v0.6.0
func WithEventTypeBroker(broker string) EventTypeOption
func WithEventTypeBrokerFailed ¶ added in v0.12.0
func WithEventTypeBrokerFailed(reason, message string) EventTypeOption
func WithEventTypeBrokerUnknown ¶ added in v0.12.0
func WithEventTypeBrokerUnknown(reason, message string) EventTypeOption
func WithEventTypeDescription ¶ added in v0.6.0
func WithEventTypeDescription(description string) EventTypeOption
func WithEventTypeLabels ¶ added in v0.6.0
func WithEventTypeLabels(labels map[string]string) EventTypeOption
func WithEventTypeOwnerReference ¶ added in v0.6.0
func WithEventTypeOwnerReference(ownerRef metav1.OwnerReference) EventTypeOption
func WithEventTypeSource ¶ added in v0.6.0
func WithEventTypeSource(source string) EventTypeOption
func WithEventTypeType ¶ added in v0.6.0
func WithEventTypeType(t string) EventTypeOption
type FlowsParallelOption ¶ added in v0.11.0
ParallelOption enables further configuration of a Parallel.
func WithFlowsParallelAddressableNotReady ¶ added in v0.11.0
func WithFlowsParallelAddressableNotReady(reason, message string) FlowsParallelOption
func WithFlowsParallelBranchStatuses ¶ added in v0.11.0
func WithFlowsParallelBranchStatuses(branchStatuses []v1alpha1.ParallelBranchStatus) FlowsParallelOption
func WithFlowsParallelBranches ¶ added in v0.11.0
func WithFlowsParallelBranches(branches []v1alpha1.ParallelBranch) FlowsParallelOption
func WithFlowsParallelChannelTemplateSpec ¶ added in v0.11.0
func WithFlowsParallelChannelTemplateSpec(cts *messagingvbeta1.ChannelTemplateSpec) FlowsParallelOption
func WithFlowsParallelChannelsNotReady ¶ added in v0.11.0
func WithFlowsParallelChannelsNotReady(reason, message string) FlowsParallelOption
func WithFlowsParallelGeneration ¶ added in v0.12.0
func WithFlowsParallelGeneration(gen int64) FlowsParallelOption
func WithFlowsParallelIngressChannelStatus ¶ added in v0.11.0
func WithFlowsParallelIngressChannelStatus(status v1alpha1.ParallelChannelStatus) FlowsParallelOption
func WithFlowsParallelReply ¶ added in v0.11.0
func WithFlowsParallelReply(reply *duckv1.Destination) FlowsParallelOption
func WithFlowsParallelStatusObservedGeneration ¶ added in v0.12.0
func WithFlowsParallelStatusObservedGeneration(gen int64) FlowsParallelOption
func WithFlowsParallelSubscriptionsNotReady ¶ added in v0.11.0
func WithFlowsParallelSubscriptionsNotReady(reason, message string) FlowsParallelOption
type FlowsSequenceOption ¶ added in v0.11.0
SequenceOption enables further configuration of a Sequence.
func WithFlowsSequenceAddressableNotReady ¶ added in v0.11.0
func WithFlowsSequenceAddressableNotReady(reason, message string) FlowsSequenceOption
func WithFlowsSequenceChannelStatuses ¶ added in v0.11.0
func WithFlowsSequenceChannelStatuses(channelStatuses []v1alpha1.SequenceChannelStatus) FlowsSequenceOption
func WithFlowsSequenceChannelTemplateSpec ¶ added in v0.11.0
func WithFlowsSequenceChannelTemplateSpec(cts *messagingv1beta1.ChannelTemplateSpec) FlowsSequenceOption
func WithFlowsSequenceChannelsNotReady ¶ added in v0.11.0
func WithFlowsSequenceChannelsNotReady(reason, message string) FlowsSequenceOption
func WithFlowsSequenceGeneration ¶ added in v0.12.0
func WithFlowsSequenceGeneration(gen int64) FlowsSequenceOption
func WithFlowsSequenceReply ¶ added in v0.11.0
func WithFlowsSequenceReply(reply *duckv1.Destination) FlowsSequenceOption
func WithFlowsSequenceStatusObservedGeneration ¶ added in v0.12.0
func WithFlowsSequenceStatusObservedGeneration(gen int64) FlowsSequenceOption
func WithFlowsSequenceSteps ¶ added in v0.11.0
func WithFlowsSequenceSteps(steps []v1alpha1.SequenceStep) FlowsSequenceOption
func WithFlowsSequenceSubscriptionStatuses ¶ added in v0.11.0
func WithFlowsSequenceSubscriptionStatuses(subscriptionStatuses []v1alpha1.SequenceSubscriptionStatus) FlowsSequenceOption
func WithFlowsSequenceSubscriptionsNotReady ¶ added in v0.11.0
func WithFlowsSequenceSubscriptionsNotReady(reason, message string) FlowsSequenceOption
type InMemoryChannelOption ¶ added in v0.7.0
type InMemoryChannelOption func(*v1alpha1.InMemoryChannel)
InMemoryChannelOption enables further configuration of a InMemoryChannel.
func WithInMemoryChannelAddress ¶ added in v0.7.0
func WithInMemoryChannelAddress(a string) InMemoryChannelOption
func WithInMemoryChannelChannelServiceNotReady ¶ added in v0.13.0
func WithInMemoryChannelChannelServiceNotReady(reason, message string) InMemoryChannelOption
func WithInMemoryChannelChannelServiceReady ¶ added in v0.7.0
func WithInMemoryChannelChannelServiceReady() InMemoryChannelOption
func WithInMemoryChannelDeploymentFailed ¶ added in v0.12.0
func WithInMemoryChannelDeploymentFailed(reason, message string) InMemoryChannelOption
func WithInMemoryChannelDeploymentReady ¶ added in v0.7.0
func WithInMemoryChannelDeploymentReady() InMemoryChannelOption
func WithInMemoryChannelDeploymentUnknown ¶ added in v0.12.0
func WithInMemoryChannelDeploymentUnknown(reason, message string) InMemoryChannelOption
func WithInMemoryChannelEndpointsNotReady ¶ added in v0.7.0
func WithInMemoryChannelEndpointsNotReady(reason, message string) InMemoryChannelOption
func WithInMemoryChannelEndpointsReady ¶ added in v0.7.0
func WithInMemoryChannelEndpointsReady() InMemoryChannelOption
func WithInMemoryChannelGeneration ¶ added in v0.12.0
func WithInMemoryChannelGeneration(gen int64) InMemoryChannelOption
func WithInMemoryChannelReady ¶ added in v0.13.0
func WithInMemoryChannelReady(host string) InMemoryChannelOption
func WithInMemoryChannelReadySubscriber ¶ added in v0.13.0
func WithInMemoryChannelReadySubscriber(uid string) InMemoryChannelOption
func WithInMemoryChannelReadySubscriberAndGeneration ¶ added in v0.13.0
func WithInMemoryChannelReadySubscriberAndGeneration(uid string, observedGeneration int64) InMemoryChannelOption
func WithInMemoryChannelServiceReady ¶ added in v0.7.0
func WithInMemoryChannelServiceReady() InMemoryChannelOption
func WithInMemoryChannelServicetNotReady ¶ added in v0.7.0
func WithInMemoryChannelServicetNotReady(reason, message string) InMemoryChannelOption
func WithInMemoryChannelStatusObservedGeneration ¶ added in v0.12.0
func WithInMemoryChannelStatusObservedGeneration(gen int64) InMemoryChannelOption
func WithInMemoryChannelStatusSubscribers ¶ added in v0.7.0
func WithInMemoryChannelStatusSubscribers(subscriberStatuses []duckv1alpha1.SubscriberStatus) InMemoryChannelOption
func WithInMemoryChannelSubscribers ¶ added in v0.7.0
func WithInMemoryChannelSubscribers(subscribers []duckv1alpha1.SubscriberSpec) InMemoryChannelOption
func WithInMemoryScopeAnnotation ¶ added in v0.13.0
func WithInMemoryScopeAnnotation(value string) InMemoryChannelOption
type LegacyApiServerSourceOption ¶ added in v0.12.0
type LegacyApiServerSourceOption func(*v1alpha1.ApiServerSource)
LegacyApiServerSourceOption enables further configuration of a Legacy ApiServerSource.
func WithLegacyApiServerSourceObjectMetaGeneration ¶ added in v0.12.0
func WithLegacyApiServerSourceObjectMetaGeneration(generation int64) LegacyApiServerSourceOption
func WithLegacyApiServerSourceSink ¶ added in v0.12.0
func WithLegacyApiServerSourceSink(uri string) LegacyApiServerSourceOption
func WithLegacyApiServerSourceSinkDepRef ¶ added in v0.12.0
func WithLegacyApiServerSourceSinkDepRef(uri string) LegacyApiServerSourceOption
func WithLegacyApiServerSourceSpec ¶ added in v0.12.0
func WithLegacyApiServerSourceSpec(spec v1alpha1.ApiServerSourceSpec) LegacyApiServerSourceOption
func WithLegacyApiServerSourceStatusObservedGeneration ¶ added in v0.12.0
func WithLegacyApiServerSourceStatusObservedGeneration(generation int64) LegacyApiServerSourceOption
func WithLegacyApiServerSourceUID ¶ added in v0.12.0
func WithLegacyApiServerSourceUID(uid string) LegacyApiServerSourceOption
type LegacySinkBindingOption ¶ added in v0.12.0
type LegacySinkBindingOption func(*legacysourcesv1alpha1.SinkBinding)
LegacySinkBindingOption enables further configuration of a SinkBinding.
func WithLegacySink ¶ added in v0.12.0
func WithLegacySink(sink duckv1.Destination) LegacySinkBindingOption
WithLegacySink assigns the sink of the SinkBinding.
func WithLegacySubject ¶ added in v0.12.0
func WithLegacySubject(subject tracker.Reference) LegacySinkBindingOption
WithLegacySubject assigns the subject of the SinkBinding.
type Listers ¶ added in v0.6.0
type Listers struct {
// contains filtered or unexported fields
}
func NewListers ¶ added in v0.6.0
func (*Listers) GetAllObjects ¶ added in v0.6.0
func (*Listers) GetApiServerSourceLister ¶ added in v0.6.0
func (l *Listers) GetApiServerSourceLister() sourcelisters.ApiServerSourceLister
func (*Listers) GetBrokerLister ¶ added in v0.6.0
func (l *Listers) GetBrokerLister() eventinglisters.BrokerLister
func (*Listers) GetConfigMapLister ¶ added in v0.6.0
func (l *Listers) GetConfigMapLister() corev1listers.ConfigMapLister
func (*Listers) GetConfigMapPropagationLister ¶ added in v0.13.0
func (l *Listers) GetConfigMapPropagationLister() configslisters.ConfigMapPropagationLister
func (*Listers) GetCustomResourceDefinitionLister ¶ added in v0.7.0
func (l *Listers) GetCustomResourceDefinitionLister() apiextensionsv1beta1listers.CustomResourceDefinitionLister
func (*Listers) GetDeploymentLister ¶ added in v0.6.0
func (l *Listers) GetDeploymentLister() appsv1listers.DeploymentLister
func (*Listers) GetEndpointsLister ¶ added in v0.6.0
func (l *Listers) GetEndpointsLister() corev1listers.EndpointsLister
func (*Listers) GetEventTypeLister ¶ added in v0.6.0
func (l *Listers) GetEventTypeLister() eventinglisters.EventTypeLister
func (*Listers) GetEventingObjects ¶ added in v0.6.0
func (*Listers) GetFlowsParallelLister ¶ added in v0.11.0
func (l *Listers) GetFlowsParallelLister() flowslisters.ParallelLister
func (*Listers) GetFlowsSequenceLister ¶ added in v0.11.0
func (l *Listers) GetFlowsSequenceLister() flowslisters.SequenceLister
func (*Listers) GetInMemoryChannelLister ¶ added in v0.7.0
func (l *Listers) GetInMemoryChannelLister() messaginglisters.InMemoryChannelLister
func (*Listers) GetK8sServiceLister ¶ added in v0.6.0
func (l *Listers) GetK8sServiceLister() corev1listers.ServiceLister
func (*Listers) GetKubeObjects ¶ added in v0.6.0
func (*Listers) GetLegacyApiServerSourceLister ¶ added in v0.12.0
func (l *Listers) GetLegacyApiServerSourceLister() legacysourcelisters.ApiServerSourceLister
func (*Listers) GetLegacyContainerSourceLister ¶ added in v0.12.0
func (l *Listers) GetLegacyContainerSourceLister() legacysourcelisters.ContainerSourceLister
func (*Listers) GetLegacyCronJobSourceLister ¶ added in v0.12.0
func (l *Listers) GetLegacyCronJobSourceLister() legacysourcelisters.CronJobSourceLister
func (*Listers) GetLegacyObjects ¶ added in v0.12.0
func (*Listers) GetMessagingChannelLister ¶ added in v0.8.0
func (l *Listers) GetMessagingChannelLister() messaginglisters.ChannelLister
func (*Listers) GetNamespaceLister ¶ added in v0.6.0
func (l *Listers) GetNamespaceLister() corev1listers.NamespaceLister
func (*Listers) GetPingSourceLister ¶ added in v0.13.0
func (l *Listers) GetPingSourceLister() sourcelisters.PingSourceLister
func (*Listers) GetRoleBindingLister ¶ added in v0.6.0
func (l *Listers) GetRoleBindingLister() rbacv1listers.RoleBindingLister
func (*Listers) GetServiceAccountLister ¶ added in v0.6.0
func (l *Listers) GetServiceAccountLister() corev1listers.ServiceAccountLister
func (*Listers) GetServiceLister ¶ added in v0.7.0
func (l *Listers) GetServiceLister() corev1listers.ServiceLister
func (*Listers) GetSubscriberObjects ¶ added in v0.6.0
func (*Listers) GetSubscriptionLister ¶ added in v0.6.0
func (l *Listers) GetSubscriptionLister() messaginglisters.SubscriptionLister
func (*Listers) GetTriggerLister ¶ added in v0.6.0
func (l *Listers) GetTriggerLister() eventinglisters.TriggerLister
type MockDynamicContext ¶ added in v0.5.0
type MockDynamicContext struct { InnerInterface dynamic.ResourceInterface Resource schema.GroupVersionResource Namespace string }
type MockDynamicCreate ¶ added in v0.5.0
type MockDynamicCreate func(ctx *MockDynamicContext, obj *unstructured.Unstructured, options metav1.CreateOptions, subresources ...string) (MockHandled, *unstructured.Unstructured, error)
All of the functions in dynamic.Resource get mocked equivalents. For the function dynamic.Resource.Foo(), the mocked equivalent will be: MockDynamicFoo func(ctx *MockDynamicContext[, Foo's arguments]) (MockHandled[, Foo's returns])
type MockDynamicDelete ¶ added in v0.5.0
type MockDynamicDelete func(ctx *MockDynamicContext, name string, options *metav1.DeleteOptions, subresources ...string) (MockHandled, error)
type MockDynamicDeleteCollection ¶ added in v0.5.0
type MockDynamicDeleteCollection func(ctx *MockDynamicContext, options *metav1.DeleteOptions, listOptions metav1.ListOptions) (MockHandled, error)
type MockDynamicGet ¶ added in v0.5.0
type MockDynamicGet func(ctx *MockDynamicContext, name string, options metav1.GetOptions, subresources ...string) (MockHandled, *unstructured.Unstructured, error)
type MockDynamicInterface ¶ added in v0.5.0
type MockDynamicInterface struct {
// contains filtered or unexported fields
}
func NewMockDynamicInterface ¶ added in v0.5.0
func NewMockDynamicInterface(innerInterface dynamic.Interface, mocks DynamicMocks) *MockDynamicInterface
func (MockDynamicInterface) Resource ¶ added in v0.5.0
func (m MockDynamicInterface) Resource(resource schema.GroupVersionResource) dynamic.NamespaceableResourceInterface
type MockDynamicList ¶ added in v0.5.0
type MockDynamicList func(ctx *MockDynamicContext, opts metav1.ListOptions) (MockHandled, *unstructured.UnstructuredList, error)
type MockDynamicPatch ¶ added in v0.5.0
type MockDynamicPatch func(ctx *MockDynamicContext, name string, pt types.PatchType, data []byte, options metav1.PatchOptions, subresources ...string) (MockHandled, *unstructured.Unstructured, error)
type MockDynamicResource ¶ added in v0.5.0
type MockDynamicResource func(innerInterface dynamic.Interface, resource schema.GroupVersionResource) (MockHandled, dynamic.NamespaceableResourceInterface)
All of the functions in dynamic.Interface get mocked equivalents.
type MockDynamicUpdate ¶ added in v0.5.0
type MockDynamicUpdate func(ctx *MockDynamicContext, obj *unstructured.Unstructured, options metav1.UpdateOptions, subresources ...string) (MockHandled, *unstructured.Unstructured, error)
type MockDynamicUpdateStatus ¶ added in v0.5.0
type MockDynamicUpdateStatus func(ctx *MockDynamicContext, obj *unstructured.Unstructured, options metav1.UpdateOptions) (MockHandled, *unstructured.Unstructured, error)
type MockDynamicWatch ¶ added in v0.5.0
type MockDynamicWatch func(ctx *MockDynamicContext, opts metav1.ListOptions) (MockHandled, watch.Interface, error)
type MockEventRecorder ¶
type MockEventRecorder struct {
// contains filtered or unexported fields
}
MockEventRecorder is a recorder.EventRecorder that saves emitted v1 Events.
func NewEventRecorder ¶
func NewEventRecorder() *MockEventRecorder
func (*MockEventRecorder) AnnotatedEventf ¶
func (*MockEventRecorder) Event ¶
func (m *MockEventRecorder) Event(object runtime.Object, eventtype, reason, message string)
func (*MockEventRecorder) Eventf ¶
func (m *MockEventRecorder) Eventf(object runtime.Object, eventtype, reason, messageFmt string, args ...interface{})
func (*MockEventRecorder) PastEventf ¶
type MockHandled ¶
type MockHandled int
const ( // This mock has handled the function call, no further mocks nor the real client should be // called. Handled MockHandled = iota // This mock has not handled the function call, subsequent mocks or the real client should be // called. Unhandled )
type NamespaceOption ¶ added in v0.6.0
NamespaceOption enables further configuration of a Namespace.
func WithNamespaceLabeled ¶ added in v0.6.0
func WithNamespaceLabeled(labels map[string]string) NamespaceOption
type PingSourceOption ¶ added in v0.13.0
type PingSourceOption func(*v1alpha1.PingSource)
PingSourceOption enables further configuration of a CronJob.
func WithPingSourceApiVersion ¶ added in v0.13.0
func WithPingSourceApiVersion(apiVersion string) PingSourceOption
func WithPingSourceObjectMetaGeneration ¶ added in v0.13.0
func WithPingSourceObjectMetaGeneration(generation int64) PingSourceOption
func WithPingSourceSink ¶ added in v0.13.0
func WithPingSourceSink(uri *apis.URL) PingSourceOption
func WithPingSourceSpec ¶ added in v0.13.0
func WithPingSourceSpec(spec v1alpha1.PingSourceSpec) PingSourceOption
func WithPingSourceStatusObservedGeneration ¶ added in v0.13.0
func WithPingSourceStatusObservedGeneration(generation int64) PingSourceOption
func WithPingSourceUID ¶ added in v0.13.0
func WithPingSourceUID(uid string) PingSourceOption
type PingSourceV1A2Option ¶ added in v0.13.0
type PingSourceV1A2Option func(*v1alpha2.PingSource)
PingSourceV1A2Option enables further configuration of a CronJob.
func WithPingSourceV1A2Spec ¶ added in v0.13.0
func WithPingSourceV1A2Spec(spec v1alpha2.PingSourceSpec) PingSourceV1A2Option
type ServiceOption ¶ added in v0.6.0
ServiceOption enables further configuration of a Service.
func WithServiceAnnotations ¶ added in v0.8.0
func WithServiceAnnotations(annotations map[string]string) ServiceOption
func WithServiceLabels ¶ added in v0.6.0
func WithServiceLabels(labels map[string]string) ServiceOption
func WithServiceOwnerReferences ¶ added in v0.6.0
func WithServiceOwnerReferences(ownerReferences []metav1.OwnerReference) ServiceOption
func WithServicePorts ¶ added in v0.6.0
func WithServicePorts(ports []corev1.ServicePort) ServiceOption
type SinkBindingV1Alpha1Option ¶ added in v0.13.0
type SinkBindingV1Alpha1Option func(*sourcesv1alpha1.SinkBinding)
SinkBindingV1Alpha1Option enables further configuration of a SinkBinding.
func WithCloudEventOverridesV1A1 ¶ added in v0.13.0
func WithCloudEventOverridesV1A1(overrides duckv1.CloudEventOverrides) SinkBindingV1Alpha1Option
WithCloudEventOverridesV1A1 assigns the CloudEventsOverrides of the SinkBinding.
func WithSinkV1A1 ¶ added in v0.13.0
func WithSinkV1A1(sink duckv1.Destination) SinkBindingV1Alpha1Option
WithSinkV1A1 assigns the sink of the SinkBinding.
func WithSubjectV1A1 ¶ added in v0.13.0
func WithSubjectV1A1(subject tracker.Reference) SinkBindingV1Alpha1Option
WithSubjectV1A1 assigns the subject of the SinkBinding.
type SinkBindingV1Alpha2Option ¶ added in v0.13.0
type SinkBindingV1Alpha2Option func(*sourcesv1alpha2.SinkBinding)
SinkBindingV1Alpha2Option enables further configuration of a SinkBinding.
func WithCloudEventOverridesV1A2 ¶ added in v0.13.0
func WithCloudEventOverridesV1A2(overrides duckv1.CloudEventOverrides) SinkBindingV1Alpha2Option
WithCloudEventOverridesV1A1 assigns the CloudEventsOverrides of the SinkBinding.
func WithSinkV1A2 ¶ added in v0.13.0
func WithSinkV1A2(sink duckv1.Destination) SinkBindingV1Alpha2Option
WithSinkV1A2 assigns the sink of the SinkBinding.
func WithSubjectV1A2 ¶ added in v0.13.0
func WithSubjectV1A2(subject tracker.Reference) SinkBindingV1Alpha2Option
WithSubjectV1A2 assigns the subject of the SinkBinding.
type SubscriptionOption ¶ added in v0.6.0
type SubscriptionOption func(*v1alpha1.Subscription)
SubscriptionOption enables further configuration of a Subscription.
func MarkNotAddedToChannel ¶ added in v0.13.0
func MarkNotAddedToChannel(reason, msg string) SubscriptionOption
func WithSubscriptionChannel ¶ added in v0.6.0
func WithSubscriptionChannel(gvk metav1.GroupVersionKind, name string) SubscriptionOption
func WithSubscriptionDeadLetterSinkURI ¶ added in v0.13.0
func WithSubscriptionDeadLetterSinkURI(uri *apis.URL) SubscriptionOption
func WithSubscriptionDeliveryRef ¶ added in v0.13.0
func WithSubscriptionDeliveryRef(gvk metav1.GroupVersionKind, name, namespace string) SubscriptionOption
func WithSubscriptionFinalizers ¶ added in v0.6.0
func WithSubscriptionFinalizers(finalizers ...string) SubscriptionOption
func WithSubscriptionGenerateName ¶ added in v0.6.0
func WithSubscriptionGenerateName(generateName string) SubscriptionOption
func WithSubscriptionGeneration ¶ added in v0.7.0
func WithSubscriptionGeneration(gen int64) SubscriptionOption
func WithSubscriptionLabels ¶ added in v0.6.0
func WithSubscriptionLabels(labels map[string]string) SubscriptionOption
func WithSubscriptionOwnerReferences ¶ added in v0.6.0
func WithSubscriptionOwnerReferences(ownerReferences []metav1.OwnerReference) SubscriptionOption
func WithSubscriptionPhysicalSubscriptionReply ¶ added in v0.6.0
func WithSubscriptionPhysicalSubscriptionReply(uri *apis.URL) SubscriptionOption
func WithSubscriptionPhysicalSubscriptionSubscriber ¶ added in v0.6.0
func WithSubscriptionPhysicalSubscriptionSubscriber(uri *apis.URL) SubscriptionOption
func WithSubscriptionReferencesNotResolved ¶ added in v0.7.0
func WithSubscriptionReferencesNotResolved(reason, msg string) SubscriptionOption
func WithSubscriptionReferencesResolvedUnknown ¶ added in v0.12.0
func WithSubscriptionReferencesResolvedUnknown(reason, msg string) SubscriptionOption
func WithSubscriptionReply ¶ added in v0.6.0
func WithSubscriptionReply(gvk metav1.GroupVersionKind, name, namespace string) SubscriptionOption
func WithSubscriptionStatusObservedGeneration ¶ added in v0.12.0
func WithSubscriptionStatusObservedGeneration(gen int64) SubscriptionOption
func WithSubscriptionSubscriberRef ¶ added in v0.6.0
func WithSubscriptionSubscriberRef(gvk metav1.GroupVersionKind, name, namespace string) SubscriptionOption
func WithSubscriptionUID ¶ added in v0.6.0
func WithSubscriptionUID(uid types.UID) SubscriptionOption
type TriggerOption ¶ added in v0.6.0
TriggerOption enables further configuration of a Trigger.
func WithDependencyAnnotation ¶ added in v0.9.0
func WithDependencyAnnotation(dependencyAnnotation string) TriggerOption
func WithInjectionAnnotation ¶ added in v0.10.0
func WithInjectionAnnotation(injectionAnnotation string) TriggerOption
func WithTriggerBrokerFailed ¶ added in v0.6.0
func WithTriggerBrokerFailed(reason, message string) TriggerOption
WithTriggerBrokerFailed marks the Broker as failed
func WithTriggerBrokerReady ¶ added in v0.6.0
func WithTriggerBrokerReady() TriggerOption
WithTriggerBrokerReady initializes the Triggers's conditions.
func WithTriggerBrokerUnknown ¶ added in v0.12.0
func WithTriggerBrokerUnknown(reason, message string) TriggerOption
WithTriggerBrokerUnknown marks the Broker as unknown
func WithTriggerDependencyFailed ¶ added in v0.9.0
func WithTriggerDependencyFailed(reason, message string) TriggerOption
func WithTriggerDependencyReady ¶ added in v0.9.0
func WithTriggerDependencyReady() TriggerOption
func WithTriggerDependencyUnknown ¶ added in v0.9.0
func WithTriggerDependencyUnknown(reason, message string) TriggerOption
func WithTriggerGeneration ¶ added in v0.12.0
func WithTriggerGeneration(gen int64) TriggerOption
func WithTriggerNotSubscribed ¶ added in v0.6.0
func WithTriggerNotSubscribed(reason, message string) TriggerOption
func WithTriggerStatusObservedGeneration ¶ added in v0.12.0
func WithTriggerStatusObservedGeneration(gen int64) TriggerOption
func WithTriggerStatusSubscriberURI ¶ added in v0.6.0
func WithTriggerStatusSubscriberURI(uri string) TriggerOption
func WithTriggerSubscribed ¶ added in v0.6.0
func WithTriggerSubscribed() TriggerOption
func WithTriggerSubscribedUnknown ¶ added in v0.12.0
func WithTriggerSubscribedUnknown(reason, message string) TriggerOption
func WithTriggerSubscriberRef ¶ added in v0.6.0
func WithTriggerSubscriberRef(gvk metav1.GroupVersionKind, name, namespace string) TriggerOption
func WithTriggerSubscriberRefAndURIReference ¶ added in v0.10.0
func WithTriggerSubscriberRefAndURIReference(gvk metav1.GroupVersionKind, name, namespace string, rawuri string) TriggerOption
func WithTriggerSubscriberResolvedFailed ¶ added in v0.10.1
func WithTriggerSubscriberResolvedFailed(reason, message string) TriggerOption
func WithTriggerSubscriberResolvedSucceeded ¶ added in v0.10.1
func WithTriggerSubscriberResolvedSucceeded() TriggerOption
func WithTriggerSubscriberResolvedUnknown ¶ added in v0.10.1
func WithTriggerSubscriberResolvedUnknown(reason, message string) TriggerOption
func WithTriggerSubscriberURI ¶ added in v0.6.0
func WithTriggerSubscriberURI(rawurl string) TriggerOption
func WithTriggerSubscriptionNotConfigured ¶ added in v0.12.0
func WithTriggerSubscriptionNotConfigured() TriggerOption
func WithTriggerUID ¶ added in v0.6.0
func WithTriggerUID(uid string) TriggerOption
func WithUnmarshalFailedDependencyAnnotation ¶ added in v0.9.0
func WithUnmarshalFailedDependencyAnnotation() TriggerOption
type UnstructuredOption ¶ added in v0.6.0
type UnstructuredOption func(*unstructured.Unstructured)
UnstructuredOption enables further configuration of a Unstructured.
func WithUnstructuredAddressable ¶ added in v0.6.0
func WithUnstructuredAddressable(hostname string) UnstructuredOption
Source Files ¶
- apiserversource.go
- broker.go
- builder.go
- channel.go
- configmap.go
- configmappropagation.go
- containersource.go
- cronjobsource.go
- customresourcedefinition.go
- deployment.go
- eventtype.go
- factory.go
- inmemorychannel.go
- legacyapiserversource.go
- listers.go
- mock_dynamic_client.go
- mock_event_recorder.go
- namespace.go
- parallel.go
- pingsource.go
- sequence.go
- service.go
- sinkbinding.go
- subscription.go
- trigger.go
- unstructured.go