webMethods Broker Administration Java API
Version 9.5.1.0.171 091713

Uses of Class
COM.activesw.api.client.BrokerException

Uses of BrokerException in COM.activesw.api.client
 

Subclasses of BrokerException in COM.activesw.api.client
 class BrokerBadStateException
          This exception is thrown by Information Broker client methods when an API call is made that conflicts with the current system state.
 class BrokerClientContentionException
          This exception is thrown by Information Broker client methods when client contention is detected.
 class BrokerClientExistsException
          This exception is thrown by Information Broker client methods when an attempt is made to create a client and that client's ID is already in use.
 class BrokerClientGroupExistsException
          This exception is thrown by Information Broker client methods when an attempt is made to create a client group and that client group name is already in use.
 class BrokerClientQueueBrowserException
          This exception is thrown by queue browser methods when an operation on a BrokerClientQueueBrowser (including the locked) fails.
 class BrokerClientQueueLockException
          This exception is thrown by Information Broker client methods when the specified operation cannot be affected as the BrokerClient is determined to be locked for queue browser operations.
 class BrokerClusterPublisherException
          This exception is thrown by BrokerClusterPublisher methods when an error occurs while invoking methods on BrokerClusterPublisher object.
 class BrokerCommFailureException
          This exception is thrown by Information Broker client methods when a network communications failure occurs.
 class BrokerConnectionClosedException
          This exception is thrown by Information Broker client methods when an action is attempted on a BrokerClient which has been disconnected from the broker previously or was disconnected during the operation.
 class BrokerCorruptDataException
          This exception is thrown by Information Broker client methods when internal data is discovered to be corrupt
 class BrokerDependencyException
          This exception is thrown by Information Broker client methods when an opperation cannot be completed due to a dependency.
 class BrokerExistsException
          This exception is thrown by Information Broker client methods when an attempt is made to create a broker and that broker's name is already in use.
 class BrokerFailureException
          This exception is thrown by Information Broker client methods when an internal failure happens when communicating with the broker.
 class BrokerFieldNotFoundException
          This exception is thrown by Information Broker client methods when an application tries to get or set a non-existant field in an event.
 class BrokerFieldTypeMismatchException
          This exception is thrown by Information Broker client methods when a field is accessed as a type other than what it really is.
 class BrokerFileNotFoundException
          This exception is thrown by Information Broker client methods when an application tries to access a non-existant file.
 class BrokerFilterParseException
          This exception is thrown by Information Broker client methods when an error occurs during the parsing of a filter string.
 class BrokerFilterRuntimeException
          This exception is thrown by Information Broker client methods when an error occurs during a filter match.
 class BrokerFormatException
          This exception is thrown by Information Broker client methods when an internal formating error is detected.
 class BrokerHostNotFoundException
          This exception is thrown by Information Broker client methods when a host is not found.
 class BrokerIncompatibleVersionException
          This exception is thrown by Information Broker client methods when the broker is running which is incompatible with the client class version being used.
 class BrokerInputParseException
          This exception is thrown by the ADL parser when the import file contents are invalid in some way.
 class BrokerInTerritoryException
          This exception is thrown by Information Broker client methods when a territory join or create operation is performed on a broker that is already in a territory.
 class BrokerInterruptedException
          This exception is thrown by Information Broker client methods when an interruption occurs.
 class BrokerInvalidAccessListException
          This exception is thrown by Information Broker client methods when the access list specified to a call is not valid.
 class BrokerInvalidAcknowledgementException
          This exception is thrown by Information Broker client methods when an acknowledgement is determined to be invalid.
 class BrokerInvalidBrokerNameException
          This exception is thrown by Information Broker client methods when the client group name specified to a call is not valid.
 class BrokerInvalidClientException
          This exception is thrown by Information Broker client methods when a BrokerClient is determined to be invalid because it has already been disconnected or destroyed.
 class BrokerInvalidClientGroupNameException
          This exception is thrown by Information Broker client methods when the client group name specified to a call is not valid.
 class BrokerInvalidClientIdException
          This exception is thrown by Information Broker client methods when the client ID specified to a call is not valid.
 class BrokerInvalidEventException
          This exception is thrown by Information Broker client methods when an attempt is made to publish an event that is not properly formed.
 class BrokerInvalidEventTypeNameException
          This exception is thrown by Information Broker client methods when an invalid event type name is used.
 class BrokerInvalidFieldNameException
          This exception is thrown by Information Broker client methods when an invalid field name is used.
 class BrokerInvalidLicenseException
          This exception is thrown by Information Broker client methods when the license string specified to a call is not valid.
 class BrokerInvalidLogConfigException
          This exception is thrown by Information Broker client methods when the log configuration specified to a call is not valid.
 class BrokerInvalidNameException
          This exception is thrown by Information Broker client methods when a name specified to a call is not valid.
 class BrokerInvalidPlatformKeyException
          This exception is thrown by Information Broker client methods when the platform key specified to a call is not valid.
 class BrokerInvalidPortException
          This exception is thrown by Information Broker client methods when the port specified to a call is not valid.
 class BrokerInvalidSubscriptionException
          This exception is thrown by Information Broker client methods when a subscription contains an invalid event type name or subscription ID.
 class BrokerInvalidTerritoryNameException
          This exception is thrown by Information Broker client methods when the client group name specified to a call is not valid.
 class BrokerInvalidTxException
          This exception is thrown by Information Broker client methods when a name is specified which does not exist in the resource being accessed.
 class BrokerInvalidTypeCacheException
          This exception is thrown by Information Broker client methods when an internal type caching failure occurs.
 class BrokerInvalidTypeDefException
          This exception is thrown by Information Broker client methods when using a type definition from a client that is no longer connected to the broker or after the type cache has been flushed.
 class BrokerInvalidTypeException
          This exception is thrown by Information Broker client methods when a type is used which is not supported by the client classes.
 class BrokerNoPermissionException
          This exception is thrown by Information Broker client methods when access permission is denied for the operation.
 class BrokerNotImplementedException
          This exception is thrown by Information Broker client methods when the requested operation is not available.
 class BrokerNotInClusterException
          This exception is thrown by Information Broker client methods when a cluster operation is performed on a broker that is not in a cluster.
 class BrokerNotInTerritoryException
          This exception is thrown by Information Broker client methods when a territory operation is performed on a broker that is not in a territory.
 class BrokerNotRunningException
          This exception is thrown by Information Broker client methods when the host is available but no broker is running on that host.
 class BrokerNullParameterException
          This exception is thrown by Information Broker client methods when a paramter value is null.
 class BrokerOutOfRangeException
          This exception is thrown by Information Broker client methods when an out of range value is encountered.
 class BrokerProtocolException
          This exception is thrown by Information Broker client methods when an internal protocol failure occurs.
 class BrokerPublishPauseException
          This exception is thrown by Information Broker client methods when an internal failure happens when communicating with the broker.
 class BrokerQueueBrowserException
          This exception is thrown by queue browser methods when an operation on a BrokerQueueBrowser (including the locked) fails.
 class BrokerSecurityException
          This exception is thrown by Information Broker client methods when an error occurs with the security system.
 class BrokerSSLConfigException
           
 class BrokerSubscriptionExistsException
          This exception is thrown by Information Broker client methods when an attempt is made to open a subscription which is the same as another existing subscription.
 class BrokerTimeoutException
          This exception is thrown by Information Broker client methods when the operation times out.
 class BrokerTxClosedException
          This exception is thrown by Information Broker client methods when an action is attempted on a BrokerClient transaction which has been either committed or aborted.
 class BrokerUnknownBrokerNameException
          This exception is thrown by Information Broker client methods when a broker name is specified that does not exist on the host.
 class BrokerUnknownClientGroupException
          This exception is thrown by Information Broker client methods when a client group name is specified that is not defined in the broker.
 class BrokerUnknownClientIdException
          This exception is thrown by Information Broker client methods when a client ID is specified which does not exist in the broker.
 class BrokerUnknownClusterException
          This exception is thrown by Information Broker client methods when a Cluster name is specified that does not exist on the Broker.
 class BrokerUnknownEventTypeException
          This exception is thrown by Information Broker client methods when an event type name is specified which does not exist in the broker.
 class BrokerUnknownInfosetException
          This exception is thrown by Information Broker client methods when an infoset name is specified which does not exist on the event type definition in the broker.
 class BrokerUnknownKeyException
          This exception is thrown by Information Broker client methods when a platform key is specified which is not in the platform information.
 class BrokerUnknownNameException
          This exception is thrown by Information Broker client methods when a name is specified which does not exist in the resource being accessed.
 class BrokerUnknownServerException
          This exception is thrown by Information Broker client methods when the server specified to a call does not exist.
 class BrokerUnknownSessionIdException
          This exception is thrown by Information Broker client methods when the session ID specified to a call is not valid.
 class BrokerUnknownTerritoryException
          This exception is thrown by Information Broker client methods when a broker name is specified that does not exist on the host.
 

Methods in COM.activesw.api.client that return BrokerException
protected  BrokerException BrokerClientQueueBrowser.createException(BrokerQueueBrowserException ex)
           
protected  BrokerException BrokerForwardQueueBrowser.createException(BrokerQueueBrowserException ex)
           
 

Methods in COM.activesw.api.client that throw BrokerException
 void BrokerTransactionalClient.abort()
          aborts the open transaction on this client, discarding all work previously performed, and invalidates Rollback the transaction the context.
 void BrokerTransactionalClient.abort(long tx_id)
          aborts the open transaction on this client, discarding all work previously performed, and invalidates Rollback the transaction the context.
 void BrokerTransactionalClient.abort(java.lang.String external_id)
          aborts all the transactions with the given external id, discarding all work previously performed Rollback the transaction the context.
 void BrokerTransactionalClient.abort(java.lang.String[] external_ids)
          Aborts the transaction(s) which has/have the specified external_id.
static void BrokerTransactionalClient.abortAll(BrokerTransactionalClient[] tx_clients)
          aborts the given list of open transactions, discarding all work previously performed, and invalidates the context.
static void BrokerTransactionalClient.abortAll(BrokerTransactionalClient[] tx_clients, java.lang.String external_id)
          aborts all the transactions known to this broker with the given external_id Discarding all work previously performed, This method is used in distributed transactions.
 void BrokerAdminClient.abortForced(long tx_id)
          Forcibly abort a transaction.
 void BrokerAdminClient.abortForced(long[] tx_ids)
          Forcibly abort a list of transactions.
 void BrokerClient.acknowledge(long seqn)
          Acknowledge the single event specified.
 void BrokerTransactionalClient.acknowledge(long seqn)
          Acknowledge the single event specified.
 void BrokerClient.acknowledge(long[] seqn)
          Acknowledge the array of events with the given seqn numbers.
 void BrokerTransactionalClient.acknowledge(long[] seqns)
          Acknowledge the array of events with the given seqn numbers.
 void BrokerClient.acknowledge(long[] seqn, long txid)
          Acknowledge the array of events with the given seqn numbers, under the specified transaction id.
 void BrokerClient.acknowledge(long seqn, long txid)
          Acknowledge the single event specified, under the specified transaction id.
 void BrokerClient.acknowledgeThrough(long seqn)
          Acknowledges all events through the event specified.
 void BrokerTransactionalClient.acknowledgeThrough(long seqn)
          Acknowledges all events through the event specified.
 void BrokerClient.acknowledgeThrough(long seqn, long txid)
          Acknowledges all events through the event specified, under the specified transaction id.
 BrokerChangeLockInfo BrokerAdminClient.acquireChangeLock()
          Acquire the per-Broker change lock.
 BrokerJoinFailureInfo BrokerAdminClient.addBrokerToCluster(java.lang.String broker_host, java.lang.String broker_name)
          Have this broker join the cluster of the specified other broker.
static java.lang.String BrokerFormat.assemble(BrokerEvent event, java.util.Vector tokens)
          Assemble a string from the tokens, replacing references with values from the event.
static java.lang.String BrokerFormat.assemble(BrokerEvent event, java.util.Vector tokens, java.util.Locale locale)
          Assemble a string from the tokens, replacing references with values from the event.
 int BrokerClient.beginAdapterTransaction(java.lang.String transaction_id, int required_level, java.lang.String[] participants, boolean want_ack)
          Publishes an Adapter::beginTransaction event for the given transaction ID.
 long BrokerTransactionalClient.beginTransaction(java.lang.String external_id)
          Starts a transaction.
 long BrokerTransactionalClient.beginTransaction(java.lang.String external_id, int flag, int timeout)
          Starts a transaction.
 BrokerEvent[] BrokerQueueBrowser.browseEvents(int max_events, int msecs)
          Browse one or more events from the queue.
 BrokerEvent[] BrokerClient.browseEvents(int from_index, int max_events, BrokerFilterDescriptor[] filters)
          Peek one or more events from the specified client's queue.
 void BrokerClient.cancelCallbackForSubId(int sub_id)
          Cancel the client's specific callback for a subscription id.
 void BrokerTransactionalClient.cancelCallbackForSubId(int sub_id)
           
 void BrokerClient.cancelCallbackForTag(int tag)
          Cancel the client's specific callback for a tag value.
 void BrokerTransactionalClient.cancelCallbackForTag(int tag)
           
 void BrokerClient.cancelCallbacks()
          Cancel all callbacks for the client.
 void BrokerTransactionalClient.cancelCallbacks()
           
 void BrokerClient.cancelCheckForEvents()
          Cancel any pending check events request on the current client session.
 void BrokerClusterPublisher.cancelConnectionCallback()
          Cancel the cluster publisher's connection callback, if any registered.
 void BrokerClient.cancelGetEvents()
           
 void BrokerTransactionalClient.cancelGetEvents()
           
 void BrokerClusterPublisher.cancelSelectionCallback()
          Cancel the cluster publisher's selection callback, if any registered.
 void BrokerClient.cancelSubscription(BrokerSubscription sub)
          Cancel a subscription with matching event type and filter.
 void BrokerClient.cancelSubscription(java.lang.String event_type_name, java.lang.String filter)
          Cancel a subscription with matching event type and filter.
 void BrokerClient.cancelSubscriptions(BrokerSubscription[] subs)
          Cancel multiple subscriptions with matching event types and filters.
 boolean BrokerClient.canPublish(java.lang.String event_type_name)
          Test if can publish or deliver an event of a given type.
 boolean BrokerClusterPublisher.canPublish(java.lang.String event_type_name)
          Test if can publish or deliver an event of a given type.
 boolean BrokerClient.canSubscribe(java.lang.String event_type_name)
          Test if can subscribe to an event type, or have events of that type delivered to this client.
 int BrokerAdminClient.checkAndRestartForwarding()
          Check for inactivity and restart forwarding documemnts on all territory and gateway brokers on this broker.
 int BrokerAdminClient.checkAndRestartForwarding(java.lang.String remote_broker_name)
          Check for inactivity and restart forwarding documemnts across the specfied territory or gateway broker.
 void BrokerClient.checkForEvents(int msecs)
          Check for the availability of deliverable events on the client's queue.
 boolean BrokerServerClient.checkMetaDataBackup()
          Verifies that the backup of the meta-data is still OK to proceed.
protected static void BrokerEvent.checkSetEnvField(java.lang.String field_name, java.lang.String full_field_name)
           
 void BrokerAdminClient.clearClientQueueById(java.lang.String client_id)
          Clear all events from the client's queue.
 void BrokerAdminTypeDef.clearField(java.lang.String field_name)
          Clear/delete a given field.
 void BrokerEvent.clearField(java.lang.String field_name)
          Clear (un-set) a field in the event.
 void BrokerEvent.clearField(java.lang.String field_name, boolean ignoreEx)
          Clear (un-set) a field in the event.
 void BrokerEvent.clearFieldInternal(java.lang.String field_name, boolean ignoreEx)
           
 void BrokerAdminTypeDef.clearFields()
          Clear/delete all fields.
 void BrokerLogConfig.clearLogOutput(java.lang.String code)
          Clear the state of a single log output.
 void BrokerLogConfig.clearLogTopic(java.lang.String code)
          Clear the state of a single log topic.
 void BrokerClient.clearQueue()
          Clear all events from the client's queue.
 void BrokerQueueBrowser.closeQueueBrowser()
          Close the current queue browser object.
 void BrokerTransactionalClient.commit()
          commits the open transaction.
 void BrokerTransactionalClient.commit(long tx_id)
          commits the open transaction.
 void BrokerTransactionalClient.commit(java.lang.String external_id)
          commits the open transaction(s) which has/have the specified external_id.
 void BrokerTransactionalClient.commit(java.lang.String[] external_ids)
          commits the open transaction(s) which has/have the specified external_id.
static void BrokerTransactionalClient.commitAll(BrokerTransactionalClient[] tx_clients)
          commits the given list of open transaction.
static void BrokerTransactionalClient.commitAll(BrokerTransactionalClient[] tx_clients, java.lang.String external_id)
          commits all the open transaction with the given external_id.
 void BrokerAdminClient.commitForced(long tx_id)
          Forcibly commit a transaction.
 void BrokerAdminClient.commitForced(long[] tx_ids)
          Forcibly commit a list of transactions.
 void BrokerServerClient.createBroker(java.lang.String broker_name, java.lang.String description, boolean is_default)
          Create a Broker.
 void BrokerAdminClient.createClient(java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, java.lang.String user_name, java.lang.String authenticator_name, BrokerConnectionDescriptor desc)
          Create a new client on the broker.
 void BrokerAdminClient.createClientGroup(java.lang.String client_group_name, int life_cycle, int storage_type)
          Create a client group on the broker.
 BrokerClientQueueBrowser BrokerClient.createClientQueueBrowser()
          Creates a queue browser on the current client's queue.
 BrokerClientQueueBrowser BrokerAdminClient.createClientQueueBrowser(java.lang.String client_id)
          Creates a queue browser on the specified client.
 void BrokerAdminClient.createClientSubscriptionById(java.lang.String client_id, BrokerSubscription sub)
          Create a subscription for the client to all events of a given event type which match the specified filter.
 void BrokerAdminClient.createClientSubscriptionsById(java.lang.String client_id, BrokerSubscription[] subs)
          Open multiple subscriptions for a client at one time.
 void BrokerAdminClient.createCluster(java.lang.String clusterName)
          Create a new cluster with this broker as the first member.
 void BrokerAdminClient.createClusterGateway(java.lang.String cluster_name, java.lang.String broker_host, java.lang.String broker_name, boolean isPrimary)
          Create a gateway to the specified cluster by having the current broker communicate with the broker specified by broker_host and broker_name.
 BrokerQueueBrowser BrokerAdminClient.createForwardQueueBrowser(java.lang.String remoteBroker)
          Creates a queue browser on the forwarding queue of the specified remote broker.
 BrokerLockedClientQueueBrowser BrokerAdminClient.createLockedClientQueueBrowser(java.lang.String client_id)
          Creates a locked queue browser on the specified client.
 BrokerLockedQueueBrowser BrokerAdminClient.createLockedForwardQueueBrowser(java.lang.String remoteBroker)
          Creates a locked queue browser on the forwarding queue of the specified remote broker.
 void BrokerAdminClient.createTerritory(java.lang.String territory_name)
          Create a new territory with this broker as the first member.
 void BrokerAdminClient.createTerritoryGateway(java.lang.String territory_name, java.lang.String broker_host, java.lang.String broker_name)
          Create a gateway to the specified territory by having the current broker communicate with the broker specified by broker_host and broker_name.
 void BrokerCompleteBroker.deepRefresh(BrokerAdminClient client)
          Refreshes the information about a Broker based on the given client.
 void BrokerCompleteServer.deepRefresh(BrokerServerClient client, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Refreshes the information about a Broker server based on the given client.
static BrokerCompleteBroker BrokerCompleteBroker.deepRetrieve(BrokerAdminClient client)
          Retrieves the information about a Broker based on the given client.
static BrokerCompleteServer BrokerCompleteServer.deepRetrieve(BrokerServerClient client, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Retrieves all the information about a Broker server and creates an object.
 void BrokerCompleteBroker.deepStore(BrokerAdminClient client)
          Stores the information from this object into the Broker for which the given client object has been provided.
 int BrokerLockedClientQueueBrowser.deleteEvents(long[] seqns)
          Delete events in the queue.
 int BrokerLockedForwardQueueBrowser.deleteEvents(long[] seqns)
          Delete events in the queue.
 int BrokerLockedQueueBrowser.deleteEvents(long[] seqns)
          Delete events in the queue.
 int BrokerAdminClient.deleteLogEvents(int from_index, int num_events)
          Deletes one or more events from the broker's log.
 void BrokerClient.deliver(java.lang.String dest_id, BrokerEvent event)
          Deliver one event.
 void BrokerClusterPublisher.deliver(java.lang.String dest_id, BrokerEvent event)
          Deliver one event.
 void BrokerTransactionalClient.deliver(java.lang.String dest_id, BrokerEvent event)
          Deliver one event in the given transaction.
 void BrokerClient.deliver(java.lang.String dest_id, BrokerEvent[] events)
          Deliver multiple events.
 void BrokerClusterPublisher.deliver(java.lang.String dest_id, BrokerEvent[] events)
          Deliver multiple events.
 void BrokerTransactionalClient.deliver(java.lang.String dest_id, BrokerEvent[] events)
          Deliver multiple events on the given transaction.
protected  void BrokerClient.deliver(java.lang.String dest_id, BrokerEvent[] events, BrokerTransactionalClient tx_client)
          Deliver multiple events on the given transaction.
protected  void BrokerClient.deliver(java.lang.String dest_id, BrokerEvent event, BrokerTransactionalClient tx_client)
          Deliver one event in the given transaction.
 void BrokerClient.deliverAckReplyEvent(BrokerEvent request_event, long publish_seqn)
          Delivers an Adapter::ack event to the originator of the specified event, which is most likely a request event.
 void BrokerTransactionalClient.deliverAckReplyEvent(BrokerEvent request_event, long publish_seqn)
          Delivers an Adapter::ack event to the originator of the specified event, which is most likely a request event for given transaction.
protected  void BrokerClient.deliverAckReplyEvent(BrokerEvent request_event, long publish_seqn, BrokerTransactionalClient tx_client)
          Delivers an Adapter::ack event to the originator of the specified event, which is most likely a request event for given transaction.
 void BrokerClient.deliverErrorReplyEvent(BrokerEvent request_event, BrokerEvent error_event)
          /** Give a single error event to the broker to all be delivered to the client that published the 'request_event'.
 void BrokerTransactionalClient.deliverErrorReplyEvent(BrokerEvent request_event, BrokerEvent error_event)
          Give a single error event to the broker to all be delivered to the client that published the 'request_event' for given transaction.
protected  void BrokerClient.deliverErrorReplyEvent(BrokerEvent request_event, BrokerEvent error_event, BrokerTransactionalClient tx_client)
          Give a single error event to the broker to all be delivered to the client that published the 'request_event' for given transaction.
 void BrokerClient.deliverNullReplyEvent(BrokerEvent request_event, java.lang.String reply_event_type_name, long publish_seqn)
          Delivers a null event of type 'reply_event_type_name' to the originator of the specified event, which is most likely a request event.
 void BrokerTransactionalClient.deliverNullReplyEvent(BrokerEvent request_event, java.lang.String reply_event_type_name, long publish_seqn)
          Delivers a null event of type 'reply_event_type_name' to the originator of the specified event, which is most likely a request event for given transaction.
protected  void BrokerClient.deliverNullReplyEvent(BrokerEvent request_event, java.lang.String reply_event_type_name, long publish_seqn, BrokerTransactionalClient tx_client)
          Delivers a null event of type 'reply_event_type_name' to the originator of the specified event, which is most likely a request event for given transaction.
 int BrokerClient.deliverPartialReplyEvents(BrokerEvent request_event, BrokerEvent[] events, int flag, int token)
          Give multiple events to the broker to all be delivered to the client that published the 'request_event'.
 int BrokerTransactionalClient.deliverPartialReplyEvents(BrokerEvent request_event, BrokerEvent[] events, int flag, int token)
          Give multiple events to the broker to all be delivered to the client that published the 'request_event' for the given transaction.
protected  int BrokerClient.deliverPartialReplyEvents(BrokerEvent request_event, BrokerEvent[] events, int flag, int token, BrokerTransactionalClient tx_client)
          Give multiple events to the broker to all be delivered to the client that published the 'request_event' for the given transaction.
 void BrokerClient.deliverReplyEvent(BrokerEvent request_event, BrokerEvent event)
          Give a single event to the broker to all be delivered to the client that published the 'request_event'.
 void BrokerTransactionalClient.deliverReplyEvent(BrokerEvent request_event, BrokerEvent event)
          Give a single event to the broker to all be delivered to the client that published the 'request_event' for the given transaction.
protected  void BrokerClient.deliverReplyEvent(BrokerEvent request_event, BrokerEvent event, BrokerTransactionalClient tx_client)
          Give a single event to the broker to all be delivered to the client that published the 'request_event' for the given transaction.
 void BrokerClient.deliverReplyEvents(BrokerEvent request_event, BrokerEvent[] events)
          Give multiple events to the broker to all be delivered to the client that published the 'request_event'.
 void BrokerTransactionalClient.deliverReplyEvents(BrokerEvent request_event, BrokerEvent[] events)
          Give multiple events to the broker to all be delivered to the client that published the 'request_event' for given transaction.
 void BrokerClient.deliverReplyEvents(BrokerEvent request_event, BrokerEvent[] events, BrokerTransactionalClient tx_client)
          Give multiple events to the broker to all be delivered to the client that published the 'request_event' for given transaction.
 BrokerEvent[] BrokerClient.deliverRequestAndWait(java.lang.String dest_id, BrokerEvent event, int msecs)
          Deliver one request event and wait for replies.
 BrokerEvent[] BrokerClusterPublisher.deliverRequestAndWait(java.lang.String dest_id, BrokerEvent event, int msecs)
          Deliver one request event and wait for replies.
 BrokerEvent[] BrokerTransactionalClient.deliverRequestAndWait(java.lang.String dest_id, BrokerEvent event, int msecs)
           
 void BrokerClient.deliverWithAck(java.lang.String dest_id, BrokerEvent[] events, int ack_type, long[] ack_seqn)
          Deliver multiple events.
 void BrokerTransactionalClient.deliverWithAck(java.lang.String dest_id, BrokerEvent[] events, int ack_type, long[] ack_seqn)
          Deliver multiple events on the given transaction.
protected  void BrokerClient.deliverWithAck(java.lang.String dest_id, BrokerEvent[] events, int ack_type, long[] ack_seqn, BrokerTransactionalClient tx_client)
          Deliver multiple events on the given transaction.
 void BrokerClient.destroy()
          Destroy the client.
 void BrokerClusterPublisher.destroy()
          Destroy BrokerClusterPublisher.
 void BrokerMonitorClient.destroy()
          Destroys the Broker Monitor client.
 void BrokerServerClient.destroy()
          Destroy the server client.
 void BrokerAdminClient.destroyBroker()
          Destroy this Broker.
 void BrokerAdminClient.destroyClientById(java.lang.String client_id)
          Destroy the specified client.
 void BrokerAdminClient.destroyClientGroup(java.lang.String client_group_name, boolean force_destroy)
          Destroy the named client group.
 void BrokerAdminClient.destroyClientSubscriptionById(java.lang.String client_id, BrokerSubscription sub)
          Cancel a subscription for a client with matching event type and filter.
 void BrokerAdminClient.destroyClientSubscriptionsById(java.lang.String client_id, BrokerSubscription[] subs)
          Cancel multiple subscriptions for a client with matching event types and filters.
 void BrokerAdminClient.destroyClusterGateway(java.lang.String cluster_name, java.lang.String broker_name)
          Destroy a gateway to the specified cluster.
 void BrokerAdminClient.destroyEventType(java.lang.String event_type_name, boolean force_destroy)
          Destroy the named event type.
 void BrokerAdminClient.destroyEventTypeInfoset(java.lang.String event_type_name, java.lang.String infoset_name)
          Destroy the specified infoset for the specified event type.
 void BrokerAdminClient.destroyEventTypeInfosets(java.lang.String event_type_name, java.lang.String[] infoset_names)
          Destroy the specified infosets for the specified event type.
 void BrokerAdminClient.destroyEventTypes(java.lang.String[] event_type_names, boolean force_destroy)
          Destroy the named event types.
 void BrokerAdminClient.destroyTerritoryGateway(java.lang.String territory_name)
          Destroy a gateway to the specified territory.
 void BrokerClient.disconnect()
          Disconnect the client.
 void BrokerClusterPublisher.disconnect()
          Disconnect BrokerClusterPublisher.
 void BrokerAdminClient.disconnectClientById(java.lang.String client_id)
          Disconnect all sessions for the specified client.
 void BrokerAdminClient.disconnectClientSessionById(java.lang.String client_id, int session_id)
          Disconnect the specified session for the specified client.
static void BrokerClient.dispatch(int msecs)
          This function gets the next incoming event and passes it to the proper callback method.
static void BrokerTransactionalClient.dispatch(int msecs)
           
 boolean BrokerAdminClient.doesClientSubscriptionExistById(java.lang.String client_id, java.lang.String event_type_name, java.lang.String filter)
          Test if a subscription exists on the client with the given event type name and filter.
 boolean BrokerClient.doesSubscriptionExist(java.lang.String event_type_name, java.lang.String filter)
          Checks to see if the given subscription exists.
 int BrokerClient.endAdapterTransaction(java.lang.String transaction_id, int mode, boolean want_ack)
          Publishes an Adapter::endTransaction event for the given transaction ID.
static void BrokerTransactionalClient.endAll(BrokerTransactionalClient[] tx_clients, int end_state)
           
static void BrokerTransactionalClient.endAll(BrokerTransactionalClient[] tx_clients, java.lang.String externalId, int end_state)
          Ends the given list of current transactions.
protected  void BrokerClient.endExt(java.lang.String[] ext_ids, int tx_state)
          Ends the transaction
 void BrokerServerClient.endMetaDataBackup()
          Notifies the broker that backup of the meta-data is complete.
protected  void BrokerClient.endTr(long[] tx_ids, int tx_state)
           
 void BrokerTransactionalClient.endTransaction(long tx_id, int end_state)
           
 void BrokerTransactionalClient.endTransaction(java.lang.String external_id, int end_state)
          Ends the current transaction.
protected  void BrokerClient.endTx(long[] tx_ids, int tx_state)
          Ends the transaction
 void BrokerClusterPublisher.excludeBroker(java.lang.String brokerName)
          Exclude specified broker for cluster operations.
static void BrokerTypeCache.flushCache(BrokerClient client)
          Flush all the type definitions from the cache associated with the specified client.
 void BrokerTransactionalClient.forget(long tx_id)
          Forget the specified heuristically completed transaction.
 void BrokerTransactionalClient.forget(java.lang.String external_id)
          Forget the specified heuristically completed transaction.
static void BrokerTransactionalClient.forgetAll(BrokerTransactionalClient[] tx_clients, java.lang.String external_id)
          Forget the transaction with the specified external_id in the given list of transactional clients.
static void BrokerTransactionalClient.forgetAll(BrokerTransactionalClient tx_client, java.lang.String[] external_ids)
          Forget the transaction with the specified external_id in the given list of transactional clients.
protected  void BrokerClient.forgetExt(java.lang.String[] ext_ids)
           
 void BrokerAdminClient.forgetForced()
          Forcibly purge all heuristic transactions.
 void BrokerAdminClient.forgetForced(long tx_id)
          Forcibly purge a heuristic transaction.
 void BrokerAdminClient.forgetForced(long[] tx_ids)
          Forcibly purge a list of heuristic transactions.
protected  void BrokerClient.forgetTx(long[] tx_ids)
          Forgets the transaction This can be called at any time, hence informing the broker that the the current transaction should be marked invalid.
 java.lang.String BrokerFormat.format(BrokerEvent event)
          Return formatted string, using for resolving all event field references.
 java.lang.String BrokerFormat.format(BrokerEvent event, java.util.Locale locale)
          Return formatted string, using for resolving all event field references.
static java.lang.String BrokerFormat.format(BrokerEvent event, java.lang.String format_string)
          Format an event using a format string.
static java.lang.String BrokerFormat.format(BrokerEvent event, java.lang.String format_string, java.util.Locale locale)
          Format an event using a format string.
static BrokerEvent BrokerEvent.fromBinData(BrokerClient client, byte[] data)
           
static BrokerEvent BrokerEvent.fromBinData(BrokerClient client, byte[] data, java.lang.String event_type_name)
          Create an event using a byte array given out by toBinData().
 void BrokerEvent.fromObject(java.lang.Object obj)
          Deprecated. As of Java API v6.5.
 void BrokerEvent.fromObject(java.lang.Object obj, boolean readOnly)
          Deprecated. As of Java API v6.5.
 short[] BrokerClient.getAccessLabel()
          Get the access label for this client.
 java.util.Locale BrokerServerClient.getActiveFilterCollationLocale()
          Returns the active Broker Server Filter Collation locale.
 int BrokerServerClient.getActivePort()
          Get the base port currently being used by the Broker server.
 BrokerProcessInfo BrokerServerClient.getActiveProcessInfo()
          Get the process information currently in use by the Broker server.
 BrokerSSLConfig BrokerServerClient.getActiveSSLConfig()
          Get the SSL configuration currently in use on by the Broker server.
 BrokerSSLConfigV2 BrokerServerClient.getActiveSSLConfigV2()
          Get the SSL configuration currently in use on by the Broker server.
 BrokerSSLIdentity BrokerServerClient.getActiveSSLIdentity()
          Get the BrokerServer's SSL identity that is currently in use on by the Broker server.
 BrokerTraceEvent[] BrokerAdminClient.getActivityTraces(int seqn, int msecs)
          Get an array of broker activity traces.
 BrokerAccessControlList BrokerServerClient.getAdminACL()
          Get the Broker server's administrative access control list (ACL).
 BrokerClusterGatewayInfo[] BrokerAdminClient.getAllClusterGateways()
          Get the list of clusters accessible from this broker either through local gateways or gateways from other brokers.
 BrokerAllQueueStat[] BrokerAdminClient.getAllQueueStats()
          Get All client's statistics.
 BrokerTerritoryGatewayInfo[] BrokerAdminClient.getAllTerritoryGateways()
          Get the list of territories accessible from this broker either through local gateways or gateways from other brokers.
 int BrokerServerClient.getAuditOnErrorState()
          Returns 1 if the audit error state is enabled and 0 if the audit error state is disabled
 short[] BrokerServerClient.getAuditOperations()
          Returns the audit operations
 COM.activesw.api.client.BrokerAuditLogEntry[] BrokerServerClient.getAuditRecords(java.lang.Integer noRecords, java.lang.Integer AckId, int msecs)
          Reads the 'noRecords' number of audit records with AckId as the last accessed record id.
 int BrokerServerClient.getAuditState()
          Returns 1 if the audit state is enabled and 0 if the audit state is disabled
 boolean BrokerAccessControlList.getAuthNameState(java.lang.String name)
          Get the allow state for a single authenticator name.
 java.util.Locale[] BrokerServerClient.getAvailableLocales()
           
 COM.activesw.api.client.BrokerBasicAuthIdentity BrokerServerClient.getBasicAuthIdentity()
          Returns the Broker Server's basic authentication identity that is in use.
 boolean BrokerServerClient.getBasicAuthStatus()
          Returns whether basic authentication is configured on Broker Server.
 boolean BrokerEvent.getBooleanField(java.lang.String field_name)
          Get the value of a boolean field.
 boolean BrokerEvent.getBooleanProperty(java.lang.String property_name)
           
 boolean[] BrokerEvent.getBooleanSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a boolean sequence field.
 java.lang.String BrokerAdminClient.getBrokerDescription()
          Get the broker description
 java.lang.String BrokerClient.getBrokerName()
          Get the client's broker name.
 BrokerInfo[] BrokerServerClient.getBrokers()
          Get the list of Brokers in a given server.
 BrokerInfo[] BrokerAdminClient.getBrokersInCluster()
          Get the list of brokers in the cluster, including this broker.
 BrokerInfo[] BrokerAdminClient.getBrokersInTerritory()
          Get the list of brokers in the territory, including this broker.
 BrokerSSLCertificate BrokerClient.getBrokerSSLCertificate()
          Get the secure socket certificate for the broker.
 BrokerEvent BrokerAdminClient.getBrokerStats()
          Get the Broker statistics.
 BrokerClientQueueBrowserInfo BrokerClientQueueBrowser.getBrowserInfo()
           
 BrokerQueueBrowserInfo BrokerQueueBrowser.getBrowserInfo()
          Get information on the current queue browser.
 boolean BrokerServerClient.getBypassAuthCheckStatus()
          Returns whether to bypass basic authentication checks on Broker Server.
 byte BrokerEvent.getByteField(java.lang.String field_name)
          Get the value of a byte field.
 byte BrokerEvent.getByteProperty(java.lang.String property_name)
           
 byte[] BrokerEvent.getByteSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a byte sequence field.
 java.lang.String[] BrokerClient.getCanPublishNames()
          Get the list of event type names which this client can publish or deliver.
 java.lang.String[] BrokerClusterPublisher.getCanPublishNames()
          Get the list of event type names which this client can publish or deliver.
 BrokerTypeDef[] BrokerClient.getCanPublishTypeDefs()
          Get the definitions for the the event types this client can publish or deliver.
 java.lang.String[] BrokerClient.getCanSubscribeNames()
          Get the list of event type names which this client can subscribe to or have delivered to it.
 BrokerTypeDef[] BrokerClient.getCanSubscribeTypeDefs()
          Get the definitions for the the event types this client can subscribe to or have delivered to it.
 char BrokerEvent.getCharField(java.lang.String field_name)
          Get the value of a char field.
 char[] BrokerEvent.getCharSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a char sequence field.
 BrokerAccessControlList BrokerAdminClient.getClientGroupACL(java.lang.String client_group_name)
          Get the specified client group's access control list (ACL).
 java.lang.String[] BrokerAdminClient.getClientGroupCanPublishList(java.lang.String client_group_name)
          Get the list of event types the client group can publish or deliver.
 java.lang.String[] BrokerAdminClient.getClientGroupCanSubscribeList(java.lang.String client_group_name)
          Get the list of event types the client group can subscribe to or have delivered to it.
 BrokerClientGroupInfo BrokerAdminClient.getClientGroupInfo(java.lang.String client_group_name)
          Get the specified client group's information.
 BrokerClientGroupInfo[] BrokerAdminClient.getClientGroupInfos(java.lang.String[] client_group_names)
          Get the client group information for the requested client groups.
 java.lang.String[] BrokerAdminClient.getClientGroupLogAcknowledgeList(java.lang.String client_group_name)
          Get the list of event types that are logged when they are acknowledged by a client in the the specified client group.
 java.lang.String[] BrokerAdminClient.getClientGroupLogPublishList(java.lang.String client_group_name)
          Get the list of event types that are logged when published or delivered by a client in the the specified client group.
 java.lang.String[] BrokerAdminClient.getClientGroupNames()
          Get the list of client group names from the broker.
 BrokerEvent BrokerAdminClient.getClientGroupStats(java.lang.String client_group_name)
          Get the specified client group's statistics.
 java.lang.String[] BrokerAdminClient.getClientGroupsWhichCanLogAcknowledge(java.lang.String event_type_name)
          Get the list of client groups which can log acknowledgement of the specified event type.
 java.lang.String[] BrokerAdminClient.getClientGroupsWhichCanLogPublish(java.lang.String event_type_name)
          Get the list of client groups which can log publish of the specified event type.
 java.lang.String[] BrokerAdminClient.getClientGroupsWhichCanPublish(java.lang.String event_type_name)
          Get the list of client groups which can publish the specified event type.
 java.lang.String[] BrokerAdminClient.getClientGroupsWhichCanSubscribe(java.lang.String event_type_name)
          Get the list of client groups which can subscribe the specified event type.
 java.lang.String[] BrokerAdminClient.getClientIds()
          Get the IDs of all the clients in the Broker.
 java.lang.String[] BrokerAdminClient.getClientIdsByClientGroup(java.lang.String client_group_name)
          Get the IDs of all the clients in the Broker which are members of the specified client group.
 java.lang.String[] BrokerAdminClient.getClientIdsWhichAreSubscribed(java.lang.String event_type_name)
          Get the IDs of all the clients in the Broker which are subscribed to the specified event type.
 BrokerClientInfo BrokerClient.getClientInfo()
          Get the current client's information.
 BrokerClientInfo BrokerAdminClient.getClientInfoById(java.lang.String client_id)
          Get the specified client's information.
 BrokerClientInfo[] BrokerAdminClient.getClientInfosById(java.lang.String[] client_ids)
          Get the client information for the requested clients.
 BrokerEvent BrokerClient.getClientInfoset()
          Get the infoset for this client.
 BrokerEvent BrokerAdminClient.getClientInfosetById(java.lang.String client_id)
          Get the infoset for this client.
 BrokerClientQueueBrowserInfo[] BrokerAdminClient.getClientQueueBrowsers(java.lang.String client_id)
          Gets the list of QueueBrowsers opened by the specified client.
 int BrokerClient.getClientSSLEncryptionLevel()
          Get the secure socket encryption level.
 BrokerEvent BrokerAdminClient.getClientStatsById(java.lang.String client_id)
          Get a client's statistics.
 BrokerEvent[] BrokerAdminClient.getClientStatsByIds(java.lang.String[] client_ids)
          Get statistics for the list of client IDs.
 BrokerSubscription[] BrokerAdminClient.getClientSubscriptionsById(java.lang.String client_id)
          Get the list of open subscriptions for a client.
 BrokerAccessControlList BrokerAdminClient.getClusterACL()
          Get the access control list (ACL) which brokers in the cluster are using to accept connections from other brokers in their cluster.
 BrokerAccessControlList BrokerAdminClient.getClusterGatewayACL(java.lang.String cluster_name)
          Get the access control list (ACL) which this broker is using to accept connections from the other broker across the gateway.
 int BrokerAdminClient.getClusterGatewayKeepAlive(java.lang.String cluster_name)
          Returns KeepAlive interval on the gateway.
 boolean BrokerAdminClient.getClusterGatewayRefuseAllUpdates(java.lang.String cluster_name)
          Returns whether a cluster gateway refuses all updates.
 BrokerSharedEventTypeInfo[] BrokerAdminClient.getClusterGatewaySharedEventTypes(java.lang.String cluster_name, java.lang.String broker_name)
          Get the information on event types shared across a cluster gateway.
 BrokerEvent BrokerAdminClient.getClusterGatewayStats(java.lang.String cluster_name, java.lang.String broker_name)
          Get the cluster gateway statistics.
 BrokerClusterInfo BrokerAdminClient.getClusterInfo()
          Get the cluster's settings.
 BrokerEvent BrokerClusterPublisher.getClusterPublisherInfo()
          Get the cluster publisher info.
 BrokerEvent BrokerClusterPublisher.getClusterPublisherStats()
          Get the cluster publisher statistics.
 boolean BrokerAdminClient.getClusterStaticGatewayForwarding(java.lang.String cluster_name)
          Get current static gateway forwarding status.
 BrokerEvent BrokerAdminClient.getClusterStats()
          Get the cluster statistics.
 BrokerDate BrokerEvent.getDateField(java.lang.String field_name)
          Get the value of a date field.
 BrokerDate[] BrokerEvent.getDateSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a date sequence field.
 java.lang.String BrokerServerClient.getDefaultBrokerName()
          Get the name of the default Broker in the server.
 java.lang.String BrokerAdminTypeDef.getDescription()
          Get the type's description.
 java.lang.String BrokerServerClient.getDescription()
          Get the Broker server description.
 java.lang.String BrokerTypeDef.getDescription()
          Get the type's description.
 java.lang.String BrokerServerClient.getDNFromKeystore(java.lang.String keystore, java.lang.String password, BrokerSSLConfigV2.KeystoreType keystoreType)
          Get the distinguished name in the given keystore on the broker server.
 java.lang.String[] BrokerServerClient.getDNsFromCertFile(java.lang.String certificate_file, java.lang.String password)
          Get the list of distinguished names available in the given certificate file on the broker server.
 double BrokerEvent.getDoubleField(java.lang.String field_name)
          Get the value of a double field.
 double BrokerEvent.getDoubleProperty(java.lang.String property_name)
           
 double[] BrokerEvent.getDoubleSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a double sequence field.
 BrokerEvent BrokerClient.getEvent(int msecs)
          Gets a single event from this client's queue.
 BrokerEvent BrokerTransactionalClient.getEvent(int msecs)
          Gets a single event from this client's queue, that is part of the given open transaction context.
protected  BrokerEvent BrokerClient.getEvent(int msecs, BrokerTransactionalClient tx_client)
          Gets a single event from this client's queue, that is part of the given open transaction context.
 BrokerAdminTypeDef BrokerAdminClient.getEventAdminTypeDef(java.lang.String event_type_name)
          Get the specified event type's definition.
 BrokerAdminTypeDef[] BrokerAdminClient.getEventAdminTypeDefs(java.lang.String[] event_type_names)
          Get the definitions for the requested event types.
 BrokerAdminTypeDef[] BrokerAdminClient.getEventAdminTypeDefsByScope(java.lang.String scope_name)
          Get the definitions for the event types within the named scope.
 BrokerEvent BrokerEvent.getEventField(java.lang.String field_name)
          Get the value of an event field.
 boolean BrokerAdminClient.getEventLogging()
           
 boolean BrokerClient.getEventLogging()
           
 BrokerEvent[] BrokerClient.getEvents(int max_events, int msecs)
          Gets one or more events from this client's queue.
 BrokerEvent[] BrokerTransactionalClient.getEvents(int max_events, int msecs)
          Gets one or more events from this client's queue, that is a part of the the give open transaction context.
protected  BrokerEvent[] BrokerClient.getEvents(int max_events, int msecs, BrokerTransactionalClient tx_client)
          Gets one or more events from this client's queue, that is a part of the the give open transaction context.
 BrokerEvent[] BrokerClient.getEvents(int max_events, long seqn, int msecs)
          The sequence number is the event to acknowledge through.
 BrokerEvent[] BrokerTransactionalClient.getEvents(int max_events, long seqn, int msecs)
          This request gets processed only after the BrokerTransactionalClient is is committed.
protected  BrokerEvent[] BrokerClient.getEvents(int max_events, long seqn, int msecs, BrokerTransactionalClient tx_client)
          This request gets processed only after the given BrokerTransactionalClient is is committed.
 BrokerEvent[] BrokerEvent.getEventSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of an event sequence field.
 BrokerTypeDef BrokerClient.getEventTypeDef(java.lang.String event_type_name)
          Get the specified event type's definition.
 BrokerTypeDef[] BrokerClient.getEventTypeDefs(java.lang.String[] event_type_names)
          Get the definitions for the requested event types.
 BrokerEvent BrokerClient.getEventTypeInfoset(java.lang.String event_type_name, java.lang.String infoset_name)
          Get the specified infoset for the specified event type.
 java.lang.String[] BrokerClient.getEventTypeInfosetNames(java.lang.String event_type_name)
          Get the list of infosets names for an event type.
 BrokerEvent[] BrokerClient.getEventTypeInfosets(java.lang.String event_type_name, java.lang.String[] infoset_names)
          Get the requested infosets for the specified event type.
 java.lang.String[] BrokerClient.getEventTypeNames()
          Get the complete list of event type names from the broker.
 java.lang.String[] BrokerClient.getEventTypeNames(java.lang.String scope_name)
          Get the list of event type names from the broker which are a member of the specified event type scope.
 BrokerEvent BrokerAdminClient.getEventTypeStats(java.lang.String event_type_name)
          Get statistics for an event type.
 BrokerField BrokerEvent.getField(java.lang.String field_name)
          Get the value of field.
 BrokerAdminTypeDef BrokerAdminTypeDef.getFieldDef(java.lang.String field_name)
          Get the type of a field as a BrokerAdminTypeDef.
 BrokerTypeDef BrokerTypeDef.getFieldDef(java.lang.String field_name)
          Get the BrokerTypeDef for a given field.
 BrokerTypeDef BrokerTypeDef.getFieldDefInternal(java.lang.String full_field_name, java.lang.String field_name)
           
 java.lang.String[] BrokerAdminTypeDef.getFieldNames(java.lang.String field_name)
          Get the list of field names in an event type.
 java.lang.String[] BrokerEvent.getFieldNames(java.lang.String field_name)
          Get the list of field names in an event.
 java.lang.String[] BrokerTypeDef.getFieldNames(java.lang.String field_name)
          Get the list of field names in an event type.
 short BrokerAdminTypeDef.getFieldType(java.lang.String field_name)
          Get the type for a given field.
 short BrokerEvent.getFieldType(java.lang.String field_name)
          Gets the type for the specified field.
 short BrokerTypeDef.getFieldType(java.lang.String field_name)
          Get the type for a given field.
protected  java.util.Locale BrokerServerClient.getFilterCollationLocaleInternal(boolean saved)
           
 BrokerFilterDescriptor[] BrokerQueueBrowser.getFilters()
          Get the current filters set on the queue browser.
 java.lang.String BrokerServerClient.getFipsMode()
          Returns the FIPS mode set on the Broker Server.
 float BrokerEvent.getFloatField(java.lang.String field_name)
          Get the value of a float field.
 float BrokerEvent.getFloatProperty(java.lang.String property_name)
           
 float[] BrokerEvent.getFloatSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a float sequence field.
 java.util.Map<java.lang.String,java.lang.String> BrokerServerClient.getHardwareInfo()
          Get the Broker server hardware info string.
 BrokerEvent BrokerAdminClient.getHeuristicTransactions()
          Get the list of heuristic transactions in the Broker transaction manager.
 int BrokerEvent.getIntegerField(java.lang.String field_name)
          Get the value of an integer field.
 int[] BrokerEvent.getIntegerSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of an integer sequence field.
 int BrokerEvent.getIntProperty(java.lang.String property_name)
           
 java.lang.String BrokerServerClient.getIssuerDNFromKeystore(java.lang.String keystore, java.lang.String password, BrokerSSLConfigV2.KeystoreType keystoreType)
          Get the issuer distinguished name in the given keystore on the broker server.
 java.util.Calendar BrokerDate.getJavaCalendar()
          Get the date as a Java Calendar object.
 java.util.Date BrokerDate.getJavaDate()
          Get the date as a Java Date object.
 COM.activesw.api.client.BrokerJMSEvent BrokerClient.getJMSClientInfoset()
           
 COM.activesw.api.client.BrokerJMSEvent[] BrokerClient.getJMSEvents(int max_events, long seqn, int msecs)
           
 COM.activesw.api.client.BrokerJMSEvent[] BrokerTransactionalClient.getJMSEvents(int max_events, long seqn, int msecs)
          This request gets processed only after the BrokerTransactionalClient is is committed.
protected  COM.activesw.api.client.BrokerJMSEvent[] BrokerClient.getJMSEvents(int max_events, long seqn, int msecs, BrokerTransactionalClient tx_client)
           
 long BrokerClient.getLastPublishSequenceNumber()
          Get the highest sequence number used by this client in a publish or deliver call.
 java.lang.String BrokerServerClient.getLicense()
          Deprecated. Deprecated in webMethods Broker 9.0, instead use BrokerServerClient.getLicenseFileName()
 java.lang.String BrokerServerClient.getLicenseContent()
          Get the Broker Server license file content.
 java.lang.String BrokerServerClient.getLicenseFileName()
          Get the Broker Server license file name.
 BrokerClusterGatewayInfo[] BrokerAdminClient.getLocalClusterGateways()
          Get the list of clusters this broker is a gateway for.
 BrokerTerritoryGatewayInfo[] BrokerAdminClient.getLocalTerritoryGateways()
          Get the list of territories this broker is a gateway for.
 java.lang.String[] BrokerClient.getLogAcknowledgeNames()
          Get the list of event types which can be logged when clients of this client group acknowledges them.
 BrokerLogConfig BrokerServerClient.getLogConfig()
          Get the Broker server logging configuration.
 BrokerEvent[] BrokerAdminClient.getLogEvents(int from_index, int max_events, int msecs)
          Gets one or more events from the brokers event log at the given zero-based index.
 int BrokerAdminClient.getLogLength()
          Returns the number of events in the broker's log.
 BrokerLogConfigEntry BrokerLogConfig.getLogOutput(java.lang.String code)
          Get the value of a single log output.
 java.lang.String[] BrokerClient.getLogPublishNames()
          Get the list of event types that are logged when published by clients of this client's client group.
 BrokerLogConfigEntry BrokerLogConfig.getLogTopic(java.lang.String code)
          Get the value of a single log topic's state.
 long BrokerEvent.getLongField(java.lang.String field_name)
          Get the value of a long field.
 long BrokerEvent.getLongProperty(java.lang.String property_name)
           
 long[] BrokerEvent.getLongSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a long sequence field.
 java.lang.String[] BrokerServerClient.getMetaDataStorageFiles()
          Get the path names for the MetaData storage files.
 int BrokerServerClient.getMonitorPort()
          Get the broker monitor port managing the current Broker Server.
static java.lang.String BrokerClient.getPlatformInfo(java.lang.String key)
          Get a platform info value.
 int BrokerAdminClient.getPostPrepareTimeout()
          Get the default post-prepare timeout.
 int BrokerAdminClient.getPostPrepareTimeoutAction()
          Get the post-prepare timeout action.
 int BrokerAdminClient.getPrePrepareTimeout()
          Get the default pre-prepare timeout.
 java.lang.String BrokerServerClient.getProductDisplayName()
          Get the Product display name.
 java.lang.Object BrokerEvent.getProperty(java.lang.String property_name)
           
 java.lang.String[] BrokerEvent.getPropertyNames(java.lang.String field_name)
          Get the list of property names in an event.
 int BrokerServerClient.getPublicationProcessingState()
          Get the broker server publication processing state.
 int BrokerClient.getQueueLength()
          Get the number of events currently in the client's queue.
 int BrokerAdminClient.getRecoverMode()
          Gets the global recover mode.
 int BrokerAdminClient.getRemoteBrokerKeepAlive(java.lang.String broker_name)
          Returns KeepAlive interval for a remote broker.
 int BrokerEvent.getRetrievedSessionId()
          Get the session id on which this event was retrieved.
 boolean BrokerEvent.getRetrievedStatus()
          Get the acknowledgement status of the event.
 java.lang.String[] BrokerServerClient.getRootDNsFromCertFile(java.lang.String certificate_file, java.lang.String password)
          Get the list of trusted root distinguished names available in the given certificate file on the broker server.
 java.lang.String[] BrokerServerClient.getRootDNsFromTruststore(java.lang.String truststore, BrokerSSLConfigV2.TruststoreType truststoreType)
          Get the list of trusted root distinguished names available in the given truststore on the broker server.
 java.util.Locale BrokerServerClient.getSavedFilterCollationLocale()
          Returns the saved Broker Server Filter Collation locale.
 BrokerSSLConfig BrokerServerClient.getSavedSSLConfig()
          Get the SSL configuration to be used next time the Broker server is started.
 BrokerSSLConfigV2 BrokerServerClient.getSavedSSLConfigV2()
          Get the SSL configuration to be used next time the Broker server is started.
 BrokerSSLIdentity BrokerServerClient.getSavedSSLIdentity()
          Get the BrokerServer's SSL identity that will be used the next time the Broker server is restarted.
 java.lang.String[] BrokerClient.getScopeNames()
          Get the complete list of event type scope names from the broker.
 BrokerField BrokerEvent.getSequenceField(java.lang.String field_name, int offset, int max_n)
          Get the value of a sequence field.
 int BrokerEvent.getSequenceFieldSize(java.lang.String field_name)
          Get the size of a sequence field.
 java.util.Locale BrokerClient.getServerFilterCollationLocale()
          Returns the active Broker Server Filter Collation locale.
 BrokerServerLogEntry[] BrokerServerClient.getServerLogEntries(BrokerDate first_entry, java.lang.String locale, int num_entries)
           
 BrokerServerLogEntry[] BrokerMonitorClient.getServerLogEntries(int base_port, BrokerDate first_entry, java.lang.String locale, int num_entries)
          Get a set of server log entries, for the server listening on the given base port number.
 COM.activesw.api.client.BrokerServerLogInfo BrokerServerClient.getServerLogStatus()
          Get the server log status.
 COM.activesw.api.client.BrokerServerLogInfo BrokerMonitorClient.getServerLogStatus(int base_port)
          Get the server log status, for the server listening on the given base port number.
static int BrokerServerClient.getServerProcessRunStatus(java.lang.String broker_host)
          Specifies whether the Broker Server is online, stopped, starting, stopping, unresponsive, failed, or unknown.
static int BrokerServerClient.getServerProcessRunStatus(java.lang.String broker_monitor_host, int monitorPort, int brokerPort)
           
 int BrokerMonitorClient.getServerRunStatus(int port)
          Specifies whether the Broker Server is online, stopped, starting, stopping, unresponsive, failed, or unknown.
 COM.activesw.api.client.BrokerServerInfo[] BrokerMonitorClient.getServers()
          Get the configuration details of all Broker Servers on the host.
 BrokerFilterDescriptor[] BrokerClient.getSessionFilters()
          Get the current filter used for event retrieval operations.
 short BrokerEvent.getShortField(java.lang.String field_name)
          Get the value of a short field.
 short BrokerEvent.getShortProperty(java.lang.String property_name)
           
 short[] BrokerEvent.getShortSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a short sequence field.
 short[] BrokerEvent.getShortSeqFieldInternal(java.lang.String field_name, int offset, int max_n)
           
static BrokerSSLCertificate BrokerConnectionDescriptor.getSSLCertificate(java.lang.String certificate_file, java.lang.String trust_file, COM.activesw.api.client.enums.KeystoreType keystore_type, COM.activesw.api.client.enums.TruststoreType truststore_type, java.lang.String password)
          Get the SSL certificate for a specific distinguished name from a certificate file.
static BrokerSSLCertificate BrokerConnectionDescriptor.getSSLCertificate(java.lang.String certificate_file, java.lang.String password, java.lang.String distinguished_name)
          Get the SSL certificate for a specific distinguished name from a certificate file.
static java.lang.String[] BrokerConnectionDescriptor.getSSLCertificateDns(java.lang.String certificate_file, java.lang.String password)
          Get the list of distinguished names from a certificate file.
static java.lang.String[] BrokerConnectionDescriptor.getSSLCertificateDns(java.lang.String certificate_file, java.lang.String trust_file, COM.activesw.api.client.enums.KeystoreType keystore_type, COM.activesw.api.client.enums.TruststoreType truststore_type, java.lang.String password)
          Get the list of distinguished names from a certificate file.
static java.lang.String[] BrokerConnectionDescriptor.getSSLRootDns(java.lang.String keystore, java.lang.String truststore, COM.activesw.api.client.enums.KeystoreType keystore_type, COM.activesw.api.client.enums.TruststoreType truststore_type, java.lang.String password)
          Get the list of trusted root distinguished names from a certificate file.
 BrokerSSLStatus BrokerServerClient.getSSLStatus()
          Get the current status of the Broker server SSL configuration.
 int BrokerClient.getStateShareLimit()
          Get the number of clients allowed to be connected using this client ID at one time.
 boolean BrokerAdminClient.getStaticGatewayForwarding(java.lang.String territory_name)
          Get current static gateway forwarding status.
 BrokerEvent BrokerServerClient.getStats()
          Get the Broker server statistics.
 BrokerEvent BrokerServerClient.getStorageStats()
          Get the Broker server storage statistics.
 int BrokerAdminTypeDef.getStorageType()
          Get the type's storage type.
 int BrokerTypeDef.getStorageType()
          Get the type's storage type.
 java.lang.String BrokerEvent.getStringField(java.lang.String field_name)
          Get the value of a string field.
 java.lang.String BrokerEvent.getStringProperty(java.lang.String property_name)
           
 java.lang.String[] BrokerEvent.getStringSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a string sequence field.
 BrokerEvent BrokerEvent.getStructFieldAsEvent(java.lang.String field_name)
          Get the value of a structure field.
 BrokerEvent[] BrokerEvent.getStructSeqFieldAsEvents(java.lang.String field_name, int offset, int max_n)
          Get the value of a structure sequence field.
 BrokerSubscription[] BrokerClient.getSubscriptions()
          Get the list of open subscriptions.
 int BrokerEvent.getTag()
          Get the event's 'tag' envelope field.
 BrokerAccessControlList BrokerAdminClient.getTerritoryACL()
          Get the access control list (ACL) which brokers in the territory are using to accept connections from other brokers in their territory.
 BrokerAccessControlList BrokerAdminClient.getTerritoryGatewayACL(java.lang.String territory_name)
          Get the access control list (ACL) which this broker is using to accept connections from the other broker across the gateway.
 int BrokerAdminClient.getTerritoryGatewayKeepAlive(java.lang.String territory_name)
          Returns KeepAlive interval on the gateway.
 boolean BrokerAdminClient.getTerritoryGatewayRefuseAllUpdates(java.lang.String territory_name)
          Returns whether a territory gateway refuses all updates.
 BrokerSharedEventTypeRefuseUpdateInfo[] BrokerAdminClient.getTerritoryGatewayRefuseEventTypeUpdates(java.lang.String territory_name)
          Returns which event types a territory gateway refuses updates for.
 BrokerSharedEventTypeInfo[] BrokerAdminClient.getTerritoryGatewaySharedEventTypes(java.lang.String territory_name)
          Get the information on event types shared across a territory gateway.
 BrokerEvent BrokerAdminClient.getTerritoryGatewayStats(java.lang.String territory_name)
          Get the territory gateway statistics.
 BrokerTerritoryInfo BrokerAdminClient.getTerritoryInfo()
          Get the territory's settings.
 java.lang.String BrokerClient.getTerritoryName()
          Get the territory name of the client's broker.
 java.lang.String BrokerClusterPublisher.getTerritoryName()
          Get the territory name of the client's broker.
 BrokerEvent BrokerAdminClient.getTerritoryStats()
          Get the territory statistics.
 int BrokerAdminTypeDef.getTimeToLive()
          Get the type's time-to-live.
 int BrokerTypeDef.getTimeToLive()
          Get the type's time-to-live.
 BrokerEvent BrokerAdminClient.getTransactions()
          Get the list of current transactions in the Broker transaction manager.
 BrokerEvent BrokerAdminClient.getTransactionsByClient(java.lang.String client_id)
          Get the list of a client's transactions in the Broker transaction manager.
 int BrokerTransactionalClient.getTransactionTimeout()
           
protected  int BrokerClient.getTxTimeout(long tx_id)
           
 BrokerTypeDef BrokerEvent.getTypeDef()
          Get the event's type definition.
 char BrokerEvent.getUCCharField(java.lang.String field_name)
          Get the value of a unicode char field.
 char[] BrokerEvent.getUCCharSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a unicode char sequence field.
 java.lang.String BrokerEvent.getUCStringField(java.lang.String field_name)
          Get the value of a unicode string field.
 java.lang.String[] BrokerEvent.getUCStringSeqField(java.lang.String field_name, int offset, int max_n)
          Get the value of a unicode string sequence field.
 BrokerEvent BrokerServerClient.getUsageStats()
          Get the Broker server system usage statistics.
 boolean BrokerAccessControlList.getUserNameState(java.lang.String name)
          Get the allow state for a single user name.
 int BrokerAdminTypeDef.getValidationType()
          Get the type's validation type.
 int BrokerTypeDef.getValidationType()
          Get the type's validation type.
 java.lang.String BrokerMonitorClient.getVersion()
          Get the version of the Broker Monitor.
 java.lang.String BrokerServerClient.getVersion()
          Get the Broker server version string.
 void BrokerClusterPublisher.includeBroker(java.lang.String brokerName)
          Include specified broker for cluster operations.
 void BrokerClient.incrementRedeliveryCount(long seqn)
          Increments the redelivery count on the single event specified.
 void BrokerLockedClientQueueBrowser.insertEventsAtHead(BrokerEvent[] events)
          Insert events in into the queue.
 void BrokerLockedForwardQueueBrowser.insertEventsAtHead(BrokerEvent[] events)
          Throws an UnsupportedOperationException.
 void BrokerLockedQueueBrowser.insertEventsAtHead(BrokerEvent[] events)
          Insert events in into the queue.
 void BrokerLockedClientQueueBrowser.insertEventsAtTail(BrokerEvent[] events)
          Insert events in into the queue.
 void BrokerLockedForwardQueueBrowser.insertEventsAtTail(BrokerEvent[] events)
          Insert events in into the queue.
 void BrokerLockedQueueBrowser.insertEventsAtTail(BrokerEvent[] events)
          Insert events in into the queue.
 void BrokerAdminTypeDef.insertFieldDef(java.lang.String field_name, int index, BrokerAdminTypeDef field_def)
          Insert the a field using a BrokerAdminTypeDef.
 void BrokerClient.interruptCheckForEvents()
          Interrupt any blocked awCheckForEvents call on the current client session.
static void BrokerClient.interruptDispatch()
          Interrupt the current dispatch call.
static void BrokerTransactionalClient.interruptDispatch()
           
 void BrokerClient.interruptGetEvents()
          Interrupt the current getEvent call for the client.
 void BrokerTransactionalClient.interruptGetEvents()
          Interrupt the current getEvents() call for the client.
 boolean BrokerClient.isClientPending()
          Check if any events are pending for the client.
 boolean BrokerEvent.isFieldSet(java.lang.String field_name)
          Determine if the specified field is set in the event.
 boolean BrokerEvent.isFieldSetInternal(java.lang.String field_name)
           
static boolean BrokerClient.isPending()
          Check if any events are pending for any client.
 boolean BrokerClientPoll.isReady(int operations)
          Check if operations are ready.
 boolean BrokerClientPoll.isRequested(int operations)
          Check if operations are requested.
 boolean BrokerServerClient.isStreamingEnabled()
          Returns true if streaming is enabled on the Broker Server.
 void BrokerClient.jmsClientPublish(COM.activesw.api.client.BrokerJMSEvent[] events, boolean async)
           
 void BrokerTransactionalClient.jmsClientPublish(COM.activesw.api.client.BrokerJMSEvent[] events, boolean async)
          Publish multiple events on the given transaction.
protected  void BrokerClient.jmsClientPublish(COM.activesw.api.client.BrokerJMSEvent[] events, boolean async, BrokerTransactionalClient tx_client)
           
 BrokerJoinFailureInfo BrokerAdminClient.joinTerritory(java.lang.String broker_host, java.lang.String broker_name)
          Have this broker join the territory of the specified other broker.
 void BrokerAdminClient.leaveCluster(int msecs, boolean forced)
          Make this broker leave its current cluster.
 void BrokerAdminClient.leaveTerritory(int msecs, boolean forced)
          Make this broker leave its current territory.
 void BrokerClusterPublisher.localPublish(BrokerEvent event)
          Publish one event to clients on the local broker only.
 void BrokerClusterPublisher.localPublish(BrokerEvent[] events)
          Publish multiple events to clients on the local broker only.
 BrokerEvent[] BrokerClusterPublisher.localPublishRequestAndWait(BrokerEvent event, int msecs)
          Publish one request event and wait for replies.
static void BrokerClient.mainLoop()
          A limited main loop which executes until told to stop.
static void BrokerTransactionalClient.mainLoop()
           
 java.lang.String BrokerClient.makeTransactionId()
          Generate a unique transaction ID for use in transaction operations.
 int BrokerClient.makeUniqueSubId()
          Generates a unique subscription id.
 boolean BrokerFilter.match(BrokerEvent event)
          Check if the given event matches the filter.
 void BrokerLockedClientQueueBrowser.modifyEvents(long[] seqns, BrokerEvent[] events)
          Modify events in the queue.
 void BrokerLockedForwardQueueBrowser.modifyEvents(long[] seqns, BrokerEvent[] events)
          Modify events in the queue.
 void BrokerLockedQueueBrowser.modifyEvents(long[] seqns, BrokerEvent[] events)
          Modify events in the queue.
 void BrokerClient.negativeAcknowledge(long seqn)
          Negative acknowledges the single event specified.
 void BrokerTransactionalClient.negativeAcknowledge(long seqn)
          Negatively acknowledge the single event specified.
 void BrokerClient.negativeAcknowledge(long[] seqn)
          Negative acknowledges the events specified.
 void BrokerTransactionalClient.negativeAcknowledge(long[] seqns)
          Negative acknowledge the array of events with the given seqn numbers.
protected  void BrokerClient.negativeAcknowledgeInternal(long[] seqn, long tx_id)
           
static BrokerClient BrokerClient.newOrReconnect(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Attempts to create the client.
static BrokerClient BrokerTransactionalClient.newOrReconnect(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Attempts to create the broker client.If the creation fails because the client already exists, then it reconnects to the client instead.
static BrokerClusterPublisher BrokerClusterPublisher.newOrReconnect(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc, BrokerConnectionDescriptor mon_desc)
          Attempts to create BrokerClusterPublisher.
static BrokerAdminClient BrokerAdminClient.newOrReconnectAdmin(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Attempts to create the administrative client.
static BrokerTransactionalClient BrokerTransactionalClient.newOrReconnectTransactionalClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Attempts to create the transactional client.
 void BrokerClient.newSubscription(BrokerSubscription sub)
          Subscribe to all events of a given event type.
 void BrokerClient.newSubscription(int sub_id, java.lang.String event_type_name, java.lang.String filter)
          Subscribe to all events of a given event type which match the specified filter.
 void BrokerClient.newSubscription(java.lang.String event_type_name, java.lang.String filter)
          Subscribe to all events of a given event type which match the specified filter.
 void BrokerClient.newSubscriptions(BrokerSubscription[] subs)
          Open multiple subscriptions at one time.
protected  long BrokerClient.newTx(java.lang.String external_id, int existsFlag, long timeout, long tx_id)
          Creates a transaction context that can be used to aggregate multiple publish and acknowledge operations into a single unit of work that can be committed or aborted atomically.
 void BrokerAdminTypeDef.orderFields(java.lang.String field_name, java.lang.String[] new_field_names)
          Set the order of fields in a type.
 void BrokerServerClient.pausePublishProcessing()
          pause broker server publication processing.
 void BrokerClient.ping()
          Checks for network connectivity to the Broker using the default client timeout.
 void BrokerClient.ping(int msecs)
          Checks for network connectivity to the Broker.
static BrokerClientPoll[] BrokerClient.poll(BrokerClientPoll[] polls, int msecs)
          Allows one or more clients to polled for pending operations, returning only after at least one client has a ready operation, the current thread is interrupted or the given timeout has expired.
 int BrokerTransactionalClient.prepare(long tx_id)
          Prepares the transactions with the specified broker transaction id for commit.
 int BrokerTransactionalClient.prepare(java.lang.String external_id)
          Prepares the transactions with the specified external_id for commit.
static void BrokerTransactionalClient.prepareAll(BrokerTransactionalClient[] tx_clients, java.lang.String external_id)
          Prepare the specified transaction for commit.
static void BrokerTransactionalClient.prepareAll(BrokerTransactionalClient tx_client, java.lang.String[] external_ids)
          Prepare the specified list of transactions for commit.
protected  void BrokerClient.prepareExt(java.lang.String[] ext_ids)
           
protected  int BrokerClient.prepareTx(long[] tx_ids)
          Prepares the transaction
 void BrokerClient.prime()
          Tell the client to send a request for events but not block.
 void BrokerClient.prime(int num)
          Tell the client to send a request for events but not block.
 void BrokerTransactionalClient.prime(int num)
          Tell the client to send a request for events but not block.
protected  void BrokerClient.prime(int num, BrokerTransactionalClient tx_client)
           
static void BrokerClient.primeAllClients()
          Tell all clients to send a request for events but not block.
static void BrokerClient.primeAllClients(int num)
          Tell all clients to send a request for events but not block.
 void BrokerClient.primeWithAck(int num)
           
 void BrokerTransactionalClient.primeWithAck(int num)
           
protected  void BrokerClient.primeWithAck(int num, BrokerTransactionalClient tx_client)
           
 void BrokerMonitorClient.pruneMonitorLog(int base_port, BrokerDate older_than)
          Delete entries from the Broker Monitor's log.
 void BrokerServerClient.pruneServerLog(BrokerDate older_than)
          Delete entries from the server log.
 void BrokerClient.publish(BrokerEvent event)
          Publish one event.
 void BrokerClusterPublisher.publish(BrokerEvent event)
          Publish one event.
 void BrokerTransactionalClient.publish(BrokerEvent event)
          Publish one event with the given transaction id.
 void BrokerClient.publish(BrokerEvent[] events)
          Publish multiple events.
 void BrokerClusterPublisher.publish(BrokerEvent[] events)
          Publish multiple events.
protected  void BrokerClient.publish(BrokerEvent[] events, BrokerTransactionalClient tx_client)
          Publish multiple events on the given transaction.
protected  void BrokerClient.publish(BrokerEvent event, BrokerTransactionalClient tx_client)
          Publish one event with the given transaction id.
 void BrokerTransactionalClient.publish(COM.activesw.api.client.BrokerJMSEvent event)
          Publish one event with the given transaction id.
 BrokerEvent[] BrokerClient.publishRequestAndWait(BrokerEvent event, int msecs)
          Publish one request event to the broker and wait for replies.
 BrokerEvent[] BrokerClusterPublisher.publishRequestAndWait(BrokerEvent event, int msecs)
          Publish one request event and wait for replies.
 BrokerEvent[] BrokerTransactionalClient.publishRequestAndWait(BrokerEvent event, int msecs)
           
 void BrokerClient.publishWithAck(BrokerEvent[] events, int ack_type, long[] ack_seqn)
          Publish multiple events.
 void BrokerTransactionalClient.publishWithAck(BrokerEvent[] events, int ack_type, long[] ack_seqn)
          Publish multiple events for the given transaction.
protected  void BrokerClient.publishWithAck(BrokerEvent[] events, int ack_type, long[] ack_seqn, BrokerTransactionalClient tx_client)
          Publish multiple events for the given transaction.
static BrokerCompleteCollection BrokerCompleteCollection.read(java.io.Reader reader)
          Creates a new BrokerCompleteCollection based upon textual input.
static BrokerCompleteCollection BrokerCompleteCollection.readFile(java.lang.String filename)
          Creates a new BrokerCompleteCollection based upon textual input read from a file.
static BrokerClient BrokerClient.reconnect(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Reconnects a client.
static BrokerClient BrokerTransactionalClient.reconnect(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Reconnects a client.
static BrokerClusterPublisher BrokerClusterPublisher.reconnect(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc, BrokerConnectionDescriptor mon_desc)
          Reconnects BrokerClusterPublisher.
static BrokerAdminClient BrokerAdminClient.reconnectAdmin(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Reconnects an administrative client.
static BrokerTransactionalClient BrokerTransactionalClient.reconnectTransactionalClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Reconnects a transactional client.
 java.lang.String[] BrokerTransactionalClient.recover(int flag)
          Get the list of user defined, externally generated transaction identifiers that the client has prepared transactions for.
protected  java.lang.String[] BrokerClient.recoverTx()
           
 void BrokerCompleteBroker.refresh(BrokerAdminClient client)
          Refreshes the information about a Broker based on the given client.
 void BrokerCompleteClient.refresh(BrokerAdminClient client)
          Refreshes the information about the Client using the given broker admin client.
 void BrokerCompleteClientGroup.refresh(BrokerAdminClient client)
          Refreshes the information about the Client Group using the given client.
 void BrokerCompleteEventType.refresh(BrokerAdminClient client)
          Refreshes the information about the Event Type using the given client.
 void BrokerCompleteTerritory.refresh(BrokerAdminClient client)
          Refreshes the information about a Territory based on the given broker admin client.
 void BrokerCompleteTerritoryGateway.refresh(BrokerAdminClient client)
          Refreshes the information about a Territory Gateway based on the given broker admin client.
 void BrokerCompleteServer.refresh(BrokerServerClient client)
          Refreshes the information about a Broker server based on the given client.
 void BrokerCompleteBroker.refreshTerritoryAndGateways(BrokerAdminClient client)
          Refreshes only information about a Broker's territory and gateways.
 void BrokerClient.registerCallback(BrokerCallback obj, java.lang.Object client_data)
          Register a general callback for events received by this client.
 void BrokerTransactionalClient.registerCallback(BrokerCallback obj, java.lang.Object client_data)
           
 void BrokerClient.registerCallbackForSubId(int sub_id, BrokerCallback obj, java.lang.Object client_data)
          Register a specific callback for events received by this client which matched a given subscription ID.
 void BrokerTransactionalClient.registerCallbackForSubId(int sub_id, BrokerCallback obj, java.lang.Object client_data)
           
 void BrokerClient.registerCallbackForTag(int tag, boolean cancel_when_done, BrokerCallback obj, java.lang.Object client_data)
          Register a specific callback for events received by this client which have the _env.tag field set to the specified value.
 void BrokerTransactionalClient.registerCallbackForTag(int tag, boolean cancel_when_done, BrokerCallback obj, java.lang.Object client_data)
           
 void BrokerClient.registerConnectionCallback(BrokerConnectionCallback obj, java.lang.Object client_data)
          Register a connection callback for this client.
 void BrokerClusterPublisher.registerConnectionCallback(BrokerCPConnectionCallback obj, java.lang.Object client_data)
          Register a connection callback for the cluster publisher.
 void BrokerServerClient.registerConnectionCallback(BrokerServerConnectionCallback obj, java.lang.Object client_data)
          Register a connection callback for this client.
 void BrokerClusterPublisher.registerSelectionCallback(BrokerCPSelectionCallback obj, java.lang.Object client_data)
          Register a cluster publisher selection callback for this client.
 void BrokerAdminClient.releaseChangeLock()
          Release the per-Broker change lock.
 void BrokerMonitorClient.reloadConfig()
          Make Broker Monitor to re-load its configuration for all the servers.
 void BrokerMonitorClient.reloadConfigForServer(int port)
          Make Broker Monitor to re-read its configuration for the specified server.
 void BrokerAdminClient.removeBrokerFromCluster(java.lang.String broker_host, java.lang.String broker_name)
          Force the removal of a given broker from the cluster.
 void BrokerAdminClient.removeBrokerFromTerritory(java.lang.String broker_host, java.lang.String broker_name)
          Force the removal of a given broker from the territory.
 void BrokerAdminTypeDef.renameField(java.lang.String old_field_name, java.lang.String new_field_name)
          Rename or move a field.
 BrokerEvent[] BrokerClient.resendUnacknowledgedEvents(long[] seqn)
          A list of events with the given "seqn" numbers will be sent to the broker again since they had not been acknowledged so far.
 void BrokerQueueBrowser.resetFilters()
          Remove all existing filters on the queue browser.
 void BrokerClient.resetSessionFilters()
          Reset existing filters on the client session.
 void BrokerTransactionalClient.resume(long tx_id)
          Resume a suspended transaction.
 void BrokerTransactionalClient.resume(java.lang.String external_id)
          Resume a suspended transaction.
static void BrokerTransactionalClient.resumeAll(BrokerTransactionalClient[] tx_clients, java.lang.String external_id)
          Resume the given list of suspended transactions.
 void BrokerServerClient.resumePublishProcessing()
          resume broker server publication processing.
static BrokerCompleteBroker BrokerCompleteBroker.retrieve(BrokerAdminClient client)
          Retrieves the information about a Broker based on the given client.
static BrokerCompleteTerritory BrokerCompleteTerritory.retrieve(BrokerAdminClient client)
          Retrieves the information about a Territory based on the given broker admin client.
static BrokerCompleteClient BrokerCompleteClient.retrieve(BrokerAdminClient client, java.lang.String client_id)
          Retrieves the information about the specified Client with the given broker admin client.
static BrokerCompleteClientGroup BrokerCompleteClientGroup.retrieve(BrokerAdminClient client, java.lang.String client_group_name)
          Retrieves the information about the specified Client Group with the given client.
static BrokerCompleteEventType BrokerCompleteEventType.retrieve(BrokerAdminClient client, java.lang.String event_type_name)
          Retrieves the information about the specified Event Type with the given client.
static BrokerCompleteTerritoryGateway BrokerCompleteTerritoryGateway.retrieve(BrokerAdminClient client, java.lang.String territory_name)
          Retrieves the information about a Territory Gateway based on the given broker admin client.
static BrokerCompleteServer BrokerCompleteServer.retrieve(BrokerServerClient client)
          Retrieves the information about a Broker Server and creates an object.
 void BrokerServerClient.setAdminACL(BrokerAccessControlList acl)
          Set the Broker server's administrative access control list (ACL).
 void BrokerServerClient.setAuditOnErrorState(int state)
          Sets the audit error state and the action for the audit log error
 void BrokerServerClient.setAuditOperations(short[] ops)
          Sets the current audit operations as specified by the values in ops.
 void BrokerServerClient.setAuditState(int state)
          Enables/Disables the audit state.
 void BrokerAccessControlList.setAuthNames(java.lang.String[] names)
          Set the list of authenticator names which are allowed.
 void BrokerAccessControlList.setAuthNameState(java.lang.String name, boolean is_allowed)
          Set the allow state for a single authenticator name.
 void BrokerAccessControlList.setAuthNameStates(java.lang.String[] names, boolean is_allowed)
          Set the allow state for a list of authenticator names.
 void BrokerClient.setAutomaticControlLabel(boolean enabled)
          Enable or disable automatic setting of the _env.controlLabel field.
 void BrokerServerClient.setBasicAuthIdentity(COM.activesw.api.client.BrokerBasicAuthIdentity new_identity)
          Sets the Broker Server's identity for basic authentication.
 void BrokerEvent.setBooleanField(java.lang.String field_name, boolean value)
          Sets the value of a boolean field.
 void BrokerEvent.setBooleanProperty(java.lang.String property_name, boolean value)
           
 void BrokerEvent.setBooleanSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, boolean[] value)
          Sets the value of a subrange of a boolean sequence field.
 void BrokerClientPoll.setBrokerClient(BrokerClient client)
          Set the Broker client.
 void BrokerAdminClient.setBrokerDescription(java.lang.String description)
          Set the broker description
 void BrokerEvent.setByteField(java.lang.String field_name, byte value)
          Sets the value of a byte field.
 void BrokerEvent.setByteProperty(java.lang.String property_name, byte value)
           
 void BrokerEvent.setByteSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, byte[] value)
          Sets the value of a subrange of a byte sequence field.
 void BrokerEvent.setCharField(java.lang.String field_name, char value)
          Sets the value of a char field.
 void BrokerEvent.setCharSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, char[] value)
          Sets the value of a subrange of a char sequence field.
 void BrokerAdminClient.setClientGroupAccessLabelRequired(java.lang.String client_group_name, boolean required)
          Set whether or not an access label is required for connecting to a client group.
 void BrokerAdminClient.setClientGroupACL(java.lang.String client_group_name, BrokerAccessControlList acl)
          Set the specified client group's access control list (ACL).
 void BrokerAdminClient.setClientGroupCanPublishList(java.lang.String client_group_name, java.lang.String[] event_type_names)
          Set the list of event types the client group can publish to deliver.
 void BrokerAdminClient.setClientGroupCanSubscribeList(java.lang.String client_group_name, java.lang.String[] event_type_names)
          Set the list of event types the client group can subscribe to or have delivered to it.
 void BrokerAdminClient.setClientGroupDescription(java.lang.String client_group_name, java.lang.String description)
          Set the description string for a client group.
 void BrokerAdminClient.setClientGroupLogAcknowledgeList(java.lang.String client_group_name, java.lang.String[] event_type_names)
          Set the list of event types that are logged when acknowledged by a client in the the specified client group.
 void BrokerAdminClient.setClientGroupLogPublishList(java.lang.String client_group_name, java.lang.String[] event_type_names)
          Set the list of event types that are logged when published or delivered by a client in the the specified client group.
 void BrokerAdminClient.setClientGroupRequiredEncryption(java.lang.String client_group_name, int level)
          Set the required encryption for a client group.
 void BrokerClient.setClientInfoset(BrokerEvent infoset)
          Set the infoset for this client.
 void BrokerAdminClient.setClientInfosetById(java.lang.String client_id, BrokerEvent infoset)
          Set the infoset for a client.
 void BrokerAdminClient.setClientLastPublishSequenceNumberById(java.lang.String client_id, long seqn)
          Set a client's high publisher sequence number.
 void BrokerAdminClient.setClientStateShareLimitById(java.lang.String client_id, int limit)
          Set a client's state share limit.
 void BrokerAdminClient.setClusterACL(BrokerAccessControlList acl)
          Set the access control list (ACL) which brokers in this cluster will use to accept connections from other brokers in the cluster.
 void BrokerAdminClient.setClusterGatewayACL(java.lang.String cluster_name, java.lang.String broker_name, BrokerAccessControlList acl)
          Set the access control list (ACL) which this broker will use to accept connections from the other broker across the gateway.
 void BrokerAdminClient.setClusterGatewayKeepAlive(java.lang.String cluster_name, java.lang.String broker_name, int KeepAlive)
          Sets or disables KeepAlive interval on the gateway.
 void BrokerAdminClient.setClusterGatewayPause(java.lang.String cluster_name, java.lang.String broker_name, boolean pause)
          Pauses or resumes a cluster gateway
 void BrokerAdminClient.setClusterGatewayRefuseAllUpdates(java.lang.String cluster_name, java.lang.String broker_name, boolean refuse_updates)
          Sets whether a cluster gateway refuses all updates.
 void BrokerAdminClient.setClusterGatewaySecurity(java.lang.String cluster_name, java.lang.String broker_name, int auth_type, int encrypt_level)
          Set the type of security used for the Cluster gateway.
 void BrokerAdminClient.setClusterGatewaySharedEventTypes(java.lang.String cluster_name, java.lang.String broker_name, BrokerSharedEventTypeInfo[] infos)
          Set the complete list of shared event types on a cluster gateway.
 void BrokerAdminClient.setClusterPrimaryGateway(java.lang.String cluster_name, java.lang.String broker_name)
          Set the gateway connection to the input cluster and broker as the Primary Cluster gateway from this Broker to the remote cluster.
 void BrokerAdminClient.setClusterSecurity(int auth_type, int encrypt_level)
          Set the type of security used in the cluster.
 void BrokerAdminClient.setClusterStaticGatewayForwarding(java.lang.String cluster_name, java.lang.String broker_name, boolean enable)
          Enable or disable static gateway forwarding,
 void BrokerEvent.setDateField(java.lang.String field_name, BrokerDate value)
          Sets the value of a date field.
 void BrokerEvent.setDateSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, BrokerDate[] value)
          Sets the value of a subrange of a date sequence field.
 void BrokerServerClient.setDefaultBrokerName(java.lang.String broker_name)
          Set the name of the default Broker in the server.
 void BrokerAdminTypeDef.setDescription(java.lang.String description)
          Set the type's description.
 void BrokerServerClient.setDescription(java.lang.String description)
          Set the Broker server description.
 void BrokerEvent.setDoubleField(java.lang.String field_name, double value)
          Sets the value of a double field.
 void BrokerEvent.setDoubleProperty(java.lang.String property_name, double value)
           
 void BrokerEvent.setDoubleSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, double[] value)
          Sets the value of a subrange of a double sequence field.
 void BrokerAdminClient.setEventAdminTypeDef(BrokerAdminTypeDef type_def)
          Set the specified event type's definition.
 void BrokerAdminClient.setEventAdminTypeDefs(BrokerAdminTypeDef[] type_defs)
          Set the specified event type definitions.
 void BrokerEvent.setEventField(java.lang.String field_name, BrokerEvent value)
          Sets the value of an event field.
 void BrokerAdminClient.setEventLogging(boolean enabled)
           
 void BrokerEvent.setEventSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, BrokerEvent[] value)
          Set the value of an event sequence field.
 void BrokerAdminClient.setEventTypeInfoset(java.lang.String event_type_name, java.lang.String infoset_name, BrokerEvent infoset)
          Set the specified infoset for an event type.
 void BrokerAdminClient.setEventTypeInfosets(java.lang.String event_type_name, BrokerEvent[] infosets)
          Set the specified infosets for the specified event type.
 BrokerSetFailureInfo BrokerAdminClient.setEventTypesAndClientGroups(java.lang.String[] event_type_names_to_destroy, java.lang.String[] client_group_names_to_destroy, BrokerCompleteEventType[] event_types, BrokerCompleteClientGroup[] client_groups, boolean forced)
          Creates, modifies, and destroys event types and client groups as an atomic operation.
 void BrokerEvent.setField(java.lang.String field_name, BrokerField field)
          Sets the value of a field.
 void BrokerEvent.setField(java.lang.String field_name, short field_type, java.lang.Object value)
          Sets the value of a field.
 void BrokerAdminTypeDef.setFieldDef(java.lang.String field_name, BrokerAdminTypeDef field_def)
          Set the type of a field.
 void BrokerAdminTypeDef.setFieldType(java.lang.String field_name, short field_type, java.lang.String type_name)
          Set the type for a given field.
 void BrokerQueueBrowser.setFilter(BrokerFilterDescriptor filter)
          Set filter for queue browser's browse operation.
 void BrokerServerClient.setFilterCollationLocale(java.lang.String locale)
          Set the Broker Server Filter Collation locale.
 void BrokerQueueBrowser.setFilters(BrokerFilterDescriptor[] filters)
          Set filters for queue browser's browse operation.
 void BrokerEvent.setFloatField(java.lang.String field_name, float value)
          Sets the value of a float field.
 void BrokerEvent.setFloatProperty(java.lang.String property_name, float value)
           
 void BrokerEvent.setFloatSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, float[] value)
          Sets the value of a subrange of a float sequence field.
 void BrokerEvent.setIntegerField(java.lang.String field_name, int value)
          Sets the value of an integer field.
 void BrokerEvent.setIntegerSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, int[] value)
          Sets the value of a subrange of an integer sequence field.
 void BrokerEvent.setIntProperty(java.lang.String property_name, int value)
           
 void BrokerServerClient.setLicense(java.lang.String license)
          Deprecated. Deprecated in webMethods Broker 9.0, instead use BrokerServerClient.setLicenseFileName(String)
 void BrokerServerClient.setLicenseContent(java.lang.String licenseFileContent)
          Set the license file content for Broker Server.
 void BrokerServerClient.setLicenseFile(java.lang.String licenseFile)
          Deprecated. Deprecated in webMethods Broker 9.0, instead use BrokerServerClient.setLicenseFileName(String)
 void BrokerServerClient.setLicenseFileName(java.lang.String licenseFileName)
          Set the license file name for Broker Server.
 void BrokerServerClient.setLogConfig(BrokerLogConfig log_config)
          Set the Broker server logging configuration.
protected  void BrokerAdminClient.setLogFilter(java.lang.String event_name, java.lang.String filter_expr)
          Allows filtering of log content.
protected  void BrokerAdminClient.setLogFilters(BrokerFilter[] filters)
          Allows filtering of log content.
 void BrokerLogConfig.setLogOutput(BrokerLogConfigEntry log_output)
          Set the value of a simple log output's state.
 void BrokerLogConfig.setLogOutput(java.lang.String code, boolean enabled, java.lang.String value)
          Set the value of a single log output's state.
 void BrokerLogConfig.setLogTopic(BrokerLogConfigEntry log_topic)
          Set the value of a single log topic's state.
 void BrokerLogConfig.setLogTopic(java.lang.String code, boolean enabled, java.lang.String value)
          Set the value of a single log topic's state.
 void BrokerEvent.setLongField(java.lang.String field_name, long value)
          Sets the value of a long field.
 void BrokerEvent.setLongProperty(java.lang.String property_name, long value)
           
 void BrokerEvent.setLongSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, long[] value)
          Sets the value of a subrange of a long sequence field.
 void BrokerEvent.setNullProperty(java.lang.String property_name, java.lang.String value)
           
static void BrokerClient.setPlatformInfo(java.lang.String key, java.lang.String value)
          Set a platform info value.
 void BrokerQueueBrowser.setPosition(int position)
          Set the browse cursor to the specified position on the queue.
 void BrokerAdminClient.setPostPrepareTimeout(int timeout_secs)
          Set the default post-prepare timeout.
 void BrokerAdminClient.setPostPrepareTimeoutAction(int action)
          Set the post-prepare timeout action.
 void BrokerAdminClient.setPrePrepareTimeout(int timeout_secs)
          Set the default pre-prepare timeout.
protected  void BrokerClientPoll.setReady(int ready)
          Set the poll's ready operations.
 void BrokerAdminClient.setRecoverMode(int mode)
          Sets the global recover mode to either restricted (the default) or global.
 void BrokerAdminClient.setRemoteBrokerKeepAlive(java.lang.String broker_name, int KeepAlive)
          Sets or disables KeepAlive interval for the remote broker.
protected  void BrokerClientPoll.setRequested(int requested)
          Set the poll's requested operations.
 void BrokerEvent.setSequenceField(java.lang.String field_name, short field_type, int src_offset, int dest_offset, int n, java.lang.Object value)
          Sets the value of a subrange of a sequence field.
 void BrokerEvent.setSequenceFieldSize(java.lang.String field_name, int size)
          Set the size of a sequence field.
 void BrokerClient.setSessionFilter(BrokerFilterDescriptor filter)
          Set filter for event retrieval operations.
 void BrokerClient.setSessionFilters(BrokerFilterDescriptor[] filter)
          Set filters for event retrieval operations.
 void BrokerConnectionDescriptor.setSharedEventOrdering(java.lang.String ordering)
          Set the shared event ordering status of the descriptor.
 void BrokerEvent.setShortField(java.lang.String field_name, short value)
          Sets the value of a short field.
 void BrokerEvent.setShortProperty(java.lang.String property_name, short value)
           
 void BrokerEvent.setShortSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, short[] value)
          Sets the value of a subrange of a short sequence field.
 void BrokerConnectionDescriptor.setSSLCertificate(java.lang.String keystore, java.lang.String truststore, COM.activesw.api.client.enums.KeystoreType keystore_type, COM.activesw.api.client.enums.TruststoreType truststore_type, java.lang.String password)
           
 void BrokerServerClient.setSSLConfig(BrokerSSLConfig new_config)
          Set the SSL configuration to be used next time the Broker server is started.
 void BrokerServerClient.setSSLConfig(java.lang.String certificate_file, java.lang.String password, java.lang.String distinguished_name)
          Set the SSL configuration to be used next time the Broker server is started.
 void BrokerServerClient.setSSLConfigV2(BrokerSSLConfigV2 new_config)
          Set the SSL configuration to be used next time the Broker server is started.
 void BrokerClient.setStateShareLimit(int limit)
          Set the number of clients which can be simultaneously connected using this client ID.
 void BrokerAdminClient.setStaticGatewayForwarding(java.lang.String territory_name, boolean enable)
          Enable or disable static gateway forwarding,
 void BrokerAdminTypeDef.setStorageType(int storage_type)
          Set the type's storage type.
 void BrokerEvent.setStringField(java.lang.String field_name, java.lang.String value)
          Sets the value of a string field.
 void BrokerEvent.setStringFieldToSubstring(java.lang.String field_name, int offset, int nc, java.lang.String value)
          Sets the value of a string field to a substring of another string.
 void BrokerEvent.setStringProperty(java.lang.String property_name, java.lang.String value)
           
 void BrokerEvent.setStringSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, java.lang.String[] value)
          Sets the value of a subrange of a string sequence field.
 void BrokerEvent.setStructFieldFromEvent(java.lang.String field_name, BrokerEvent value)
          Sets the value of a structure field.
 void BrokerEvent.setStructSeqFieldFromEvents(java.lang.String field_name, int src_offset, int dest_offset, int n, BrokerEvent[] value)
          Sets the value of a structure sequence field.
 void BrokerEvent.setTag(int tag)
          Set the event's 'tag' envelope field.
 void BrokerAdminClient.setTerritoryACL(BrokerAccessControlList acl)
          Set the access control list (ACL) which brokers in this territory will use to accept connections from other brokers in the territory.
 void BrokerAdminClient.setTerritoryGatewayACL(java.lang.String territory_name, BrokerAccessControlList acl)
          Set the access control list (ACL) which this broker will use to accept connections from the other broker across the gateway.
 void BrokerAdminClient.setTerritoryGatewayKeepAlive(java.lang.String territory_name, int KeepAlive)
          Sets or disables KeepAlive interval on the gateway.
 void BrokerAdminClient.setTerritoryGatewayPause(java.lang.String territory_name, boolean pause)
          Pauses or resumes gateway
 void BrokerAdminClient.setTerritoryGatewayRefuseAllUpdates(java.lang.String territory_name, boolean refuse_updates)
          Sets whether a territory gateway refuses all updates.
 void BrokerAdminClient.setTerritoryGatewayRefuseEventTypeUpdates(java.lang.String territory_name, BrokerSharedEventTypeRefuseUpdateInfo[] infos)
          Sets which event types a territory gateway refuses updates for.
 void BrokerAdminClient.setTerritoryGatewaySecurity(java.lang.String territory_name, int auth_type, int encrypt_level)
          Set the type of security used for the territory gateway.
 void BrokerAdminClient.setTerritoryGatewaySharedEventTypes(java.lang.String territory_name, BrokerSharedEventTypeInfo[] infos)
          Set the complete list of shared event types on a territory gateway.
 void BrokerAdminClient.setTerritorySecurity(int auth_type, int encrypt_level)
          Set the type of security used in the territory.
 void BrokerDate.setTime(int hr, int m, int s, int ms, boolean normalize_time)
          Set the time only.
 void BrokerAdminTypeDef.setTimeToLive(int time_to_live)
          Set the type's time-to-live.
 void BrokerTransactionalClient.setTransactionId(long tx_id, java.lang.String external_id)
          Associates a Broker transaction with an external identifier.
 void BrokerTransactionalClient.setTransactionId(java.lang.String external_id)
          Associates the current Broker transaction with an external identifier.
 void BrokerTransactionalClient.setTransactionTimeout(int seconds)
           
protected  void BrokerClient.setTxId(long tx_id, java.lang.String external_id)
          Sets the Broker transaction's external identifier.
protected  void BrokerClient.setTxTimeout(int seconds, long tx_id)
           
 void BrokerAdminTypeDef.setTypeName(java.lang.String type_name)
          Set the fully qualified name of this event type.
 void BrokerEvent.setTypeName(java.lang.String event_type_name)
           
 void BrokerEvent.setUCCharField(java.lang.String field_name, char value)
          Sets the value of a unicode char field.
 void BrokerEvent.setUCCharSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, char[] value)
          Sets the value of a subrange of a unicode char sequence field.
 void BrokerEvent.setUCStringField(java.lang.String field_name, java.lang.String value)
          Sets the value of a unicode string field.
 void BrokerEvent.setUCStringFieldToSubstring(java.lang.String field_name, int offset, int nc, java.lang.String value)
          Sets the value of a unicode string field to a substring of another string.
 void BrokerEvent.setUCStringSeqField(java.lang.String field_name, int src_offset, int dest_offset, int n, java.lang.String[] value)
          Sets the value of a subrange of a unicode string sequence field.
 void BrokerAccessControlList.setUserNames(java.lang.String[] names)
          Set the list of user names which are allowed access.
 void BrokerAccessControlList.setUserNameState(java.lang.String name, boolean is_allowed)
          Set the allow state for a single user name.
 void BrokerAccessControlList.setUserNameStates(java.lang.String[] names, boolean is_allowed)
          Set the allow state for a list of user names.
 void BrokerAdminTypeDef.setValidationType(int validation_type)
          Set the type's validation type.
 boolean BrokerServerClient.startMetaDataBackup()
          Notifies the broker that backup of the meta-data is going to start.
 void BrokerMonitorClient.startServer(int port)
          Start a server.
static void BrokerServerClient.startServerProcess(java.lang.String broker_host)
          Start the Broker server process (if it is not already started).
static void BrokerServerClient.startServerProcess(java.lang.String broker_monitor_host, int monitorPort, int brokerPort)
           
static void BrokerClient.stopMainLoop()
          Interrupt the current mainLoop calls.
static void BrokerTransactionalClient.stopMainLoop()
           
 void BrokerServerClient.stopProcess()
          Stop the Broker server process.
 void BrokerCompleteBroker.store(BrokerAdminClient client)
          Stores the information from this object into the Broker for which the given client object has been provided.
 void BrokerCompleteClient.store(BrokerAdminClient client)
          Stores the information from this Client into the broker for which the given broker admin client has been provided.
 void BrokerCompleteClientGroup.store(BrokerAdminClient client)
          Stores the information from this Client Group into the broker for which the given client object has been provided.
 void BrokerCompleteEventType.store(BrokerAdminClient client)
          Stores the information from this object into the broker for which the given client object has been provided.
 void BrokerCompleteTerritory.store(BrokerAdminClient client)
          Stores the information from this Territory into the broker for which the given client object has been provided.
 void BrokerCompleteTerritoryGateway.store(BrokerAdminClient client)
          Stores the information from this Territory Gateway into the broker for which the given client object has been provided.
 void BrokerCompleteTerritoryGateway.store(BrokerAdminClient client, boolean clusterGateway)
           
 void BrokerCompleteServer.store(BrokerServerClient client)
          Stores the information from this object into the server for which the given client object has been provided.
 void BrokerTransactionalClient.suspend(long tx_id)
          Suspend the transaction with the given external_id.
 void BrokerTransactionalClient.suspend(java.lang.String external_id)
          Suspend the transaction with the given external_id.
static void BrokerTransactionalClient.suspendAll(BrokerTransactionalClient[] tx_clients, java.lang.String external_id)
          Suspend the given list of current transactions.
static void BrokerClient.threadedCallbacks(boolean enabled)
          A convenience method to run the mainLoop method on another thread.
static void BrokerTransactionalClient.threadedCallbacks(boolean enabled)
           
 java.lang.String BrokerEvent.toFormattedString(java.lang.String formatString)
          Format an event string.
 java.lang.String BrokerEvent.toFormattedString(java.lang.String formatString, java.util.Locale locale)
          Format an event string.
 java.lang.String BrokerEvent.toLocalizedFormattedString(java.lang.String formatString)
          Format an event string.
 void BrokerEvent.toObject(java.lang.Object obj)
          Deprecated. As of Java API v6.5.
 java.lang.String BrokerCompleteBroker.toString(int indent_level)
          Converts this broker's information into a string.
 java.lang.String BrokerCompleteClient.toString(int indent_level)
          Converts this Client's information into a string.
 java.lang.String BrokerCompleteClientGroup.toString(int indent_level)
          Converts this Client Group's information into a string.
 java.lang.String BrokerCompleteCollection.toString(int indent_level)
          Converts this object's information into a string.
 java.lang.String BrokerCompleteEventType.toString(int indent_level)
          Converts this event type's information into a string.
 java.lang.String BrokerCompleteServer.toString(int indent_level)
          Converts this server's information into a string.
 java.lang.String BrokerCompleteTerritory.toString(int indent_level)
          Converts this Territory's information into a string.
 java.lang.String BrokerCompleteTerritoryGateway.toString(int indent_level)
          Converts this Territory Gateway's information into a string.
 byte[] BrokerEvent.toWireEvent()
           
 void BrokerEvent.validate(BrokerClient client)
          Validate event in the context of the specified client.
 void BrokerCompleteBroker.write(java.io.Writer writer, int indent_level)
          Writes this broker's information out in a textual format.
 void BrokerCompleteClient.write(java.io.Writer writer, int indent_level)
          Writes this Client's information out in a textual format.
 void BrokerCompleteClientGroup.write(java.io.Writer writer, int indent_level)
          Writes this Client Group's information out in a textual format.
 void BrokerCompleteCollection.write(java.io.Writer writer, int indent_level)
          Writes this object's information out in a textual format.
 void BrokerCompleteEventType.write(java.io.Writer writer, int indent_level)
          Writes this event type's information out in a textual format.
 void BrokerCompleteServer.write(java.io.Writer writer, int indent_level)
          Writes this server's information out in a textual format.
 void BrokerCompleteTerritory.write(java.io.Writer writer, int indent_level)
          Writes this Territory's information out in a textual format.
 void BrokerCompleteTerritoryGateway.write(java.io.Writer writer, int indent_level)
          Writes this Territory Gateway's information out in a textual format.
 void BrokerCompleteCollection.write(java.io.Writer writer, int indent_level, boolean escape_unicode)
          Writes this object's information out in a textual format.
static void BrokerCompleteCollection.writeVersionNumber(java.io.Writer writer, int indent_level)
          Writes a version number string.
 

Constructors in COM.activesw.api.client that throw BrokerException
BrokerAccessControlList(BrokerAccessControlList acl)
          Copy constructor.
BrokerAdminClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Protected reconnect constructor.
BrokerAdminClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Creates an administrative client.
BrokerAdminTypeDef(BrokerAdminTypeDef type_def)
          Copy constructor.
BrokerAdminTypeDef(BrokerTypeDef normal_def)
          Create from a normal type definition.
BrokerAdminTypeDef(short type)
          Create a new type definition for a non-Event type.
BrokerAdminTypeDef(java.lang.String type_name, short type)
          Create a new type definition.
BrokerClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Protected reconnect constructor.
BrokerClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Creates a client.
BrokerClientPoll(BrokerClient client, int requested, java.lang.Object data)
          Create a client poll object.
BrokerClusterPublisher(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc, BrokerConnectionDescriptor mon_desc)
          Creates a BrokerClusterPublisher.
BrokerCompleteBroker(BrokerInfo info)
          Constructor.
BrokerEvent(BrokerClient client, java.lang.String event_type_name)
          Create an event of the appropriate type with an associated client.
BrokerEvent(BrokerClient client, java.lang.String event_type_name, java.lang.Class storage_class)
          Deprecated. As of Java API v6.5.
BrokerEvent(BrokerClient client, java.lang.String event_type_name, java.lang.Object storage_object)
          Deprecated. As of Java API v6.5.
BrokerEvent(BrokerEvent event)
          Copy constructor.
BrokerEvent(java.lang.String event_type_name, BrokerClusterPublisher bcp)
          Create an event of the appropriate type with an associated client from the BrokerClusterPublisher's cluster pool.
BrokerEvent(java.lang.String event_type_name, BrokerClusterPublisher bcp, java.lang.Class storage_class)
          Deprecated. As of Java API v6.5.
BrokerEvent(java.lang.String event_type_name, BrokerClusterPublisher bcp, java.lang.Object storage_object)
          Deprecated. As of Java API v6.5.
BrokerFilter(BrokerClient client, java.lang.String event_type_name, java.lang.String filter_string)
          Create the filter.
BrokerFilter(BrokerClient client, java.lang.String event_type_name, java.lang.String filter_string, java.util.Locale locale)
          Create the filter in the given locale.
BrokerLogConfig(BrokerLogConfig log_config)
          Copy constructor.
BrokerMonitorClient(java.lang.String broker_monitor_host)
          Create a Broker Monitor client.
BrokerMonitorClient(java.lang.String broker_monitor_host, BrokerConnectionDescriptor desc)
          Create a Broker Monitor client.
BrokerServerClient(java.lang.String broker_host, BrokerConnectionDescriptor desc)
          Create a Broker server client.
BrokerTransactionalClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, BrokerConnectionDescriptor desc)
          Protected reconnect constructor.
BrokerTransactionalClient(java.lang.String broker_host, java.lang.String broker_name, java.lang.String client_id, java.lang.String client_group, java.lang.String app_name, BrokerConnectionDescriptor desc)
          Creates a broker client that is transactional.
 


webMethods Broker Administration Java API
Version 9.5.1.0.171 091713


Copyright © 2001 - 2013 Software AG Darmstadt, Germany and/or Software AG USA, Inc., Reston, VA, United States of America, and/or their suppliers.