Package org.infinispan.util.logging
Interface Log
-
- All Superinterfaces:
org.jboss.logging.BasicLogger
- All Known Implementing Classes:
Log_$logger
@MessageLogger(projectCode="ISPN") public interface Log extends org.jboss.logging.BasicLogger
Infinispan's log abstraction layer on top of JBoss Logging. It contains explicit methods for all INFO or above levels so that they can be internationalized. For the core module, message ids ranging from 0001 to 0900 inclusively have been reserved.Log log = LogFactory.getLog( getClass() );
The above will get you an instance of Log, which can be used to generate log messages either via JBoss Logging which then can delegate to Log4J (if the libraries are present) or (if not) the built-in JDK logger. In addition to the 6 log levels available, this framework also supports parameter interpolation, similar to the JDKsString.format(String, Object...)
method. What this means is, that the following block:if (log.isTraceEnabled()) { log.trace("This is a message " + message + " and some other value is " + value); }
... could be replaced with ...if (log.isTraceEnabled()) log.tracef("This is a message %s and some other value is %s", message, value);
This greatly enhances code readability. If you are passing a Throwable, note that this should be passed in before the vararg parameter list.- Since:
- 4.0
- Author:
- Manik Surtani
-
-
Method Summary
-
Methods inherited from interface org.jboss.logging.BasicLogger
debug, debug, debug, debug, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugf, debugv, debugv, debugv, debugv, debugv, debugv, debugv, debugv, error, error, error, error, errorf, errorf, errorf, errorf, errorf, errorf, errorf, errorf, errorv, errorv, errorv, errorv, errorv, errorv, errorv, errorv, fatal, fatal, fatal, fatal, fatalf, fatalf, fatalf, fatalf, fatalf, fatalf, fatalf, fatalf, fatalv, fatalv, fatalv, fatalv, fatalv, fatalv, fatalv, fatalv, info, info, info, info, infof, infof, infof, infof, infof, infof, infof, infof, infov, infov, infov, infov, infov, infov, infov, infov, isDebugEnabled, isEnabled, isInfoEnabled, isTraceEnabled, log, log, log, log, logf, logf, logf, logf, logf, logf, logf, logf, logf, logf, logf, logf, logv, logv, logv, logv, logv, logv, logv, logv, logv, logv, logv, logv, trace, trace, trace, trace, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracef, tracev, tracev, tracev, tracev, tracev, tracev, tracev, tracev, warn, warn, warn, warn, warnf, warnf, warnf, warnf, warnf, warnf, warnf, warnf, warnv, warnv, warnv, warnv, warnv, warnv, warnv, warnv
-
-
-
-
Method Detail
-
errorReadingProperties
@LogMessage(level=WARN) @Message(value="Unexpected error reading properties", id=4) void errorReadingProperties(@Cause IOException e)
-
unableToCopyEntryForUpdate
@LogMessage(level=WARN) @Message(value="Detected write skew on key [%s]. Another process has changed the entry since we last read it! Unable to copy entry for update.", id=5) void unableToCopyEntryForUpdate(Object key)
-
remoteExecutionFailed
@LogMessage(level=WARN) @Message(value="Failed remote execution on node %s", id=6) void remoteExecutionFailed(Address address, @Cause Throwable t)
-
localExecutionFailed
@LogMessage(level=WARN) @Message(value="Failed local execution ", id=7) void localExecutionFailed(@Cause Throwable t)
-
cannotSelectRandomMembers
@LogMessage(level=WARN) @Message(value="Can not select %s random members for %s", id=8) void cannotSelectRandomMembers(int numNeeded, List<Address> members)
-
problemApplyingStateForKey
@LogMessage(level=WARN) @Message(value="Problem %s encountered when applying state for key %s!", id=16) void problemApplyingStateForKey(String msg, Object key, @Cause Throwable t)
-
expectedJustOneResponse
@LogMessage(level=WARN) @Message(value="Expected just one response; got %s", id=21) void expectedJustOneResponse(Map<Address,Response> lr)
-
notStartingEvictionThread
@LogMessage(level=INFO) @Message(value="wakeUpInterval is <= 0, not starting expired purge thread", id=25) void notStartingEvictionThread()
-
exceptionPurgingDataContainer
@LogMessage(level=WARN) @Message(value="Caught exception purging data container!", id=26) void exceptionPurgingDataContainer(@Cause Throwable e)
-
unableToPassivateEntry
@LogMessage(level=WARN) @Message(value="Unable to passivate entry under %s", id=28) void unableToPassivateEntry(Object key, @Cause Exception e)
-
passivatingAllEntries
@LogMessage(level=INFO) @Message(value="Passivating all entries to disk", id=29) void passivatingAllEntries()
-
passivatedEntries
@LogMessage(level=INFO) @Message(value="Passivated %d entries in %s", id=30) void passivatedEntries(long numEntries, String duration)
-
mbeansSuccessfullyRegistered
@LogMessage(level=TRACE) @Message(value="MBeans were successfully registered to the platform MBean server.", id=31) void mbeansSuccessfullyRegistered()
-
problemsUnregisteringMBeans
@LogMessage(level=WARN) @Message(value="Problems un-registering MBeans", id=32) void problemsUnregisteringMBeans(@Cause Exception e)
-
unableToUnregisterMBeanWithPattern
@LogMessage(level=WARN) @Message(value="Unable to unregister Cache MBeans with pattern %s", id=33) void unableToUnregisterMBeanWithPattern(String pattern, @Cause MBeanRegistrationException e)
-
jmxMBeanAlreadyRegistered
@Message(value="There\'s already a JMX MBean instance %s already registered under \'%s\' JMX domain. If you want to allow multiple instances configured with same JMX domain enable \'allowDuplicateDomains\' attribute in \'globalJmxStatistics\' config element", id=34) JmxDomainConflictException jmxMBeanAlreadyRegistered(String mBeanName, String jmxDomain)
-
couldNotFindAttribute
@LogMessage(level=WARN) @Message(value="Did not find attribute %s", id=36) void couldNotFindAttribute(String name)
-
failedToUpdateAttribute
@LogMessage(level=WARN) @Message(value="Failed to update attribute name %s with value %s", id=37) void failedToUpdateAttribute(String name, Object value)
-
queriedAttributeNotFound
@LogMessage(level=WARN) @Message(value="Did not find queried attribute with name %s", id=42) void queriedAttributeNotFound(String attributeName)
-
errorWritingValueForAttribute
@LogMessage(level=WARN) @Message(value="Exception while writing value for attribute %s", id=43) void errorWritingValueForAttribute(String attributeName, @Cause Exception e)
-
couldNotInvokeSetOnAttribute
@LogMessage(level=WARN) @Message(value="Could not invoke set on attribute %s with value %s", id=44) void couldNotInvokeSetOnAttribute(String attributeName, Object value)
-
unknownResponsesFromRemoteCache
@LogMessage(level=ERROR) @Message(value="Unknown responses from remote cache: %s", id=46) void unknownResponsesFromRemoteCache(Collection<Response> responses)
-
errorDoingRemoteCall
@LogMessage(level=ERROR) @Message(value="Error while doing remote call", id=47) void errorDoingRemoteCall(@Cause Exception e)
-
interruptedWaitingAsyncStorePush
@LogMessage(level=ERROR) @Message(value="Interrupted or timeout while waiting for AsyncCacheWriter worker threads to push all state to the decorated store", id=48) void interruptedWaitingAsyncStorePush(@Cause InterruptedException e)
-
interruptedAcquiringLock
@LogMessage(level=ERROR) @Message(value="Interrupted on acquireLock for %d milliseconds!", id=52) void interruptedAcquiringLock(long ms, @Cause InterruptedException e)
-
unableToProcessAsyncModifications
@LogMessage(level=WARN) @Message(value="Unable to process some async modifications after %d retries!", id=53) void unableToProcessAsyncModifications(int retries)
-
unexpectedErrorInAsyncStoreCoordinator
@LogMessage(level=ERROR) @Message(value="Unexpected error in AsyncStoreCoordinator thread. AsyncCacheWriter is dead!", id=55) void unexpectedErrorInAsyncStoreCoordinator(@Cause Throwable t)
-
errorChangingSingletonStoreStatus
@LogMessage(level=ERROR) @Message(value="Exception reported changing cache active status", id=58) void errorChangingSingletonStoreStatus(@Cause SingletonCacheWriter.PushStateException e)
-
unableToReadVersionId
@LogMessage(level=ERROR) @Message(value="Unable to read version id from first two bytes of stream, barfing.", id=66) void unableToReadVersionId()
-
exceptionHandlingCommand
@LogMessage(level=WARN) @Message(value="Caught exception when handling command %s", id=71) void exceptionHandlingCommand(ReplicableCommand cmd, @Cause Throwable t)
-
unexpectedErrorReplicating
@LogMessage(level=ERROR) @Message(value="Unexpected error while replicating", id=73) void unexpectedErrorReplicating(@Cause Throwable t)
-
startingJGroupsChannel
@LogMessage(level=INFO) @Message(value="Starting JGroups channel %s", id=78) void startingJGroupsChannel(String cluster)
-
localAndPhysicalAddress
@LogMessage(level=INFO) @Message(value="Channel %s local address is %s, physical addresses are %s", id=79) void localAndPhysicalAddress(String cluster, Address address, List<Address> physicalAddresses)
-
disconnectJGroups
@LogMessage(level=INFO) @Message(value="Disconnecting JGroups channel %s", id=80) void disconnectJGroups(String cluster)
-
problemClosingChannel
@LogMessage(level=ERROR) @Message(value="Problem closing channel %s; setting it to null", id=81) void problemClosingChannel(@Cause Exception e, String cluster)
-
wrongTypeForJGroupsChannelLookup
@LogMessage(level=ERROR) @Message(value="Class [%s] cannot be cast to JGroupsChannelLookup! Not using a channel lookup.", id=83) void wrongTypeForJGroupsChannelLookup(String channelLookupClassName, @Cause Exception e)
-
errorInstantiatingJGroupsChannelLookup
@LogMessage(level=ERROR) @Message(value="Errors instantiating [%s]! Not using a channel lookup.", id=84) void errorInstantiatingJGroupsChannelLookup(String channelLookupClassName, @Cause Exception e)
-
errorCreatingChannelFromConfigFile
@Message(value="Error while trying to create a channel using the specified configuration file: %s", id=85) CacheConfigurationException errorCreatingChannelFromConfigFile(String cfg, @Cause Exception e)
-
errorCreatingChannelFromXML
@Message(value="Error while trying to create a channel using the specified configuration XML: %s", id=86) CacheConfigurationException errorCreatingChannelFromXML(String cfg, @Cause Exception e)
-
errorCreatingChannelFromConfigString
@Message(value="Error while trying to create a channel using the specified configuration string: %s", id=87) CacheConfigurationException errorCreatingChannelFromConfigString(String cfg, @Cause Exception e)
-
unableToUseJGroupsPropertiesProvided
@LogMessage(level=INFO) @Message(value="Unable to use any JGroups configuration mechanisms provided in properties %s. Using default JGroups configuration!", id=88) void unableToUseJGroupsPropertiesProvided(org.infinispan.commons.util.TypedProperties props)
-
interruptedWaitingForCoordinator
@LogMessage(level=ERROR) @Message(value="getCoordinator(): Interrupted while waiting for members to be set", id=89) void interruptedWaitingForCoordinator(@Cause InterruptedException e)
-
receivedMergedView
@LogMessage(level=INFO) @Message(value="Received new, MERGED cluster view for channel %s: %s", id=93) void receivedMergedView(String cluster, org.jgroups.View newView)
-
receivedClusterView
@LogMessage(level=INFO) @Message(value="Received new cluster view for channel %s: %s", id=94) void receivedClusterView(String cluster, org.jgroups.View newView)
-
errorProcessing1pcPrepareCommand
@LogMessage(level=ERROR) @Message(value="Error while processing a prepare in a single-phase transaction", id=97) void errorProcessing1pcPrepareCommand(@Cause Throwable e)
-
errorRollingBack
@LogMessage(level=ERROR) @Message(value="Exception during rollback", id=98) void errorRollingBack(@Cause Throwable e)
-
unfinishedTransactionsRemain
@LogMessage(level=WARN) @Message(value="Stopping, but there are %s local transactions and %s remote transactions that did not finish in time.", id=100) void unfinishedTransactionsRemain(int localTransactions, int remoteTransactions)
-
failedSynchronizationRegistration
@LogMessage(level=WARN) @Message(value="Failed synchronization registration", id=101) void failedSynchronizationRegistration(@Cause Exception e)
-
unableToRollbackGlobalTx
@LogMessage(level=WARN) @Message(value="Unable to roll back global transaction %s", id=102) void unableToRollbackGlobalTx(GlobalTransaction gtx, @Cause Throwable e)
-
fallingBackToEmbeddedTm
@LogMessage(level=WARN) @Message(value="Falling back to EmbeddedTransactionManager from Infinispan", id=104) void fallingBackToEmbeddedTm()
-
failedToCreateInitialCtx
@LogMessage(level=ERROR) @Message(value="Failed creating initial JNDI context", id=105) void failedToCreateInitialCtx(@Cause NamingException e)
-
unableToInvokeWebsphereStaticGetTmMethod
@LogMessage(level=ERROR) @Message(value="Found WebSphere TransactionManager factory class [%s], but couldn\'t invoke its static \'getTransactionManager\' method", id=106) void unableToInvokeWebsphereStaticGetTmMethod(@Cause Exception ex, String className)
-
retrievingTm
@LogMessage(level=INFO) @Message(value="Retrieving transaction manager %s", id=107) void retrievingTm(TransactionManager tm)
-
errorEnlistingResource
@LogMessage(level=ERROR) @Message(value="Error enlisting resource", id=108) void errorEnlistingResource(@Cause XAException e)
-
beforeCompletionFailed
@LogMessage(level=ERROR) @Message(value="beforeCompletion() failed for %s", id=109) void beforeCompletionFailed(Synchronization s, @Cause Throwable t)
-
unexpectedErrorFromResourceManager
@LogMessage(level=ERROR) @Message(value="Unexpected error from resource manager!", id=110) void unexpectedErrorFromResourceManager(@Cause Throwable t)
-
afterCompletionFailed
@LogMessage(level=ERROR) @Message(value="afterCompletion() failed for %s", id=111) void afterCompletionFailed(Synchronization s, @Cause Throwable t)
-
errorCommittingTx
@LogMessage(level=WARN) @Message(value="exception while committing", id=112) void errorCommittingTx(@Cause XAException e)
-
recoveryIgnored
@LogMessage(level=WARN) @Message(value="Recovery call will be ignored as recovery is disabled. More on recovery: http://community.jboss.org/docs/DOC-16646", id=115) void recoveryIgnored()
-
missingListPreparedTransactions
@LogMessage(level=WARN) @Message(value="Missing the list of prepared transactions from node %s. Received response is %s", id=116) void missingListPreparedTransactions(Object key, Object value)
-
preparedTxAlreadyExists
@LogMessage(level=ERROR) @Message(value="There\'s already a prepared transaction with this xid: %s. New transaction is %s. Are there two different transactions having same Xid in the cluster?", id=117) void preparedTxAlreadyExists(RecoveryAwareTransaction previous, RecoveryAwareRemoteTransaction remoteTransaction)
-
unableToSetValue
@LogMessage(level=ERROR) @Message(value="Unable to set value!", id=121) void unableToSetValue(@Cause Exception e)
-
failedToCallStopAfterFailure
@LogMessage(level=WARN) @Message(value="Attempted to stop() from FAILED state, but caught exception", id=126) void failedToCallStopAfterFailure(@Cause Throwable t)
-
version
@LogMessage(level=INFO) @Message(value="Infinispan version: %s", id=128) void version(String version)
-
cacheNotStarted
@LogMessage(level=WARN) @Message(value="Received a remote call but the cache is not in STARTED state - ignoring call.", id=129) void cacheNotStarted()
-
noAnnotateMethodsFoundInListener
@LogMessage(level=WARN) @Message(value="Attempted to register listener of class %s, but no valid, public methods annotated with method-level event annotations found! Ignoring listener.", id=133) void noAnnotateMethodsFoundInListener(Class<?> listenerClass)
-
unableToInvokeListenerMethodAndRemoveListener
@LogMessage(level=WARN) @Message(value="Unable to invoke method %s on Object instance %s - removing this target object from list of listeners!", id=134) void unableToInvokeListenerMethodAndRemoveListener(Method m, Object target, @Cause Throwable e)
-
unableToLockToInvalidate
@LogMessage(level=WARN) @Message(value="Could not lock key %s in order to invalidate from L1 at node %s, skipping....", id=135) void unableToLockToInvalidate(Object key, Address address)
-
executionError
@LogMessage(level=ERROR) @Message(value="Error executing command %s on %s, writing keys %s", id=136) void executionError(String commandType, String cacheName, String affectedKeys, @Cause Throwable t)
-
failedInvalidatingRemoteCache
@LogMessage(level=INFO) @Message(value="Failed invalidating remote cache", id=137) void failedInvalidatingRemoteCache(@Cause Throwable e)
-
couldNotRegisterObjectName
@LogMessage(level=INFO) @Message(value="Could not register object with name: %s", id=138) void couldNotRegisterObjectName(ObjectName objectName, @Cause InstanceAlreadyExistsException e)
-
couldNotRollbackPrepared1PcTransaction
@LogMessage(level=WARN) @Message(value="Could not rollback prepared 1PC transaction. This transaction will be rolled back by the recovery process, if enabled. Transaction: %s", id=141) void couldNotRollbackPrepared1PcTransaction(LocalTransaction localTransaction, @Cause Throwable e1)
-
failedLoadingValueFromCacheStore
@LogMessage(level=WARN) @Message(value="Failed loading value for key %s from cache store", id=144) void failedLoadingValueFromCacheStore(Object key, @Cause Exception e)
-
failedToInvalidateKeys
@LogMessage(level=ERROR) @Message(value="Error invalidating keys from L1 after rehash", id=147) void failedToInvalidateKeys(@Cause Exception e)
-
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup
@LogMessage(level=WARN) @Message(value="Fetch persistent state and purge on startup are both disabled, cache may contain stale entries on startup", id=149) void staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup()
-
passivationWithoutEviction
@LogMessage(level=INFO) @Message(value="Passivation configured without an eviction policy being selected. Only manually evicted entities will be passivated.", id=152) void passivationWithoutEviction()
-
couldNotCompleteInjectedTransaction
@LogMessage(level=WARN) @Message(value="Could not complete injected transaction.", id=160) void couldNotCompleteInjectedTransaction(@Cause Throwable t)
-
usingBatchModeTransactionManager
@LogMessage(level=INFO) @Message(value="Using a batchMode transaction manager", id=161) void usingBatchModeTransactionManager()
-
couldNotInstantiateTransactionManager
@LogMessage(level=INFO) @Message(value="Could not instantiate transaction manager", id=162) void couldNotInstantiateTransactionManager(@Cause Exception e)
-
customInterceptorExpectsInjection
@LogMessage(level=ERROR) @Message(value="Custom interceptor %s has used @Inject, @Start or @Stop. These methods will not be processed. Please extend org.infinispan.interceptors.base.BaseCustomInterceptor instead, and your custom interceptor will have access to a cache and cacheManager. Override stop() and start() for lifecycle methods.", id=173) void customInterceptorExpectsInjection(String customInterceptorFQCN)
-
randomCacheModeSynonymsDeprecated
@LogMessage(level=WARN) @Message(value="%s has been deprecated as a synonym for %s. Use one of %s instead", id=177) void randomCacheModeSynonymsDeprecated(String candidate, String mode, List<String> synonyms)
-
errorProcessing2pcCommitCommand
@LogMessage(level=ERROR) @Message(value="Error while processing a commit in a two-phase transaction", id=188) void errorProcessing2pcCommitCommand(@Cause Throwable e)
-
componentFailedToStop
@LogMessage(level=WARN) @Message(value="While stopping a cache or cache manager, one of its components failed to stop", id=189) void componentFailedToStop(@Cause Throwable e)
-
localIndexingWithSharedCacheLoaderRequiresPreload
@LogMessage(level=DEBUG) @Message(value="When indexing locally a cache with shared cache loader, preload must be enabled", id=191) void localIndexingWithSharedCacheLoaderRequiresPreload()
-
hashNumVirtualNodesDeprecated
@LogMessage(level=WARN) @Message(value="hash\'s \'numVirtualNodes\' attribute has been deprecated. Please use hash.numSegments instead", id=192) void hashNumVirtualNodesDeprecated()
-
consistentHashDeprecated
@LogMessage(level=WARN) @Message(value="hash\'s \'consistentHash\' attribute has been deprecated. Please use hash.consistentHashFactory instead", id=193) void consistentHashDeprecated()
-
failedLoadingKeysFromCacheStore
@LogMessage(level=WARN) @Message(value="Failed loading keys from cache store", id=194) void failedLoadingKeysFromCacheStore(@Cause Exception e)
-
rebalanceError
@LogMessage(level=ERROR) @Message(value="Error during rebalance for cache %s on node %s, topology id = %d", id=195) void rebalanceError(String cacheName, Address node, int topologyId, @Cause Throwable cause)
-
failedToRecoverClusterState
@LogMessage(level=ERROR) @Message(value="Failed to recover cluster state after the current node became the coordinator (or after merge)", id=196) void failedToRecoverClusterState(@Cause Throwable cause)
-
errorUpdatingMembersList
@LogMessage(level=WARN) @Message(value="Error updating cluster member list for view %d, waiting for next view", id=197) void errorUpdatingMembersList(int viewId, @Cause Throwable cause)
-
unableToRegisterMBeans
@LogMessage(level=INFO) @Message(value="Unable to register MBeans for default cache", id=198) void unableToRegisterMBeans()
-
unableToRegisterMBeans
@LogMessage(level=INFO) @Message(value="Unable to register MBeans for named cache %s", id=199) void unableToRegisterMBeans(String cacheName)
-
unableToRegisterCacheManagerMBeans
@LogMessage(level=INFO) @Message(value="Unable to register MBeans for cache manager", id=200) void unableToRegisterCacheManagerMBeans()
-
cacheBackupsDataToSameSite
@LogMessage(level=TRACE) @Message(value="This cache is configured to backup to its own site (%s).", id=201) void cacheBackupsDataToSameSite(String siteName)
-
warnXsiteBackupFailed
@LogMessage(level=WARN) @Message(value="Problems backing up data for cache %s to site %s: %s", id=202) void warnXsiteBackupFailed(String cacheName, String key, Object value)
-
cannotRespondToRollback
@LogMessage(level=WARN) @Message(value="The rollback request for tx %s cannot be processed by the cache %s as this cache is not transactional!", id=203) void cannotRespondToRollback(GlobalTransaction globalTransaction, String cacheName)
-
cannotRespondToCommit
@LogMessage(level=WARN) @Message(value="The commit request for tx %s cannot be processed by the cache %s as this cache is not transactional!", id=204) void cannotRespondToCommit(GlobalTransaction globalTransaction, String cacheName)
-
tryingToBringOnlineNonexistentSite
@LogMessage(level=WARN) @Message(value="Trying to bring back an non-existent site (%s)!", id=205) void tryingToBringOnlineNonexistentSite(String siteName)
-
couldNotExecuteCancellationLocally
@LogMessage(level=WARN) @Message(value="Could not execute cancellation command locally", id=206) void couldNotExecuteCancellationLocally(@Cause Throwable e)
-
couldNotInterruptThread
@LogMessage(level=WARN) @Message(value="Could not interrupt as no thread found for command uuid %s", id=207) void couldNotInterruptThread(UUID id)
-
noLiveOwnersFoundForSegments
@LogMessage(level=ERROR) @Message(value="No live owners found for segments %s of cache %s. Excluded owners: %s", id=208) void noLiveOwnersFoundForSegments(Collection<Integer> segments, String cacheName, Collection<Address> faultySources)
-
failedToRetrieveTransactionsForSegments
@LogMessage(level=WARN) @Message(value="Failed to retrieve transactions of cache %s from node %s, segments %s", id=209) void failedToRetrieveTransactionsForSegments(String cacheName, Address source, Collection<Integer> segments, @Cause Exception e)
-
failedToRequestSegments
@LogMessage(level=WARN) @Message(value="Failed to request state of cache %s from node %s, segments %s", id=210) void failedToRequestSegments(String cacheName, Address source, Collection<Integer> segments, @Cause Throwable e)
-
unableToRemoveEntryAfterActivation
@LogMessage(level=WARN) @Message(value="Unable to remove entry under %s from cache store after activation", id=214) void unableToRemoveEntryAfterActivation(Object key, @Cause Exception e)
-
unknownMigrator
@Message(value="Unknown migrator %s", id=215) Exception unknownMigrator(String migratorName)
-
entriesMigrated
@LogMessage(level=INFO) @Message(value="%d entries migrated to cache %s in %s", id=216) void entriesMigrated(long count, String name, String prettyTime)
-
remoteException
@Message(value="Received exception from %s, see cause for remote stack trace", id=217) RemoteException remoteException(Address sender, @Cause Throwable t)
-
timeoutWaitingUntilTransactionPrepared
@LogMessage(level=INFO) @Message(value="Timeout while waiting for the transaction validation. The command will not be processed. Transaction is %s", id=218) void timeoutWaitingUntilTransactionPrepared(String globalTx)
-
shutdownHandlingCommand
@LogMessage(level=WARN) @Message(value="Shutdown while handling command %s", id=219) void shutdownHandlingCommand(ReplicableCommand command)
-
customInterceptorMissingClass
@Message(value="Custom interceptor missing class", id=222) CacheConfigurationException customInterceptorMissingClass()
-
suggestCustomInterceptorInheritance
@LogMessage(level=WARN) @Message(value="Custom interceptor \'%s\' does not extend BaseCustomInterceptor, which is recommended", id=223) void suggestCustomInterceptorInheritance(String customInterceptorClassName)
-
multipleCustomInterceptorPositions
@Message(value="Custom interceptor \'%s\' specifies more than one position", id=224) CacheConfigurationException multipleCustomInterceptorPositions(String customInterceptorClassName)
-
missingCustomInterceptorPosition
@Message(value="Custom interceptor \'%s\' doesn\'t specify a position", id=225) CacheConfigurationException missingCustomInterceptorPosition(String customInterceptorClassName)
-
warnConcurrentUpdateSupportCannotBeConfigured
@LogMessage(level=WARN) @Message(value="Support for concurrent updates can no longer be configured (it is always enabled by default)", id=227) void warnConcurrentUpdateSupportCannotBeConfigured()
-
failedToRecoverCacheState
@LogMessage(level=ERROR) @Message(value="Failed to recover cache %s state after the current node became the coordinator", id=228) void failedToRecoverCacheState(String cacheName, @Cause Throwable cause)
-
unexpectedInitialVersion
@Message(value="Unexpected initial version type (only NumericVersion instances supported): %s", id=229) IllegalArgumentException unexpectedInitialVersion(String className)
-
rebalanceStartError
@LogMessage(level=ERROR) @Message(value="Failed to start rebalance for cache %s", id=230) void rebalanceStartError(String cacheName, @Cause Throwable cause)
-
parserRootElementAlreadyRegistered
@LogMessage(level=WARN) @Message(value="Root element for %s already registered in ParserRegistry by %s. Cannot install %s.", id=234) void parserRootElementAlreadyRegistered(QName qName, String oldParser, String newParser)
-
parserDoesNotDeclareNamespaces
@Message(value="Configuration parser %s does not declare any Namespace annotations", id=235) CacheConfigurationException parserDoesNotDeclareNamespaces(String name)
-
directoryCannotBeCreated
@Message(value="Directory %s does not exist and cannot be created!", id=238) CacheConfigurationException directoryCannotBeCreated(String path)
-
missingForeignExternalizer
@Message(value="Missing foreign externalizer with id=%s, either externalizer was not configured by client, or module lifecycle implementation adding externalizer was not loaded properly", id=242) CacheException missingForeignExternalizer(int foreignId)
-
unknownExternalizerReaderIndex
@Message(value="Type of data read is unknown. Id=%d is not amongst known reader indexes.", id=243) CacheException unknownExternalizerReaderIndex(int readerIndex)
-
advanceExternalizerTypeClassesUndefined
@Message(value="AdvancedExternalizer\'s getTypeClasses for externalizer %s must return a non-empty set", id=244) CacheConfigurationException advanceExternalizerTypeClassesUndefined(String className)
-
duplicateExternalizerIdFound
@Message(value="Duplicate id found! AdvancedExternalizer id=%d for %s is shared by another externalizer (%s). Reader index is %d", id=245) CacheConfigurationException duplicateExternalizerIdFound(int externalizerId, Class<?> typeClass, String otherExternalizer, int readerIndex)
-
internalExternalizerIdLimitExceeded
@Message(value="Internal %s externalizer is using an id(%d) that exceeded the limit. It needs to be smaller than %d", id=246) CacheConfigurationException internalExternalizerIdLimitExceeded(org.infinispan.commons.marshall.AdvancedExternalizer<?> ext, int externalizerId, int maxId)
-
foreignExternalizerUsingNegativeId
@Message(value="Foreign %s externalizer is using a negative id(%d). Only positive id values are allowed.", id=247) CacheConfigurationException foreignExternalizerUsingNegativeId(org.infinispan.commons.marshall.AdvancedExternalizer<?> ext, int externalizerId)
-
loaderConfigurationDoesNotSpecifyLoaderClass
@Message(value="The cache loader configuration %s does not specify the loader class using @ConfigurationFor", id=249) CacheConfigurationException loaderConfigurationDoesNotSpecifyLoaderClass(String className)
-
errorExecutingParallelStoreTask
@LogMessage(level=ERROR) @Message(value="Error executing parallel store task", id=252) void errorExecutingParallelStoreTask(@Cause Throwable cause)
-
strictPeerToPeerDeprecated
@LogMessage(level=WARN) @Message(value="The transport element\'s \'strictPeerToPeer\' attribute is no longer in use.", id=254) void strictPeerToPeerDeprecated()
-
errorProcessingPrepare
@LogMessage(level=ERROR) @Message(value="Error while processing prepare", id=255) void errorProcessingPrepare(@Cause Throwable e)
-
configuratorSAXParseError
@LogMessage(level=ERROR) @Message(value="Configurator SAXParse error", id=256) void configuratorSAXParseError(@Cause Exception e)
-
configuratorSAXError
@LogMessage(level=ERROR) @Message(value="Configurator SAX error", id=257) void configuratorSAXError(@Cause Exception e)
-
configuratorError
@LogMessage(level=ERROR) @Message(value="Configurator general error", id=258) void configuratorError(@Cause Exception e)
-
errorAsyncStoreNotStopped
@LogMessage(level=ERROR) @Message(value="Async store executor did not stop properly", id=259) void errorAsyncStoreNotStopped()
-
failedOutBoundTransferExecution
@LogMessage(level=ERROR) @Message(value="Failed to execute outbound transfer", id=261) void failedOutBoundTransferExecution(@Cause Throwable e)
-
failedToEnlistTransactionXaAdapter
@LogMessage(level=ERROR) @Message(value="Failed to enlist TransactionXaAdapter to transaction", id=262) void failedToEnlistTransactionXaAdapter(@Cause Throwable e)
-
warnFifoStrategyIsDeprecated
@LogMessage(level=WARN) @Message(value="FIFO strategy is deprecated, LRU will be used instead", id=263) void warnFifoStrategyIsDeprecated()
-
warnL1NotHavingReaperThread
@LogMessage(level=WARN) @Message(value="Not using an L1 invalidation reaper thread. This could lead to memory leaks as the requestors map may grow indefinitely!", id=264) void warnL1NotHavingReaperThread()
-
unableToCreateInterceptor
@LogMessage(level=WARN) @Message(value="Problems creating interceptor %s", id=267) void unableToCreateInterceptor(Class type, @Cause Exception e)
-
unableToRollbackInvalidationsDuringPrepare
@LogMessage(level=WARN) @Message(value="Unable to broadcast invalidations as a part of the prepare phase. Rolling back.", id=268) void unableToRollbackInvalidationsDuringPrepare(@Cause Throwable e)
-
warnGridFSMetadataCacheRequiresSync
@LogMessage(level=WARN) @Message(value="Cache used for Grid metadata should be synchronous.", id=269) void warnGridFSMetadataCacheRequiresSync()
-
warnCouldNotCommitLocalTx
@LogMessage(level=WARN) @Message(value="Could not commit local tx %s", id=270) void warnCouldNotCommitLocalTx(Object transactionDescription, @Cause Exception e)
-
warnCouldNotRollbackLocalTx
@LogMessage(level=WARN) @Message(value="Could not rollback local tx %s", id=271) void warnCouldNotRollbackLocalTx(Object transactionDescription, @Cause Exception e)
-
warnExceptionRemovingRecovery
@LogMessage(level=WARN) @Message(value="Exception removing recovery information", id=272) void warnExceptionRemovingRecovery(@Cause Exception e)
-
invalidConfigurationIndexingWithInvalidation
@Message(value="Indexing can not be enabled on caches in Invalidation mode", id=273) CacheConfigurationException invalidConfigurationIndexingWithInvalidation()
-
persistenceWithoutCacheLoaderInterceptor
@LogMessage(level=ERROR) @Message(value="Persistence enabled without any CacheLoaderInterceptor in InterceptorChain!", id=274) void persistenceWithoutCacheLoaderInterceptor()
-
persistenceWithoutCacheWriteInterceptor
@LogMessage(level=ERROR) @Message(value="Persistence enabled without any CacheWriteInterceptor in InterceptorChain!", id=275) void persistenceWithoutCacheWriteInterceptor()
-
missingMigrationData
@Message(value="Could not find migration data in cache %s", id=276) CacheException missingMigrationData(String name)
-
keyMigrationFailed
@LogMessage(level=WARN) @Message(value="Could not migrate key %s", id=277) void keyMigrationFailed(String key, @Cause Throwable cause)
-
invalidConfigurationIndexingWithoutModule
@Message(value="Indexing can only be enabled if infinispan-query.jar is available on your classpath, and this jar has not been detected.", id=278) CacheConfigurationException invalidConfigurationIndexingWithoutModule()
-
errorReadingFileStore
@Message(value="Failed to read stored entries from file. Error in file %s at offset %d", id=279) PersistenceException errorReadingFileStore(String path, long offset)
-
exceptionInvokingListener
@Message(value="Caught exception [%s] while invoking method [%s] on listener instance: %s", id=280) CacheListenerException exceptionInvokingListener(String name, Method m, Object target, @Cause Throwable cause)
-
thirdPartySuspected
@Message(value="%s reported that a third node was suspected, see cause for info on the node that was suspected", id=281) SuspectException thirdPartySuspected(Address sender, @Cause SuspectException e)
-
invocationBatchingNeedsTransactionalCache
@Message(value="Cannot enable Invocation Batching when the Transaction Mode is NON_TRANSACTIONAL, set the transaction mode to TRANSACTIONAL", id=282) CacheConfigurationException invocationBatchingNeedsTransactionalCache()
-
invocationBatchingCannotBeRecoverable
@Message(value="A cache configured with invocation batching can\'t have recovery enabled", id=283) CacheConfigurationException invocationBatchingCannotBeRecoverable()
-
clusterListenerInstallationFailure
@LogMessage(level=WARN) @Message(value="Problem encountered while installing cluster listener", id=284) void clusterListenerInstallationFailure(@Cause Throwable cause)
-
unsuccessfulResponseForClusterListeners
@LogMessage(level=WARN) @Message(value="Issue when retrieving cluster listeners from %s response was %s", id=285) void unsuccessfulResponseForClusterListeners(Address address, Response response)
-
exceptionDuringClusterListenerRetrieval
@LogMessage(level=WARN) @Message(value="Issue when retrieving cluster listeners from %s", id=286) void exceptionDuringClusterListenerRetrieval(Address address, @Cause Throwable cause)
-
unauthorizedAccess
@Message(value="Unauthorized access: subject \'%s\' lacks \'%s\' permission", id=287) SecurityException unauthorizedAccess(String subject, String permission)
-
invalidPrincipalRoleMapper
@Message(value="A principal-to-role mapper has not been specified", id=288) CacheConfigurationException invalidPrincipalRoleMapper()
-
unableToSendXSiteState
@LogMessage(level=WARN) @Message(value="Unable to send X-Site state chunk to \'%s\'.", id=289) void unableToSendXSiteState(String site, @Cause Throwable cause)
-
unableToApplyXSiteState
@LogMessage(level=WARN) @Message(value="Unable to apply X-Site state chunk.", id=291) void unableToApplyXSiteState(@Cause Throwable cause)
-
unrecognizedAttribute
@LogMessage(level=WARN) @Message(value="Unrecognized attribute \'%s\'. Please check your configuration. Ignoring!", id=292) void unrecognizedAttribute(String property)
-
ignoreXmlAttribute
@LogMessage(level=INFO) @Message(value="Ignoring XML attribute %s, please remove from configuration file", id=293) void ignoreXmlAttribute(Object attribute)
-
ignoreXmlElement
@LogMessage(level=INFO) @Message(value="Ignoring XML element %s, please remove from configuration file", id=294) void ignoreXmlElement(Object element)
-
undefinedThreadPoolName
@Message(value="No thread pool with name %s found", id=295) CacheConfigurationException undefinedThreadPoolName(String name)
-
invalidPermission
@Message(value="Attempt to add a %s permission to a SecurityPermissionCollection", id=296) IllegalArgumentException invalidPermission(Permission permission)
-
readOnlyPermissionCollection
@Message(value="Attempt to add a permission to a read-only SecurityPermissionCollection", id=297) SecurityException readOnlyPermissionCollection()
-
authorizationEnabledWithoutSecurityManager
@LogMessage(level=DEBUG) @Message(value="Using internal security checker", id=298) void authorizationEnabledWithoutSecurityManager()
-
unableToAcquireLock
@Message(value="Unable to acquire lock after %s for key %s and requestor %s. Lock is held by %s", id=299) TimeoutException unableToAcquireLock(String timeout, Object key, Object requestor, Object owner)
-
exceptionProcessingEntryRetrievalValues
@Message(value="There was an exception while processing retrieval of entry values", id=300) CacheException exceptionProcessingEntryRetrievalValues(@Cause Throwable cause)
-
unsuccessfulResponseRetrievingTransactionsForSegments
@LogMessage(level=WARN) @Message(value="Issue when retrieving transactions from %s, response was %s", id=302) void unsuccessfulResponseRetrievingTransactionsForSegments(Address address, Response response)
-
ambiguousConfigurationFiles
@LogMessage(level=WARN) @Message(value="More than one configuration file with specified name on classpath. The first one will be used:\n %s", id=304) void ambiguousConfigurationFiles(String files)
-
partitionDegraded
@Message(value="Cluster is operating in degraded mode because of node failures.", id=305) AvailabilityException partitionDegraded()
-
degradedModeKeyUnavailable
@Message(value="Key \'%s\' is not available. Not all owners are in this partition", id=306) AvailabilityException degradedModeKeyUnavailable(Object key)
-
clearDisallowedWhilePartitioned
@Message(value="Cannot clear when the cluster is partitioned", id=307) AvailabilityException clearDisallowedWhilePartitioned()
-
rebalancingEnabled
@LogMessage(level=INFO) @Message(value="Rebalancing enabled", id=308) void rebalancingEnabled()
-
rebalancingSuspended
@LogMessage(level=INFO) @Message(value="Rebalancing suspended", id=309) void rebalancingSuspended()
-
startingRebalancePhase
@LogMessage(level=DEBUG) @Message(value="Starting new rebalance phase for cache %s, topology %s", id=310) void startingRebalancePhase(String cacheName, CacheTopology cacheTopology)
-
stopOrderIgnored
@LogMessage(level=WARN) @Message(value="Cyclic dependency detected between caches, stop order ignored", id=321) void stopOrderIgnored()
-
failedToRestartXSiteStateTransfer
@LogMessage(level=WARN) @Message(value="Unable to re-start x-site state transfer to site %s", id=322) void failedToRestartXSiteStateTransfer(String siteName, @Cause Throwable cause)
-
cacheIsTerminated
@Message(value="%s is in \'%s\' state and so it does not accept new invocations. Either restart it or recreate the cache container.", id=323) IllegalLifecycleStateException cacheIsTerminated(String cacheName, String state)
-
cacheIsStopping
@Message(value="%s is in \'STOPPING\' state and this is an invocation not belonging to an on-going transaction, so it does not accept new invocations. Either restart it or recreate the cache container.", id=324) IllegalLifecycleStateException cacheIsStopping(String cacheName)
-
creatingTmpCacheTimedOut
@Message(value="Creating tmp cache %s timed out waiting for rebalancing to complete on node %s ", id=325) RuntimeException creatingTmpCacheTimedOut(String cacheName, Address address)
-
remoteTransactionTimeout
@LogMessage(level=WARN) @Message(value="Remote transaction %s timed out. Rolling back after %d ms", id=326) void remoteTransactionTimeout(GlobalTransaction gtx, long ageMilliSeconds)
-
unsupportedConfiguration
@Message(value="Cannot find a parser for element \'%s\' in namespace \'%s\'. Check that your configuration is up-to date for Infinispan \'%s\' and if you have the proper dependency in the classpath", id=327) CacheConfigurationException unsupportedConfiguration(String element, String namespaceUri, String version)
-
rebalancePhaseConfirmedOnNode
@LogMessage(level=DEBUG) @Message(value="Rebalance phase %s confirmed for cache %s on node %s, topology id = %d", id=328) void rebalancePhaseConfirmedOnNode(CacheTopology.Phase phase, String cacheName, Address node, int topologyId)
-
errorReadingRebalancingStatus
@LogMessage(level=WARN) @Message(value="Unable to read rebalancing status from coordinator %s", id=329) void errorReadingRebalancingStatus(Address coordinator, @Cause Exception e)
-
distributedTaskFailover
@LogMessage(level=WARN) @Message(value="Distributed task failed at %s. The task is failing over to be executed at %s", id=330) void distributedTaskFailover(Address failedAtAddress, Address failoverTarget, @Cause Exception e)
-
unableToInvokeListenerMethod
@LogMessage(level=WARN) @Message(value="Unable to invoke method %s on Object instance %s ", id=331) void unableToInvokeListenerMethod(Method m, Object target, @Cause Throwable e)
-
twoPhaseCommitAsyncBackup
@Message(value="Two-phase commit can only be used with synchronous backup strategy.", id=335) CacheConfigurationException twoPhaseCommitAsyncBackup()
-
finishedRebalance
@LogMessage(level=DEBUG) @Message(value="Finished rebalance for cache %s, topology %s", id=336) void finishedRebalance(String cacheName, CacheTopology topology)
-
backupMissingSite
@Message(value="The \'site\' must be specified!", id=337) CacheConfigurationException backupMissingSite()
-
missingBackupFailurePolicyClass
@Message(value="It is required to specify a \'failurePolicyClass\' when using a custom backup failure policy!", id=338) CacheConfigurationException missingBackupFailurePolicyClass()
-
backupForNullCache
@Message(value="Null name not allowed (use \'defaultRemoteCache()\' in case you want to specify the default cache name).", id=339) CacheConfigurationException backupForNullCache()
-
backupForMissingParameters
@Message(value="Both \'remoteCache\' and \'remoteSite\' must be specified for a backup\'!", id=340) CacheConfigurationException backupForMissingParameters()
-
syncPropertiesConfigOnAsyncCache
@Message(value="Cannot configure sync properties for an async cache. Set the cache mode to sync first.", id=342) IllegalStateException syncPropertiesConfigOnAsyncCache()
-
missingTransportConfiguration
@Message(value="Must have a transport set in the global configuration in order to define a clustered cache", id=343) CacheConfigurationException missingTransportConfiguration()
-
invalidReaperWakeUpInterval
@Message(value="reaperWakeUpInterval must be >= 0, we got %d", id=344) CacheConfigurationException invalidReaperWakeUpInterval(long timeout)
-
invalidCompletedTxTimeout
@Message(value="completedTxTimeout must be >= 0, we got %d", id=345) CacheConfigurationException invalidCompletedTxTimeout(long timeout)
-
invalidTxModeForTotalOrder
@Message(value="Total Order based protocol not available for transaction mode %s", id=346) CacheConfigurationException invalidTxModeForTotalOrder(TransactionMode transactionMode)
-
invalidCacheModeForTotalOrder
@Message(value="Cache mode %s is not supported by Total Order based protocol", id=347) CacheConfigurationException invalidCacheModeForTotalOrder(String friendlyCacheModeString)
-
unavailableTotalOrderWithTxRecovery
@Message(value="Total Order based protocol not available with recovery", id=348) CacheConfigurationException unavailableTotalOrderWithTxRecovery()
-
invalidLockingModeForTotalOrder
@Message(value="Total Order based protocol not available with %s", id=349) CacheConfigurationException invalidLockingModeForTotalOrder(LockingMode lockingMode)
-
l1OnlyForDistributedCache
@Message(value="Enabling the L1 cache is only supported when using DISTRIBUTED as a cache mode. Your cache mode is set to %s", id=350) CacheConfigurationException l1OnlyForDistributedCache(String cacheMode)
-
l1InvalidLifespan
@Message(value="Using a L1 lifespan of 0 or a negative value is meaningless", id=351) CacheConfigurationException l1InvalidLifespan()
-
l1NotValidWithExpirationEviction
@Message(value="Enabling the L1 cache is not supported when using EXCEPTION based eviction.", id=352) CacheConfigurationException l1NotValidWithExpirationEviction()
-
interceptorClassAndInstanceDefined
@Message(value="Cannot define both interceptor class (%s) and interceptor instance (%s)", id=354) CacheConfigurationException interceptorClassAndInstanceDefined(String customInterceptorClassName, String customInterceptor)
-
unableToInstantiateClass
@Message(value="Unable to instantiate loader/writer instance for StoreConfiguration %s", id=355) CacheConfigurationException unableToInstantiateClass(Class<?> storeConfigurationClass)
-
evictionSizeTooLarge
@Message(value="Maximum data container size is currently 2^48 - 1, the number provided was %s", id=356) CacheConfigurationException evictionSizeTooLarge(long value)
-
xaResourceEndFailed
@LogMessage(level=ERROR) @Message(value="end() failed for %s", id=357) void xaResourceEndFailed(XAResource resource, @Cause Throwable t)
-
existingConfigForInternalCache
@Message(value="A cache configuration named %s already exists. This cannot be configured externally by the user.", id=358) CacheConfigurationException existingConfigForInternalCache(String name)
-
degradedModeKeysUnavailable
@Message(value="Keys \'%s\' are not available. Not all owners are in this partition", id=359) AvailabilityException degradedModeKeysUnavailable(Collection<?> keys)
-
evictionExecutorDeprecated
@LogMessage(level=WARN) @Message(value="The xml element eviction-executor has been deprecated and replaced by expiration-executor, please update your configuration file.", id=360) void evictionExecutorDeprecated()
-
remoteTransactionAlreadyRolledBack
@Message(value="Cannot commit remote transaction %s as it was already rolled back", id=361) CacheException remoteTransactionAlreadyRolledBack(GlobalTransaction gtx)
-
remoteTransactionStatusMissing
@Message(value="Could not find status for remote transaction %s, please increase transaction.completedTxTimeout", id=362) TimeoutException remoteTransactionStatusMissing(GlobalTransaction gtx)
-
noFilterIndexingServiceProviderFound
@LogMessage(level=WARN) @Message(value="No filter indexing service provider found for indexed filter of type %s", id=363) void noFilterIndexingServiceProviderFound(String filterClassName)
-
clusterListenerRegisteredWithOnlyPreEvents
@Message(value="Attempted to register cluster listener of class %s, but listener is annotated as only observing pre events!", id=364) CacheException clusterListenerRegisteredWithOnlyPreEvents(Class<?> listenerClass)
-
jgroupsConfigurationNotFound
@Message(value="Could not find the specified JGroups configuration file \'%s\'", id=365) CacheConfigurationException jgroupsConfigurationNotFound(String cfg)
-
unableToAddNullCustomStore
@Message(value="Unable to add a \'null\' Custom Cache Store", id=366) IllegalArgumentException unableToAddNullCustomStore()
-
memoryApproximationUnsupportedVM
@LogMessage(level=WARN) @Message(value="Memory approximation calculation for eviction is unsupported for the \'%s\' Java VM", id=368) void memoryApproximationUnsupportedVM(String javaVM)
-
illegalCacheName
@Message(value="Cache name \'%s\' cannot be used as it is a reserved, internal name", id=370) IllegalArgumentException illegalCacheName(String name)
-
configurationInUse
@Message(value="Cannot remove cache configuration \'%s\' because it is in use", id=371) IllegalStateException configurationInUse(String configurationName)
-
statisticsEnabledNotAvailable
@Message(value="Statistics are enabled while attribute \'available\' is set to false.", id=372) CacheConfigurationException statisticsEnabledNotAvailable()
-
templateConfigurationStartAttempt
@Message(value="Attempted to start a cache using configuration template \'%s\'", id=373) CacheConfigurationException templateConfigurationStartAttempt(String cacheName)
-
undeclaredConfiguration
@Message(value="No such template \'%s\' when declaring \'%s\'", id=374) CacheConfigurationException undeclaredConfiguration(String template, String name)
-
noConfiguration
@Message(value="Cannot use configuration \'%s\' as a template", id=375) CacheConfigurationException noConfiguration(String extend)
-
interceptorStackNotSupported
@Message(value="Interceptor stack is not supported in simple cache", id=376) UnsupportedOperationException interceptorStackNotSupported()
-
lockOperationsNotSupported
@Message(value="Explicit lock operations are not supported in simple cache", id=377) UnsupportedOperationException lockOperationsNotSupported()
-
invocationBatchingNotEnabled
@Message(value="Invocation batching not enabled in current configuration! Please enable it.", id=378) CacheConfigurationException invocationBatchingNotEnabled()
-
distributedExecutorsNotSupported
@Message(value="Distributed Executors Framework is not supported in simple cache", id=380) CacheConfigurationException distributedExecutorsNotSupported()
-
notSupportedInSimpleCache
@Message(value="This configuration is not supported for simple cache", id=381) CacheConfigurationException notSupportedInSimpleCache()
-
missingGlobalStatePersistentLocation
@LogMessage(level=WARN) @Message(value="Global state persistence was enabled without specifying a location", id=382) void missingGlobalStatePersistentLocation()
-
evictionMaxEntriesDeprecated
@LogMessage(level=WARN) @Message(value="The eviction max-entries attribute has been deprecated. Please use the size attribute instead", id=383) void evictionMaxEntriesDeprecated()
-
unableToBroadcastInvalidation
@Message(value="Unable to broadcast invalidation messages", id=384) RuntimeException unableToBroadcastInvalidation(@Cause Throwable e)
-
dataContainerConfigurationDeprecated
@LogMessage(level=WARN) @Message(value="The data container class configuration has been deprecated. This has no current replacement", id=385) void dataContainerConfigurationDeprecated()
-
failedReadingPersistentState
@Message(value="Failed to read persisted state from file %s. Aborting.", id=386) CacheConfigurationException failedReadingPersistentState(@Cause IOException e, File stateFile)
-
failedWritingGlobalState
@Message(value="Failed to write state to file %s.", id=387) CacheConfigurationException failedWritingGlobalState(@Cause IOException e, File stateFile)
-
nonWritableStateFile
@Message(value="The state file %s is not writable. Aborting.", id=388) CacheConfigurationException nonWritableStateFile(File stateFile)
-
globalStateLoad
@LogMessage(level=INFO) @Message(value="Loaded global state, version=%s timestamp=%s", id=389) void globalStateLoad(String version, String timestamp)
-
globalStateWrite
@LogMessage(level=INFO) @Message(value="Persisted state, version=%s timestamp=%s", id=390) void globalStateWrite(String version, String timestamp)
-
recoveryNotSupportedWithNonTxCache
@Message(value="Recovery not supported with non transactional cache", id=391) CacheConfigurationException recoveryNotSupportedWithNonTxCache()
-
recoveryNotSupportedWithSynchronization
@Message(value="Recovery not supported with Synchronization", id=392) CacheConfigurationException recoveryNotSupportedWithSynchronization()
-
transactionNotificationsDisabled
@LogMessage(level=INFO) @Message(value="Transaction notifications are disabled. This prevents cluster listeners from working properly!", id=395) void transactionNotificationsDisabled()
-
ignoringUnsolicitedState
@LogMessage(level=DEBUG) @Message(value="Received unsolicited state from node %s for segment %d of cache %s", id=396) void ignoringUnsolicitedState(Address node, int segment, String cacheName)
-
persistentConsistentHashMismatch
@Message(value="CH Factory \'%s\' cannot restore a persisted CH of class \'%s\'", id=398) IllegalStateException persistentConsistentHashMismatch(String hashFactory, String consistentHashClass)
-
timeoutWaitingForInitialNodes
@Message(value="Timeout while waiting for %d members in cluster. Last view had %s", id=399) TimeoutException timeoutWaitingForInitialNodes(int initialClusterSize, List<?> members)
-
remoteNodeSuspected
@Message(value="Node %s was suspected", id=400) SuspectException remoteNodeSuspected(Address address)
-
remoteNodeTimedOut
@Message(value="Node %s timed out, time : %s %s", id=401) TimeoutException remoteNodeTimedOut(Address address, long time, TimeUnit unit)
-
coordinatorTimeoutWaitingForView
@Message(value="Timeout waiting for view %d. Current view is %d, current status is %s", id=402) TimeoutException coordinatorTimeoutWaitingForView(int expectedViewId, int currentViewId, Object clusterManagerStatus)
-
noIndexableClassesDefined
@LogMessage(level=WARN) @Message(value="No indexable classes were defined for this indexed cache; switching to autodetection (support for autodetection will be removed in Infinispan 10.0).", id=403) void noIndexableClassesDefined()
-
failedInvokingCacheManagerListener
@LogMessage(level=ERROR) @Message(value="Caught exception while invoking a cache manager listener!", id=405) void failedInvokingCacheManagerListener(@Cause Exception e)
-
ignoredReplicationQueueAttribute
@LogMessage(level=WARN) @Message(value="The replication queue is no longer supported since version 9.0. Attribute %s on line %d will be ignored.", id=406) void ignoredReplicationQueueAttribute(String attributeName, int line)
-
extraneousMembersJoinRestoredCache
@Message(value="Extraneous members %s are attempting to join cache %s, as they were not members of the persisted state", id=407) CacheJoinException extraneousMembersJoinRestoredCache(List<Address> extraneousMembers, String cacheName)
-
nodeWithPersistentStateJoiningClusterWithoutState
@Message(value="Node %s with persistent state attempting to join cache %s on cluster without state", id=408) CacheJoinException nodeWithPersistentStateJoiningClusterWithoutState(Address joiner, String cacheName)
-
nodeWithoutPersistentStateJoiningCacheWithState
@Message(value="Node %s without persistent state attempting to join cache %s on cluster with state", id=409) CacheJoinException nodeWithoutPersistentStateJoiningCacheWithState(Address joiner, String cacheName)
-
nodeWithIncompatibleStateJoiningCache
@Message(value="Node %s attempting to join cache %s with incompatible state", id=410) CacheJoinException nodeWithIncompatibleStateJoiningCache(Address joiner, String cacheName)
-
warnAboutUberJarDuplicates
@LogMessage(level=WARN) @Message(value="Classpath does not look correct. Make sure you are not mixing uber and jars", id=411) void warnAboutUberJarDuplicates()
-
unknownTransactionConfiguration
@Message(value="Cannot determine a synthetic transaction configuration from mode=%s, xaEnabled=%s, recoveryEnabled=%s, batchingEnabled=%s", id=412) CacheConfigurationException unknownTransactionConfiguration(TransactionMode mode, boolean xaEnabled, boolean recoveryEnabled, boolean batchingEnabled)
-
unableToInstantiateSerializer
@Message(value="Unable to instantiate serializer for %s", id=413) CacheConfigurationException unableToInstantiateSerializer(Class<?> storeConfigurationClass)
-
globalSecurityAuthShouldBeEnabled
@Message(value="Global security authorization should be enabled if cache authorization enabled.", id=414) CacheConfigurationException globalSecurityAuthShouldBeEnabled()
-
ignoredAttribute
@LogMessage(level=WARN) @Message(value="The %s is no longer supported since version %s. Attribute %s on line %d will be ignored.", id=415) void ignoredAttribute(String componentName, String version, String attributeName, int line)
-
transactionalStoreInNonTransactionalCache
@Message(value="It is not possible for a store to be transactional in a non-transactional cache. ", id=417) CacheConfigurationException transactionalStoreInNonTransactionalCache()
-
transactionalStoreInPassivatedCache
@Message(value="It is not possible for a store to be transactional when passivation is enabled. ", id=418) CacheConfigurationException transactionalStoreInPassivatedCache()
-
evictionDisabled
@LogMessage(level=WARN) @Message(value="Eviction of an entry invoked without an explicit eviction strategy for cache %s", id=419) void evictionDisabled(String cacheName)
-
attributeNotAllowedInInvalidationMode
@Message(value="Cannot enable \'%s\' in invalidation caches!", id=420) CacheConfigurationException attributeNotAllowedInInvalidationMode(String attributeName)
-
viewHandlingError
@LogMessage(level=ERROR) @Message(value="Error while handling view %s", id=421) void viewHandlingError(int viewId, @Cause Throwable t)
-
failedWaitingForTopology
@Message(value="Failed waiting for topology %d", id=422) TimeoutException failedWaitingForTopology(int requestTopologyId)
-
duplicateExternalizerIdFound
@Message(value="Duplicate id found! AdvancedExternalizer id=%d is shared by another externalizer (%s)", id=423) CacheConfigurationException duplicateExternalizerIdFound(int externalizerId, String otherExternalizer)
-
invalidEvictionSize
@Message(value="Eviction size value cannot be less than or equal to zero if eviction is enabled", id=424) CacheConfigurationException invalidEvictionSize()
-
memoryEvictionInvalidStrategyLIRS
@Message(value="Eviction cannot use memory-based approximation with LIRS", id=425) CacheConfigurationException memoryEvictionInvalidStrategyLIRS()
-
timeoutWaitingForAcks
@Message(value="Timeout after %s waiting for acks. Id=%s", id=427) TimeoutException timeoutWaitingForAcks(String timeout, long id)
-
elementDeprecatedUseOther
@LogMessage(level=WARN) @Message(value="The \'%s\' element has been deprecated. Please use the \'%s\' element instead", id=428) void elementDeprecatedUseOther(Element element, Element other)
-
writeSkewOnRead
@Message(value="On key %s previous read version (%s) is different from currently read version (%s)", id=429) WriteSkewException writeSkewOnRead(@Param Object key, Object key2, EntryVersion lastVersion, EntryVersion remoteVersion)
-
nonSharedStoreConfiguredAsShared
@Message(value="%s cannot be shared", id=430) CacheConfigurationException nonSharedStoreConfiguredAsShared(String storeType)
-
warnStoreAnnotationMissing
@LogMessage(level=WARN) @Message(value="Unable to validate %s\'s configuration as the @Store annotation is missing", id=431) void warnStoreAnnotationMissing(String name)
-
missingDefaultCacheDeclaration
@Message(value="Missing configuration for default cache \'%s\' declared on container", id=432) CacheConfigurationException missingDefaultCacheDeclaration(String defaultCache)
-
noDefaultCache
@Message(value="A default cache has been requested, but no cache has been set as default for this container", id=433) CacheConfigurationException noDefaultCache()
-
deprecatedDefaultCache
@LogMessage(level=WARN) @Message(value="Direct usage of the ___defaultcache name to retrieve the default cache is deprecated", id=434) void deprecatedDefaultCache()
-
defaultCacheConfigurationWithoutName
@LogMessage(level=WARN) @Message(value="Cache manager initialized with a default cache configuration but without a name for it. Set it in the GlobalConfiguration.", id=435) void defaultCacheConfigurationWithoutName()
-
noSuchCacheConfiguration
@Message(value="Cache \'%s\' has been requested, but no cache configuration exists with that name and no default cache has been set for this container", id=436) CacheConfigurationException noSuchCacheConfiguration(String name)
-
warnConfigurationForAnnotationMissing
@LogMessage(level=WARN) @Message(value="Unable to validate %s with the implementing store as the @ConfigurationFor annotation is missing", id=437) void warnConfigurationForAnnotationMissing(String name)
-
duplicateCacheName
@Message(value="Cache with name %s is defined more than once!", id=438) CacheConfigurationException duplicateCacheName(String name)
-
receivedXSiteClusterView
@LogMessage(level=INFO) @Message(value="Received new x-site view: %s", id=439) void receivedXSiteClusterView(Collection<String> view)
-
errorSendingResponse
@LogMessage(level=ERROR) @Message(value="Error sending response for request %d@%s, command %s", id=440) void errorSendingResponse(long requestId, org.jgroups.Address origin, ReplicableCommand command)
-
unsupportedAsyncCacheMode
@Message(value="Unsupported async cache mode \'%s\' for transactional caches", id=441) CacheConfigurationException unsupportedAsyncCacheMode(CacheMode cacheMode)
-
singletonStoreCannotBeShared
@Message(value="Invalid cache loader configuration for \'%s\'. If a cache loader is configured as a singleton, the cache loader cannot be shared in a cluster!", id=442) CacheConfigurationException singletonStoreCannotBeShared(String name)
-
clusteredTransactionalStoreMustBeShared
@Message(value="Invalid cache loader configuration for \'%s\'. In order for a cache loader to be transactional, it must also be shared.", id=443) CacheConfigurationException clusteredTransactionalStoreMustBeShared(String simpleName)
-
transactionalStoreCannotBeAsync
@Message(value="Invalid cache loader configuration for \'%s\'. A cache loader cannot be both Asynchronous and transactional.", id=444) CacheConfigurationException transactionalStoreCannotBeAsync(String simpleName)
-
onlyOneFetchPersistentStoreAllowed
@Message(value="At most one store can be set to \'fetchPersistentState\'!", id=445) CacheConfigurationException onlyOneFetchPersistentStoreAllowed()
-
multipleSitesWithSameName
@Message(value="Multiple sites with name \'%s\' are configured. That is not allowed!", id=446) CacheConfigurationException multipleSitesWithSameName(String site)
-
siteMustBeInBackups
@Message(value="The site \'%s\' must be defined within the set of backups!", id=447) CacheConfigurationException siteMustBeInBackups(String site)
-
awaitInitialTransferOnlyForDistOrRepl
@Message(value="\'awaitInitialTransfer\' can be enabled only if cache mode is distributed or replicated.", id=448) CacheConfigurationException awaitInitialTransferOnlyForDistOrRepl()
-
invalidXSiteStateTransferTimeout
@Message(value="XSite state transfer timeout must be higher or equals than 1 (one).", id=449) CacheConfigurationException invalidXSiteStateTransferTimeout()
-
invalidXSiteStateTransferWaitTime
@Message(value="XSite state transfer waiting time between retries must be higher or equals than 1 (one).", id=450) CacheConfigurationException invalidXSiteStateTransferWaitTime()
-
timeoutWaitingForView
@Message(value="Timed out waiting for view %d, current view is %d", id=451) TimeoutException timeoutWaitingForView(int expectedViewId, int currentViewId)
-
topologyUpdateError
@LogMessage(level=ERROR) @Message(value="Failed to update topology for cache %s", id=452) void topologyUpdateError(String cacheName, @Cause Throwable cause)
-
configAlreadyDefined
@Message(value="Attempt to define configuration for cache %s which already exists", id=453) CacheConfigurationException configAlreadyDefined(String cacheName)
-
warnAttemptToOverrideExistingConfiguration
@LogMessage(level=WARN) @Message(value="Calling getCache with a cache override is no longer supported. Please invoke createCache first and then getCache. Cache name was %s", id=454) void warnAttemptToOverrideExistingConfiguration(String cacheName)
-
transactionCleanupError
@LogMessage(level=ERROR) @Message(value="Failure during leaver transactions cleanup", id=455) void transactionCleanupError(@Cause Throwable e)
-
atomicMapDoesNotExist
@Message(value="Cache does not contain the atomic map.", id=456) IllegalStateException atomicMapDoesNotExist()
-
atomicMapHasWrongType
@Message(value="Cache contains %s which is not of expected type %s", id=457) IllegalStateException atomicMapHasWrongType(Object value, Class<?> type)
-
atomicFineGrainedNeedsGroups
@Message(value="Fine grained maps require clustering.hash.groups enabled.", id=458) IllegalStateException atomicFineGrainedNeedsGroups()
-
atomicFineGrainedNeedsTransactions
@Message(value="Fine grained maps require transactional cache.", id=459) IllegalStateException atomicFineGrainedNeedsTransactions()
-
atomicFineGrainedNeedsExplicitTxOrAutoCommit
@Message(value="Fine grained maps require explict transaction or auto-commit enabled", id=460) IllegalStateException atomicFineGrainedNeedsExplicitTxOrAutoCommit()
-
invalidEncodingClass
@Message(value="Class %s should be a subclass of %s", id=461) CacheException invalidEncodingClass(Class<?> configured, Class<?> required)
-
getConflictsAlreadyInProgress
@Message(value="ConflictManager.getConflicts() already in progress", id=462) IllegalStateException getConflictsAlreadyInProgress()
-
getConflictsStateTransferInProgress
@Message(value="Unable to retrieve conflicts as StateTransfer is currently in progress for cache \'%s\'", id=463) IllegalStateException getConflictsStateTransferInProgress(String cacheName)
-
partitionHandlingConfigurationEnabledDeprecated
@LogMessage(level=WARN) @Message(value="The partition handling \'enabled\' attribute has been deprecated. Please update your configuration to use \'when-split\' instead", id=464) void partitionHandlingConfigurationEnabledDeprecated()
-
exceptionDuringConflictResolution
@LogMessage(level=WARN) @Message(value="Exception encountered when trying to resolve conflict on Keys \'%s\': %s", id=466) void exceptionDuringConflictResolution(Object key, Throwable t)
-
scatteredCacheNeedsSingleOwner
@Message(value="Scattered cache supports only single owner.", id=467) CacheConfigurationException scatteredCacheNeedsSingleOwner()
-
invalidationBatchSizeAppliesOnNonScattered
@Message(value="Invalidation batch size configuration options applies only to scattered caches.", id=468) CacheConfigurationException invalidationBatchSizeAppliesOnNonScattered()
-
scatteredCacheIsNonTransactional
@Message(value="Scattered cache does not support transactional mode.", id=469) CacheConfigurationException scatteredCacheIsNonTransactional()
-
failedConfirmingRevokedSegments
@LogMessage(level=ERROR) @Message(value="Failed confirming revoked segments. State transfer cannot continue.", id=470) void failedConfirmingRevokedSegments(@Cause Throwable t)
-
failedProcessingValuesDuringRebalance
@LogMessage(level=ERROR) @Message(value="Failed processing values received from remote node during rebalance.", id=471) void failedProcessingValuesDuringRebalance(@Cause Throwable t)
-
cacheManagerIsStopping
@Message(value="Cache manager is stopping", id=472) IllegalLifecycleStateException cacheManagerIsStopping()
-
invalidMessageType
@LogMessage(level=ERROR) @Message(value="Invalid message type %s received from %s", id=473) void invalidMessageType(int messageType, org.jgroups.Address origin)
-
errorProcessingRequest
@LogMessage(level=ERROR) @Message(value="Error processing request %d@%s", id=474) void errorProcessingRequest(long requestId, org.jgroups.Address origin, @Cause Throwable t)
-
errorProcessingResponse
@LogMessage(level=ERROR) @Message(value="Error processing response for request %d from %s", id=475) void errorProcessingResponse(long requestId, org.jgroups.Address sender, @Cause Throwable t)
-
requestTimedOut
@Message(value="Timed out waiting for responses for request %d from %s", id=476) TimeoutException requestTimedOut(long requestId, String targetsWithoutResponses)
-
xsiteAdminOperationError
@LogMessage(level=ERROR) @Message(value="Unable to perform operation %s for site %s", id=477) void xsiteAdminOperationError(String operationName, String siteName, @Cause Throwable t)
-
unableToFindRemoteSiteTransaction
@Message(value="Couldn\'t find a local transaction corresponding to remote site transaction %s", id=478) CacheException unableToFindRemoteSiteTransaction(GlobalTransaction globalTransaction)
-
unableToFindLocalTransactionFromRemoteSiteTransaction
@Message(value="LocalTransaction not found but present in the tx table for remote site transaction %s", id=479) IllegalStateException unableToFindLocalTransactionFromRemoteSiteTransaction(GlobalTransaction globalTransaction)
-
ignoringInvalidateVersionsFromOldTopology
@LogMessage(level=WARN) @Message(value="Ignoring versions invalidation from topology %d, current topology is %d", id=480) void ignoringInvalidateVersionsFromOldTopology(int invalidationTopology, int currentTopologyId)
-
remoteTransactionOriginatorNotInView
@Message(value="Cannot create remote transaction %s, the originator is not in the cluster view", id=481) CacheException remoteTransactionOriginatorNotInView(GlobalTransaction gtx)
-
remoteTransactionAlreadyCompleted
@Message(value="Cannot create remote transaction %s, already completed", id=482) CacheException remoteTransactionAlreadyCompleted(GlobalTransaction gtx)
-
classNotFound
@Message(value="Class %s not found", id=483) CacheConfigurationException classNotFound(String name)
-
wildcardsNotAllowedInCacheNames
@Message(value="Wildcards not allowed in cache names: \'%s\'", id=484) CacheConfigurationException wildcardsNotAllowedInCacheNames(String name)
-
configurationNameMatchesMultipleWildcards
@Message(value="Configuration \'%s\' matches multiple wildcard templates", id=485) CacheConfigurationException configurationNameMatchesMultipleWildcards(String name)
-
duplicateIdWrapper
@Message(value="Cannot register Wrapper: duplicate Id %d", id=486) org.infinispan.commons.dataconversion.EncodingException duplicateIdWrapper(byte id)
-
wrapperClassNotFound
@Message(value="Wrapper with class \'%s\' not found", id=487) org.infinispan.commons.dataconversion.EncodingException wrapperClassNotFound(Class<?> wrapperClass)
-
wrapperIdNotFound
@Message(value="Wrapper with Id %d not found", id=488) org.infinispan.commons.dataconversion.EncodingException wrapperIdNotFound(byte id)
-
duplicateIdEncoder
@Message(value="Cannot register Encoder: duplicate Id %d", id=489) org.infinispan.commons.dataconversion.EncodingException duplicateIdEncoder(short id)
-
encoderClassNotFound
@Message(value="Encoder with class \'%s\' not found", id=490) org.infinispan.commons.dataconversion.EncodingException encoderClassNotFound(Class<?> wrapperClass)
-
encoderIdNotFound
@Message(value="Encoder with Id %d not found", id=491) org.infinispan.commons.dataconversion.EncodingException encoderIdNotFound(short id)
-
cannotFindTranscoder
@Message(value="Cannot find transcoder between \'%s\' to \'%s\'", id=492) org.infinispan.commons.dataconversion.EncodingException cannotFindTranscoder(org.infinispan.commons.dataconversion.MediaType mediaType, org.infinispan.commons.dataconversion.MediaType another)
-
invalidBinaryFormat
@Message(value="Invalid binary format: \'%s\'", id=494) org.infinispan.commons.dataconversion.EncodingException invalidBinaryFormat(Object content)
-
errorTranscoding
@Message(value="Error transcoding content", id=495) org.infinispan.commons.dataconversion.EncodingException errorTranscoding(@Cause Throwable cause)
-
errorTranscodingContent
@Message(value="Error transcoding content \'%s\'", id=496) org.infinispan.commons.dataconversion.EncodingException errorTranscodingContent(@Cause Throwable cause, Object content)
-
unsupportedContent
@Message(value="Unsupported content \'%s\' during transcoding", id=497) org.infinispan.commons.dataconversion.EncodingException unsupportedContent(Object content)
-
allIndexingInNonReplicatedCache
@LogMessage(level=WARN) @Message(value="Indexing mode ALL without owning all data locally (replicated mode).", id=498) void allIndexingInNonReplicatedCache()
-
configurationSerializationFailed
@Message(value="Could not serialize the configuration of cache \'%s\' (%s)", id=499) CacheConfigurationException configurationSerializationFailed(String cacheName, Configuration configuration, @Cause Exception e)
-
incompatibleClusterConfiguration
@Message(value="Cannot create clustered configuration for cache \'%s\' because configuration %n%s%n is incompatible with the existing configuration %n%s", id=500) CacheConfigurationException incompatibleClusterConfiguration(String cacheName, Configuration configuration, Configuration existing)
-
globalStateDisabled
@Message(value="Cannot persist cache configuration as global state is disabled", id=501) CacheConfigurationException globalStateDisabled()
-
errorPersistingGlobalConfiguration
@Message(value="Error while persisting global configuration state", id=502) CacheConfigurationException errorPersistingGlobalConfiguration(@Cause Throwable cause)
-
compatibilityModeOnlyCompatibleWithObjectStorage
@Message(value="Compatibility mode requires OBJECT storage type but was: %s", id=503) CacheConfigurationException compatibilityModeOnlyCompatibleWithObjectStorage(StorageType storageType)
-
offHeapMemoryEvictionNotSupportedWithObject
@Message(value="MEMORY based eviction is not supported with OBJECT storage", id=504) CacheConfigurationException offHeapMemoryEvictionNotSupportedWithObject()
-
offHeapMemoryEvictionSizeNotLargeEnoughForAddresses
@Message(value="MEMORY based OFF_HEAP eviction configured size %d must be larger than %d to store configured address count of %d", id=505) CacheConfigurationException offHeapMemoryEvictionSizeNotLargeEnoughForAddresses(long configuredSize, long addressMemorySize, int addressCount)
-
biasedReadsAppliesOnlyToScattered
@Message(value="Biased reads are supported only in scattered cache. Maybe you were looking for L1?", id=506) CacheConfigurationException biasedReadsAppliesOnlyToScattered()
-
cacheExists
@Message(value="Cache %s already exists", id=507) CacheConfigurationException cacheExists(String cacheName)
-
cannotRenamePersistentFile
@Message(value="Cannot rename file %s to %s", id=508) CacheConfigurationException cannotRenamePersistentFile(String absolutePath, File persistentFile, @Cause Throwable cause)
-
unableToAddNullEntryMergePolicyFactory
@Message(value="Unable to add a \'null\' EntryMergePolicyFactory", id=509) IllegalArgumentException unableToAddNullEntryMergePolicyFactory()
-
customStorageStrategyNotSet
@Message(value="ConfigurationStrategy set to CUSTOM, but none specified", id=510) CacheConfigurationException customStorageStrategyNotSet()
-
managerConfigurationStorageUnavailable
@Message(value="ConfigurationStrategy cannot be set to MANAGED in embedded mode", id=511) CacheConfigurationException managerConfigurationStorageUnavailable()
-
globalStateCannotAcquireLockFile
@Message(value="Cannot acquire lock \'%s\' for persistent global state", id=512) CacheConfigurationException globalStateCannotAcquireLockFile(@Cause Throwable cause, File lockFile)
-
exceptionBasedEvictionOnlySupportedInTransactionalCaches
@Message(value="Exception based eviction requires a transactional cache that doesn\'t allow for 1 phase commit or synchronizations", id=513) CacheConfigurationException exceptionBasedEvictionOnlySupportedInTransactionalCaches()
-
containerFull
@Message(value="Container eviction limit %d reached, write operation(s) is blocked", id=514) ContainerFullException containerFull(long size)
-
immutableConfiguration
@Message(value="The configuration is immutable", id=515) UnsupportedOperationException immutableConfiguration()
-
invalidPersistentState
@Message(value="The state file for \'%s\' is invalid. Startup halted to prevent further corruption of persistent state", id=516) CacheConfigurationException invalidPersistentState(String globalScope)
-
ignoringCacheTopology
@LogMessage(level=WARN) @Message(value="Ignoring cache topology from %s during merge: %s", id=517) void ignoringCacheTopology(Collection<Address> sender, CacheTopology topology)
-
updatingTopology
@LogMessage(level=DEBUG) @Message(value="Updating topology for cache %s, topology %s, availability mode %s", id=518) void updatingTopology(String cacheName, CacheTopology currentTopology, AvailabilityMode availabilityMode)
-
updatingStableTopology
@LogMessage(level=DEBUG) @Message(value="Updating stable topology for cache %s, topology %s", id=519) void updatingStableTopology(String cacheName, CacheTopology currentTopology)
-
updatingAvailabilityMode
@LogMessage(level=DEBUG) @Message(value="Updating availability mode for cache %s from %s to %s, topology %s", id=520) void updatingAvailabilityMode(String cacheName, AvailabilityMode oldMode, AvailabilityMode newMode, CacheTopology topology)
-
cacheRecoveredAfterMerge
@LogMessage(level=DEBUG) @Message(value="Cache %s recovered after merge with topology = %s, availability mode %s", id=521) void cacheRecoveredAfterMerge(String cacheName, CacheTopology currentTopology, AvailabilityMode availabilityMode)
-
startingConflictResolution
@LogMessage(level=DEBUG) @Message(value="Conflict resolution starting for cache %s with topology %s", id=522) void startingConflictResolution(String cacheName, CacheTopology currentTopology)
-
finishedConflictResolution
@LogMessage(level=DEBUG) @Message(value="Conflict resolution finished for cache %s with topology %s", id=523) void finishedConflictResolution(String cacheName, CacheTopology currentTopology)
-
failedConflictResolution
@LogMessage(level=DEBUG) @Message(value="Conflict resolution failed for cache %s with topology %s", id=524) void failedConflictResolution(String cacheName, CacheTopology currentTopology, @Cause Throwable t)
-
cancelledConflictResolution
@LogMessage(level=DEBUG) @Message(value="Conflict resolution cancelled for cache %s with topology %s", id=525) void cancelledConflictResolution(String cacheName, CacheTopology currentTopology)
-
storeStartupAttemptsExceeded
@Message(value="Maximum startup attempts exceeded for store %s", id=527) PersistenceException storeStartupAttemptsExceeded(String storeName, @Cause Throwable t)
-
degradedModeLockUnavailable
@Message(value="Cannot acquire lock %s as this partition is DEGRADED", id=528) AvailabilityException degradedModeLockUnavailable(Object key)
-
errorDeserializing
@Message(value="Class \'%s\' blocked by deserialization white list. Include the class name in the server white list to authorize.", id=529) CacheException errorDeserializing(String className)
-
unsupportedAsyncCacheMode
@LogMessage(level=WARN) @Message(value="Unsupported async cache mode \'%s\' for transactional caches, forcing %s", id=530) void unsupportedAsyncCacheMode(CacheMode unsupportedCacheMode, CacheMode forcedCacheMode)
-
storeNotSegmented
@Message(value="Store or loader %s must implement SegmentedLoadWriteStore or its config must extend AbstractSegmentedStoreConfiguration if configured as segmented", id=531) CacheConfigurationException storeNotSegmented(Class<?> implementedClass)
-
passivationStoreCannotBeShared
@Message(value="Invalid cache loader configuration for \'%s\'. If a cache loader is configured with passivation, the cache loader cannot be shared in a cluster!", id=532) CacheConfigurationException passivationStoreCannotBeShared(String name)
-
cannotConvertContent
@Message(value="Content \'%s (MediaType: \'%s\') cannot be converted to \'%s\'", id=533) org.infinispan.commons.dataconversion.EncodingException cannotConvertContent(Object content, org.infinispan.commons.dataconversion.MediaType contentType, org.infinispan.commons.dataconversion.MediaType destination)
-
groupingOnlyCompatibleWithObjectStorage
@Message(value="Grouping requires OBJECT storage type but was: %s", id=534) CacheConfigurationException groupingOnlyCompatibleWithObjectStorage(StorageType storageType)
-
warnCompatibilityDeprecated
@LogMessage(level=WARN) @Message(value="Cache \'%s\' uses the deprecated compatibility mode configuration. See \'Embedded/Remote Interoperability\' in the user guide for a replacement", id=536) void warnCompatibilityDeprecated(String cacheName)
-
factoryCannotConstructComponent
@Message(value="Factory doesn\'t know how to construct component %s", id=537) CacheConfigurationException factoryCannotConstructComponent(String componentName)
-
moduleStopError
@LogMessage(level=ERROR) @Message(value="Error stopping module %s", id=538) void moduleStopError(String module, @Cause Throwable t)
-
sharedStoreWithLocalCache
@Message(value="A store cannot be shared when utilised with a local cache.", id=549) CacheConfigurationException sharedStoreWithLocalCache()
-
invalidationPartitionHandlingNotSuported
@Message(value="Invalidation mode only supports when-split=ALLOW_READ_WRITES", id=550) CacheConfigurationException invalidationPartitionHandlingNotSuported()
-
warnUnableToPersistInternalCaches
@LogMessage(level=WARN) @Message(value="Unable to persist Infinispan internal caches as no global state enabled", id=569) @Once void warnUnableToPersistInternalCaches()
-
-