Package org.apache.geode.cache.wan
Interface GatewaySender
public interface GatewaySender
- Since:
- GemFire 7.0
-
Nested Class Summary
Nested Classes -
Field Summary
FieldsModifier and TypeFieldDescriptionstatic final intRetry a connection from sender to receiver after specified time interval (in milliseconds) in case receiver is not up and running.static final intThe default alert threshold in millisecondsstatic final booleanThe default batch conflationstatic final intThe default batch sizestatic final intThe default batch time interval in millisecondsstatic final booleanThe default value ( true) for writing to disk synchronously in case of persistence.static final intstatic final intstatic final booleanstatic final booleanstatic final booleanstatic final booleanstatic final booleanDeprecated.- Manual start of senders is deprecated and will be removed in a later release.static final intThe default maximum amount of memory (MB) to allow in the queue before overflowing entries to diskstatic final booleanstatic final GatewaySender.OrderPolicystatic final intstatic final booleanThe default value (false)of whether to persist queue data to disk or not.static final intThe default buffer size for socket buffers from a sending GatewaySender to its receivingGatewayReceiver.static final intThe default amount of time in milliseconds that a socket read between a sendingGatewayand its receivingGatewaywill block.static final booleanstatic final intstatic final StringThe obsolete socket read timeout java system property.static final longTime, in seconds, that we allow before aGatewaySenderis considered dead and should be abortedstatic final intNumber of times to retry to get events for a transaction from the gateway sender queue when group-transaction-events is set to true.static final intMilliseconds to wait before retrying to get events for a transaction from the gateway sender queue when group-transaction-events is true.static final intThe default minimum socket read timeout.static final intSize of the oplog file used for the persistent queue in bytesstatic final booleanIf the System property is set, use it. -
Method Summary
Modifier and TypeMethodDescriptionvoidAdds the providedGatewayEventFilterto this GatewaySender.voiddestroy()Destroys the GatewaySender.intReturns the alert threshold in milliseconds for entries in a GatewaySender's queue.intReturns the batch size for this GatewaySender.intReturns the batch time interval for this GatewaySender.Gets the disk store name for overflow or persistence.intReturns the number of dispatcher threads working for thisGatewaySender.booleanReturns enforceThreadsConnectSameReceiver boolean property for this GatewaySender.Returns the list ofGatewayEventFilteradded to this GatewaySender.Returns thisGatewaySender'sGatewayEventSubstitutionFilter.Returns the list ofGatewayTransportFilteradded to this GatewaySender.getId()Returns the id of this GatewaySender.intReturns the maximum amount of memory (in MB) for a GatewaySender's queue.intReturns the order policy followed while dispatching the events to remote ds.intReturns the id of the remoteGatewayReceiver's DistributedSystem.intReturns the configured buffer size of the socket connection between this GatewaySender and its receivingGatewayReceiver.intReturns the amount of time in milliseconds that a socket read between a sending GatewaySender and its receivingGatewayReceiverwill block.booleanAnswers whether to enable batch conflation for a GatewaySender 's queue.booleanReturns isDiskSynchronous boolean property for this GatewaySender.booleanDeprecated.- Manual start of senders is deprecated and will be removed in a later release.booleanReturns isParallel boolean property for this GatewaySender.booleanisPaused()Returns whether or not this GatewaySender is paused.booleanReturns true if persistence is enabled for this GatewaySender, otherwise returns false.booleanReturns whether or not this GatewaySender is running.booleanReturns groupTransactionEvents boolean property for this GatewaySender.voidpause()Pauses the dispatching of the events from the underlying queue.voidRebalances this GatewaySender.voidRemoves the providedGatewayEventFilterfrom this GatewaySender.voidresume()Resumes this paused GatewaySender.voidstart()Starts this GatewaySender.voidStarts this GatewaySender and discards previous queue content.voidstop()Stops this GatewaySender.
-
Field Details
-
DEFAULT_MANUAL_START
Deprecated.- Manual start of senders is deprecated and will be removed in a later release.The default value (false) for manually starting aGatewaySender.- See Also:
-
DEFAULT_DISK_SYNCHRONOUS
static final boolean DEFAULT_DISK_SYNCHRONOUSThe default value ( true) for writing to disk synchronously in case of persistence.- See Also:
-
DEFAULT_SOCKET_BUFFER_SIZE
static final int DEFAULT_SOCKET_BUFFER_SIZEThe default buffer size for socket buffers from a sending GatewaySender to its receivingGatewayReceiver.- See Also:
-
DEFAULT_SOCKET_READ_TIMEOUT
static final int DEFAULT_SOCKET_READ_TIMEOUTThe default amount of time in milliseconds that a socket read between a sendingGatewayand its receivingGatewaywill block. -
MINIMUM_SOCKET_READ_TIMEOUT
static final int MINIMUM_SOCKET_READ_TIMEOUTThe default minimum socket read timeout.- See Also:
-
QUEUE_OPLOG_SIZE
static final int QUEUE_OPLOG_SIZESize of the oplog file used for the persistent queue in bytes -
DEFAULT_PERSISTENCE_ENABLED
static final boolean DEFAULT_PERSISTENCE_ENABLEDThe default value (false)of whether to persist queue data to disk or not.- See Also:
-
DEFAULT_BATCH_CONFLATION
static final boolean DEFAULT_BATCH_CONFLATIONThe default batch conflation- See Also:
-
DEFAULT_BATCH_SIZE
static final int DEFAULT_BATCH_SIZEThe default batch size- See Also:
-
DEFAULT_BATCH_TIME_INTERVAL
static final int DEFAULT_BATCH_TIME_INTERVALThe default batch time interval in milliseconds- See Also:
-
DEFAULT_ALERT_THRESHOLD
static final int DEFAULT_ALERT_THRESHOLDThe default alert threshold in milliseconds- See Also:
-
DEFAULT_PARALLELISM_REPLICATED_REGION
static final int DEFAULT_PARALLELISM_REPLICATED_REGION -
DEFAULT_DISTRIBUTED_SYSTEM_ID
static final int DEFAULT_DISTRIBUTED_SYSTEM_ID- See Also:
-
DEFAULT_DISPATCHER_THREADS
static final int DEFAULT_DISPATCHER_THREADS- See Also:
-
DEFAULT_FORWARD_EXPIRATION_DESTROY
static final boolean DEFAULT_FORWARD_EXPIRATION_DESTROY- See Also:
-
DEFAULT_ORDER_POLICY
-
DEFAULT_MAXIMUM_QUEUE_MEMORY
static final int DEFAULT_MAXIMUM_QUEUE_MEMORYThe default maximum amount of memory (MB) to allow in the queue before overflowing entries to disk- See Also:
-
GATEWAY_SENDER_TIMEOUT
static final long GATEWAY_SENDER_TIMEOUTTime, in seconds, that we allow before aGatewaySenderis considered dead and should be aborted -
GATEWAY_CONNECTION_READ_TIMEOUT_PROPERTY
The obsolete socket read timeout java system property. Since customers have been given this property, it is used to log a warning.- See Also:
-
GATEWAY_CONNECTION_IDLE_TIMEOUT
static final int GATEWAY_CONNECTION_IDLE_TIMEOUT -
REMOVE_FROM_QUEUE_ON_EXCEPTION
static final boolean REMOVE_FROM_QUEUE_ON_EXCEPTIONIf the System property is set, use it. Otherwise, set default to 'true'. -
EARLY_ACK
static final boolean EARLY_ACK -
DEFAULT_IS_PARALLEL
static final boolean DEFAULT_IS_PARALLEL- See Also:
-
DEFAULT_MUST_GROUP_TRANSACTION_EVENTS
static final boolean DEFAULT_MUST_GROUP_TRANSACTION_EVENTS- See Also:
-
DEFAULT_IS_FOR_INTERNAL_USE
static final boolean DEFAULT_IS_FOR_INTERNAL_USE- See Also:
-
DEFAULT_ENFORCE_THREADS_CONNECT_SAME_RECEIVER
static final boolean DEFAULT_ENFORCE_THREADS_CONNECT_SAME_RECEIVER- See Also:
-
CONNECTION_RETRY_INTERVAL
static final int CONNECTION_RETRY_INTERVALRetry a connection from sender to receiver after specified time interval (in milliseconds) in case receiver is not up and running. Default is set to 1000 milliseconds i.e. 1 second. -
GET_TRANSACTION_EVENTS_FROM_QUEUE_RETRIES
static final int GET_TRANSACTION_EVENTS_FROM_QUEUE_RETRIESNumber of times to retry to get events for a transaction from the gateway sender queue when group-transaction-events is set to true. When group-transaction-events is set to true and a batch ready to be sent does not contain all the events for all the transactions to which the events belong, the gateway sender will try to get the missing events of the transactions from the queue to add them to the batch before sending it. If the missing events are not in the queue when the gateway sender tries to get them it will retry for a maximum of times equal to the value set in this parameter before delivering the batch without the missing events and logging an error. Setting this parameter to a very low value could cause that under heavy load and group-transaction-events set to true, batches are sent with incomplete transactions. Setting it to a high value could cause that under heavy load and group-transaction-events set to true, batches are held for some time before being sent. -
GET_TRANSACTION_EVENTS_FROM_QUEUE_WAIT_TIME_MS
static final int GET_TRANSACTION_EVENTS_FROM_QUEUE_WAIT_TIME_MSMilliseconds to wait before retrying to get events for a transaction from the gateway sender queue when group-transaction-events is true.
-
-
Method Details
-
start
void start()Starts this GatewaySender. Once the GatewaySender is running, its configuration cannot be changed. -
startWithCleanQueue
void startWithCleanQueue()Starts this GatewaySender and discards previous queue content. Once the GatewaySender is running, its configuration cannot be changed. -
stop
void stop()Stops this GatewaySender. The scope of this operation is the VM on which it is invoked. In case the GatewaySender is parallel, the GatewaySender will be stopped on individual node where this API is called. If the GatewaySender is not parallel, then the GatewaySender will stop on this VM and the secondary GatewaySender will become primary and start dispatching events. The GatewaySender will wait for GatewaySender.MAXIMUM_SHUTDOWN_WAIT_TIME seconds before stopping itself. If the system property is set to -1 then it will wait until all the events are dispatched from the queue.- See Also:
-
pause
void pause()Pauses the dispatching of the events from the underlying queue. It should be kept in mind that the events will still be getting queued into the queue. The scope of this operation is the VM on which it is invoked. In case the GatewaySender is parallel, the GatewaySender will be paused on individual node where this API is called and the GatewaySender on other VM's can still dispatch events. In case the GatewaySender is not parallel, and the running GatewaySender on which this API is invoked is not primary then PRIMARY GatewaySender will still continue dispatching events. The batch of events that are in the process of being dispatched are dispatched irrespective of the state of pause operation. We can expect maximum of one batch of events being received at the GatewayReceiver even after the GatewaySenders were paused.- See Also:
-
resume
void resume()Resumes this paused GatewaySender. -
rebalance
void rebalance()Rebalances this GatewaySender. -
isRunning
boolean isRunning()Returns whether or not this GatewaySender is running.- Returns:
- whether this GatewaySender is running
-
isPaused
boolean isPaused()Returns whether or not this GatewaySender is paused.- Returns:
- whether this GatewaySender is paused
-
addGatewayEventFilter
Adds the providedGatewayEventFilterto this GatewaySender.- Parameters:
filter- theGatewayEventFilterto add
-
removeGatewayEventFilter
Removes the providedGatewayEventFilterfrom this GatewaySender.- Parameters:
filter- theGatewayEventFilterto remove
-
getGatewayEventSubstitutionFilter
GatewayEventSubstitutionFilter getGatewayEventSubstitutionFilter()Returns thisGatewaySender'sGatewayEventSubstitutionFilter.- Returns:
- this
GatewaySender'sGatewayEventSubstitutionFilter
-
getId
String getId()Returns the id of this GatewaySender.- Returns:
- the id of this GatewaySender.
-
getRemoteDSId
int getRemoteDSId()Returns the id of the remoteGatewayReceiver's DistributedSystem.- Returns:
- the id of the remote
GatewayReceiver's DistributedSystem.
-
getSocketBufferSize
int getSocketBufferSize()Returns the configured buffer size of the socket connection between this GatewaySender and its receivingGatewayReceiver. The default is 32768 bytes.- Returns:
- the configured buffer size of the socket connection between this GatewaySender and its
receiving
GatewayReceiver
-
getSocketReadTimeout
int getSocketReadTimeout()Returns the amount of time in milliseconds that a socket read between a sending GatewaySender and its receivingGatewayReceiverwill block. The default value is 0 which is interpreted as infinite timeout.- Returns:
- the amount of time in milliseconds that a socket read between a sending GatewaySender
and its receiving
GatewayReceiverwill block
-
getDiskStoreName
String getDiskStoreName()Gets the disk store name for overflow or persistence.- Returns:
- disk store name
-
getMaximumQueueMemory
int getMaximumQueueMemory()Returns the maximum amount of memory (in MB) for a GatewaySender's queue. The default is 100.- Returns:
- maximum amount of memory (in MB) for a GatewaySender's queue
-
getBatchSize
int getBatchSize()Returns the batch size for this GatewaySender. Default batchSize is 100.- Returns:
- the batch size for this GatewaySender.
-
getBatchTimeInterval
int getBatchTimeInterval()Returns the batch time interval for this GatewaySender. Default value of batchTimeInterval is 1000.- Returns:
- the batch time interval for this GatewaySender
-
isBatchConflationEnabled
boolean isBatchConflationEnabled()Answers whether to enable batch conflation for a GatewaySender 's queue. The default value is false.- Returns:
- whether to enable batch conflation for batches sent from a GatewaySender to its
corresponding
GatewayReceiver.
-
isPersistenceEnabled
boolean isPersistenceEnabled()Returns true if persistence is enabled for this GatewaySender, otherwise returns false. Default is false if not set explicitly.- Returns:
- true if persistence is enabled for this GatewaySender
-
getAlertThreshold
int getAlertThreshold()Returns the alert threshold in milliseconds for entries in a GatewaySender's queue. Default value is 0.- Returns:
- the alert threshold for entries in a GatewaySender's queue
-
getGatewayEventFilters
List<GatewayEventFilter> getGatewayEventFilters()Returns the list ofGatewayEventFilteradded to this GatewaySender.- Returns:
- the list of
GatewayEventFilteradded to this GatewaySender.
-
getGatewayTransportFilters
List<GatewayTransportFilter> getGatewayTransportFilters()Returns the list ofGatewayTransportFilteradded to this GatewaySender.- Returns:
- the list of
GatewayTransportFilteradded to this GatewaySender.
-
isDiskSynchronous
boolean isDiskSynchronous()Returns isDiskSynchronous boolean property for this GatewaySender. Default value is true.- Returns:
- isDiskSynchronous boolean property for this GatewaySender
-
isManualStart
Deprecated.- Manual start of senders is deprecated and will be removed in a later release.Returns the manual start boolean property for this GatewaySender. Default is false i.e. the GatewaySender will automatically start once created.- Returns:
- the manual start boolean property for this GatewaySender
-
isParallel
boolean isParallel()Returns isParallel boolean property for this GatewaySender.- Returns:
- isParallel boolean property for this GatewaySender
-
mustGroupTransactionEvents
boolean mustGroupTransactionEvents()Returns groupTransactionEvents boolean property for this GatewaySender.- Returns:
- groupTransactionEvents boolean property for this GatewaySender
-
getDispatcherThreads
int getDispatcherThreads()Returns the number of dispatcher threads working for thisGatewaySender. Default number of dispatcher threads is 5.- Returns:
- the number of dispatcher threads working for this
GatewaySender
-
getOrderPolicy
GatewaySender.OrderPolicy getOrderPolicy()Returns the order policy followed while dispatching the events to remote ds. Order policy is set only when dispatcher threads are > 1. Default value of order policy is KEY.- Returns:
- the order policy followed while dispatching the events to remote ds.
-
getMaxParallelismForReplicatedRegion
int getMaxParallelismForReplicatedRegion() -
destroy
void destroy()Destroys the GatewaySender.In case of ParallelGatewaySender, the destroy operation does distributed destroy of the Queue Region. In case of SerialGatewaySender, the Queue Region is destroyed locally.
- Since:
- Geode 1.1
-
getEnforceThreadsConnectSameReceiver
boolean getEnforceThreadsConnectSameReceiver()Returns enforceThreadsConnectSameReceiver boolean property for this GatewaySender.- Returns:
- enforceThreadsConnectSameReceiver boolean property for this GatewaySender
-