Package | Description |
---|---|
COM.activesw.api.client |
Modifier and Type | Class and Description |
---|---|
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 |
BrokerClientQueueBrowserException
This exception is thrown by queue browser methods when an operation on a BrokerClientQueueBrowser (including the locked) fails.
|
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 |
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 |
BrokerInterruptedException
This exception is thrown by Information Broker client methods when an interruption occurs.
|
class |
BrokerInvalidAcknowledgementException
This exception is thrown by Information Broker client methods when an acknowledgement is determined to be invalid.
|
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 |
BrokerInvalidClientIdException
This exception is thrown by Information Broker client methods when the client ID specified to a call is not valid.
|
class |
BrokerInvalidClientLicenseIDException
This exception is thrown by Broker client when supplied client license property value is empty/null.
|
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 |
BrokerInvalidPlatformKeyException
This exception is thrown by Information Broker client methods when the platform key 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 |
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 |
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 |
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 |
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.
|
Modifier and Type | Method and Description |
---|---|
protected BrokerException |
BrokerClientQueueBrowser.createException(BrokerQueueBrowserException ex) |
Modifier and Type | Method and Description |
---|---|
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 |
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.
|
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[] |
BrokerClient.browseEvents(int from_index,
int max_events,
COM.activesw.api.client.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.
|
void |
BrokerClient.checkForEvents(int msecs)
Check for the availability of deliverable events on the client's queue.
|
protected static void |
BrokerEvent.checkSetEnvField(java.lang.String field_name,
java.lang.String full_field_name) |
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 |
BrokerClient.clearQueue()
Clear all events from the client's queue.
|
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.
|
BrokerClientQueueBrowser |
BrokerClient.createClientQueueBrowser()
Creates a queue browser on the current client's queue.
|
int |
BrokerLockedClientQueueBrowser.deleteEvents(long[] seqns)
Delete events in the queue.
|
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 |
BrokerClient.disconnect()
Disconnect the client.
|
void |
BrokerClusterPublisher.disconnect()
Disconnect BrokerClusterPublisher.
|
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 |
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
|
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) |
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
|
java.lang.String |
BrokerFormat.format(BrokerEvent event,
java.util.Locale locale)
Return formatted string, using
|
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.
|
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 |
BrokerClient.getBrokerName()
Get the client's broker name.
|
BrokerSSLCertificate |
BrokerClient.getBrokerSSLCertificate()
Get the secure socket certificate for the broker.
|
BrokerClientQueueBrowserInfo |
BrokerClientQueueBrowser.getBrowserInfo() |
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.
|
COM.activesw.api.client.BrokerClientInfo |
BrokerClient.getClientInfo()
Get the current client's information.
|
BrokerEvent |
BrokerClient.getClientInfoset()
Get the infoset for this client.
|
int |
BrokerClient.getClientSSLEncryptionLevel()
Get the secure socket encryption level.
|
BrokerEvent |
BrokerClusterPublisher.getClusterPublisherInfo()
Get the cluster publisher info.
|
BrokerEvent |
BrokerClusterPublisher.getClusterPublisherStats()
Get the cluster publisher 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 |
BrokerTypeDef.getDescription()
Get the type's description.
|
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.
|
BrokerEvent |
BrokerEvent.getEventField(java.lang.String field_name)
Get the value of an event field.
|
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.
|
BrokerField |
BrokerEvent.getField(java.lang.String field_name)
Get the value of field.
|
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[] |
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 |
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.
|
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.
|
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.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[] |
BrokerClient.getLogAcknowledgeNames()
Get the list of event types which can be logged when clients of this client group acknowledges them.
|
java.lang.String[] |
BrokerClient.getLogPublishNames()
Get the list of event types that are logged when published by clients of this client's client group.
|
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.
|
static java.lang.String |
BrokerClient.getPlatformInfo(java.lang.String key)
Get a platform info value.
|
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 |
BrokerClient.getQueueLength()
Get the number of events currently in the client's queue.
|
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[] |
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.
|
COM.activesw.api.client.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,
KeystoreType keystore_type,
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,
KeystoreType keystore_type,
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,
KeystoreType keystore_type,
TruststoreType truststore_type,
java.lang.String password)
Get the list of trusted root distinguished names from a certificate file.
|
int |
BrokerClient.getStateShareLimit()
Get the number of clients allowed to be connected using this client ID at one time.
|
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.
|
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.
|
int |
BrokerTypeDef.getTimeToLive()
Get the type's time-to-live.
|
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.
|
int |
BrokerTypeDef.getValidationType()
Get the type's validation type.
|
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 |
BrokerLockedClientQueueBrowser.insertEventsAtTail(BrokerEvent[] events)
Insert events in into the queue.
|
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.
|
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) |
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 |
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 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 |
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 |
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 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 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 flags)
Get the list of user defined, externally generated transaction identifiers that the client has prepared transactions for.
|
protected java.lang.String[] |
BrokerClient.recoverTx(int flags,
long lastTxID) |
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 |
BrokerClusterPublisher.registerSelectionCallback(BrokerCPSelectionCallback obj,
java.lang.Object client_data)
Register a cluster publisher selection callback for this client.
|
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 |
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 |
BrokerClient.setAutomaticControlLabel(boolean enabled)
Enable or disable automatic setting of the _env.controlLabel field.
|
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 |
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 |
BrokerClient.setClientInfoset(BrokerEvent infoset)
Set the infoset for this client.
|
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 |
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 |
BrokerEvent.setEventField(java.lang.String field_name,
BrokerEvent value)
Sets the value of an event field.
|
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 |
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 |
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 |
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.
|
protected void |
BrokerClientPoll.setReady(int ready)
Set the poll's ready operations.
|
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(COM.activesw.api.client.BrokerFilterDescriptor filter)
Set filter for event retrieval operations.
|
void |
BrokerClient.setSessionFilters(COM.activesw.api.client.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,
KeystoreType keystore_type,
TruststoreType truststore_type,
java.lang.String password) |
void |
BrokerClient.setStateShareLimit(int limit)
Set the number of clients which can be simultaneously connected using this client ID.
|
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 |
BrokerDate.setTime(int hr,
int m,
int s,
int ms,
boolean normalize_time)
Set the time only.
|
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 |
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.
|
static void |
BrokerClient.stopMainLoop()
Interrupt the current mainLoop calls.
|
static void |
BrokerTransactionalClient.stopMainLoop() |
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.
|
byte[] |
BrokerEvent.toWireEvent() |
void |
BrokerEvent.validate(BrokerClient client)
Validate event in the context of the specified client.
|
Constructor and Description |
---|
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.
|
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.
|
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.
|
Copyright © 2002-2006 webMethods, Inc. Copyright © 2007-2021 Software AG Darmstadt, Germany and/or Software AG USA Inc., Reston, VA, USA, and/or its subsidiaries and/or its affiliates and/or their licensors.