rabbitmq logo
RabbitMQ v3.2.0, Nov 11 21

rabbitmq.Shovel

The rabbitmq.Shovel resource creates and manages a dynamic shovel.

Example Usage

using Pulumi;
using RabbitMQ = Pulumi.RabbitMQ;

class MyStack : Stack
{
    public MyStack()
    {
        var testVHost = new RabbitMQ.VHost("testVHost", new RabbitMQ.VHostArgs
        {
        });
        var testExchange = new RabbitMQ.Exchange("testExchange", new RabbitMQ.ExchangeArgs
        {
            Settings = new RabbitMQ.Inputs.ExchangeSettingsArgs
            {
                AutoDelete = true,
                Durable = false,
                Type = "fanout",
            },
            Vhost = testVHost.Name,
        });
        var testQueue = new RabbitMQ.Queue("testQueue", new RabbitMQ.QueueArgs
        {
            Settings = new RabbitMQ.Inputs.QueueSettingsArgs
            {
                AutoDelete = true,
                Durable = false,
            },
            Vhost = testVHost.Name,
        });
        var shovelTest = new RabbitMQ.Shovel("shovelTest", new RabbitMQ.ShovelArgs
        {
            Info = new RabbitMQ.Inputs.ShovelInfoArgs
            {
                DestinationQueue = testQueue.Name,
                DestinationUri = "amqp:///test",
                SourceExchange = testExchange.Name,
                SourceExchangeKey = "test",
                SourceUri = "amqp:///test",
            },
            Vhost = testVHost.Name,
        });
    }

}
package main

import (
	"github.com/pulumi/pulumi-rabbitmq/sdk/v3/go/rabbitmq"
	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)

func main() {
	pulumi.Run(func(ctx *pulumi.Context) error {
		testVHost, err := rabbitmq.NewVHost(ctx, "testVHost", nil)
		if err != nil {
			return err
		}
		testExchange, err := rabbitmq.NewExchange(ctx, "testExchange", &rabbitmq.ExchangeArgs{
			Settings: &ExchangeSettingsArgs{
				AutoDelete: pulumi.Bool(true),
				Durable:    pulumi.Bool(false),
				Type:       pulumi.String("fanout"),
			},
			Vhost: testVHost.Name,
		})
		if err != nil {
			return err
		}
		testQueue, err := rabbitmq.NewQueue(ctx, "testQueue", &rabbitmq.QueueArgs{
			Settings: &QueueSettingsArgs{
				AutoDelete: pulumi.Bool(true),
				Durable:    pulumi.Bool(false),
			},
			Vhost: testVHost.Name,
		})
		if err != nil {
			return err
		}
		_, err = rabbitmq.NewShovel(ctx, "shovelTest", &rabbitmq.ShovelArgs{
			Info: &ShovelInfoArgs{
				DestinationQueue:  testQueue.Name,
				DestinationUri:    pulumi.String("amqp:///test"),
				SourceExchange:    testExchange.Name,
				SourceExchangeKey: pulumi.String("test"),
				SourceUri:         pulumi.String("amqp:///test"),
			},
			Vhost: testVHost.Name,
		})
		if err != nil {
			return err
		}
		return nil
	})
}

Coming soon!

import pulumi
import pulumi_rabbitmq as rabbitmq

test_v_host = rabbitmq.VHost("testVHost")
test_exchange = rabbitmq.Exchange("testExchange",
    settings=rabbitmq.ExchangeSettingsArgs(
        auto_delete=True,
        durable=False,
        type="fanout",
    ),
    vhost=test_v_host.name)
test_queue = rabbitmq.Queue("testQueue",
    settings=rabbitmq.QueueSettingsArgs(
        auto_delete=True,
        durable=False,
    ),
    vhost=test_v_host.name)
shovel_test = rabbitmq.Shovel("shovelTest",
    info=rabbitmq.ShovelInfoArgs(
        destination_queue=test_queue.name,
        destination_uri="amqp:///test",
        source_exchange=test_exchange.name,
        source_exchange_key="test",
        source_uri="amqp:///test",
    ),
    vhost=test_v_host.name)
import * as pulumi from "@pulumi/pulumi";
import * as rabbitmq from "@pulumi/rabbitmq";

const testVHost = new rabbitmq.VHost("test", {});
const testExchange = new rabbitmq.Exchange("test", {
    settings: {
        autoDelete: true,
        durable: false,
        type: "fanout",
    },
    vhost: testVHost.name,
});
const testQueue = new rabbitmq.Queue("test", {
    settings: {
        autoDelete: true,
        durable: false,
    },
    vhost: testVHost.name,
});
const shovelTest = new rabbitmq.Shovel("shovelTest", {
    info: {
        destinationQueue: testQueue.name,
        destinationUri: "amqp:///test",
        sourceExchange: testExchange.name,
        sourceExchangeKey: "test",
        sourceUri: "amqp:///test",
    },
    vhost: testVHost.name,
});

Coming soon!

Create Shovel Resource

new Shovel(name: string, args: ShovelArgs, opts?: CustomResourceOptions);
@overload
def Shovel(resource_name: str,
           opts: Optional[ResourceOptions] = None,
           info: Optional[ShovelInfoArgs] = None,
           name: Optional[str] = None,
           vhost: Optional[str] = None)
@overload
def Shovel(resource_name: str,
           args: ShovelArgs,
           opts: Optional[ResourceOptions] = None)
func NewShovel(ctx *Context, name string, args ShovelArgs, opts ...ResourceOption) (*Shovel, error)
public Shovel(string name, ShovelArgs args, CustomResourceOptions? opts = null)
public Shovel(String name, ShovelArgs args)
public Shovel(String name, ShovelArgs args, CustomResourceOptions options)
type: rabbitmq:Shovel
properties: # The arguments to resource properties.
options: # Bag of options to control resource's behavior.

name string
The unique name of the resource.
args ShovelArgs
The arguments to resource properties.
opts CustomResourceOptions
Bag of options to control resource's behavior.
resource_name str
The unique name of the resource.
args ShovelArgs
The arguments to resource properties.
opts ResourceOptions
Bag of options to control resource's behavior.
ctx Context
Context object for the current deployment.
name string
The unique name of the resource.
args ShovelArgs
The arguments to resource properties.
opts ResourceOption
Bag of options to control resource's behavior.
name string
The unique name of the resource.
args ShovelArgs
The arguments to resource properties.
opts CustomResourceOptions
Bag of options to control resource's behavior.
name String
The unique name of the resource.
args ShovelArgs
The arguments to resource properties.
options CustomResourceOptions
Bag of options to control resource's behavior.

Shovel Resource Properties

To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.

Inputs

The Shovel resource accepts the following input properties:

Info Pulumi.RabbitMQ.Inputs.ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

Vhost string

The vhost to create the resource in.

Name string

The shovel name.

Info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

Vhost string

The vhost to create the resource in.

Name string

The shovel name.

info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

vhost String

The vhost to create the resource in.

name String

The shovel name.

info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

vhost string

The vhost to create the resource in.

name string

The shovel name.

info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

vhost str

The vhost to create the resource in.

name str

The shovel name.

info Property Map

The settings of the dynamic shovel. The structure is described below.

vhost String

The vhost to create the resource in.

name String

The shovel name.

Outputs

All input properties are implicitly available as output properties. Additionally, the Shovel resource produces the following output properties:

Id string

The provider-assigned unique ID for this managed resource.

Id string

The provider-assigned unique ID for this managed resource.

id String

The provider-assigned unique ID for this managed resource.

id string

The provider-assigned unique ID for this managed resource.

id str

The provider-assigned unique ID for this managed resource.

id String

The provider-assigned unique ID for this managed resource.

Look up Existing Shovel Resource

Get an existing Shovel resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.

public static get(name: string, id: Input<ID>, state?: ShovelState, opts?: CustomResourceOptions): Shovel
@staticmethod
def get(resource_name: str,
        id: str,
        opts: Optional[ResourceOptions] = None,
        info: Optional[ShovelInfoArgs] = None,
        name: Optional[str] = None,
        vhost: Optional[str] = None) -> Shovel
func GetShovel(ctx *Context, name string, id IDInput, state *ShovelState, opts ...ResourceOption) (*Shovel, error)
public static Shovel Get(string name, Input<string> id, ShovelState? state, CustomResourceOptions? opts = null)
public static Shovel get(String name, Output<String> id, ShovelState state, CustomResourceOptions options)
Resource lookup is not supported in YAML
name
The unique name of the resulting resource.
id
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
resource_name
The unique name of the resulting resource.
id
The unique provider ID of the resource to lookup.
name
The unique name of the resulting resource.
id
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
name
The unique name of the resulting resource.
id
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
name
The unique name of the resulting resource.
id
The unique provider ID of the resource to lookup.
state
Any extra arguments used during the lookup.
opts
A bag of options that control this resource's behavior.
The following state arguments are supported:
Info Pulumi.RabbitMQ.Inputs.ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

Name string

The shovel name.

Vhost string

The vhost to create the resource in.

Info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

Name string

The shovel name.

Vhost string

The vhost to create the resource in.

info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

name String

The shovel name.

vhost String

The vhost to create the resource in.

info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

name string

The shovel name.

vhost string

The vhost to create the resource in.

info ShovelInfoArgs

The settings of the dynamic shovel. The structure is described below.

name str

The shovel name.

vhost str

The vhost to create the resource in.

info Property Map

The settings of the dynamic shovel. The structure is described below.

name String

The shovel name.

vhost String

The vhost to create the resource in.

Supporting Types

ShovelInfo

DestinationUri string

The amqp uri for the destination .

SourceUri string

The amqp uri for the source.

AckMode string

Determines how the shovel should acknowledge messages. Possible values are: on-confirm, on-publish and no-ack. Defaults to on-confirm.

AddForwardHeaders bool

Whether to add x-shovelled headers to shovelled messages.

Deprecated:

use destination_add_forward_headers instead

DeleteAfter string

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

Deprecated:

use source_delete_after instead

DestinationAddForwardHeaders bool

Whether to add x-shovelled headers to shovelled messages.

DestinationAddTimestampHeader bool
DestinationAddress string

The AMQP 1.0 destination link address.

DestinationApplicationProperties string

Application properties to set when shovelling messages.

DestinationExchange string

The exchange to which messages should be published. Either this or destination_queue must be specified but not both.

DestinationExchangeKey string

The routing key when using destination_exchange.

DestinationProperties string

Properties to overwrite when shovelling messages.

DestinationProtocol string

The protocol (amqp091 or amqp10) to use when connecting to the destination. Defaults to amqp091.

DestinationPublishProperties string

A map of properties to overwrite when shovelling messages.

DestinationQueue string

The queue to which messages should be published. Either this or destination_exchange must be specified but not both.

PrefetchCount int

The maximum number of unacknowledged messages copied over a shovel at any one time.

Deprecated:

use source_prefetch_count instead

ReconnectDelay int

The duration in seconds to reconnect to a broker after disconnected. Defaults to 1.

SourceAddress string

The AMQP 1.0 source link address.

SourceDeleteAfter string

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

SourceExchange string

The exchange from which to consume. Either this or source_queue must be specified but not both.

SourceExchangeKey string

The routing key when using source_exchange.

SourcePrefetchCount int

The maximum number of unacknowledged messages copied over a shovel at any one time.

SourceProtocol string

The protocol (amqp091 or amqp10) to use when connecting to the source. Defaults to amqp091.

SourceQueue string

The queue from which to consume. Either this or source_exchange must be specified but not both.

DestinationUri string

The amqp uri for the destination .

SourceUri string

The amqp uri for the source.

AckMode string

Determines how the shovel should acknowledge messages. Possible values are: on-confirm, on-publish and no-ack. Defaults to on-confirm.

AddForwardHeaders bool

Whether to add x-shovelled headers to shovelled messages.

Deprecated:

use destination_add_forward_headers instead

DeleteAfter string

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

Deprecated:

use source_delete_after instead

DestinationAddForwardHeaders bool

Whether to add x-shovelled headers to shovelled messages.

DestinationAddTimestampHeader bool
DestinationAddress string

The AMQP 1.0 destination link address.

DestinationApplicationProperties string

Application properties to set when shovelling messages.

DestinationExchange string

The exchange to which messages should be published. Either this or destination_queue must be specified but not both.

DestinationExchangeKey string

The routing key when using destination_exchange.

DestinationProperties string

Properties to overwrite when shovelling messages.

DestinationProtocol string

The protocol (amqp091 or amqp10) to use when connecting to the destination. Defaults to amqp091.

DestinationPublishProperties string

A map of properties to overwrite when shovelling messages.

DestinationQueue string

The queue to which messages should be published. Either this or destination_exchange must be specified but not both.

PrefetchCount int

The maximum number of unacknowledged messages copied over a shovel at any one time.

Deprecated:

use source_prefetch_count instead

ReconnectDelay int

The duration in seconds to reconnect to a broker after disconnected. Defaults to 1.

SourceAddress string

The AMQP 1.0 source link address.

SourceDeleteAfter string

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

SourceExchange string

The exchange from which to consume. Either this or source_queue must be specified but not both.

SourceExchangeKey string

The routing key when using source_exchange.

SourcePrefetchCount int

The maximum number of unacknowledged messages copied over a shovel at any one time.

SourceProtocol string

The protocol (amqp091 or amqp10) to use when connecting to the source. Defaults to amqp091.

SourceQueue string

The queue from which to consume. Either this or source_exchange must be specified but not both.

destinationUri String

The amqp uri for the destination .

sourceUri String

The amqp uri for the source.

ackMode String

Determines how the shovel should acknowledge messages. Possible values are: on-confirm, on-publish and no-ack. Defaults to on-confirm.

addForwardHeaders Boolean

Whether to add x-shovelled headers to shovelled messages.

Deprecated:

use destination_add_forward_headers instead

deleteAfter String

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

Deprecated:

use source_delete_after instead

destinationAddForwardHeaders Boolean

Whether to add x-shovelled headers to shovelled messages.

destinationAddTimestampHeader Boolean
destinationAddress String

The AMQP 1.0 destination link address.

destinationApplicationProperties String

Application properties to set when shovelling messages.

destinationExchange String

The exchange to which messages should be published. Either this or destination_queue must be specified but not both.

destinationExchangeKey String

The routing key when using destination_exchange.

destinationProperties String

Properties to overwrite when shovelling messages.

destinationProtocol String

The protocol (amqp091 or amqp10) to use when connecting to the destination. Defaults to amqp091.

destinationPublishProperties String

A map of properties to overwrite when shovelling messages.

destinationQueue String

The queue to which messages should be published. Either this or destination_exchange must be specified but not both.

prefetchCount Integer

The maximum number of unacknowledged messages copied over a shovel at any one time.

Deprecated:

use source_prefetch_count instead

reconnectDelay Integer

The duration in seconds to reconnect to a broker after disconnected. Defaults to 1.

sourceAddress String

The AMQP 1.0 source link address.

sourceDeleteAfter String

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

sourceExchange String

The exchange from which to consume. Either this or source_queue must be specified but not both.

sourceExchangeKey String

The routing key when using source_exchange.

sourcePrefetchCount Integer

The maximum number of unacknowledged messages copied over a shovel at any one time.

sourceProtocol String

The protocol (amqp091 or amqp10) to use when connecting to the source. Defaults to amqp091.

sourceQueue String

The queue from which to consume. Either this or source_exchange must be specified but not both.

destinationUri string

The amqp uri for the destination .

sourceUri string

The amqp uri for the source.

ackMode string

Determines how the shovel should acknowledge messages. Possible values are: on-confirm, on-publish and no-ack. Defaults to on-confirm.

addForwardHeaders boolean

Whether to add x-shovelled headers to shovelled messages.

Deprecated:

use destination_add_forward_headers instead

deleteAfter string

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

Deprecated:

use source_delete_after instead

destinationAddForwardHeaders boolean

Whether to add x-shovelled headers to shovelled messages.

destinationAddTimestampHeader boolean
destinationAddress string

The AMQP 1.0 destination link address.

destinationApplicationProperties string

Application properties to set when shovelling messages.

destinationExchange string

The exchange to which messages should be published. Either this or destination_queue must be specified but not both.

destinationExchangeKey string

The routing key when using destination_exchange.

destinationProperties string

Properties to overwrite when shovelling messages.

destinationProtocol string

The protocol (amqp091 or amqp10) to use when connecting to the destination. Defaults to amqp091.

destinationPublishProperties string

A map of properties to overwrite when shovelling messages.

destinationQueue string

The queue to which messages should be published. Either this or destination_exchange must be specified but not both.

prefetchCount number

The maximum number of unacknowledged messages copied over a shovel at any one time.

Deprecated:

use source_prefetch_count instead

reconnectDelay number

The duration in seconds to reconnect to a broker after disconnected. Defaults to 1.

sourceAddress string

The AMQP 1.0 source link address.

sourceDeleteAfter string

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

sourceExchange string

The exchange from which to consume. Either this or source_queue must be specified but not both.

sourceExchangeKey string

The routing key when using source_exchange.

sourcePrefetchCount number

The maximum number of unacknowledged messages copied over a shovel at any one time.

sourceProtocol string

The protocol (amqp091 or amqp10) to use when connecting to the source. Defaults to amqp091.

sourceQueue string

The queue from which to consume. Either this or source_exchange must be specified but not both.

destination_uri str

The amqp uri for the destination .

source_uri str

The amqp uri for the source.

ack_mode str

Determines how the shovel should acknowledge messages. Possible values are: on-confirm, on-publish and no-ack. Defaults to on-confirm.

add_forward_headers bool

Whether to add x-shovelled headers to shovelled messages.

Deprecated:

use destination_add_forward_headers instead

delete_after str

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

Deprecated:

use source_delete_after instead

destination_add_forward_headers bool

Whether to add x-shovelled headers to shovelled messages.

destination_add_timestamp_header bool
destination_address str

The AMQP 1.0 destination link address.

destination_application_properties str

Application properties to set when shovelling messages.

destination_exchange str

The exchange to which messages should be published. Either this or destination_queue must be specified but not both.

destination_exchange_key str

The routing key when using destination_exchange.

destination_properties str

Properties to overwrite when shovelling messages.

destination_protocol str

The protocol (amqp091 or amqp10) to use when connecting to the destination. Defaults to amqp091.

destination_publish_properties str

A map of properties to overwrite when shovelling messages.

destination_queue str

The queue to which messages should be published. Either this or destination_exchange must be specified but not both.

prefetch_count int

The maximum number of unacknowledged messages copied over a shovel at any one time.

Deprecated:

use source_prefetch_count instead

reconnect_delay int

The duration in seconds to reconnect to a broker after disconnected. Defaults to 1.

source_address str

The AMQP 1.0 source link address.

source_delete_after str

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

source_exchange str

The exchange from which to consume. Either this or source_queue must be specified but not both.

source_exchange_key str

The routing key when using source_exchange.

source_prefetch_count int

The maximum number of unacknowledged messages copied over a shovel at any one time.

source_protocol str

The protocol (amqp091 or amqp10) to use when connecting to the source. Defaults to amqp091.

source_queue str

The queue from which to consume. Either this or source_exchange must be specified but not both.

destinationUri String

The amqp uri for the destination .

sourceUri String

The amqp uri for the source.

ackMode String

Determines how the shovel should acknowledge messages. Possible values are: on-confirm, on-publish and no-ack. Defaults to on-confirm.

addForwardHeaders Boolean

Whether to add x-shovelled headers to shovelled messages.

Deprecated:

use destination_add_forward_headers instead

deleteAfter String

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

Deprecated:

use source_delete_after instead

destinationAddForwardHeaders Boolean

Whether to add x-shovelled headers to shovelled messages.

destinationAddTimestampHeader Boolean
destinationAddress String

The AMQP 1.0 destination link address.

destinationApplicationProperties String

Application properties to set when shovelling messages.

destinationExchange String

The exchange to which messages should be published. Either this or destination_queue must be specified but not both.

destinationExchangeKey String

The routing key when using destination_exchange.

destinationProperties String

Properties to overwrite when shovelling messages.

destinationProtocol String

The protocol (amqp091 or amqp10) to use when connecting to the destination. Defaults to amqp091.

destinationPublishProperties String

A map of properties to overwrite when shovelling messages.

destinationQueue String

The queue to which messages should be published. Either this or destination_exchange must be specified but not both.

prefetchCount Number

The maximum number of unacknowledged messages copied over a shovel at any one time.

Deprecated:

use source_prefetch_count instead

reconnectDelay Number

The duration in seconds to reconnect to a broker after disconnected. Defaults to 1.

sourceAddress String

The AMQP 1.0 source link address.

sourceDeleteAfter String

Determines when (if ever) the shovel should delete itself. Possible values are: never, queue-length or an integer.

sourceExchange String

The exchange from which to consume. Either this or source_queue must be specified but not both.

sourceExchangeKey String

The routing key when using source_exchange.

sourcePrefetchCount Number

The maximum number of unacknowledged messages copied over a shovel at any one time.

sourceProtocol String

The protocol (amqp091 or amqp10) to use when connecting to the source. Defaults to amqp091.

sourceQueue String

The queue from which to consume. Either this or source_exchange must be specified but not both.

Import

Shovels can be imported using the name and vhost E.g.

 $ pulumi import rabbitmq:index/shovel:Shovel test shovelTest@test

Package Details

Repository
RabbitMQ pulumi/pulumi-rabbitmq
License
Apache-2.0
Notes

This Pulumi package is based on the rabbitmq Terraform Provider.