Tabnine Logo
org.apache.activemq.broker
Code IndexAdd Tabnine to your IDE (free)

How to use org.apache.activemq.broker

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

origin: apache/activemq

/**
 * Adds a new transport connector for the given TransportServer transport
 *
 * @return the newly created and added transport connector
 * @throws Exception
 */
public TransportConnector addConnector(TransportServer transport) throws Exception {
  return addConnector(new TransportConnector(transport));
}
origin: apache/activemq

@Override
public void setBrokerService(BrokerService brokerService) {
  this.brokerService = brokerService;
  this.localBrokerId = brokerService.getRegionBroker().getBrokerId();
  localBrokerPath[0] = localBrokerId;
}
origin: apache/activemq

@Override
public void forgetTransaction(ConnectionContext context, TransactionId transactionId) throws Exception {
  next.forgetTransaction(context, transactionId);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].forgetTransaction(context, transactionId);
  }
}
origin: spring-projects/spring-framework

private void startActiveMqBroker() throws Exception {
  this.activeMQBroker = new BrokerService();
  this.activeMQBroker.addConnector("stomp://localhost:" + this.port);
  this.activeMQBroker.setStartAsync(false);
  this.activeMQBroker.setPersistent(false);
  this.activeMQBroker.setUseJmx(false);
  this.activeMQBroker.getSystemUsage().getMemoryUsage().setLimit(1024 * 1024 * 5);
  this.activeMQBroker.getSystemUsage().getTempUsage().setLimit(1024 * 1024 * 5);
  this.activeMQBroker.start();
}
origin: apache/activemq

@Override
public void updateClientClusterInfo() {
  if (isRebalanceClusterClients() || isUpdateClusterClients()) {
    ConnectionControl control = getConnectionControl();
    for (Connection c : this.connections) {
      c.updateClient(control);
      if (isRebalanceClusterClients()) {
        control = getConnectionControl();
      }
    }
  }
}
origin: apache/activemq

/**
 * Overriding removeConnection to make sure the security context is cleaned.
 */
@Override
public void removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error) throws Exception {
  super.removeConnection(context, info, error);
  context.setSecurityContext(null);
}
origin: apache/activemq

@Override
public void commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase) throws Exception {
  next.commitTransaction(context, xid, onePhase);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].commitTransaction(context, xid, onePhase);
  }
}
origin: apache/activemq

@Override
public void addConnection(ConnectionContext context, ConnectionInfo info) throws Exception {
  next.addConnection(context, info);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].addConnection(context, info);
  }
}
origin: apache/activemq

@Override
public void send(ProducerBrokerExchange producerExchange, Message messageSend) throws Exception {
  next.send(producerExchange, messageSend);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].send(producerExchange, messageSend);
  }
}
origin: apache/activemq

@Override
public void beginTransaction(ConnectionContext context, TransactionId xid) throws Exception {
  next.beginTransaction(context, xid);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].beginTransaction(context, xid);
  }
}
origin: apache/activemq

@Override
public void stop() throws Exception {
  next.stop();
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].stop();
  }
}
origin: apache/activemq

@Override
public void addProducer(ConnectionContext context, ProducerInfo info) throws Exception {
  next.addProducer(context, info);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].addProducer(context, info);
  }
}
origin: apache/activemq

/**
 * Remove 'self' from the BrokerStack
 */
public void remove() {
  parent.setNext(getNext());
}
origin: apache/activemq

@Override
public void acknowledge(ConsumerBrokerExchange consumerExchange, MessageAck ack) throws Exception {
  next.acknowledge(consumerExchange, ack);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].acknowledge(consumerExchange, ack);
  }
}
origin: apache/activemq

@Override
public Subscription addConsumer(ConnectionContext context, ConsumerInfo info) throws Exception {
  Subscription answer = next.addConsumer(context, info);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].addConsumer(context, info);
  }
  return answer;
}
origin: apache/activemq

@Override
public void addSession(ConnectionContext context, SessionInfo info) throws Exception {
  next.addSession(context, info);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].addSession(context, info);
  }
}
origin: apache/activemq

@Override
public void removeSession(ConnectionContext context, SessionInfo info) throws Exception {
  next.removeSession(context, info);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].removeSession(context, info);
  }
}
origin: apache/activemq

@Override
public void gc() {
  next.gc();
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].gc();
  }
}
origin: apache/activemq

@Override
public void addBroker(Connection connection, BrokerInfo info) {
  next.addBroker(connection, info);
  Broker brokers[] = getListeners();
  for (int i = 0; i < brokers.length; i++) {
    brokers[i].addBroker(connection, info);
  }
}
origin: apache/activemq

@Override
public void virtualDestinationRemoved(ConnectionContext context,
    VirtualDestination virtualDestination) {
  getNext().virtualDestinationRemoved(context, virtualDestination);
}
org.apache.activemq.broker

Most used classes

  • BrokerService
    Manages the life-cycle of an ActiveMQ Broker. A BrokerService consists of a number of transport conn
  • TransportConnector
  • BrokerFactory
    A helper class to create a fully configured broker service using a URI. The list of currently suppor
  • ManagementContext
    An abstraction over JMX mbean registration
  • ConnectionContext
    Used to hold context information needed to process requests sent to a broker.
  • Destination,
  • BrokerFilter,
  • ProducerBrokerExchange,
  • SslContext,
  • Connection,
  • BrokerView,
  • BrokerContext,
  • BrokerServiceAware,
  • MBeanInfo,
  • BrokerRegistry,
  • AnnotatedMBean,
  • QueueViewMBean,
  • TopicView,
  • DestinationStatistics
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