com.rabbitmq.http.client.Client Maven / Gradle / Ivy
Show all versions of http-client Show documentation
/*
* Copyright 2015-2021 the original author or authors.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
* https://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package com.rabbitmq.http.client;
import com.fasterxml.jackson.annotation.JsonInclude;
import com.fasterxml.jackson.databind.DeserializationFeature;
import com.fasterxml.jackson.databind.ObjectMapper;
import com.rabbitmq.http.client.domain.*;
import java.util.stream.Collectors;
import org.apache.http.conn.ssl.SSLConnectionSocketFactory;
import org.springframework.core.ParameterizedTypeReference;
import org.springframework.http.HttpEntity;
import org.springframework.http.HttpMethod;
import org.springframework.http.HttpStatus;
import org.springframework.http.ResponseEntity;
import org.springframework.http.converter.HttpMessageConverter;
import org.springframework.http.converter.json.Jackson2ObjectMapperBuilder;
import org.springframework.http.converter.json.MappingJackson2HttpMessageConverter;
import org.springframework.util.LinkedMultiValueMap;
import org.springframework.util.MultiValueMap;
import org.springframework.util.StringUtils;
import org.springframework.web.client.HttpClientErrorException;
import org.springframework.web.client.RestTemplate;
import org.springframework.web.util.DefaultUriBuilderFactory;
import org.springframework.web.util.UriBuilder;
import org.springframework.web.util.UriUtils;
import javax.net.ssl.SSLContext;
import java.net.MalformedURLException;
import java.net.URI;
import java.net.URISyntaxException;
import java.net.URL;
import java.util.*;
public class Client {
protected final RestTemplate rt;
protected final URI rootUri;
//
// API
//
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(String url, String username, String password) throws MalformedURLException, URISyntaxException {
this(new URL(url), username, password);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @param configurator {@link HttpClientBuilderConfigurator} to use
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(String url, String username, String password, HttpClientBuilderConfigurator configurator)
throws MalformedURLException, URISyntaxException {
this(new URL(url), username, password, configurator);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(URL url, String username, String password) throws MalformedURLException, URISyntaxException {
this(url, username, password, null, null);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @param configurator {@link HttpClientBuilderConfigurator} to use
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(URL url, String username, String password, HttpClientBuilderConfigurator configurator)
throws MalformedURLException, URISyntaxException {
this(url, username, password, null, null, configurator);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @param sslConnectionSocketFactory ssl connection factory for http client
* @param sslContext ssl context for http client
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
private Client(URL url, String username, String password, SSLConnectionSocketFactory sslConnectionSocketFactory, SSLContext sslContext)
throws MalformedURLException, URISyntaxException {
this(new ClientParameters()
.url(url).username(username).password(password).restTemplateConfigurator(
new HttpComponentsRestTemplateConfigurator(sslConnectionSocketFactory, sslContext)
)
);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @param sslContext ssl context for http client
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(URL url, String username, String password, SSLContext sslContext) throws MalformedURLException, URISyntaxException {
this(url, username, password, null, sslContext);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "http://localhost:15672/api/".
* @param username the username.
* @param password the password
* @param sslConnectionSocketFactory ssl connection factory for http client
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
private Client(URL url, String username, String password, SSLConnectionSocketFactory sslConnectionSocketFactory) throws MalformedURLException, URISyntaxException {
this(url, username, password, sslConnectionSocketFactory, null);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "https://guest:guest@localhost:15672/api/".
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(String url) throws MalformedURLException, URISyntaxException {
this(new ClientParameters().url(url).restTemplateConfigurator(new HttpComponentsRestTemplateConfigurator()));
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "https://guest:guest@localhost:15672/api/".
* @param configurator {@link HttpClientBuilderConfigurator} to use
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(String url, HttpClientBuilderConfigurator configurator) throws MalformedURLException, URISyntaxException {
this(Utils.urlWithoutCredentials(url),
Utils.extractUsernamePassword(url)[0],
Utils.extractUsernamePassword(url)[1],
configurator
);
}
/**
* Construct an instance with the provided url and credentials.
*
* The instance will be using Apache HttpComponents HTTP Client to create requests.
*
* @param url the url e.g. "https://guest:guest@localhost:15672/api/".
* @throws MalformedURLException for a badly formed URL.
* @throws URISyntaxException for a badly formed URL.
* @see HttpComponentsRestTemplateConfigurator
*/
public Client(URL url) throws MalformedURLException, URISyntaxException {
this(url, null, null);
}
private Client(URL url, String username, String password, SSLConnectionSocketFactory sslConnectionSocketFactory, SSLContext sslContext, HttpClientBuilderConfigurator configurator) throws MalformedURLException, URISyntaxException {
this(new ClientParameters().url(url).username(username).password(password)
.restTemplateConfigurator(new HttpComponentsRestTemplateConfigurator(sslConnectionSocketFactory, sslContext, configurator)));
}
/**
* Construct an instance with the provided {@link ClientParameters}.
*
* The instance will be using the standard JDK facilities to create HTTP requests.
*
* @param parameters the client parameters to use
* @throws URISyntaxException for a badly formed URL.
* @throws MalformedURLException for a badly formed URL.
* @see SimpleRestTemplateConfigurator
* @since 3.6.0
*/
public Client(ClientParameters parameters) throws URISyntaxException, MalformedURLException {
parameters.validate();
URL url = parameters.getUrl();
if (url.toString().endsWith("/")) {
this.rootUri = url.toURI();
} else {
this.rootUri = new URL(url.toString() + "/").toURI();
}
RestTemplate restTemplate = new RestTemplate();
restTemplate.setMessageConverters(getMessageConverters());
RestTemplateConfigurator restTemplateConfigurator = parameters.getRestTemplateConfigurator() == null ?
new SimpleRestTemplateConfigurator() :
parameters.getRestTemplateConfigurator();
this.rt = restTemplateConfigurator.configure(new ClientCreationContext(restTemplate, parameters, this.rootUri));
}
/**
* @return cluster state overview
*/
public OverviewResponse getOverview() {
return this.rt.getForObject(uriWithPath("./overview"), OverviewResponse.class);
}
/**
* Performs a basic node aliveness check: declares a queue, publishes a message
* that routes to it, consumes it, cleans up.
*
* @param vhost vhost to use to perform aliveness check in
* @return true if the check succeeded
*/
public boolean alivenessTest(String vhost) {
final URI uri = uriWithPath("./aliveness-test/" + encodePathSegment(vhost));
return this.rt.getForObject(uri, AlivenessTestResult.class).isSuccessful();
}
/**
* @return information about the user used by this client instance
*/
public CurrentUserDetails whoAmI() {
final URI uri = uriWithPath("./whoami/");
return this.rt.getForObject(uri, CurrentUserDetails.class);
}
/**
* Retrieves state and metrics information for all nodes in the cluster.
*
* @return list of nodes in the cluster
*/
public List getNodes() {
final URI uri = uriWithPath("./nodes/");
return Arrays.asList(this.rt.getForObject(uri, NodeInfo[].class));
}
/**
* Retrieves state and metrics information for individual node.
*
* @param name node name
* @return node information
*/
public NodeInfo getNode(String name) {
final URI uri = uriWithPath("./nodes/" + encodePathSegment(name));
return this.rt.getForObject(uri, NodeInfo.class);
}
/**
* Retrieves state and metrics information for all client connections across the cluster.
*
* @return list of connections across the cluster
*/
public List getConnections() {
final URI uri = uriWithPath("./connections/");
return Arrays.asList(this.rt.getForObject(uri, ConnectionInfo[].class));
}
/**
* Retrieves state and metrics information for all client connections across the cluster
* using query parameters
*
* @param queryParameters
* @return list of connections across the cluster
*/
@SuppressWarnings("unchecked")
public Page getConnections(QueryParameters queryParameters) {
final URI uri = uriWithPath("./connections/", queryParameters);
ParameterizedTypeReference> type = new ParameterizedTypeReference>() {
};
return (queryParameters.pagination().hasAny()) ? this.rt.exchange(uri, HttpMethod.GET, null, type).getBody() :
new Page(this.rt.getForObject(uri, ConnectionInfo[].class));
}
/**
* Retrieves state and metrics information for individual client connection.
*
* @param name connection name
* @return connection information
*/
public ConnectionInfo getConnection(String name) {
final URI uri = uriWithPath("./connections/" + encodePathSegment(name));
return this.rt.getForObject(uri, ConnectionInfo.class);
}
/**
* Forcefully closes individual connection.
* The client will receive a connection.close method frame.
*
* @param name connection name
*/
public void closeConnection(String name) {
final URI uri = uriWithPath("./connections/" + encodePathSegment(name));
deleteIgnoring404(uri);
}
/**
* Forcefully closes individual connection with a user-provided message.
* The client will receive a connection.close method frame.
*
* @param name connection name
* @param reason the reason of closing
*/
public void closeConnection(String name, String reason) {
final URI uri = uriWithPath("./connections/" + encodePathSegment(name));
MultiValueMap headers = new LinkedMultiValueMap();
headers.put("X-Reason", Collections.singletonList(reason));
deleteIgnoring404(uri, headers);
}
/**
* Retrieves state and metrics information for all channels across the cluster.
*
* @return list of channels across the cluster
*/
public List getChannels() {
final URI uri = uriWithPath("./channels/");
return Arrays.asList(this.rt.getForObject(uri, ChannelInfo[].class));
}
/**
* Retrieves state and metrics information for all channels across the cluster.
* using query parameters
*
* @param queryParameters
* @return list of channels across the cluster
*/
@SuppressWarnings("unchecked")
public Page getChannels(QueryParameters queryParameters) {
final URI uri = uriWithPath("./channels/", queryParameters);
ParameterizedTypeReference> type = new ParameterizedTypeReference>() {
};
return (queryParameters.pagination().hasAny()) ? this.rt.exchange(uri, HttpMethod.GET, null, type).getBody() :
new Page(this.rt.getForObject(uri, ChannelInfo[].class));
}
/**
* Retrieves state and metrics information for all channels on individual connection.
* @param connectionName the connection name to retrieve channels
* @return list of channels on the connection
*/
public List getChannels(String connectionName) {
final URI uri = uriWithPath("./connections/" + encodePathSegment(connectionName) + "/channels/");
return Arrays.asList(this.rt.getForObject(uri, ChannelInfo[].class));
}
/**
* Retrieves state and metrics information for individual channel.
*
* @param name channel name
* @return channel information
*/
public ChannelInfo getChannel(String name) {
final URI uri = uriWithPath("./channels/" + encodePathSegment(name));
return this.rt.getForObject(uri, ChannelInfo.class);
}
public List getVhosts() {
final URI uri = uriWithPath("./vhosts/");
return Arrays.asList(this.rt.getForObject(uri, VhostInfo[].class));
}
public VhostInfo getVhost(String name) {
final URI uri = uriWithPath("./vhosts/" + encodePathSegment(name));
return getForObjectReturningNullOn404(uri, VhostInfo.class);
}
/**
* Create a virtual host with name, tracing flag, and metadata.
* Note metadata (description and tags) are supported as of RabbitMQ 3.8.
*
* @param name name of the virtual host
* @param tracing whether tracing is enabled or not
* @param description virtual host description (requires RabbitMQ 3.8 or more)
* @param tags virtual host tags (requires RabbitMQ 3.8 or more)
* @since 3.4.0
*/
public void createVhost(String name, boolean tracing, String description, String... tags) {
Map body = new HashMap();
body.put("tracing", tracing);
if (description != null && !description.isEmpty()) {
body.put("description", description);
}
if (tags != null && tags.length > 0) {
body.put("tags", String.join(",", tags));
}
final URI uri = uriWithPath("./vhosts/" + encodePathSegment(name));
this.rt.put(uri, body);
}
/**
* Create a virtual host with name and metadata.
* Note metadata (description and tags) are supported as of RabbitMQ 3.8.
*
* @param name name of the virtual host
* @param description virtual host description (requires RabbitMQ 3.8 or more)
* @param tags virtual host tags (requires RabbitMQ 3.8 or more)
* @since 3.4.0
*/
public void createVhost(String name, String description, String... tags) {
this.createVhost(name, false, description, tags);
}
/**
* Create a virtual host with name and tracing flag.
*
* @param name name of the virtual host
* @param tracing whether tracing is enabled or not
* @since 3.4.0
*/
public void createVhost(String name, boolean tracing) {
this.createVhost(name, tracing, null);
}
public void createVhost(String name) {
final URI uri = uriWithPath("./vhosts/" + encodePathSegment(name));
this.rt.put(uri, null);
}
public void deleteVhost(String name) {
final URI uri = uriWithPath("./vhosts/" + encodePathSegment(name));
deleteIgnoring404(uri);
}
public List getPermissionsIn(String vhost) {
final URI uri = uriWithPath("./vhosts/" + encodePathSegment(vhost) + "/permissions");
UserPermissions[] result = this.getForObjectReturningNullOn404(uri, UserPermissions[].class);
return asListOrNull(result);
}
public List getPermissionsOf(String username) {
final URI uri = uriWithPath("./users/" + encodePathSegment(username) + "/permissions");
UserPermissions[] result = this.getForObjectReturningNullOn404(uri, UserPermissions[].class);
return asListOrNull(result);
}
public List getPermissions() {
final URI uri = uriWithPath("./permissions");
UserPermissions[] result = this.getForObjectReturningNullOn404(uri, UserPermissions[].class);
return asListOrNull(result);
}
public UserPermissions getPermissions(String vhost, String username) {
final URI uri = uriWithPath("./permissions/" + encodePathSegment(vhost) + "/" + encodePathSegment(username));
return this.getForObjectReturningNullOn404(uri, UserPermissions.class);
}
public List getTopicPermissionsIn(String vhost) {
final URI uri = uriWithPath("./vhosts/" + encodePathSegment(vhost) + "/topic-permissions");
TopicPermissions[] result = this.getForObjectReturningNullOn404(uri, TopicPermissions[].class);
return asListOrNull(result);
}
public List getTopicPermissionsOf(String username) {
final URI uri = uriWithPath("./users/" + encodePathSegment(username) + "/topic-permissions");
TopicPermissions[] result = this.getForObjectReturningNullOn404(uri, TopicPermissions[].class);
return asListOrNull(result);
}
public List getTopicPermissions() {
final URI uri = uriWithPath("./topic-permissions");
TopicPermissions[] result = this.getForObjectReturningNullOn404(uri, TopicPermissions[].class);
return asListOrNull(result);
}
public List getTopicPermissions(String vhost, String username) {
final URI uri = uriWithPath("./topic-permissions/" + encodePathSegment(vhost) + "/" + encodePathSegment(username));
return asListOrNull(this.getForObjectReturningNullOn404(uri, TopicPermissions[].class));
}
public List getExchanges() {
final URI uri = uriWithPath("./exchanges/");
return Arrays.asList(this.rt.getForObject(uri, ExchangeInfo[].class));
}
@SuppressWarnings("unchecked")
public Page getExchanges(QueryParameters queryParameters) {
final URI uri = uriWithPath("./exchanges/", queryParameters);
ParameterizedTypeReference> type = new ParameterizedTypeReference>() {
};
return (queryParameters.pagination().hasAny()) ? this.rt.exchange(uri, HttpMethod.GET, null, type).getBody() :
new Page(this.rt.getForObject(uri, ExchangeInfo[].class));
}
public List getExchanges(String vhost) {
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost));
final ExchangeInfo[] result = this.getForObjectReturningNullOn404(uri, ExchangeInfo[].class);
return asListOrNull(result);
}
@SuppressWarnings("unchecked")
public Page getExchanges(String vhost, QueryParameters queryParameters) {
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost), queryParameters);
ParameterizedTypeReference> type = new ParameterizedTypeReference>() {
};
return (queryParameters.pagination().hasAny()) ? this.rt.exchange(uri, HttpMethod.GET, null, type).getBody() :
new Page(this.rt.getForObject(uri, ExchangeInfo[].class));
}
public ExchangeInfo getExchange(String vhost, String name) {
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost) + "/" + encodePathSegment(name));
return this.getForObjectReturningNullOn404(uri, ExchangeInfo.class);
}
public void declareExchange(String vhost, String name, ExchangeInfo info) {
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost) + "/" + encodePathSegment(name));
this.rt.put(uri, info);
}
public void deleteExchange(String vhost, String name) {
this.deleteIgnoring404(uriWithPath("./exchanges/" + encodePathSegment(vhost) + "/" + encodePathSegment(name)));
}
/**
* Publishes a message to an exchange.
*
* DO NOT USE THIS METHOD IN PRODUCTION. The HTTP API has to create a new TCP
* connection for each message published, which is highly suboptimal.
*
* Use this method for test or development code only.
* In production, use AMQP 0-9-1 or any other messaging protocol that uses a long-lived connection.
*
* @param vhost the virtual host to use
* @param exchange the target exchange
* @param routingKey the routing key to use
* @param outboundMessage the message to publish
* @return true if message has been routed to at least a queue, false otherwise
* @since 3.4.0
*/
public boolean publish(String vhost, String exchange, String routingKey, OutboundMessage outboundMessage) {
if (vhost == null || vhost.isEmpty()) {
throw new IllegalArgumentException("vhost cannot be null or blank");
}
if (exchange == null || exchange.isEmpty()) {
throw new IllegalArgumentException("exchange cannot be null or blank");
}
Map body = Utils.bodyForPublish(routingKey, outboundMessage);
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost) + "/" + encodePathSegment(exchange) + "/publish");
Map, ?> response = this.rt.postForObject(uri, body, Map.class);
Boolean routed = (Boolean) response.get("routed");
if (routed == null) {
return false;
} else {
return routed.booleanValue();
}
}
public List getQueues() {
final URI uri = uriWithPath("./queues/");
return Arrays.asList(this.rt.getForObject(uri, QueueInfo[].class));
}
public List getQueues(String vhost) {
final URI uri = uriWithPath("./queues/" + encodePathSegment(vhost));
final QueueInfo[] result = this.getForObjectReturningNullOn404(uri, QueueInfo[].class);
return asListOrNull(result);
}
@SuppressWarnings("unchecked")
public Page getQueues(String vhost, QueryParameters queryParameters) {
final URI uri = uriWithPath("./queues/" + encodePathSegment(vhost), queryParameters);
ParameterizedTypeReference> type = new ParameterizedTypeReference>() {
};
return (queryParameters.pagination().hasAny()) ? this.rt.exchange(uri, HttpMethod.GET, null, type).getBody() :
new Page(this.rt.getForObject(uri, QueueInfo[].class));
}
public QueueInfo getQueue(String vhost, String name) {
final URI uri = uriWithPath("./queues/" + encodePathSegment(vhost) + "/" + encodePathSegment(name));
return this.getForObjectReturningNullOn404(uri, QueueInfo.class);
}
@SuppressWarnings("unchecked")
public Page getQueues(QueryParameters queryParameters) {
final URI uri = uriWithPath("./queues/", queryParameters);
ParameterizedTypeReference> type = new ParameterizedTypeReference>() {
};
return (queryParameters.pagination().hasAny()) ? this.rt.exchange(uri, HttpMethod.GET, null, type).getBody() :
new Page(this.rt.getForObject(uri, QueueInfo[].class));
}
public void declarePolicy(String vhost, String name, PolicyInfo info) {
final URI uri = uriWithPath("./policies/" + encodePathSegment(vhost) + "/" + encodePathSegment(name));
this.rt.put(uri, info);
}
public void declareQueue(String vhost, String name, QueueInfo info) {
final URI uri = uriWithPath("./queues/" + encodePathSegment(vhost) + "/" + encodePathSegment(name));
this.rt.put(uri, info);
}
public void purgeQueue(String vhost, String name) {
this.deleteIgnoring404(uriWithPath("./queues/" + encodePathSegment(vhost) + "/" + encodePathSegment(name) + "/contents/"));
}
public void deleteQueue(String vhost, String name) {
this.deleteIgnoring404(uriWithPath("./queues/" + encodePathSegment(vhost) + "/" + encodePathSegment(name)));
}
public void deleteQueue(String vhost, String name, DeleteQueueParameters deleteInfo) {
this.deleteIgnoring404(uriWithPath("./queues/" + encodePathSegment(vhost) + "/" + encodePathSegment(name), deleteInfo.getAsQueryParams()));
}
/**
* Get messages from a queue.
*
* DO NOT USE THIS METHOD IN PRODUCTION. Getting messages with the HTTP API
* is intended for diagnostics or tests. It does not implement reliable delivery
* and so should be treated as a sysadmin's tool rather than a general API for messaging.
*
* @param vhost the virtual host the target queue is in
* @param queue the queue to consume from
* @param count the maximum number of messages to get
* @param ackMode determines whether the messages will be removed from the queue
* @param encoding the expected encoding of the message payload
* @param truncate to truncate the message payload if it is larger than the size given (in bytes), -1 means no truncation
* @return the list of messages
* @see GetAckMode
* @see GetEncoding
* @since 3.4.0
*/
public List get(String vhost, String queue,
int count, GetAckMode ackMode, GetEncoding encoding, int truncate) {
if (vhost == null || vhost.isEmpty()) {
throw new IllegalArgumentException("vhost cannot be null or blank");
}
if (queue == null || queue.isEmpty()) {
throw new IllegalArgumentException("queue cannot be null or blank");
}
Map body = Utils.bodyForGet(count, ackMode, encoding, truncate);
final URI uri = uriWithPath("./queues/" + encodePathSegment(vhost) + "/" + encodePathSegment(queue) + "/get");
return Arrays.asList(this.rt.postForObject(uri, body, InboundMessage[].class));
}
/**
* Get messages from a queue, with no limit for message payload truncation.
*
* DO NOT USE THIS METHOD IN PRODUCTION. Getting messages with the HTTP API
* is intended for diagnostics or tests. It does not implement reliable delivery
* and so should be treated as a sysadmin's tool rather than a general API for messaging.
*
* @param vhost the virtual host the target queue is in
* @param queue the queue to consume from
* @param count the maximum number of messages to get
* @param ackMode determines whether the messages will be removed from the queue
* @param encoding the expected encoding of the message payload
* @return the list of messages
* @see GetAckMode
* @see GetEncoding
* @since 3.4.0
*/
public List get(String vhost, String queue,
int count, GetAckMode ackMode, GetEncoding encoding) {
return get(vhost, queue, count, ackMode, encoding, -1);
}
/**
* Get one message from a queue and requeue it.
*
* DO NOT USE THIS METHOD IN PRODUCTION. Getting messages with the HTTP API
* is intended for diagnostics or tests. It does not implement reliable delivery
* and so should be treated as a sysadmin's tool rather than a general API for messaging.
*
* @param vhost the virtual host the target queue is in
* @param queue the queue to consume from
* @return the message, null if the queue is empty
* @see GetAckMode
* @see GetEncoding
* @since 3.4.0
*/
public InboundMessage get(String vhost, String queue) {
List inboundMessages = get(vhost, queue, 1, GetAckMode.NACK_REQUEUE_TRUE, GetEncoding.AUTO, 50000);
if (inboundMessages != null && inboundMessages.size() == 1) {
return inboundMessages.get(0);
} else {
return null;
}
}
public void deletePolicy(String vhost, String name) {
this.deleteIgnoring404(uriWithPath("./policies/" + encodePathSegment(vhost) + "/" + encodePathSegment(name)));
}
public List getUsers() {
final URI uri = uriWithPath("./users/");
return Arrays.asList(this.rt.getForObject(uri, UserInfo[].class));
}
public UserInfo getUser(String username) {
final URI uri = uriWithPath("./users/" + encodePathSegment(username));
return this.getForObjectReturningNullOn404(uri, UserInfo.class);
}
public void createUser(String username, char[] password, List tags) {
if(username == null) {
throw new IllegalArgumentException("username cannot be null");
}
if(password == null) {
throw new IllegalArgumentException("password cannot be null or empty. If you need to create a user that "
+ "will only authenticate using an x509 certificate, use createUserWithPasswordHash with a blank hash.");
}
Map body = new HashMap();
body.put("password", new String(password));
body.put("tags", String.join(",", tags));
final URI uri = uriWithPath("./users/" + encodePathSegment(username));
this.rt.put(uri, body);
}
public void createUserWithPasswordHash(String username, char[] passwordHash, List tags) {
if(username == null) {
throw new IllegalArgumentException("username cannot be null");
}
// passwordless authentication is a thing. See
// https://github.com/rabbitmq/hop/issues/94 and https://www.rabbitmq.com/authentication.html. MK.
if(passwordHash == null) {
passwordHash = "".toCharArray();
}
Map body = new HashMap();
body.put("password_hash", String.valueOf(passwordHash));
body.put("tags", String.join(",", tags));
final URI uri = uriWithPath("./users/" + encodePathSegment(username));
this.rt.put(uri, body);
}
public void updateUser(String username, char[] password, List tags) {
if(username == null) {
throw new IllegalArgumentException("username cannot be null");
}
Map body = new HashMap();
// only update password if provided
if(password != null) {
body.put("password", new String(password));
}
body.put("tags", String.join(",", tags));
final URI uri = uriWithPath("./users/" + encodePathSegment(username));
this.rt.put(uri, body);
}
public void deleteUser(String username) {
this.deleteIgnoring404(uriWithPath("./users/" + encodePathSegment(username)));
}
public void updatePermissions(String vhost, String username, UserPermissions permissions) {
final URI uri = uriWithPath("./permissions/" + encodePathSegment(vhost) + "/" + encodePathSegment(username));
this.rt.put(uri, permissions);
}
public void clearPermissions(String vhost, String username) {
final URI uri = uriWithPath("./permissions/" + encodePathSegment(vhost) + "/" + encodePathSegment(username));
deleteIgnoring404(uri);
}
public void updateTopicPermissions(String vhost, String username, TopicPermissions permissions) {
final URI uri = uriWithPath("./topic-permissions/" + encodePathSegment(vhost) + "/" + encodePathSegment(username));
this.rt.put(uri, permissions);
}
public void clearTopicPermissions(String vhost, String username) {
final URI uri = uriWithPath("./topic-permissions/" + encodePathSegment(vhost) + "/" + encodePathSegment(username));
deleteIgnoring404(uri);
}
public List getPolicies() {
final URI uri = uriWithPath("./policies/");
return Arrays.asList(this.rt.getForObject(uri, PolicyInfo[].class));
}
public List getPolicies(String vhost) {
final URI uri = uriWithPath("./policies/" + encodePathSegment(vhost));
final PolicyInfo[] result = this.getForObjectReturningNullOn404(uri, PolicyInfo[].class);
return asListOrNull(result);
}
public List getBindings() {
final URI uri = uriWithPath("./bindings/");
return Arrays.asList(this.rt.getForObject(uri, BindingInfo[].class));
}
public List getBindings(String vhost) {
final URI uri = uriWithPath("./bindings/" + encodePathSegment(vhost));
return Arrays.asList(this.rt.getForObject(uri, BindingInfo[].class));
}
/**
* Returns a list of bindings where provided exchange is the source (other things are
* bound to it).
*
* @param vhost vhost of the exchange
* @param exchange source exchange name
* @return list of bindings
*/
public List getBindingsBySource(String vhost, String exchange) {
final String x = exchange.equals("") ? "amq.default" : exchange;
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost) +
"/" + encodePathSegment(x) + "/bindings/source");
return Arrays.asList(this.rt.getForObject(uri, BindingInfo[].class));
}
/**
* Returns a list of bindings where provided exchange is the destination (it is
* bound to another exchange).
*
* @param vhost vhost of the exchange
* @param exchange destination exchange name
* @return list of bindings
*/
public List getExchangeBindingsByDestination(String vhost, String exchange) {
final String x = exchange.equals("") ? "amq.default" : exchange;
final URI uri = uriWithPath("./exchanges/" + encodePathSegment(vhost) +
"/" + encodePathSegment(x) + "/bindings/destination");
final BindingInfo[] result = this.rt.getForObject(uri, BindingInfo[].class);
return asListOrNull(result);
}
/**
* Returns a list of bindings where provided queue is the destination.
*
* @param vhost vhost of the exchange
* @param queue destination queue name
* @return list of bindings
*/
public List getQueueBindings(String vhost, String queue) {
final URI uri = uriWithPath("./queues/" + encodePathSegment(vhost) +
"/" + encodePathSegment(queue) + "/bindings");
final BindingInfo[] result = this.rt.getForObject(uri, BindingInfo[].class);
return asListOrNull(result);
}
public List getQueueBindingsBetween(String vhost, String exchange, String queue) {
final URI uri = uriWithPath("./bindings/" + encodePathSegment(vhost) +
"/e/" + encodePathSegment(exchange) + "/q/" + encodePathSegment(queue));
final BindingInfo[] result = this.rt.getForObject(uri, BindingInfo[].class);
return asListOrNull(result);
}
public List getExchangeBindingsBetween(String vhost, String source, String destination) {
final URI uri = uriWithPath("./bindings/" + encodePathSegment(vhost) +
"/e/" + encodePathSegment(source) + "/e/" + encodePathSegment(destination));
final BindingInfo[] result = this.rt.getForObject(uri, BindingInfo[].class);
return asListOrNull(result);
}
/**
* Binds a queue to an exchange.
* @param vhost virtual host the queue and exchange are in
* @param queue the queue name
* @param exchange the exchange name
* @param routingKey the routing key to use
*/
public void bindQueue(String vhost, String queue, String exchange, String routingKey) {
bindQueue(vhost, queue, exchange, routingKey, new HashMap());
}
/**
* Binds a queue to an exchange.
* @param vhost virtual host the queue and exchange are in
* @param queue the queue name
* @param exchange the exchange name
* @param routingKey the routing key to use
* @param args additional map of arguments (used by some exchange types)
*/
public void bindQueue(String vhost, String queue, String exchange, String routingKey, Map args) {
if(vhost == null || vhost.isEmpty()) {
throw new IllegalArgumentException("vhost cannot be null or blank");
}
if(queue == null || queue.isEmpty()) {
throw new IllegalArgumentException("queue cannot be null or blank");
}
if(exchange == null || exchange.isEmpty()) {
throw new IllegalArgumentException("exchange cannot be null or blank");
}
Map body = new HashMap();
if(!(args == null)) {
body.put("arguments", args);
}
body.put("routing_key", routingKey);
final URI uri = uriWithPath("./bindings/" + encodePathSegment(vhost) +
"/e/" + encodePathSegment(exchange) + "/q/" + encodePathSegment(queue));
this.rt.postForLocation(uri, body);
}
/**
* Unbinds a queue from an exchange.
* @param vhost virtual host the queue and exchange are in
* @param queue the queue name
* @param exchange the exchange name
* @param routingKey the routing key used when binding
*/
public void unbindQueue(String vhost, String queue, String exchange, String routingKey) {
if(vhost == null || vhost.isEmpty()) {
throw new IllegalArgumentException("vhost cannot be null or blank");
}
if(queue == null || queue.isEmpty()) {
throw new IllegalArgumentException("queue cannot be null or blank");
}
if(exchange == null || exchange.isEmpty()) {
throw new IllegalArgumentException("exchange cannot be null or blank");
}
this.deleteIgnoring404(uriWithPath("./bindings/" + encodePathSegment(vhost) + "/e/" + encodePathSegment(exchange) +
"/q/" + encodePathSegment(queue) + '/' + encodePathSegment(routingKey)));
}
/**
* Binds a destination exchange to a source one.
* @param vhost virtual host the exchanges are in
* @param destination the destination exchange name
* @param source the source exchange name
* @param routingKey the routing key to use
*/
public void bindExchange(String vhost, String destination, String source, String routingKey) {
bindExchange(vhost, destination, source, routingKey, new HashMap());
}
/**
* Binds a destination exchange to a source one.
* @param vhost virtual host the exchanges are in
* @param destination the destination exchange name
* @param source the source exchange name
* @param routingKey the routing key to use
* @param args additional map of arguments (used by some exchange types)
*/
public void bindExchange(String vhost, String destination, String source, String routingKey, Map args) {
if(vhost == null || vhost.isEmpty()) {
throw new IllegalArgumentException("vhost cannot be null or blank");
}
if(destination == null || destination.isEmpty()) {
throw new IllegalArgumentException("destination cannot be null or blank");
}
if(source == null || source.isEmpty()) {
throw new IllegalArgumentException("source cannot be null or blank");
}
Map body = new HashMap();
if(!(args == null)) {
body.put("arguments", args);
}
body.put("routing_key", routingKey);
final URI uri = uriWithPath("./bindings/" + encodePathSegment(vhost) +
"/e/" + encodePathSegment(source) + "/e/" + encodePathSegment(destination));
this.rt.postForLocation(uri, body);
}
/**
* Unbinds a destination exchange from a source one.
* @param vhost virtual host the exchanges are in
* @param destination the destination exchange name
* @param source the source exchange name
* @param routingKey the routing key used when binding
*/
public void unbindExchange(String vhost, String destination, String source, String routingKey) {
if(vhost == null || vhost.isEmpty()) {
throw new IllegalArgumentException("vhost cannot be null or blank");
}
if(destination == null || destination.isEmpty()) {
throw new IllegalArgumentException("destination cannot be null or blank");
}
if(source == null || source.isEmpty()) {
throw new IllegalArgumentException("source cannot be null or blank");
}
this.deleteIgnoring404(uriWithPath("./bindings/" + encodePathSegment(vhost) + "/e/" + encodePathSegment(source) +
"/e/" + encodePathSegment(destination) + '/' + encodePathSegment(routingKey)));
}
public ClusterId getClusterName() {
return this.rt.getForObject(uriWithPath("./cluster-name"), ClusterId.class);
}
public void setClusterName(String name) {
if(name== null || name.isEmpty()) {
throw new IllegalArgumentException("name cannot be null or blank");
}
final URI uri = uriWithPath("./cluster-name");
Map m = new HashMap();
m.put("name", name);
this.rt.put(uri, m);
}
@SuppressWarnings({"unchecked","rawtypes"})
public List