Package | Description |
---|---|
com.hazelcast.client.spi.impl |
Provides util classes for the Hazelcast client SPI.
|
com.hazelcast.client.spi.properties |
Contains the Hazelcast client properties implementation.
|
com.hazelcast.internal.diagnostics |
Contains functionality what is happening in a HazelcastInstance.
|
com.hazelcast.map.impl.event | |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.spi.properties |
Contains the Hazelcast properties implementation.
|
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
ClientExecutionServiceImpl.INTERNAL_EXECUTOR_POOL_SIZE |
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
ClientProperty.COMPATIBILITY_3_6_SERVER_ENABLED
When this property is true, if the client can not know the server version it will assume that the server is version 3.6.x.
|
static HazelcastProperty |
ClientProperty.DISCOVERY_SPI_ENABLED
Enables the Discovery SPI lookup over the old native implementations.
|
static HazelcastProperty |
ClientProperty.DISCOVERY_SPI_PUBLIC_IP_ENABLED
Enables the Discovery Joiner to use public ips from DiscoveredNode.
|
static HazelcastProperty |
ClientProperty.EVENT_QUEUE_CAPACITY
Capacity of the executor that handles the incoming event packets.
|
static HazelcastProperty |
ClientProperty.EVENT_THREAD_COUNT
Number of the threads to handle the incoming event packets.
|
static HazelcastProperty |
ClientProperty.HEARTBEAT_INTERVAL
Time interval between the heartbeats sent by the client to the nodes.
|
static HazelcastProperty |
ClientProperty.HEARTBEAT_TIMEOUT
Client sends heartbeat messages to the members and this is the timeout for this sending operations.
|
static HazelcastProperty |
ClientProperty.INVOCATION_TIMEOUT_SECONDS
When an invocation gets an exception because :
- Member throws an exception.
|
static HazelcastProperty |
ClientProperty.IO_BALANCER_INTERVAL_SECONDS
The interval in seconds between
IOBalancer
executions. |
static HazelcastProperty |
ClientProperty.IO_INPUT_THREAD_COUNT
Controls the number of socket input threads.
|
static HazelcastProperty |
ClientProperty.IO_OUTPUT_THREAD_COUNT
Controls the number of socket output threads.
|
static HazelcastProperty |
ClientProperty.MAX_CONCURRENT_INVOCATIONS
The maximum number of concurrent invocations allowed.
|
static HazelcastProperty |
ClientProperty.SHUFFLE_MEMBER_LIST
Client shuffles the given member list to prevent all clients to connect to the same node when
this property is set to false.
|
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
Diagnostics.DIRECTORY
Configures the output directory of the performance log files.
|
static HazelcastProperty |
SystemLogPlugin.ENABLED
If this plugin is enabled.
|
static HazelcastProperty |
Diagnostics.ENABLED
Use the
Diagnostics to see internal performance metrics and cluster related information. |
static HazelcastProperty |
Diagnostics.HUMAN_FRIENDLY_FORMAT
Determines if a human friendly, but more difficult to parse, output format is selected for dumping the metrics.
|
static HazelcastProperty |
SystemLogPlugin.LOG_PARTITIONS
If logging partition migration is enabled.
|
static HazelcastProperty |
Diagnostics.MAX_ROLLED_FILE_COUNT
The
DiagnosticsLogFile uses a rolling file approach to prevent eating too much disk space. |
static HazelcastProperty |
Diagnostics.MAX_ROLLED_FILE_SIZE_MB
The
DiagnosticsLogFile uses a rolling file approach to prevent eating too much disk space. |
static HazelcastProperty |
Diagnostics.METRICS_LEVEL
The minimum level for probes is MANDATORY, but it can be changed to INFO or DEBUG.
|
static HazelcastProperty |
SlowOperationPlugin.PERIOD_SECONDS
The period in seconds the SlowOperationPlugin runs.
|
static HazelcastProperty |
MetricsPlugin.PERIOD_SECONDS
The period in seconds the
MetricsPlugin runs. |
static HazelcastProperty |
StoreLatencyPlugin.PERIOD_SECONDS
The period in seconds this plugin runs.
|
static HazelcastProperty |
PendingInvocationsPlugin.PERIOD_SECONDS
The period in seconds this plugin runs.
|
static HazelcastProperty |
OverloadedConnectionsPlugin.PERIOD_SECONDS
The period in seconds this plugin runs.
|
static HazelcastProperty |
MemberHazelcastInstanceInfoPlugin.PERIOD_SECONDS
The period in seconds the HazelcastMemberInstanceInfoPlugin runs.
|
static HazelcastProperty |
StoreLatencyPlugin.RESET_PERIOD_SECONDS
The period in second the statistics should be reset.
|
static HazelcastProperty |
InvocationPlugin.SAMPLE_PERIOD_SECONDS
The sample period in seconds.
|
static HazelcastProperty |
OverloadedConnectionsPlugin.SAMPLES
The number of samples to take from a single overloaded connection.
|
static HazelcastProperty |
InvocationPlugin.SLOW_MAX_COUNT
The maximum number of slow invocations to print
|
static HazelcastProperty |
InvocationPlugin.SLOW_THRESHOLD_SECONDS
The threshold in seconds to consider an invocation to be slow.
|
static HazelcastProperty |
PendingInvocationsPlugin.THRESHOLD
The minimum number of invocations per type of operation before it start logging this particular operation.
|
static HazelcastProperty |
OverloadedConnectionsPlugin.THRESHOLD
The minimum number of packets in the connection before it is considered to be overloaded.
|
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
MapEventPublisherImpl.LISTENER_WITH_PREDICATE_PRODUCES_NATURAL_EVENT_TYPES
When
true , enables processing of entry events for listeners with predicates to fit with "query cache" concept:
for example when the original event indicates an update from an old value that does not match the predicate to a new value
that does match, then the entry listener will be notified with an ADDED event. |
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
AsyncInboundResponseHandler.IDLE_STRATEGY |
Modifier and Type | Method and Description |
---|---|
static IdleStrategy |
AsyncInboundResponseHandler.getIdleStrategy(HazelcastProperties properties,
HazelcastProperty property) |
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
GroupProperty.AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION
Run aggregation accumulation for multiple entries in parallel.
|
static HazelcastProperty |
GroupProperty.APPLICATION_VALIDATION_TOKEN
Use this property to verify that Hazelcast nodes only join the cluster when their 'application' level configuration is the
same.
|
static HazelcastProperty |
GroupProperty.BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
Control the maximum timeout in millis to wait for an invocation space to be available.
|
static HazelcastProperty |
GroupProperty.BACKPRESSURE_ENABLED
Using back pressure, you can prevent an overload of pending asynchronous backups.
|
static HazelcastProperty |
GroupProperty.BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
The maximum number of concurrent invocations per partition.
|
static HazelcastProperty |
GroupProperty.BACKPRESSURE_SYNCWINDOW
Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.
|
static HazelcastProperty |
GroupProperty.CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED
Defines cache invalidation event batch sending is enabled or not.
|
static HazelcastProperty |
GroupProperty.CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
Defines the cache invalidation event batch sending frequency in seconds.
|
static HazelcastProperty |
GroupProperty.CACHE_INVALIDATION_MESSAGE_BATCH_SIZE
Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch.
|
static HazelcastProperty |
GroupProperty.CLIENT_ENDPOINT_REMOVE_DELAY_SECONDS
Client connection is removed or owner node of a client is removed from cluster
ClientDisconnectedOperation runs and clean all resources of client(listeners are removed, locks/txn are released)
With this property, client has a window to connect back and prevent cleaning up its resources.
|
static HazelcastProperty |
GroupProperty.CLIENT_ENGINE_QUERY_THREAD_COUNT |
static HazelcastProperty |
GroupProperty.CLIENT_ENGINE_THREAD_COUNT
The number of threads that the client engine has available for processing requests that are not partition specific.
|
static HazelcastProperty |
GroupProperty.CLIENT_HEARTBEAT_TIMEOUT_SECONDS |
static HazelcastProperty |
GroupProperty.CLUSTER_SHUTDOWN_TIMEOUT_SECONDS |
static HazelcastProperty |
GroupProperty.COMPATIBILITY_3_6_CLIENT_ENABLED
When this property is true, if the server can not determine the connected client version, it shall assume that it is of
3.6.x version client.
|
static HazelcastProperty |
GroupProperty.CONNECT_ALL_WAIT_SECONDS |
static HazelcastProperty |
GroupProperty.CONNECTION_MONITOR_INTERVAL |
static HazelcastProperty |
GroupProperty.CONNECTION_MONITOR_MAX_FAULTS |
static HazelcastProperty |
GroupProperty.DISABLE_STALE_READ_ON_PARTITION_MIGRATION |
static HazelcastProperty |
GroupProperty.DISCOVERY_SPI_ENABLED
Enables the Discovery SPI lookup over the old native implementations.
|
static HazelcastProperty |
GroupProperty.DISCOVERY_SPI_PUBLIC_IP_ENABLED
Enables the Discovery Joiner to use public ips from DiscoveredNode.
|
static HazelcastProperty |
GroupProperty.ENABLE_JMX |
static HazelcastProperty |
GroupProperty.ENABLE_JMX_DETAILED |
static HazelcastProperty |
GroupProperty.ENTERPRISE_LICENSE_KEY |
static HazelcastProperty |
GroupProperty.EVENT_QUEUE_CAPACITY |
static HazelcastProperty |
GroupProperty.EVENT_QUEUE_TIMEOUT_MILLIS |
static HazelcastProperty |
GroupProperty.EVENT_SYNC_TIMEOUT_MILLIS
To prevent overload on the outbound connections, once and a while an event is made synchronous by wrapping it in a
fake operation and waiting for a fake response.
|
static HazelcastProperty |
GroupProperty.EVENT_THREAD_COUNT |
static HazelcastProperty |
GroupProperty.GENERIC_OPERATION_THREAD_COUNT
The number of generic operation handler threads per Member.
|
static HazelcastProperty |
GroupProperty.GRACEFUL_SHUTDOWN_MAX_WAIT |
static HazelcastProperty |
GroupProperty.HEALTH_MONITORING_DELAY_SECONDS |
static HazelcastProperty |
GroupProperty.HEALTH_MONITORING_LEVEL |
static HazelcastProperty |
GroupProperty.HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE |
static HazelcastProperty |
GroupProperty.HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE |
static HazelcastProperty |
GroupProperty.HEARTBEAT_INTERVAL_SECONDS |
static HazelcastProperty |
GroupProperty.HTTP_HEALTHCHECK_ENABLED |
static HazelcastProperty |
GroupProperty.ICMP_ENABLED
If a member should be pinged when a sufficient amount of heartbeats have passed and the member has not sent any
heartbeats.
|
static HazelcastProperty |
GroupProperty.ICMP_TIMEOUT
Ping timeout in milliseconds.
|
static HazelcastProperty |
GroupProperty.ICMP_TTL
Ping TTL (maximum numbers of hops to try the maximum numbers of hops the packets should go through or 0 for the
default.
|
static HazelcastProperty |
GroupProperty.INIT_CLUSTER_VERSION
Override cluster version to use while node is not yet member of a cluster.
|
static HazelcastProperty |
GroupProperty.INITIAL_MIN_CLUSTER_SIZE |
static HazelcastProperty |
GroupProperty.INITIAL_WAIT_SECONDS |
static HazelcastProperty |
GroupProperty.IO_BALANCER_INTERVAL_SECONDS
The interval in seconds between
IOBalancer
executions. |
static HazelcastProperty |
GroupProperty.IO_INPUT_THREAD_COUNT
Controls the number of socket input threads.
|
static HazelcastProperty |
GroupProperty.IO_OUTPUT_THREAD_COUNT
Controls the number of socket output threads.
|
static HazelcastProperty |
GroupProperty.IO_THREAD_COUNT
The number of threads doing socket input and the number of threads doing socket output.
|
static HazelcastProperty |
GroupProperty.JCACHE_PROVIDER_TYPE
Forces the JCache provider, which can have values client or server, to force the provider type.
|
static HazelcastProperty |
GroupProperty.JMX_UPDATE_INTERVAL_SECONDS |
static HazelcastProperty |
GroupProperty.LOCK_MAX_LEASE_TIME_SECONDS |
static HazelcastProperty |
GroupProperty.LOGGING_TYPE |
static HazelcastProperty |
GroupProperty.MAP_EXPIRY_DELAY_SECONDS
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
|
static HazelcastProperty |
GroupProperty.MAP_INVALIDATION_MESSAGE_BATCH_ENABLED
Defines Near Cache invalidation event batch sending is enabled or not.
|
static HazelcastProperty |
GroupProperty.MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
Defines the Near Cache invalidation event batch sending frequency in seconds.
|
static HazelcastProperty |
GroupProperty.MAP_INVALIDATION_MESSAGE_BATCH_SIZE
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.
|
static HazelcastProperty |
GroupProperty.MAP_LOAD_CHUNK_SIZE |
static HazelcastProperty |
GroupProperty.MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS |
static HazelcastProperty |
GroupProperty.MAP_WRITE_BEHIND_QUEUE_CAPACITY
Setting this capacity is valid if you set
MapStoreConfig.writeCoalescing to false . |
static HazelcastProperty |
GroupProperty.MASTER_CONFIRMATION_INTERVAL_SECONDS
The interval at which master confirmations are sent from non-master nodes to the master node
|
static HazelcastProperty |
GroupProperty.MAX_JOIN_MERGE_TARGET_SECONDS |
static HazelcastProperty |
GroupProperty.MAX_JOIN_SECONDS |
static HazelcastProperty |
GroupProperty.MAX_NO_HEARTBEAT_SECONDS
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.
|
static HazelcastProperty |
GroupProperty.MAX_NO_MASTER_CONFIRMATION_SECONDS
The timeout which defines when a cluster member is removed because it has not sent any master confirmations.
|
static HazelcastProperty |
GroupProperty.MAX_WAIT_SECONDS_BEFORE_JOIN |
static HazelcastProperty |
GroupProperty.MC_MAX_VISIBLE_INSTANCE_COUNT |
static HazelcastProperty |
GroupProperty.MC_MAX_VISIBLE_SLOW_OPERATION_COUNT |
static HazelcastProperty |
GroupProperty.MC_URL_CHANGE_ENABLED |
static HazelcastProperty |
GroupProperty.MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
The interval at which the master sends the member lists are sent to other non-master members
|
static HazelcastProperty |
GroupProperty.MEMCACHE_ENABLED |
static HazelcastProperty |
GroupProperty.MERGE_FIRST_RUN_DELAY_SECONDS
The delay until the first run of the
SplitBrainHandler |
static HazelcastProperty |
GroupProperty.MERGE_NEXT_RUN_DELAY_SECONDS
The interval between invocations of the
SplitBrainHandler |
static HazelcastProperty |
GroupProperty.OPERATION_BACKUP_TIMEOUT_MILLIS
If an operation has backups and the backups don't complete in time, then some cleanup logic can be executed.
|
static HazelcastProperty |
GroupProperty.OPERATION_CALL_TIMEOUT_MILLIS |
static HazelcastProperty |
GroupProperty.PARTITION_BACKUP_SYNC_INTERVAL |
static HazelcastProperty |
GroupProperty.PARTITION_COUNT
Total number of partitions in the Hazelcast cluster.
|
static HazelcastProperty |
GroupProperty.PARTITION_MAX_PARALLEL_REPLICATIONS |
static HazelcastProperty |
GroupProperty.PARTITION_MIGRATION_INTERVAL |
static HazelcastProperty |
GroupProperty.PARTITION_MIGRATION_TIMEOUT |
static HazelcastProperty |
GroupProperty.PARTITION_MIGRATION_ZIP_ENABLED |
static HazelcastProperty |
GroupProperty.PARTITION_OPERATION_THREAD_COUNT
The number of partition operation handler threads per Member.
|
static HazelcastProperty |
GroupProperty.PARTITION_TABLE_SEND_INTERVAL |
static HazelcastProperty |
GroupProperty.PARTITIONING_STRATEGY_CLASS |
static HazelcastProperty |
GroupProperty.PHONE_HOME_ENABLED |
static HazelcastProperty |
GroupProperty.PREFER_IPv4_STACK |
static HazelcastProperty |
GroupProperty.PRIORITY_GENERIC_OPERATION_THREAD_COUNT
The number of priority generic operation handler threads per Member.
|
static HazelcastProperty |
GroupProperty.QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
Maximum value of local partitions to trigger local pre-check for
TruePredicate query operations on maps. |
static HazelcastProperty |
GroupProperty.QUERY_OPTIMIZER_TYPE
Type of Query Optimizer.
|
static HazelcastProperty |
GroupProperty.QUERY_PREDICATE_PARALLEL_EVALUATION
Run Query Evaluations for multiple partitions in parallel.
|
static HazelcastProperty |
GroupProperty.QUERY_RESULT_SIZE_LIMIT
Result size limit for query operations on maps.
|
static HazelcastProperty |
GroupProperty.REST_ENABLED |
static HazelcastProperty |
GroupProperty.SERIALIZATION_VERSION
Hazelcast serialization version.
|
static HazelcastProperty |
GroupProperty.SHUTDOWNHOOK_ENABLED |
static HazelcastProperty |
GroupProperty.SHUTDOWNHOOK_POLICY
Behaviour when JVM is about to exit while Hazelcast instance is still running.
|
static HazelcastProperty |
GroupProperty.SLOW_INVOCATION_DETECTOR_THRESHOLD_MILLIS
Deprecated.
|
static HazelcastProperty |
GroupProperty.SLOW_OPERATION_DETECTOR_ENABLED
Enables or disables the
SlowOperationDetector . |
static HazelcastProperty |
GroupProperty.SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
Purge interval for slow operation logs.
|
static HazelcastProperty |
GroupProperty.SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
This value defines the retention time of invocations in slow operation logs.
|
static HazelcastProperty |
GroupProperty.SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
Defines if the stacktraces of slow operations are logged in the log file.
|
static HazelcastProperty |
GroupProperty.SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
Defines a threshold above which a running operation in
OperationService is considered to be slow. |
static HazelcastProperty |
GroupProperty.SOCKET_BIND_ANY |
static HazelcastProperty |
GroupProperty.SOCKET_BUFFER_DIRECT
If the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).
|
static HazelcastProperty |
GroupProperty.SOCKET_CLIENT_BIND |
static HazelcastProperty |
GroupProperty.SOCKET_CLIENT_BIND_ANY |
static HazelcastProperty |
GroupProperty.SOCKET_CLIENT_BUFFER_DIRECT |
static HazelcastProperty |
GroupProperty.SOCKET_CLIENT_RECEIVE_BUFFER_SIZE
Overrides receive buffer size for connections opened by clients.
|
static HazelcastProperty |
GroupProperty.SOCKET_CLIENT_SEND_BUFFER_SIZE
Overrides send buffer size for connections opened by clients.
|
static HazelcastProperty |
GroupProperty.SOCKET_CONNECT_TIMEOUT_SECONDS |
static HazelcastProperty |
GroupProperty.SOCKET_KEEP_ALIVE |
static HazelcastProperty |
GroupProperty.SOCKET_LINGER_SECONDS |
static HazelcastProperty |
GroupProperty.SOCKET_NO_DELAY |
static HazelcastProperty |
GroupProperty.SOCKET_RECEIVE_BUFFER_SIZE |
static HazelcastProperty |
GroupProperty.SOCKET_SEND_BUFFER_SIZE |
static HazelcastProperty |
GroupProperty.SOCKET_SERVER_BIND_ANY |
static HazelcastProperty |
GroupProperty.SYSTEM_LOG_ENABLED |
static HazelcastProperty |
GroupProperty.TCP_JOIN_PORT_TRY_COUNT
The number of incremental ports, starting with port number defined in network configuration,
that will be used to connect to a host which is defined without a port in the TCP-IP member list
while a node is searching for a cluster.
|
static HazelcastProperty |
GroupProperty.VERSION_CHECK_ENABLED
Deprecated.
|
static HazelcastProperty |
GroupProperty.WAIT_SECONDS_BEFORE_JOIN |
Modifier and Type | Method and Description |
---|---|
HazelcastProperty |
HazelcastProperty.getParent()
Returns the parent
GroupProperty of the property. |
HazelcastProperty |
HazelcastProperty.setDeprecatedName(String deprecatedName)
Sets the deprecated name of ths property.
|
Modifier and Type | Method and Description |
---|---|
boolean |
HazelcastProperties.getBoolean(HazelcastProperty property)
Returns the configured boolean value of a
HazelcastProperty . |
<E extends Enum> |
HazelcastProperties.getEnum(HazelcastProperty property,
Class<E> enumClazz)
Returns the configured enum value of a
GroupProperty . |
float |
HazelcastProperties.getFloat(HazelcastProperty property)
Returns the configured float value of a
HazelcastProperty . |
int |
HazelcastProperties.getInteger(HazelcastProperty property)
Returns the configured int value of a
HazelcastProperty . |
long |
HazelcastProperties.getLong(HazelcastProperty property)
Returns the configured long value of a
HazelcastProperty . |
long |
HazelcastProperties.getMillis(HazelcastProperty property)
Returns the configured value of a
HazelcastProperty converted to milliseconds. |
long |
HazelcastProperties.getNanos(HazelcastProperty property)
Returns the configured value of a
HazelcastProperty converted to nanoseconds. |
int |
HazelcastProperties.getSeconds(HazelcastProperty property)
Returns the configured value of a
HazelcastProperty converted to seconds. |
String |
HazelcastProperties.getString(HazelcastProperty property)
Returns the configured value of a
HazelcastProperty as String. |
Constructor and Description |
---|
HazelcastProperty(String name,
HazelcastProperty groupProperty) |
HazelcastProperty(String name,
String defaultValue,
TimeUnit timeUnit,
HazelcastProperty parent) |
Copyright © 2017 Hazelcast, Inc.. All Rights Reserved.