pipe

package
v0.0.0-...-1f78e34 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Feb 25, 2023 License: MIT Imports: 4 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type AwsVpcConfiguration

type AwsVpcConfiguration struct {
	AssignPublicIp string   `json:"AssignPublicIp,omitempty"`
	SecurityGroups []string `json:"SecurityGroups,omitempty"`
	Subnets        []string `json:"Subnets"`
}

AwsVpcConfiguration

func (*AwsVpcConfiguration) MarshalJSON

func (strct *AwsVpcConfiguration) MarshalJSON() ([]byte, error)

func (*AwsVpcConfiguration) UnmarshalJSON

func (strct *AwsVpcConfiguration) UnmarshalJSON(b []byte) error

type BatchArrayProperties

type BatchArrayProperties struct {
	Size int `json:"Size,omitempty"`
}

BatchArrayProperties

func (*BatchArrayProperties) MarshalJSON

func (strct *BatchArrayProperties) MarshalJSON() ([]byte, error)

func (*BatchArrayProperties) UnmarshalJSON

func (strct *BatchArrayProperties) UnmarshalJSON(b []byte) error

type BatchContainerOverrides

type BatchContainerOverrides struct {
	Command              []string                    `json:"Command,omitempty"`
	Environment          []*BatchEnvironmentVariable `json:"Environment,omitempty"`
	InstanceType         string                      `json:"InstanceType,omitempty"`
	ResourceRequirements []*BatchResourceRequirement `json:"ResourceRequirements,omitempty"`
}

BatchContainerOverrides

func (*BatchContainerOverrides) MarshalJSON

func (strct *BatchContainerOverrides) MarshalJSON() ([]byte, error)

func (*BatchContainerOverrides) UnmarshalJSON

func (strct *BatchContainerOverrides) UnmarshalJSON(b []byte) error

type BatchEnvironmentVariable

type BatchEnvironmentVariable struct {
	Name  string `json:"Name,omitempty"`
	Value string `json:"Value,omitempty"`
}

BatchEnvironmentVariable

func (*BatchEnvironmentVariable) MarshalJSON

func (strct *BatchEnvironmentVariable) MarshalJSON() ([]byte, error)

func (*BatchEnvironmentVariable) UnmarshalJSON

func (strct *BatchEnvironmentVariable) UnmarshalJSON(b []byte) error

type BatchJobDependency

type BatchJobDependency struct {
	JobId string `json:"JobId,omitempty"`
	Type  string `json:"Type,omitempty"`
}

BatchJobDependency

func (*BatchJobDependency) MarshalJSON

func (strct *BatchJobDependency) MarshalJSON() ([]byte, error)

func (*BatchJobDependency) UnmarshalJSON

func (strct *BatchJobDependency) UnmarshalJSON(b []byte) error

type BatchParametersMap

type BatchParametersMap struct {
}

BatchParametersMap

func (*BatchParametersMap) MarshalJSON

func (strct *BatchParametersMap) MarshalJSON() ([]byte, error)

func (*BatchParametersMap) UnmarshalJSON

func (strct *BatchParametersMap) UnmarshalJSON(b []byte) error

type BatchResourceRequirement

type BatchResourceRequirement struct {
	Type  string `json:"Type"`
	Value string `json:"Value"`
}

BatchResourceRequirement

func (*BatchResourceRequirement) MarshalJSON

func (strct *BatchResourceRequirement) MarshalJSON() ([]byte, error)

func (*BatchResourceRequirement) UnmarshalJSON

func (strct *BatchResourceRequirement) UnmarshalJSON(b []byte) error

type BatchRetryStrategy

type BatchRetryStrategy struct {
	Attempts int `json:"Attempts,omitempty"`
}

BatchRetryStrategy

func (*BatchRetryStrategy) MarshalJSON

func (strct *BatchRetryStrategy) MarshalJSON() ([]byte, error)

func (*BatchRetryStrategy) UnmarshalJSON

func (strct *BatchRetryStrategy) UnmarshalJSON(b []byte) error

type CapacityProviderStrategyItem

type CapacityProviderStrategyItem struct {
	Base             int    `json:"Base,omitempty"`
	CapacityProvider string `json:"CapacityProvider"`
	Weight           int    `json:"Weight,omitempty"`
}

CapacityProviderStrategyItem

func (*CapacityProviderStrategyItem) MarshalJSON

func (strct *CapacityProviderStrategyItem) MarshalJSON() ([]byte, error)

func (*CapacityProviderStrategyItem) UnmarshalJSON

func (strct *CapacityProviderStrategyItem) UnmarshalJSON(b []byte) error

type DeadLetterConfig

type DeadLetterConfig struct {
	Arn string `json:"Arn,omitempty"`
}

DeadLetterConfig

func (*DeadLetterConfig) MarshalJSON

func (strct *DeadLetterConfig) MarshalJSON() ([]byte, error)

func (*DeadLetterConfig) UnmarshalJSON

func (strct *DeadLetterConfig) UnmarshalJSON(b []byte) error

type EcsContainerOverride

type EcsContainerOverride struct {
	Command              []string                  `json:"Command,omitempty"`
	Cpu                  int                       `json:"Cpu,omitempty"`
	Environment          []*EcsEnvironmentVariable `json:"Environment,omitempty"`
	EnvironmentFiles     []*EcsEnvironmentFile     `json:"EnvironmentFiles,omitempty"`
	Memory               int                       `json:"Memory,omitempty"`
	MemoryReservation    int                       `json:"MemoryReservation,omitempty"`
	Name                 string                    `json:"Name,omitempty"`
	ResourceRequirements []*EcsResourceRequirement `json:"ResourceRequirements,omitempty"`
}

EcsContainerOverride

func (*EcsContainerOverride) MarshalJSON

func (strct *EcsContainerOverride) MarshalJSON() ([]byte, error)

func (*EcsContainerOverride) UnmarshalJSON

func (strct *EcsContainerOverride) UnmarshalJSON(b []byte) error

type EcsEnvironmentFile

type EcsEnvironmentFile struct {
	Type  string `json:"Type"`
	Value string `json:"Value"`
}

EcsEnvironmentFile

func (*EcsEnvironmentFile) MarshalJSON

func (strct *EcsEnvironmentFile) MarshalJSON() ([]byte, error)

func (*EcsEnvironmentFile) UnmarshalJSON

func (strct *EcsEnvironmentFile) UnmarshalJSON(b []byte) error

type EcsEnvironmentVariable

type EcsEnvironmentVariable struct {
	Name  string `json:"Name,omitempty"`
	Value string `json:"Value,omitempty"`
}

EcsEnvironmentVariable

func (*EcsEnvironmentVariable) MarshalJSON

func (strct *EcsEnvironmentVariable) MarshalJSON() ([]byte, error)

func (*EcsEnvironmentVariable) UnmarshalJSON

func (strct *EcsEnvironmentVariable) UnmarshalJSON(b []byte) error

type EcsEphemeralStorage

type EcsEphemeralStorage struct {
	SizeInGiB int `json:"SizeInGiB"`
}

EcsEphemeralStorage

func (*EcsEphemeralStorage) MarshalJSON

func (strct *EcsEphemeralStorage) MarshalJSON() ([]byte, error)

func (*EcsEphemeralStorage) UnmarshalJSON

func (strct *EcsEphemeralStorage) UnmarshalJSON(b []byte) error

type EcsInferenceAcceleratorOverride

type EcsInferenceAcceleratorOverride struct {
	DeviceName string `json:"DeviceName,omitempty"`
	DeviceType string `json:"DeviceType,omitempty"`
}

EcsInferenceAcceleratorOverride

func (*EcsInferenceAcceleratorOverride) MarshalJSON

func (strct *EcsInferenceAcceleratorOverride) MarshalJSON() ([]byte, error)

func (*EcsInferenceAcceleratorOverride) UnmarshalJSON

func (strct *EcsInferenceAcceleratorOverride) UnmarshalJSON(b []byte) error

type EcsResourceRequirement

type EcsResourceRequirement struct {
	Type  string `json:"Type"`
	Value string `json:"Value"`
}

EcsResourceRequirement

func (*EcsResourceRequirement) MarshalJSON

func (strct *EcsResourceRequirement) MarshalJSON() ([]byte, error)

func (*EcsResourceRequirement) UnmarshalJSON

func (strct *EcsResourceRequirement) UnmarshalJSON(b []byte) error

type EcsTaskOverride

type EcsTaskOverride struct {
	ContainerOverrides            []*EcsContainerOverride            `json:"ContainerOverrides,omitempty"`
	Cpu                           string                             `json:"Cpu,omitempty"`
	EphemeralStorage              *EcsEphemeralStorage               `json:"EphemeralStorage,omitempty"`
	ExecutionRoleArn              string                             `json:"ExecutionRoleArn,omitempty"`
	InferenceAcceleratorOverrides []*EcsInferenceAcceleratorOverride `json:"InferenceAcceleratorOverrides,omitempty"`
	Memory                        string                             `json:"Memory,omitempty"`
	TaskRoleArn                   string                             `json:"TaskRoleArn,omitempty"`
}

EcsTaskOverride

func (*EcsTaskOverride) MarshalJSON

func (strct *EcsTaskOverride) MarshalJSON() ([]byte, error)

func (*EcsTaskOverride) UnmarshalJSON

func (strct *EcsTaskOverride) UnmarshalJSON(b []byte) error

type Filter

type Filter struct {
	Pattern string `json:"Pattern,omitempty"`
}

Filter

func (*Filter) MarshalJSON

func (strct *Filter) MarshalJSON() ([]byte, error)

func (*Filter) UnmarshalJSON

func (strct *Filter) UnmarshalJSON(b []byte) error

type FilterCriteria

type FilterCriteria struct {
	Filters []*Filter `json:"Filters,omitempty"`
}

FilterCriteria

func (*FilterCriteria) MarshalJSON

func (strct *FilterCriteria) MarshalJSON() ([]byte, error)

func (*FilterCriteria) UnmarshalJSON

func (strct *FilterCriteria) UnmarshalJSON(b []byte) error

type HeaderParametersMap

type HeaderParametersMap struct {
}

HeaderParametersMap

func (*HeaderParametersMap) MarshalJSON

func (strct *HeaderParametersMap) MarshalJSON() ([]byte, error)

func (*HeaderParametersMap) UnmarshalJSON

func (strct *HeaderParametersMap) UnmarshalJSON(b []byte) error

type NetworkConfiguration

type NetworkConfiguration struct {
	AwsvpcConfiguration *AwsVpcConfiguration `json:"AwsvpcConfiguration,omitempty"`
}

NetworkConfiguration

func (*NetworkConfiguration) MarshalJSON

func (strct *NetworkConfiguration) MarshalJSON() ([]byte, error)

func (*NetworkConfiguration) UnmarshalJSON

func (strct *NetworkConfiguration) UnmarshalJSON(b []byte) error

type PipeEnrichmentHttpParameters

type PipeEnrichmentHttpParameters struct {
	HeaderParameters      *HeaderParametersMap      `json:"HeaderParameters,omitempty"`
	PathParameterValues   []string                  `json:"PathParameterValues,omitempty"`
	QueryStringParameters *QueryStringParametersMap `json:"QueryStringParameters,omitempty"`
}

PipeEnrichmentHttpParameters

func (*PipeEnrichmentHttpParameters) MarshalJSON

func (strct *PipeEnrichmentHttpParameters) MarshalJSON() ([]byte, error)

func (*PipeEnrichmentHttpParameters) UnmarshalJSON

func (strct *PipeEnrichmentHttpParameters) UnmarshalJSON(b []byte) error

type PipeEnrichmentParameters

type PipeEnrichmentParameters struct {
	HttpParameters *PipeEnrichmentHttpParameters `json:"HttpParameters,omitempty"`
	InputTemplate  string                        `json:"InputTemplate,omitempty"`
}

PipeEnrichmentParameters

func (*PipeEnrichmentParameters) MarshalJSON

func (strct *PipeEnrichmentParameters) MarshalJSON() ([]byte, error)

func (*PipeEnrichmentParameters) UnmarshalJSON

func (strct *PipeEnrichmentParameters) UnmarshalJSON(b []byte) error

type PipeSourceActiveMQBrokerParameters

type PipeSourceActiveMQBrokerParameters struct {
	BatchSize                      int         `json:"BatchSize,omitempty"`
	Credentials                    interface{} `json:"Credentials"`
	MaximumBatchingWindowInSeconds int         `json:"MaximumBatchingWindowInSeconds,omitempty"`
	QueueName                      string      `json:"QueueName"`
}

PipeSourceActiveMQBrokerParameters

func (*PipeSourceActiveMQBrokerParameters) MarshalJSON

func (strct *PipeSourceActiveMQBrokerParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceActiveMQBrokerParameters) UnmarshalJSON

func (strct *PipeSourceActiveMQBrokerParameters) UnmarshalJSON(b []byte) error

type PipeSourceDynamoDBStreamParameters

type PipeSourceDynamoDBStreamParameters struct {
	BatchSize                      int               `json:"BatchSize,omitempty"`
	DeadLetterConfig               *DeadLetterConfig `json:"DeadLetterConfig,omitempty"`
	MaximumBatchingWindowInSeconds int               `json:"MaximumBatchingWindowInSeconds,omitempty"`
	MaximumRecordAgeInSeconds      int               `json:"MaximumRecordAgeInSeconds,omitempty"`
	MaximumRetryAttempts           int               `json:"MaximumRetryAttempts,omitempty"`
	OnPartialBatchItemFailure      string            `json:"OnPartialBatchItemFailure,omitempty"`
	ParallelizationFactor          int               `json:"ParallelizationFactor,omitempty"`
	StartingPosition               string            `json:"StartingPosition"`
}

PipeSourceDynamoDBStreamParameters

func (*PipeSourceDynamoDBStreamParameters) MarshalJSON

func (strct *PipeSourceDynamoDBStreamParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceDynamoDBStreamParameters) UnmarshalJSON

func (strct *PipeSourceDynamoDBStreamParameters) UnmarshalJSON(b []byte) error

type PipeSourceKinesisStreamParameters

type PipeSourceKinesisStreamParameters struct {
	BatchSize                      int               `json:"BatchSize,omitempty"`
	DeadLetterConfig               *DeadLetterConfig `json:"DeadLetterConfig,omitempty"`
	MaximumBatchingWindowInSeconds int               `json:"MaximumBatchingWindowInSeconds,omitempty"`
	MaximumRecordAgeInSeconds      int               `json:"MaximumRecordAgeInSeconds,omitempty"`
	MaximumRetryAttempts           int               `json:"MaximumRetryAttempts,omitempty"`
	OnPartialBatchItemFailure      string            `json:"OnPartialBatchItemFailure,omitempty"`
	ParallelizationFactor          int               `json:"ParallelizationFactor,omitempty"`
	StartingPosition               string            `json:"StartingPosition"`
	StartingPositionTimestamp      string            `json:"StartingPositionTimestamp,omitempty"`
}

PipeSourceKinesisStreamParameters

func (*PipeSourceKinesisStreamParameters) MarshalJSON

func (strct *PipeSourceKinesisStreamParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceKinesisStreamParameters) UnmarshalJSON

func (strct *PipeSourceKinesisStreamParameters) UnmarshalJSON(b []byte) error

type PipeSourceManagedStreamingKafkaParameters

type PipeSourceManagedStreamingKafkaParameters struct {
	BatchSize                      int         `json:"BatchSize,omitempty"`
	ConsumerGroupID                string      `json:"ConsumerGroupID,omitempty"`
	Credentials                    interface{} `json:"Credentials,omitempty"`
	MaximumBatchingWindowInSeconds int         `json:"MaximumBatchingWindowInSeconds,omitempty"`
	StartingPosition               string      `json:"StartingPosition,omitempty"`
	TopicName                      string      `json:"TopicName"`
}

PipeSourceManagedStreamingKafkaParameters

func (*PipeSourceManagedStreamingKafkaParameters) MarshalJSON

func (strct *PipeSourceManagedStreamingKafkaParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceManagedStreamingKafkaParameters) UnmarshalJSON

func (strct *PipeSourceManagedStreamingKafkaParameters) UnmarshalJSON(b []byte) error

type PipeSourceParameters

type PipeSourceParameters struct {
	ActiveMQBrokerParameters        *PipeSourceActiveMQBrokerParameters        `json:"ActiveMQBrokerParameters,omitempty"`
	DynamoDBStreamParameters        *PipeSourceDynamoDBStreamParameters        `json:"DynamoDBStreamParameters,omitempty"`
	FilterCriteria                  *FilterCriteria                            `json:"FilterCriteria,omitempty"`
	KinesisStreamParameters         *PipeSourceKinesisStreamParameters         `json:"KinesisStreamParameters,omitempty"`
	ManagedStreamingKafkaParameters *PipeSourceManagedStreamingKafkaParameters `json:"ManagedStreamingKafkaParameters,omitempty"`
	RabbitMQBrokerParameters        *PipeSourceRabbitMQBrokerParameters        `json:"RabbitMQBrokerParameters,omitempty"`
	SelfManagedKafkaParameters      *PipeSourceSelfManagedKafkaParameters      `json:"SelfManagedKafkaParameters,omitempty"`
	SqsQueueParameters              *PipeSourceSqsQueueParameters              `json:"SqsQueueParameters,omitempty"`
}

PipeSourceParameters

func (*PipeSourceParameters) MarshalJSON

func (strct *PipeSourceParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceParameters) UnmarshalJSON

func (strct *PipeSourceParameters) UnmarshalJSON(b []byte) error

type PipeSourceRabbitMQBrokerParameters

type PipeSourceRabbitMQBrokerParameters struct {
	BatchSize                      int         `json:"BatchSize,omitempty"`
	Credentials                    interface{} `json:"Credentials"`
	MaximumBatchingWindowInSeconds int         `json:"MaximumBatchingWindowInSeconds,omitempty"`
	QueueName                      string      `json:"QueueName"`
	VirtualHost                    string      `json:"VirtualHost,omitempty"`
}

PipeSourceRabbitMQBrokerParameters

func (*PipeSourceRabbitMQBrokerParameters) MarshalJSON

func (strct *PipeSourceRabbitMQBrokerParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceRabbitMQBrokerParameters) UnmarshalJSON

func (strct *PipeSourceRabbitMQBrokerParameters) UnmarshalJSON(b []byte) error

type PipeSourceSelfManagedKafkaParameters

type PipeSourceSelfManagedKafkaParameters struct {
	AdditionalBootstrapServers     []string    `json:"AdditionalBootstrapServers,omitempty"`
	BatchSize                      int         `json:"BatchSize,omitempty"`
	ConsumerGroupID                string      `json:"ConsumerGroupID,omitempty"`
	Credentials                    interface{} `json:"Credentials,omitempty"`
	MaximumBatchingWindowInSeconds int         `json:"MaximumBatchingWindowInSeconds,omitempty"`

	// Optional SecretManager ARN which stores the database credentials
	ServerRootCaCertificate string                                  `json:"ServerRootCaCertificate,omitempty"`
	StartingPosition        string                                  `json:"StartingPosition,omitempty"`
	TopicName               string                                  `json:"TopicName"`
	Vpc                     *SelfManagedKafkaAccessConfigurationVpc `json:"Vpc,omitempty"`
}

PipeSourceSelfManagedKafkaParameters

func (*PipeSourceSelfManagedKafkaParameters) MarshalJSON

func (strct *PipeSourceSelfManagedKafkaParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceSelfManagedKafkaParameters) UnmarshalJSON

func (strct *PipeSourceSelfManagedKafkaParameters) UnmarshalJSON(b []byte) error

type PipeSourceSqsQueueParameters

type PipeSourceSqsQueueParameters struct {
	BatchSize                      int `json:"BatchSize,omitempty"`
	MaximumBatchingWindowInSeconds int `json:"MaximumBatchingWindowInSeconds,omitempty"`
}

PipeSourceSqsQueueParameters

func (*PipeSourceSqsQueueParameters) MarshalJSON

func (strct *PipeSourceSqsQueueParameters) MarshalJSON() ([]byte, error)

func (*PipeSourceSqsQueueParameters) UnmarshalJSON

func (strct *PipeSourceSqsQueueParameters) UnmarshalJSON(b []byte) error

type PipeTargetBatchJobParameters

type PipeTargetBatchJobParameters struct {
	ArrayProperties    *BatchArrayProperties    `json:"ArrayProperties,omitempty"`
	ContainerOverrides *BatchContainerOverrides `json:"ContainerOverrides,omitempty"`
	DependsOn          []*BatchJobDependency    `json:"DependsOn,omitempty"`
	JobDefinition      string                   `json:"JobDefinition"`
	JobName            string                   `json:"JobName"`
	Parameters         *BatchParametersMap      `json:"Parameters,omitempty"`
	RetryStrategy      *BatchRetryStrategy      `json:"RetryStrategy,omitempty"`
}

PipeTargetBatchJobParameters

func (*PipeTargetBatchJobParameters) MarshalJSON

func (strct *PipeTargetBatchJobParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetBatchJobParameters) UnmarshalJSON

func (strct *PipeTargetBatchJobParameters) UnmarshalJSON(b []byte) error

type PipeTargetCloudWatchLogsParameters

type PipeTargetCloudWatchLogsParameters struct {
	LogStreamName string `json:"LogStreamName,omitempty"`
	Timestamp     string `json:"Timestamp,omitempty"`
}

PipeTargetCloudWatchLogsParameters

func (*PipeTargetCloudWatchLogsParameters) MarshalJSON

func (strct *PipeTargetCloudWatchLogsParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetCloudWatchLogsParameters) UnmarshalJSON

func (strct *PipeTargetCloudWatchLogsParameters) UnmarshalJSON(b []byte) error

type PipeTargetEcsTaskParameters

type PipeTargetEcsTaskParameters struct {
	CapacityProviderStrategy []*CapacityProviderStrategyItem `json:"CapacityProviderStrategy,omitempty"`
	EnableECSManagedTags     bool                            `json:"EnableECSManagedTags,omitempty"`
	EnableExecuteCommand     bool                            `json:"EnableExecuteCommand,omitempty"`
	Group                    string                          `json:"Group,omitempty"`
	LaunchType               string                          `json:"LaunchType,omitempty"`
	NetworkConfiguration     *NetworkConfiguration           `json:"NetworkConfiguration,omitempty"`
	Overrides                *EcsTaskOverride                `json:"Overrides,omitempty"`
	PlacementConstraints     []*PlacementConstraint          `json:"PlacementConstraints,omitempty"`
	PlacementStrategy        []*PlacementStrategy            `json:"PlacementStrategy,omitempty"`
	PlatformVersion          string                          `json:"PlatformVersion,omitempty"`
	PropagateTags            string                          `json:"PropagateTags,omitempty"`
	ReferenceId              string                          `json:"ReferenceId,omitempty"`
	Tags                     []*Tag                          `json:"Tags,omitempty"`
	TaskCount                int                             `json:"TaskCount,omitempty"`
	TaskDefinitionArn        string                          `json:"TaskDefinitionArn"`
}

PipeTargetEcsTaskParameters

func (*PipeTargetEcsTaskParameters) MarshalJSON

func (strct *PipeTargetEcsTaskParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetEcsTaskParameters) UnmarshalJSON

func (strct *PipeTargetEcsTaskParameters) UnmarshalJSON(b []byte) error

type PipeTargetEventBridgeEventBusParameters

type PipeTargetEventBridgeEventBusParameters struct {
	DetailType string   `json:"DetailType,omitempty"`
	EndpointId string   `json:"EndpointId,omitempty"`
	Resources  []string `json:"Resources,omitempty"`
	Source     string   `json:"Source,omitempty"`
	Time       string   `json:"Time,omitempty"`
}

PipeTargetEventBridgeEventBusParameters

func (*PipeTargetEventBridgeEventBusParameters) MarshalJSON

func (strct *PipeTargetEventBridgeEventBusParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetEventBridgeEventBusParameters) UnmarshalJSON

func (strct *PipeTargetEventBridgeEventBusParameters) UnmarshalJSON(b []byte) error

type PipeTargetHttpParameters

type PipeTargetHttpParameters struct {
	HeaderParameters      *HeaderParametersMap      `json:"HeaderParameters,omitempty"`
	PathParameterValues   []string                  `json:"PathParameterValues,omitempty"`
	QueryStringParameters *QueryStringParametersMap `json:"QueryStringParameters,omitempty"`
}

PipeTargetHttpParameters

func (*PipeTargetHttpParameters) MarshalJSON

func (strct *PipeTargetHttpParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetHttpParameters) UnmarshalJSON

func (strct *PipeTargetHttpParameters) UnmarshalJSON(b []byte) error

type PipeTargetKinesisStreamParameters

type PipeTargetKinesisStreamParameters struct {
	PartitionKey string `json:"PartitionKey"`
}

PipeTargetKinesisStreamParameters

func (*PipeTargetKinesisStreamParameters) MarshalJSON

func (strct *PipeTargetKinesisStreamParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetKinesisStreamParameters) UnmarshalJSON

func (strct *PipeTargetKinesisStreamParameters) UnmarshalJSON(b []byte) error

type PipeTargetLambdaFunctionParameters

type PipeTargetLambdaFunctionParameters struct {
	InvocationType string `json:"InvocationType,omitempty"`
}

PipeTargetLambdaFunctionParameters

func (*PipeTargetLambdaFunctionParameters) MarshalJSON

func (strct *PipeTargetLambdaFunctionParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetLambdaFunctionParameters) UnmarshalJSON

func (strct *PipeTargetLambdaFunctionParameters) UnmarshalJSON(b []byte) error

type PipeTargetParameters

type PipeTargetParameters struct {
	BatchJobParameters                 *PipeTargetBatchJobParameters            `json:"BatchJobParameters,omitempty"`
	CloudWatchLogsParameters           *PipeTargetCloudWatchLogsParameters      `json:"CloudWatchLogsParameters,omitempty"`
	EcsTaskParameters                  *PipeTargetEcsTaskParameters             `json:"EcsTaskParameters,omitempty"`
	EventBridgeEventBusParameters      *PipeTargetEventBridgeEventBusParameters `json:"EventBridgeEventBusParameters,omitempty"`
	HttpParameters                     *PipeTargetHttpParameters                `json:"HttpParameters,omitempty"`
	InputTemplate                      string                                   `json:"InputTemplate,omitempty"`
	KinesisStreamParameters            *PipeTargetKinesisStreamParameters       `json:"KinesisStreamParameters,omitempty"`
	LambdaFunctionParameters           *PipeTargetLambdaFunctionParameters      `json:"LambdaFunctionParameters,omitempty"`
	RedshiftDataParameters             *PipeTargetRedshiftDataParameters        `json:"RedshiftDataParameters,omitempty"`
	SageMakerPipelineParameters        *PipeTargetSageMakerPipelineParameters   `json:"SageMakerPipelineParameters,omitempty"`
	SqsQueueParameters                 *PipeTargetSqsQueueParameters            `json:"SqsQueueParameters,omitempty"`
	StepFunctionStateMachineParameters *PipeTargetStateMachineParameters        `json:"StepFunctionStateMachineParameters,omitempty"`
}

PipeTargetParameters

func (*PipeTargetParameters) MarshalJSON

func (strct *PipeTargetParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetParameters) UnmarshalJSON

func (strct *PipeTargetParameters) UnmarshalJSON(b []byte) error

type PipeTargetRedshiftDataParameters

type PipeTargetRedshiftDataParameters struct {

	// Redshift Database
	Database string `json:"Database"`

	// Database user name
	DbUser string `json:"DbUser,omitempty"`

	// Optional SecretManager ARN which stores the database credentials
	SecretManagerArn string `json:"SecretManagerArn,omitempty"`

	// A list of SQLs.
	Sqls []string `json:"Sqls"`

	// A name for Redshift DataAPI statement which can be used as filter of ListStatement.
	StatementName string `json:"StatementName,omitempty"`
	WithEvent     bool   `json:"WithEvent,omitempty"`
}

PipeTargetRedshiftDataParameters

func (*PipeTargetRedshiftDataParameters) MarshalJSON

func (strct *PipeTargetRedshiftDataParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetRedshiftDataParameters) UnmarshalJSON

func (strct *PipeTargetRedshiftDataParameters) UnmarshalJSON(b []byte) error

type PipeTargetSageMakerPipelineParameters

type PipeTargetSageMakerPipelineParameters struct {
	PipelineParameterList []*SageMakerPipelineParameter `json:"PipelineParameterList,omitempty"`
}

PipeTargetSageMakerPipelineParameters

func (*PipeTargetSageMakerPipelineParameters) MarshalJSON

func (strct *PipeTargetSageMakerPipelineParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetSageMakerPipelineParameters) UnmarshalJSON

func (strct *PipeTargetSageMakerPipelineParameters) UnmarshalJSON(b []byte) error

type PipeTargetSqsQueueParameters

type PipeTargetSqsQueueParameters struct {
	MessageDeduplicationId string `json:"MessageDeduplicationId,omitempty"`
	MessageGroupId         string `json:"MessageGroupId,omitempty"`
}

PipeTargetSqsQueueParameters

func (*PipeTargetSqsQueueParameters) MarshalJSON

func (strct *PipeTargetSqsQueueParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetSqsQueueParameters) UnmarshalJSON

func (strct *PipeTargetSqsQueueParameters) UnmarshalJSON(b []byte) error

type PipeTargetStateMachineParameters

type PipeTargetStateMachineParameters struct {
	InvocationType string `json:"InvocationType,omitempty"`
}

PipeTargetStateMachineParameters

func (*PipeTargetStateMachineParameters) MarshalJSON

func (strct *PipeTargetStateMachineParameters) MarshalJSON() ([]byte, error)

func (*PipeTargetStateMachineParameters) UnmarshalJSON

func (strct *PipeTargetStateMachineParameters) UnmarshalJSON(b []byte) error

type PlacementConstraint

type PlacementConstraint struct {
	Expression string `json:"Expression,omitempty"`
	Type       string `json:"Type,omitempty"`
}

PlacementConstraint

func (*PlacementConstraint) MarshalJSON

func (strct *PlacementConstraint) MarshalJSON() ([]byte, error)

func (*PlacementConstraint) UnmarshalJSON

func (strct *PlacementConstraint) UnmarshalJSON(b []byte) error

type PlacementStrategy

type PlacementStrategy struct {
	Field string `json:"Field,omitempty"`
	Type  string `json:"Type,omitempty"`
}

PlacementStrategy

func (*PlacementStrategy) MarshalJSON

func (strct *PlacementStrategy) MarshalJSON() ([]byte, error)

func (*PlacementStrategy) UnmarshalJSON

func (strct *PlacementStrategy) UnmarshalJSON(b []byte) error

type QueryStringParametersMap

type QueryStringParametersMap struct {
}

QueryStringParametersMap

func (*QueryStringParametersMap) MarshalJSON

func (strct *QueryStringParametersMap) MarshalJSON() ([]byte, error)

func (*QueryStringParametersMap) UnmarshalJSON

func (strct *QueryStringParametersMap) UnmarshalJSON(b []byte) error

type Resource

type Resource struct {
	Arn                  string                    `json:"Arn,omitempty"`
	CreationTime         string                    `json:"CreationTime,omitempty"`
	CurrentState         string                    `json:"CurrentState,omitempty"`
	Description          string                    `json:"Description,omitempty"`
	DesiredState         string                    `json:"DesiredState,omitempty"`
	Enrichment           string                    `json:"Enrichment,omitempty"`
	EnrichmentParameters *PipeEnrichmentParameters `json:"EnrichmentParameters,omitempty"`
	LastModifiedTime     string                    `json:"LastModifiedTime,omitempty"`
	Name                 string                    `json:"Name,omitempty"`
	RoleArn              string                    `json:"RoleArn"`
	Source               string                    `json:"Source"`
	SourceParameters     *PipeSourceParameters     `json:"SourceParameters,omitempty"`
	StateReason          string                    `json:"StateReason,omitempty"`
	Tags                 *TagMap                   `json:"Tags,omitempty"`
	Target               string                    `json:"Target"`
	TargetParameters     *PipeTargetParameters     `json:"TargetParameters,omitempty"`
}

Resource Definition of AWS::Pipes::Pipe Resource Type

func (*Resource) MarshalJSON

func (strct *Resource) MarshalJSON() ([]byte, error)

func (*Resource) UnmarshalJSON

func (strct *Resource) UnmarshalJSON(b []byte) error

type SageMakerPipelineParameter

type SageMakerPipelineParameter struct {
	Name  string `json:"Name"`
	Value string `json:"Value"`
}

SageMakerPipelineParameter

func (*SageMakerPipelineParameter) MarshalJSON

func (strct *SageMakerPipelineParameter) MarshalJSON() ([]byte, error)

func (*SageMakerPipelineParameter) UnmarshalJSON

func (strct *SageMakerPipelineParameter) UnmarshalJSON(b []byte) error

type SelfManagedKafkaAccessConfigurationVpc

type SelfManagedKafkaAccessConfigurationVpc struct {

	// List of SecurityGroupId.
	SecurityGroup []string `json:"SecurityGroup,omitempty"`

	// List of SubnetId.
	Subnets []string `json:"Subnets,omitempty"`
}

SelfManagedKafkaAccessConfigurationVpc

func (*SelfManagedKafkaAccessConfigurationVpc) MarshalJSON

func (strct *SelfManagedKafkaAccessConfigurationVpc) MarshalJSON() ([]byte, error)

func (*SelfManagedKafkaAccessConfigurationVpc) UnmarshalJSON

func (strct *SelfManagedKafkaAccessConfigurationVpc) UnmarshalJSON(b []byte) error

type Tag

type Tag struct {
	Key   string `json:"Key"`
	Value string `json:"Value"`
}

Tag

func (*Tag) MarshalJSON

func (strct *Tag) MarshalJSON() ([]byte, error)

func (*Tag) UnmarshalJSON

func (strct *Tag) UnmarshalJSON(b []byte) error

type TagMap

type TagMap struct {
}

TagMap

func (*TagMap) MarshalJSON

func (strct *TagMap) MarshalJSON() ([]byte, error)

func (*TagMap) UnmarshalJSON

func (strct *TagMap) UnmarshalJSON(b []byte) error

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL