public abstract class SIPTransactionStack extends Object implements SIPTransactionEventListener, SIPDialogEventListener
SipStackImpl
Modifier and Type | Class and Description |
---|---|
protected class |
SIPTransactionStack.PingTimer |
Modifier | Constructor and Description |
---|---|
protected |
SIPTransactionStack()
Default constructor.
|
protected |
SIPTransactionStack(StackMessageFactory messageFactory)
Construcor for the stack.
|
Modifier and Type | Method and Description |
---|---|
void |
addExtensionMethod(String extensionMethod)
Add an extension method.
|
void |
addForkedClientTransaction(SIPClientTransaction clientTransaction) |
protected void |
addMessageProcessor(MessageProcessor newMessageProcessor)
Adds a new MessageProcessor to the list of running processors for this
SIPStack and starts it.
|
void |
addTransaction(SIPClientTransaction clientTransaction)
Add a new client transaction to the set of existing transactions.
|
void |
addTransaction(SIPServerTransaction serverTransaction)
Add a new server transaction to the set of existing transactions.
|
void |
addTransactionPendingAck(SIPServerTransaction serverTransaction)
Add entry to "Transaction Pending ACK" table.
|
String |
auditStack(Set activeCallIDs,
long leakedDialogTimer,
long leakedTransactionTimer)
Audits the SIP Stack for leaks
|
boolean |
checkBranchId()
Flag that reqests checking of branch IDs on responses.
|
void |
closeAllSockets() |
boolean |
closeReliableConnection(String myAddress,
int myPort,
String transport,
String peerAddress,
int peerPort)
Find suitable MessageProcessor and calls it's
MessageProcessor#closeReliableConnection(String, int)
method passing peerAddress and peerPort as arguments. |
SIPClientTransaction |
createClientTransaction(SIPRequest sipRequest,
MessageChannel encapsulatedMessageChannel)
Creates a client transaction that encapsulates a MessageChannel.
|
SIPDialog |
createDialog(SIPClientTransaction transaction,
SIPResponse sipResponse)
Create a Dialog given a client tx and response.
|
SIPDialog |
createDialog(SIPClientTransaction subscribeTx,
SIPTransaction notifyST)
Creates a new dialog based on a received NOTIFY.
|
SIPDialog |
createDialog(SipProviderImpl sipProvider,
SIPResponse sipResponse)
Create a Dialog given a sip provider and response.
|
SIPDialog |
createDialog(SIPTransaction transaction)
Create a dialog and add this transaction to it.
|
MessageChannel |
createMessageChannel(SIPRequest request,
MessageProcessor mp,
Hop nextHop)
Creates a client transaction to handle a new request.
|
protected MessageProcessor |
createMessageProcessor(InetAddress ipAddress,
int port,
String transport)
Creates the equivalent of a JAIN listening point and attaches to the
stack.
|
MessageChannel |
createRawMessageChannel(String sourceIpAddress,
int sourcePort,
Hop nextHop)
Creates a new MessageChannel for a given Hop.
|
SIPServerTransaction |
createServerTransaction(MessageChannel encapsulatedMessageChannel)
Creates a server transaction that encapsulates a MessageChannel.
|
protected void |
decrementActiveClientTransactionCount()
This method is called when a client tx transitions to the Completed or
Terminated state.
|
void |
dialogErrorEvent(SIPDialogErrorEvent dialogErrorEvent)
Invoked when an error has ocurred with a dialog.
|
void |
disableLogging()
For debugging -- allows you to disable logging or enable logging
selectively.
|
void |
enableLogging()
Globally enable message logging ( for debugging)
|
SIPTransaction |
findCancelTransaction(SIPRequest cancelRequest,
boolean isServer)
Get the transaction to cancel.
|
boolean |
findMergedTransaction(SIPRequest sipRequest)
See if there is a pending transaction with the same Merge ID as the Merge
ID obtained from the SIP Request.
|
SIPServerTransaction |
findPendingTransaction(String transactionId)
Finds a pending server transaction.
|
SIPClientTransaction |
findSubscribeTransaction(SIPRequest notifyMessage,
ListeningPointImpl listeningPoint)
Find a matching client SUBSCRIBE to the incoming notify.
|
SIPTransaction |
findTransaction(SIPMessage sipMessage,
boolean isServer)
Find the transaction corresponding to a given request.
|
SIPTransaction |
findTransaction(String transactionId,
boolean isServer) |
SIPServerTransaction |
findTransactionPendingAck(SIPRequest ackMessage)
Get entry in the server transaction pending ACK table corresponding to an
ACK.
|
int |
getAckTimeoutFactor()
Get the dialog timeout counter.
|
int |
getActiveClientTransactionCount()
Get the count of client transactions that is not in the completed or
terminated state.
|
AddressResolver |
getAddressResolver()
get the address resolver interface.
|
ClientAuthType |
getClientAuth() |
int |
getClientTransactionTableSize()
Get the size of the client transaction table.
|
int |
getConnectionLingerTimer() |
SIPDialog |
getDialog(String dialogId)
Return the dialog for a given dialog ID.
|
Collection<Dialog> |
getDialogs()
This method is slated for addition to the next spec revision.
|
Collection<Dialog> |
getDialogs(DialogState state) |
SIPDialog |
getEarlyDialog(String dialogId) |
int |
getEarlyDialogTimeout() |
SIPClientTransaction |
getForkedTransaction(String transactionId) |
String |
getHostAddress()
Deprecated.
|
Dialog |
getJoinDialog(JoinHeader joinHeader)
Get the Join Dialog from the stack.
|
SocketAddress |
getLocalAddressForTcpDst(InetAddress dst,
int dstPort,
InetAddress localAddress,
int localPort)
Creates and binds, if necessary, a socket connected to the specified
destination address and port and then returns its local address.
|
SocketAddress |
getLocalAddressForTlsDst(InetAddress dst,
int dstPort,
InetAddress localAddress)
Creates and binds, if necessary, a TCP SSL socket connected to the
specified destination address and port and then returns its local
address.
|
int |
getMaxForkTime() |
int |
getMaxMessageSize()
Maximum size of a single TCP message.
|
int |
getMaxTxLifetimeInvite() |
int |
getMaxTxLifetimeNonInvite() |
MessageParserFactory |
getMessageParserFactory() |
MessageProcessorFactory |
getMessageProcessorFactory() |
protected MessageProcessor[] |
getMessageProcessors()
Gets an array of running MessageProcessors on this SIPStack.
|
long |
getMinKeepAliveInterval() |
NetworkLayer |
getNetworkLayer()
Return the network layer (i.e.
|
Hop |
getNextHop(SIPRequest sipRequest)
Get the default route string.
|
int |
getReceiveUdpBufferSize()
Size of the receive UDP buffer.
|
ExecutorService |
getReinviteExecutor()
Executor used to optimize the ReinviteSender Runnable in the sendRequest
of the SipDialog
|
ReleaseReferencesStrategy |
getReleaseReferencesStrategy() |
int |
getReliableConnectionKeepAliveTimeout() |
Dialog |
getReplacesDialog(ReplacesHeader replacesHeader)
Get the Replaced Dialog from the stack.
|
SIPServerTransaction |
getRetransmissionAlertTransaction(String dialogId)
Retrieve a transaction from our table of transactions with pending
retransmission alerts.
|
Router |
getRouter() |
Router |
getRouter(SIPRequest request)
Get the router algorithm.
|
ScheduledExecutorService |
getSelfRoutingThreadpoolExecutor() |
int |
getSendUdpBufferSize()
Size of the send UDP buffer.
|
ServerLogger |
getServerLogger()
Server log is the place where we log messages for the signaling trace
viewer.
|
int |
getServerTransactionTableSize()
Get the size of the server transaction table.
|
abstract SipListener |
getSipListener() |
long |
getSslHandshakeTimeout() |
int |
getStackCongestionControlTimeout() |
StackLogger |
getStackLogger()
Deprecated.
|
int |
getTcpPostParsingThreadPoolSize()
If all calls are occurring on a single TCP socket then the stack would process them in single thread.
|
ThreadAuditor |
getThreadAuditor()
get the thread auditor object
|
int |
getThreadPriority() |
SipTimer |
getTimer() |
boolean |
isAggressiveCleanup() |
boolean |
isAlive()
return the status of the toExit flag.
|
boolean |
isCancelClientTransactionChecked() |
boolean |
isDeliverRetransmittedAckToListener()
This is a testing interface.
|
boolean |
isDeliverTerminatedEventForAck() |
boolean |
isDeliverUnsolicitedNotify() |
static boolean |
isDialogCreated(String method)
Return true if extension is supported.
|
boolean |
isEventForked(String ename)
Return true if a given event can result in a forked subscription.
|
boolean |
isLoggingEnabled()
Deprecated.
|
boolean |
isLoggingEnabled(int level)
Deprecated.
|
boolean |
isLogStackTraceOnMessageSend() |
boolean |
isNon2XXAckPassedToListener() |
boolean |
isPatchRport() |
boolean |
isPatchWebSocketHeaders() |
boolean |
isRemoteTagReassignmentAllowed() |
boolean |
isRfc2543Supported() |
boolean |
isSslRenegotiationEnabled() |
boolean |
isTransactionPendingAck(SIPServerTransaction serverTransaction)
Check if this entry exists in the "Transaction Pending ACK" table.
|
void |
mapTransaction(SIPServerTransaction transaction)
Map a Server transaction (possibly sending out a 100 if the server tx is
an INVITE).
|
ServerRequestInterface |
newSIPServerRequest(SIPRequest requestReceived,
MessageChannel requestMessageChannel)
Handles a new SIP request.
|
ServerResponseInterface |
newSIPServerResponse(SIPResponse responseReceived,
MessageChannel responseMessageChannel)
Handles a new SIP response.
|
void |
printDialogTable()
Print the dialog table.
|
SIPDialog |
putDialog(SIPDialog dialog)
Put a dialog into the dialog table.
|
void |
putInMergeTable(SIPServerTransaction sipTransaction,
SIPRequest sipRequest)
Put this into the merge request table.
|
protected void |
putMergeDialog(SIPDialog sipDialog) |
void |
putPendingTransaction(SIPServerTransaction tr)
Put a transaction in the pending transaction list.
|
protected void |
reInit()
Re Initialize the stack instance.
|
void |
removeDialog(SIPDialog dialog)
Remove the dialog from the dialog table.
|
void |
removeDialog(String dialogId)
Remove the dialog given its dialog id.
|
void |
removeFromMergeTable(SIPServerTransaction tr)
Remove a transaction from the merge table.
|
protected void |
removeMergeDialog(String mergeId) |
protected void |
removeMessageProcessor(MessageProcessor oldMessageProcessor)
Removes a MessageProcessor from this SIPStack.
|
void |
removePendingTransaction(SIPServerTransaction tr)
Remove a pending Server transaction from the stack.
|
void |
removeTransaction(SIPTransaction sipTransaction)
Remove transaction.
|
protected void |
removeTransactionHash(SIPTransaction sipTransaction)
Remove the transaction from transaction hash.
|
boolean |
removeTransactionPendingAck(SIPServerTransaction serverTransaction)
Remove entry from "Transaction Pending ACK" table.
|
void |
setAddressResolver(AddressResolver addressResolver)
Set the address resolution interface
|
void |
setAggressiveCleanup(boolean aggressiveCleanup) |
void |
setClientAuth(ClientAuthType clientAuth) |
void |
setConnectionLingerTimer(int connectionLingerTimer) |
void |
setDeliverDialogTerminatedEventForNullDialog() |
void |
setDeliverTerminatedEventForAck(boolean deliverTerminatedEventForAck) |
void |
setDeliverUnsolicitedNotify(boolean deliverUnsolicitedNotify) |
void |
setEarlyDialogTimeout(int earlyDialogTimeout) |
protected void |
setHostAddress(String stackAddress)
Set my address.
|
boolean |
setKeepAliveTimeout(String myAddress,
int myPort,
String transport,
String peerAddress,
int peerPort,
long keepAliveTimeout)
Find suitable MessageProcessor and calls it's
MessageProcessor#setKeepAliveTimeout(String, int, long) method passing
peerAddress and peerPort as arguments. |
void |
setLogRecordFactory(LogRecordFactory logRecordFactory)
Set the logger factory.
|
void |
setLogStackTraceOnMessageSend(boolean logStackTraceOnMessageSend) |
void |
setMaxConnections(int nconnections)
Set the max # of simultaneously handled TCP connections.
|
void |
setMaxForkTime(int maxForkTime) |
void |
setMaxTxLifetimeInvite(int maxTxLifetimeInvite) |
void |
setMaxTxLifetimeNonInvite(int maxTxLifetimeNonInvite) |
protected void |
setMessageFactory(StackMessageFactory messageFactory)
Set the message factory.
|
void |
setMessageParserFactory(MessageParserFactory messageParserFactory) |
void |
setMessageProcessorFactory(MessageProcessorFactory messageProcessorFactory) |
void |
setNon2XXAckPassedToListener(boolean passToListener) |
void |
setPatchRport(Boolean patchRport) |
void |
setPatchWebSocketHeaders(Boolean patchWebSocketHeaders) |
void |
setReceiveUdpBufferSize(int receiveUdpBufferSize)
Size of the receive UDP buffer.
|
void |
setReleaseReferencesStrategy(ReleaseReferencesStrategy releaseReferencesStrategy) |
void |
setReliableConnectionKeepAliveTimeout(int reliableConnectionKeepAliveTimeout) |
protected void |
setRouter(Router router)
Set the router algorithm.
|
void |
setSendUdpBufferSize(int sendUdpBufferSize)
Size of the send UDP buffer.
|
void |
setSingleThreaded()
Set the flag that instructs the stack to only start a single thread for
sequentially processing incoming udp messages (thus serializing the
processing).
|
void |
setSslHandshakeTimeout(long sslHandshakeTimeout) |
void |
setSslRenegotiationEnabled(boolean sslRenegotiationEnabled) |
void |
setStackCongestionControlTimeout(int stackCongestionControlTimeout) |
void |
setStackName(String stackName)
Set the descriptive name of the stack.
|
void |
setTcpPostParsingThreadPoolSize(int tcpPostParsingThreadPoolSize)
If all calls are occurring on a single TCP socket then the stack would process them in single thread.
|
void |
setThreadPoolSize(int size)
Set the thread pool size for processing incoming UDP messages.
|
void |
setThreadPriority(int threadPriority) |
void |
setTimer(SipTimer timer) |
void |
stopStack()
Stop stack.
|
void |
transactionErrorEvent(SIPTransactionErrorEvent transactionErrorEvent)
Invoked when an error has ocurred with a transaction.
|
public static final int BASE_TIMER_INTERVAL
protected int earlyDialogTimeout
protected ConcurrentHashMap<String,SIPServerTransaction> retransmissionAlertTransactions
protected ConcurrentHashMap<String,SIPDialog> earlyDialogTable
protected ConcurrentHashMap<String,SIPDialog> dialogTable
protected ConcurrentHashMap<String,SIPDialog> serverDialogMergeTestTable
protected ConcurrentHashMap<String,SIPClientTransaction> clientTransactionTable
protected boolean unlimitedServerTransactionTableSize
protected boolean unlimitedClientTransactionTableSize
protected int serverTransactionTableHighwaterMark
protected int serverTransactionTableLowaterMark
protected int clientTransactionTableHiwaterMark
protected int clientTransactionTableLowaterMark
protected ConcurrentHashMap<String,SIPServerTransaction> serverTransactionTable
protected boolean deliverRetransmittedAckToListener
protected ServerLogger serverLogger
protected DefaultRouter defaultRouter
protected boolean needsLogging
protected IOHandler ioHandler
protected boolean toExit
protected String stackName
protected String stackAddress
protected InetAddress stackInetAddress
protected StackMessageFactory sipMessageFactory
protected Router router
protected int threadPoolSize
protected int maxConnections
protected boolean cacheServerConnections
protected boolean cacheClientConnections
protected boolean useRouterForAll
protected int maxContentLength
protected int maxMessageSize
protected int readTimeout
protected NetworkLayer networkLayer
protected String outboundProxy
protected String routerPath
protected boolean isAutomaticDialogSupportEnabled
protected boolean generateTimeStampHeader
protected AddressResolver addressResolver
protected int maxListenerResponseTime
protected int maxTxLifetimeInvite
protected int maxTxLifetimeNonInvite
protected boolean rfc2543Supported
protected ThreadAuditor threadAuditor
protected LogRecordFactory logRecordFactory
protected boolean cancelClientTransactionChecked
protected boolean remoteTagReassignmentAllowed
protected boolean logStackTraceOnMessageSend
protected int receiveUdpBufferSize
protected int sendUdpBufferSize
protected boolean isBackToBackUserAgent
protected boolean checkBranchId
protected boolean isAutomaticDialogErrorHandlingEnabled
protected boolean isDialogTerminatedEventDeliveredForNullDialog
protected int maxForkTime
protected boolean patchWebSocketHeaders
protected boolean patchRport
protected ClientAuthType clientAuth
protected long minKeepAliveInterval
protected int dialogTimeoutFactor
public MessageParserFactory messageParserFactory
public MessageProcessorFactory messageProcessorFactory
public long nioSocketMaxIdleTime
public List<SIPMessageValve> sipMessageValves
public SIPEventInterceptor sipEventInterceptor
protected static ScheduledExecutorService selfRoutingThreadpoolExecutor
protected SecurityManagerProvider securityManagerProvider
protected int reliableConnectionKeepAliveTimeout
protected SocketTimeoutAuditor socketTimeoutAuditor
protected SIPTransactionStack()
protected SIPTransactionStack(StackMessageFactory messageFactory)
messageFactory
- User-implemented factory for processing messages.public ScheduledExecutorService getSelfRoutingThreadpoolExecutor()
protected void reInit()
public SocketAddress getLocalAddressForTcpDst(InetAddress dst, int dstPort, InetAddress localAddress, int localPort) throws IOException
dst
- the destination address that the socket would need to connect
to.dstPort
- the port number that the connection would be established
with.localAddress
- the address that we would like to bind on (null for
the "any" address).localPort
- the port that we'd like our socket to bind to (0 for a
random port).IOException
- if binding the socket failspublic SocketAddress getLocalAddressForTlsDst(InetAddress dst, int dstPort, InetAddress localAddress) throws IOException
dst
- the destination address that the socket would need to connect
to.dstPort
- the port number that the connection would be established
with.localAddress
- the address that we would like to bind on
(null for the "any" address).IOException
- if binding the socket failspublic void disableLogging()
public void enableLogging()
public void printDialogTable()
public SIPServerTransaction getRetransmissionAlertTransaction(String dialogId)
dialogId
- public static boolean isDialogCreated(String method)
public void addExtensionMethod(String extensionMethod)
extensionMethod
- -- extension method to support for dialog creationpublic SIPDialog putDialog(SIPDialog dialog)
dialog
- -- dialog to put into the dialog table.public SIPDialog createDialog(SIPTransaction transaction)
transaction
- -- tx to add to the dialog.public SIPDialog createDialog(SIPClientTransaction transaction, SIPResponse sipResponse)
transaction
- sipResponse
- public SIPDialog createDialog(SipProviderImpl sipProvider, SIPResponse sipResponse)
sipProvider
- sipResponse
- public SIPDialog createDialog(SIPClientTransaction subscribeTx, SIPTransaction notifyST)
subscribeTx
- - the transaction started with the SUBSCRIBE that we sentnotifyST
- - the ServerTransaction created for an incoming NOTIFYpublic void removeDialog(SIPDialog dialog)
dialog
- -- dialog to remove.protected void removeMergeDialog(String mergeId)
protected void putMergeDialog(SIPDialog sipDialog)
public SIPDialog getDialog(String dialogId)
dialogId
- is the dialog id to check.public void removeDialog(String dialogId)
dialogId
- is the dialog Id to remove.public SIPClientTransaction findSubscribeTransaction(SIPRequest notifyMessage, ListeningPointImpl listeningPoint)
notifyMessage
- public void addTransactionPendingAck(SIPServerTransaction serverTransaction)
serverTransaction
- public SIPServerTransaction findTransactionPendingAck(SIPRequest ackMessage)
ackMessage
- public boolean removeTransactionPendingAck(SIPServerTransaction serverTransaction)
serverTransaction
- public boolean isTransactionPendingAck(SIPServerTransaction serverTransaction)
serverTransaction
- public SIPTransaction findTransaction(SIPMessage sipMessage, boolean isServer)
sipMessage
- request for which to retrieve the transaction.isServer
- search the server transaction table if true.public SIPTransaction findTransaction(String transactionId, boolean isServer)
public SIPTransaction findCancelTransaction(SIPRequest cancelRequest, boolean isServer)
public SIPServerTransaction findPendingTransaction(String transactionId)
requestReceived
- public boolean findMergedTransaction(SIPRequest sipRequest)
public void removePendingTransaction(SIPServerTransaction tr)
tr
- -- pending transaction to remove.public void removeFromMergeTable(SIPServerTransaction tr)
tr
- -- the server transaction to remove from the merge table.public void putInMergeTable(SIPServerTransaction sipTransaction, SIPRequest sipRequest)
sipTransaction
- -- transaction to put into the merge table.public void mapTransaction(SIPServerTransaction transaction)
transaction
- -- the server transaction to map.public ServerRequestInterface newSIPServerRequest(SIPRequest requestReceived, MessageChannel requestMessageChannel)
requestReceived
- Request to handle.requestMessageChannel
- Channel that received message.public ServerResponseInterface newSIPServerResponse(SIPResponse responseReceived, MessageChannel responseMessageChannel)
responseReceived
- Response to handle.responseMessageChannel
- Channel that received message.public MessageChannel createMessageChannel(SIPRequest request, MessageProcessor mp, Hop nextHop) throws IOException
nextHop
- Hop to create a channel to contact.IOException
public SIPClientTransaction createClientTransaction(SIPRequest sipRequest, MessageChannel encapsulatedMessageChannel)
encapsulatedMessageChannel
- Message channel of the transport layer.public SIPServerTransaction createServerTransaction(MessageChannel encapsulatedMessageChannel)
encapsulatedMessageChannel
- Message channel of the transport layer.public int getClientTransactionTableSize()
public int getServerTransactionTableSize()
public void addTransaction(SIPClientTransaction clientTransaction)
clientTransaction
- -- client transaction to add to the set.public void removeTransaction(SIPTransaction sipTransaction)
public void addTransaction(SIPServerTransaction serverTransaction) throws IOException
serverTransaction
- -- server transaction to add to the set.IOException
protected void decrementActiveClientTransactionCount()
protected void removeTransactionHash(SIPTransaction sipTransaction)
public void transactionErrorEvent(SIPTransactionErrorEvent transactionErrorEvent)
transactionErrorEvent
in interface SIPTransactionEventListener
transactionErrorEvent
- Error event.public void dialogErrorEvent(SIPDialogErrorEvent dialogErrorEvent)
SIPDialogEventListener
dialogErrorEvent
in interface SIPDialogEventListener
dialogErrorEvent
- Error event.public void stopStack()
public void closeAllSockets()
public void putPendingTransaction(SIPServerTransaction tr)
public NetworkLayer getNetworkLayer()
@Deprecated public boolean isLoggingEnabled()
@Deprecated public boolean isLoggingEnabled(int level)
level
- @Deprecated public StackLogger getStackLogger()
public ServerLogger getServerLogger()
public int getMaxMessageSize()
public void setSingleThreaded()
public int getTcpPostParsingThreadPoolSize()
public void setTcpPostParsingThreadPoolSize(int tcpPostParsingThreadPoolSize)
tcpPostParsingThreadPoolSize
- public void setThreadPoolSize(int size)
size
- -- the thread pool size.public void setMaxConnections(int nconnections)
nconnections
- -- the number of connections to handle.public Hop getNextHop(SIPRequest sipRequest) throws SipException
sipRequest
- is the request for which we want to compute the next hop.SipException
public void setStackName(String stackName)
stackName
- -- descriptive name of the stack.protected void setHostAddress(String stackAddress) throws UnknownHostException
stackAddress
- -- A string containing the stack address.UnknownHostException
public String getHostAddress()
protected void setRouter(Router router)
router
- A class that implements the Router interface.public Router getRouter(SIPRequest request)
public Router getRouter()
public boolean isAlive()
protected void addMessageProcessor(MessageProcessor newMessageProcessor) throws IOException
IOException
protected void removeMessageProcessor(MessageProcessor oldMessageProcessor)
oldMessageProcessor
- protected MessageProcessor[] getMessageProcessors()
protected MessageProcessor createMessageProcessor(InetAddress ipAddress, int port, String transport) throws IOException
ipAddress
- -- ip address for the listening point.port
- -- port for the listening point.transport
- -- transport for the listening point.IOException
protected void setMessageFactory(StackMessageFactory messageFactory)
messageFactory
- -- messageFactory to set.public MessageChannel createRawMessageChannel(String sourceIpAddress, int sourcePort, Hop nextHop) throws UnknownHostException
sourceIpAddress
- - Ip address of the source of this message.sourcePort
- - source port of the message channel to be created.nextHop
- Hop to create a MessageChannel to.UnknownHostException
- If the host in the Hop doesn't exist.public boolean isEventForked(String ename)
ename
- -- event name to check.public AddressResolver getAddressResolver()
public void setAddressResolver(AddressResolver addressResolver)
addressResolver
- -- the address resolver to set.public void setLogRecordFactory(LogRecordFactory logRecordFactory)
logRecordFactory
- -- the log record factory to set.public ThreadAuditor getThreadAuditor()
public String auditStack(Set activeCallIDs, long leakedDialogTimer, long leakedTransactionTimer)
public void setNon2XXAckPassedToListener(boolean passToListener)
public boolean isNon2XXAckPassedToListener()
public int getActiveClientTransactionCount()
public boolean isRfc2543Supported()
public boolean isCancelClientTransactionChecked()
public boolean isRemoteTagReassignmentAllowed()
public Collection<Dialog> getDialogs()
public Collection<Dialog> getDialogs(DialogState state)
public Dialog getReplacesDialog(ReplacesHeader replacesHeader)
replacesHeader
- -- the header that references the dialog being replaced.public Dialog getJoinDialog(JoinHeader joinHeader)
joinHeader
- -- the header that references the dialog being joined.public void setTimer(SipTimer timer)
timer
- the timer to setpublic SipTimer getTimer() throws IllegalStateException
IllegalStateException
public int getReceiveUdpBufferSize()
public void setReceiveUdpBufferSize(int receiveUdpBufferSize)
public int getSendUdpBufferSize()
public void setSendUdpBufferSize(int sendUdpBufferSize)
public boolean checkBranchId()
public void setLogStackTraceOnMessageSend(boolean logStackTraceOnMessageSend)
logStackTraceOnMessageSend
- the logStackTraceOnMessageSend to setpublic boolean isLogStackTraceOnMessageSend()
public void setDeliverDialogTerminatedEventForNullDialog()
public void addForkedClientTransaction(SIPClientTransaction clientTransaction)
public SIPClientTransaction getForkedTransaction(String transactionId)
public void setDeliverUnsolicitedNotify(boolean deliverUnsolicitedNotify)
deliverUnsolicitedNotify
- the deliverUnsolicitedNotify to setpublic boolean isDeliverUnsolicitedNotify()
public void setDeliverTerminatedEventForAck(boolean deliverTerminatedEventForAck)
deliverTerminatedEventForAck
- the deliverTerminatedEventForAck to setpublic boolean isDeliverTerminatedEventForAck()
public long getMinKeepAliveInterval()
public void setPatchWebSocketHeaders(Boolean patchWebSocketHeaders)
public boolean isPatchWebSocketHeaders()
public void setPatchRport(Boolean patchRport)
public boolean isPatchRport()
public void setMaxForkTime(int maxForkTime)
maxForkTime
- the maxForkTime to setpublic int getMaxForkTime()
public boolean isDeliverRetransmittedAckToListener()
public int getAckTimeoutFactor()
public abstract SipListener getSipListener()
public ExecutorService getReinviteExecutor()
public void setMessageParserFactory(MessageParserFactory messageParserFactory)
messageParserFactory
- the messageParserFactory to setpublic MessageParserFactory getMessageParserFactory()
public void setMessageProcessorFactory(MessageProcessorFactory messageProcessorFactory)
messageProcessorFactory
- the messageProcessorFactory to setpublic MessageProcessorFactory getMessageProcessorFactory()
public void setAggressiveCleanup(boolean aggressiveCleanup)
aggressiveCleanup
- the aggressiveCleanup to setpublic boolean isAggressiveCleanup()
public int getEarlyDialogTimeout()
public void setClientAuth(ClientAuthType clientAuth)
clientAuth
- the clientAuth to setpublic ClientAuthType getClientAuth()
public void setThreadPriority(int threadPriority)
threadPriority
- the threadPriority to setpublic int getThreadPriority()
public int getReliableConnectionKeepAliveTimeout()
public void setReliableConnectionKeepAliveTimeout(int reliableConnectionKeepAliveTimeout)
public boolean setKeepAliveTimeout(String myAddress, int myPort, String transport, String peerAddress, int peerPort, long keepAliveTimeout)
MessageProcessor#setKeepAliveTimeout(String, int, long)
method passing
peerAddress and peerPort as arguments.myAddress
- - server ip addressmyPort
- - server porttransport
- - transportpeerAddress
- - peerAddresspeerPort
- - peerPortMessageProcessor#setKeepAliveTimeout(String, int, long)
if MessageProcessor was foundpublic boolean closeReliableConnection(String myAddress, int myPort, String transport, String peerAddress, int peerPort)
MessageProcessor#closeReliableConnection(String, int)
method passing peerAddress and peerPort as arguments.myAddress
- - server ip addressmyPort
- - server porttransport
- - transportpeerAddress
- - peerAddresspeerPort
- - peerPortpublic long getSslHandshakeTimeout()
public void setSslHandshakeTimeout(long sslHandshakeTimeout)
sslHandshakeTimeout
- the sslHandshakeTimeout to setpublic void setEarlyDialogTimeout(int earlyDialogTimeout)
earlyDialogTimeout
- the earlyDialogTimeout to setpublic int getMaxTxLifetimeInvite()
public void setMaxTxLifetimeInvite(int maxTxLifetimeInvite)
maxTxLifetimeInvite
- the maxTxLifetimeInvite to setpublic int getMaxTxLifetimeNonInvite()
public void setMaxTxLifetimeNonInvite(int maxTxLifetimeNonInvite)
maxTxLifetimeNonInvite
- the maxTxLifetimeNonInvite to setpublic boolean isSslRenegotiationEnabled()
public void setSslRenegotiationEnabled(boolean sslRenegotiationEnabled)
public int getConnectionLingerTimer()
public void setConnectionLingerTimer(int connectionLingerTimer)
connectionLingerTimer
- the connectionLingerTimer to setpublic int getStackCongestionControlTimeout()
public void setStackCongestionControlTimeout(int stackCongestionControlTimeout)
stackCongestionControlTimeout
- the stackCongestionControlTimeout to setpublic ReleaseReferencesStrategy getReleaseReferencesStrategy()
public void setReleaseReferencesStrategy(ReleaseReferencesStrategy releaseReferencesStrategy)
releaseReferencesStrategy
- the releaseReferencesStrategy to setCopyright © 2016. All Rights Reserved.