Tabnine Logo
Broker.getBrokerName
Code IndexAdd Tabnine to your IDE (free)

How to use
getBrokerName
method
in
org.apache.activemq.broker.Broker

Best Java code snippets using org.apache.activemq.broker.Broker.getBrokerName (Showing top 20 results out of 315)

origin: apache/activemq

@Override
public String getBrokerName() {
  return getNext().getBrokerName();
}
origin: apache/activemq

final void messageSent(final ConnectionContext context, final Message msg) throws Exception {
  pendingSends.decrementAndGet();
  destinationStatistics.getEnqueues().increment();
  destinationStatistics.getMessages().increment();
  destinationStatistics.getMessageSize().addSize(msg.getSize());
  messageDelivered(context, msg);
  consumersLock.readLock().lock();
  try {
    if (consumers.isEmpty()) {
      onMessageWithNoConsumers(context, msg);
    }
  }finally {
    consumersLock.readLock().unlock();
  }
  LOG.debug("{} Message {} sent to {}", new Object[]{ broker.getBrokerName(), msg.getMessageId(), this.destination });
  wakeup();
}
origin: apache/activemq

throw new IllegalStateException(broker.getBrokerName()
    + " Cannot add a consumer to a session that had not been registered: " + sessionId);
origin: apache/activemq

config.setBrokerName(broker.getBrokerName());
origin: apache/activemq

@Override
public void start() throws Exception {
  broker = brokerService.getBroker();
  brokerInfo.setBrokerName(broker.getBrokerName());
  brokerInfo.setBrokerId(broker.getBrokerId());
  brokerInfo.setPeerBrokerInfos(broker.getPeerBrokerInfos());
origin: apache/activemq

protected ActiveMQMapMessage prepareSubscriptionMessage(SubscriptionViewMBean subscriber) throws JMSException {
  Broker regionBroker = getBrokerService().getRegionBroker();
  ActiveMQMapMessage statsMessage = new ActiveMQMapMessage();
  statsMessage.setString("brokerName", regionBroker.getBrokerName());
  statsMessage.setString("brokerId", regionBroker.getBrokerId().toString());
  statsMessage.setString("destinationName", subscriber.getDestinationName());
  statsMessage.setString("clientId", subscriber.getClientId());
  statsMessage.setString("connectionId", subscriber.getConnectionId());
  statsMessage.setLong("sessionId", subscriber.getSessionId());
  statsMessage.setString("selector", subscriber.getSelector());
  statsMessage.setLong("enqueueCounter", subscriber.getEnqueueCounter());
  statsMessage.setLong("dequeueCounter", subscriber.getDequeueCounter());
  statsMessage.setLong("dispatchedCounter", subscriber.getDispatchedCounter());
  statsMessage.setLong("dispatchedQueueSize", subscriber.getDispatchedQueueSize());
  statsMessage.setInt("prefetchSize", subscriber.getPrefetchSize());
  statsMessage.setInt("maximumPendingMessageLimit", subscriber.getMaximumPendingMessageLimit());
  statsMessage.setBoolean("exclusive", subscriber.isExclusive());
  statsMessage.setBoolean("retroactive", subscriber.isRetroactive());
  statsMessage.setBoolean("slowConsumer", subscriber.isSlowConsumer());
  return statsMessage;
}
origin: pierre/meteo

public String getBrokerName() {
  return next.getBrokerName();
}
origin: org.apache.activemq/activemq-broker

@Override
public String getBrokerName() {
  return getNext().getBrokerName();
}
origin: org.apache.activemq/activemq-all

@Override
public String getBrokerName() {
  return getNext().getBrokerName();
}
origin: org.apache.activemq/activemq-osgi

@Override
public String getBrokerName() {
  return getNext().getBrokerName();
}
origin: pierre/meteo

public String getBrokerName() {
  return getNext().getBrokerName();
}
origin: org.apache.activemq/activemq-broker

final void messageSent(final ConnectionContext context, final Message msg) throws Exception {
  pendingSends.decrementAndGet();
  destinationStatistics.getEnqueues().increment();
  destinationStatistics.getMessages().increment();
  destinationStatistics.getMessageSize().addSize(msg.getSize());
  messageDelivered(context, msg);
  consumersLock.readLock().lock();
  try {
    if (consumers.isEmpty()) {
      onMessageWithNoConsumers(context, msg);
    }
  }finally {
    consumersLock.readLock().unlock();
  }
  LOG.debug("{} Message {} sent to {}", new Object[]{ broker.getBrokerName(), msg.getMessageId(), this.destination });
  wakeup();
}
origin: org.apache.activemq/activemq-osgi

final void messageSent(final ConnectionContext context, final Message msg) throws Exception {
  pendingSends.decrementAndGet();
  destinationStatistics.getEnqueues().increment();
  destinationStatistics.getMessages().increment();
  destinationStatistics.getMessageSize().addSize(msg.getSize());
  messageDelivered(context, msg);
  consumersLock.readLock().lock();
  try {
    if (consumers.isEmpty()) {
      onMessageWithNoConsumers(context, msg);
    }
  }finally {
    consumersLock.readLock().unlock();
  }
  LOG.debug("{} Message {} sent to {}", new Object[]{ broker.getBrokerName(), msg.getMessageId(), this.destination });
  wakeup();
}
origin: org.apache.activemq/activemq-all

final void messageSent(final ConnectionContext context, final Message msg) throws Exception {
  pendingSends.decrementAndGet();
  destinationStatistics.getEnqueues().increment();
  destinationStatistics.getMessages().increment();
  destinationStatistics.getMessageSize().addSize(msg.getSize());
  messageDelivered(context, msg);
  consumersLock.readLock().lock();
  try {
    if (consumers.isEmpty()) {
      onMessageWithNoConsumers(context, msg);
    }
  }finally {
    consumersLock.readLock().unlock();
  }
  LOG.debug("{} Message {} sent to {}", new Object[]{ broker.getBrokerName(), msg.getMessageId(), this.destination });
  wakeup();
}
origin: pierre/meteo

public Response processAddConsumer(ConsumerInfo info) throws Exception {
  SessionId sessionId = info.getConsumerId().getParentId();
  ConnectionId connectionId = sessionId.getParentId();
  TransportConnectionState cs = lookupConnectionState(connectionId);
  SessionState ss = cs.getSessionState(sessionId);
  if (ss == null) {
    throw new IllegalStateException(broker.getBrokerName()
        + " Cannot add a consumer to a session that had not been registered: " + sessionId);
  }
  // Avoid replaying dup commands
  if (!ss.getConsumerIds().contains(info.getConsumerId())) {
    broker.addConsumer(cs.getContext(), info);
    try {
      ss.addConsumer(info);
    } catch (IllegalStateException e) {
      broker.removeConsumer(cs.getContext(), info);
    }
  }
  return null;
}
origin: org.apache.activemq/activemq-broker

throw new IllegalStateException(broker.getBrokerName()
    + " Cannot add a consumer to a session that had not been registered: " + sessionId);
origin: org.apache.activemq/activemq-all

throw new IllegalStateException(broker.getBrokerName()
    + " Cannot add a consumer to a session that had not been registered: " + sessionId);
origin: org.apache.activemq/activemq-osgi

protected ActiveMQMapMessage prepareSubscriptionMessage(SubscriptionViewMBean subscriber) throws JMSException {
  Broker regionBroker = getBrokerService().getRegionBroker();
  ActiveMQMapMessage statsMessage = new ActiveMQMapMessage();
  statsMessage.setString("brokerName", regionBroker.getBrokerName());
  statsMessage.setString("brokerId", regionBroker.getBrokerId().toString());
  statsMessage.setString("destinationName", subscriber.getDestinationName());
  statsMessage.setString("clientId", subscriber.getClientId());
  statsMessage.setString("connectionId", subscriber.getConnectionId());
  statsMessage.setLong("sessionId", subscriber.getSessionId());
  statsMessage.setString("selector", subscriber.getSelector());
  statsMessage.setLong("enqueueCounter", subscriber.getEnqueueCounter());
  statsMessage.setLong("dequeueCounter", subscriber.getDequeueCounter());
  statsMessage.setLong("dispatchedCounter", subscriber.getDispatchedCounter());
  statsMessage.setLong("dispatchedQueueSize", subscriber.getDispatchedQueueSize());
  statsMessage.setInt("prefetchSize", subscriber.getPrefetchSize());
  statsMessage.setInt("maximumPendingMessageLimit", subscriber.getMaximumPendingMessageLimit());
  statsMessage.setBoolean("exclusive", subscriber.isExclusive());
  statsMessage.setBoolean("retroactive", subscriber.isRetroactive());
  statsMessage.setBoolean("slowConsumer", subscriber.isSlowConsumer());
  return statsMessage;
}
origin: org.apache.activemq/activemq-all

protected ActiveMQMapMessage prepareSubscriptionMessage(SubscriptionViewMBean subscriber) throws JMSException {
  Broker regionBroker = getBrokerService().getRegionBroker();
  ActiveMQMapMessage statsMessage = new ActiveMQMapMessage();
  statsMessage.setString("brokerName", regionBroker.getBrokerName());
  statsMessage.setString("brokerId", regionBroker.getBrokerId().toString());
  statsMessage.setString("destinationName", subscriber.getDestinationName());
  statsMessage.setString("clientId", subscriber.getClientId());
  statsMessage.setString("connectionId", subscriber.getConnectionId());
  statsMessage.setLong("sessionId", subscriber.getSessionId());
  statsMessage.setString("selector", subscriber.getSelector());
  statsMessage.setLong("enqueueCounter", subscriber.getEnqueueCounter());
  statsMessage.setLong("dequeueCounter", subscriber.getDequeueCounter());
  statsMessage.setLong("dispatchedCounter", subscriber.getDispatchedCounter());
  statsMessage.setLong("dispatchedQueueSize", subscriber.getDispatchedQueueSize());
  statsMessage.setInt("prefetchSize", subscriber.getPrefetchSize());
  statsMessage.setInt("maximumPendingMessageLimit", subscriber.getMaximumPendingMessageLimit());
  statsMessage.setBoolean("exclusive", subscriber.isExclusive());
  statsMessage.setBoolean("retroactive", subscriber.isRetroactive());
  statsMessage.setBoolean("slowConsumer", subscriber.isSlowConsumer());
  return statsMessage;
}
origin: org.apache.activemq/activemq-broker

protected ActiveMQMapMessage prepareSubscriptionMessage(SubscriptionViewMBean subscriber) throws JMSException {
  Broker regionBroker = getBrokerService().getRegionBroker();
  ActiveMQMapMessage statsMessage = new ActiveMQMapMessage();
  statsMessage.setString("brokerName", regionBroker.getBrokerName());
  statsMessage.setString("brokerId", regionBroker.getBrokerId().toString());
  statsMessage.setString("destinationName", subscriber.getDestinationName());
  statsMessage.setString("clientId", subscriber.getClientId());
  statsMessage.setString("connectionId", subscriber.getConnectionId());
  statsMessage.setLong("sessionId", subscriber.getSessionId());
  statsMessage.setString("selector", subscriber.getSelector());
  statsMessage.setLong("enqueueCounter", subscriber.getEnqueueCounter());
  statsMessage.setLong("dequeueCounter", subscriber.getDequeueCounter());
  statsMessage.setLong("dispatchedCounter", subscriber.getDispatchedCounter());
  statsMessage.setLong("dispatchedQueueSize", subscriber.getDispatchedQueueSize());
  statsMessage.setInt("prefetchSize", subscriber.getPrefetchSize());
  statsMessage.setInt("maximumPendingMessageLimit", subscriber.getMaximumPendingMessageLimit());
  statsMessage.setBoolean("exclusive", subscriber.isExclusive());
  statsMessage.setBoolean("retroactive", subscriber.isRetroactive());
  statsMessage.setBoolean("slowConsumer", subscriber.isSlowConsumer());
  return statsMessage;
}
org.apache.activemq.brokerBrokergetBrokerName

Javadoc

Get the name of the broker

Popular methods of Broker

  • getAdaptor
    Get a Broker from the Broker Stack that is a particular class
  • getDestinationMap
    return a reference destination map of a region based on the destination type
  • removeDestination
  • commitTransaction
    Commits a transaction.
  • forgetTransaction
    Forgets a transaction.
  • getBrokerService
  • getClients
  • getDestinations
  • getPreparedTransactions
    Gets a list of all the prepared xa transactions.
  • getVmConnectorURI
  • removeConsumer
  • acknowledge
  • removeConsumer,
  • acknowledge,
  • addBroker,
  • addConnection,
  • addConsumer,
  • addDestination,
  • addDestinationInfo,
  • addProducer,
  • addSession,
  • beginTransaction

Popular in Java

  • Creating JSON documents from java classes using gson
  • setScale (BigDecimal)
  • getApplicationContext (Context)
  • putExtra (Intent)
  • File (java.io)
    An "abstract" representation of a file system entity identified by a pathname. The pathname may be a
  • ConnectException (java.net)
    A ConnectException is thrown if a connection cannot be established to a remote host on a specific po
  • KeyStore (java.security)
    KeyStore is responsible for maintaining cryptographic keys and their owners. The type of the syste
  • Iterator (java.util)
    An iterator over a sequence of objects, such as a collection.If a collection has been changed since
  • NoSuchElementException (java.util)
    Thrown when trying to retrieve an element past the end of an Enumeration or Iterator.
  • ReentrantLock (java.util.concurrent.locks)
    A reentrant mutual exclusion Lock with the same basic behavior and semantics as the implicit monitor
  • From CI to AI: The AI layer in your organization
Tabnine Logo
  • Products

    Search for Java codeSearch for JavaScript code
  • IDE Plugins

    IntelliJ IDEAWebStormVisual StudioAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimGoLandRubyMineEmacsJupyter NotebookJupyter LabRiderDataGripAppCode
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogTabnine AcademyTerms of usePrivacy policyJava Code IndexJavascript Code Index
Get Tabnine for your IDE now