org.infinispan.util.logging
Interface Log
- All Superinterfaces:
- org.jboss.logging.BasicLogger
- All Known Subinterfaces:
- JavaLog, JavaLog, JavaLog, JavaLog, Log, Log, Log, Log, Log, Log
@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 1000 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 JDKs String.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 |
void |
abortingJoin(Exception e)
|
void |
afterCompletionFailed(Synchronization s,
Throwable t)
|
void |
alwaysProvideInMemoryStateDeprecated()
|
void |
asyncStoreCoordinatorInterrupted(InterruptedException e)
|
void |
asyncStoreShutdownTimeoutTooHigh(long configuredAsyncStopTimeout,
long cacheStopTimeout,
long asyncStopTimeout)
|
void |
beforeCompletionFailed(Synchronization s,
Throwable t)
|
void |
cacheBackupsDataToSameSite(String siteName)
|
void |
cacheLoaderIgnoringUnexpectedFile(Object parentPath,
String name)
|
void |
cacheManagerAlreadyRegistered(String jmxDomain)
|
void |
cacheNotStarted()
|
void |
cacheViewRollbackIdMismatch(int committedViewId,
int committedView)
|
void |
cannotRespondToCommit(GlobalTransaction globalTransaction,
String cacheName)
|
void |
cannotRespondToRollback(GlobalTransaction globalTransaction,
String cacheName)
|
void |
cannotSelectRandomMembers(int numNeeded,
List<Address> members)
|
void |
channelNotSetUp()
|
void |
componentFailedToStop(Throwable e)
|
void |
consistentHashDeprecated()
|
void |
couldNotAcquireLockForEviction(Object key,
Exception e)
|
void |
couldNotAcquireSharedLock()
|
void |
couldNotCompleteInjectedTransaction(Throwable t)
|
void |
couldNotExecuteCancellationLocally(String message)
|
void |
couldNotFindAttribute(String name)
|
void |
couldNotFindDescriptionField()
|
void |
couldNotInitializeModule(Object key,
Exception ex)
|
void |
couldNotInstantiateTransactionManager(Exception e)
|
void |
couldNotInterruptThread(UUID id)
|
void |
couldNotInvokeSetOnAttribute(String attributeName,
Object value)
|
void |
couldNotLoadModuleAtUrl(URL url,
Exception ex)
|
void |
couldNotRegisterObjectName(ObjectName objectName,
InstanceAlreadyExistsException e)
|
void |
couldNotResolveConfigurationSchema(String localPath,
String schemaPath,
String schemaURL)
|
void |
couldNotRollbackPrepared1PcTransaction(LocalTransaction localTransaction,
Throwable e1)
|
void |
customInterceptorExpectsInjection(String customInterceptorFQCN)
|
void |
deprecatedLoaderAsStoreConfiguration()
|
void |
disconnectAndCloseJGroups()
|
void |
distributionManagerNotJoined()
|
void |
distributionManagerNotStarted()
|
void |
entriesMigrated(long count,
String name,
String prettyTime)
|
void |
errorChangingSingletonStoreStatus(SingletonStore.PushStateException e)
|
void |
errorCommittingTx(XAException e)
|
void |
errorCreatingChannelFromConfigFile(String cfg)
|
void |
errorCreatingChannelFromConfigString(String cfg)
|
void |
errorCreatingChannelFromXML(String cfg)
|
void |
errorDoingRemoteCall(Exception e)
|
void |
errorEnlistingResource(XAException e)
|
void |
errorFlushingToFileChannel(FileChannel f,
Exception e)
|
void |
errorInstantiatingJGroupsChannelLookup(String channelLookupClassName,
Exception e)
|
void |
errorMarshallingObject(IOException ioe)
|
void |
errorModifyingAsyncStore(Exception e)
|
void |
errorProcessing1pcPrepareCommand(Throwable e)
|
void |
errorProcessing2pcCommitCommand(Throwable e)
|
void |
errorReadingConfiguration(Exception e)
|
void |
errorReadingFromFile(File f,
Exception e)
|
void |
errorReadingProperties(IOException e)
|
void |
errorRollingBack(Throwable e)
|
void |
errorSavingBucket(Bucket b,
IOException ex)
|
void |
errorUnblockingTransactions(Exception e)
|
void |
errorUpdatingMembersList(Throwable cause)
|
void |
errorWritingValueForAttribute(String attributeName,
Exception e)
|
void |
evictionWakeUpIntervalDeprecated(Long wakeUpInterval)
|
void |
exceptionHandlingCommand(ReplicableCommand cmd,
Throwable t)
|
void |
exceptionPurgingDataContainer(Exception e)
|
void |
executionError(Throwable t)
|
void |
expectedJustOneResponse(Map<Address,Response> lr)
|
void |
failedInvalidatingRemoteCache(Exception e)
|
void |
failedLoadingKeysFromCacheStore(Exception e)
|
void |
failedLoadingValueFromCacheStore(Object key,
Exception e)
|
void |
failedReplicatingQueue(int size,
Throwable t)
|
void |
failedSynchronizationRegistration(Exception e)
|
void |
failedToCallStopAfterFailure(Throwable t)
|
void |
failedToCloseResource(Throwable e)
|
void |
failedToCreateInitialCtx(NamingException e)
|
void |
failedToInvalidateKeys(Exception e)
|
void |
failedToRecoverClusterState(Throwable cause)
|
void |
failedToRequestSegments(Collection<Integer> segments,
String cacheName,
Address source,
Exception e)
|
void |
failedToRetrieveTransactionsForSegments(Collection<Integer> segments,
String cacheName,
Address source,
Exception e)
|
void |
failedToUpdateAtribute(String name,
Object value)
|
void |
fallingBackToDummyTm()
|
void |
fieldNotFound(String fieldName)
|
void |
hashNumVirtualNodesDeprecated()
|
void |
hashRehashEnabledDeprecated()
|
void |
hashRehashRpcTimeoutDeprecated()
|
void |
hashRehashWaitDeprecated()
|
void |
ignoringException(String methodName,
String exceptionName,
Throwable t)
|
void |
ignoringManagedAttribute(String methodName)
|
void |
initialRetryWaitTimeDeprecated()
|
void |
interruptedAcquiringLock(long ms,
InterruptedException e)
|
void |
interruptedWaitingAsyncStorePush(InterruptedException e)
|
void |
interruptedWaitingForCoordinator(InterruptedException e)
|
void |
invalidManagedAttributeMethod(String methodName)
|
void |
invalidTimeoutValue(Object configName1,
Object value1,
Object configName2,
Object value2)
|
void |
joinRehashAborted(Address self,
String duration)
|
void |
joinRehashCompleted(Address self,
String duration)
|
void |
keyDoesNotMapToLocalNode(Object key,
Collection<Address> nodes)
|
void |
lazyDeserializationDeprecated()
|
void |
localAndPhysicalAddress(Address address,
List<Address> physicalAddresses)
|
void |
localExecutionFailed(Throwable t)
|
void |
localIndexingWithSharedCacheLoaderRequiresPreload()
|
void |
logFlushTimeoutDeprecated()
|
void |
maxProgressingLogWritesDeprecated()
|
void |
mbeansSuccessfullyRegistered()
|
void |
missingListPreparedTransactions(Object key,
Object value)
|
void |
msgOrMsgBufferEmpty()
|
void |
namedCacheDoesNotExist(String cacheName)
|
void |
noAnnotateMethodsFoundInListener(Class<?> listenerClass)
|
void |
noLiveOwnersFoundForSegment(int segmentId,
String cacheName,
Collection<Address> owners,
Collection<Address> faultySources)
|
void |
notStartingEvictionThread()
|
void |
numRetriesDeprecated()
|
void |
passivatedEntries(int numEntries,
String duration)
|
void |
passivatingAllEntries()
|
void |
passivationWithoutEviction()
|
void |
preparedTxAlreadyExists(RecoveryAwareTransaction previous,
RecoveryAwareRemoteTransaction remoteTransaction)
|
void |
problemApplyingStateForKey(String msg,
Object key,
Throwable t)
|
void |
problemClosingChannel(Exception e)
|
void |
problemPurgingExpired(Exception e)
|
void |
problemsCreatingDirectory(File dir)
|
void |
problemsPurgingFile(File buckedFile,
CacheLoaderException e)
|
void |
problemsRemovingFile(File f)
|
void |
problemsUnregisteringMBeans(Exception e)
|
void |
propertyCouldNotBeReplaced(String line)
|
void |
queriedAttributeNotFound(String attributeName)
|
void |
randomCacheModeSynonymsDeprecated(String candidate,
String mode,
List<String> synonyms)
|
void |
readManagedAttributeAlreadyPresent(Method m)
|
void |
rebalanceError(String cacheName,
Address node,
Throwable cause)
|
void |
receivedClusterView(org.jgroups.View newView)
|
void |
receivedMergedView(org.jgroups.View newView)
|
void |
recoveryIgnored()
|
void |
rehashCommandReceivedOnNonDistributedCache()
|
RemoteException |
remoteException(Address sender,
Exception e)
|
void |
remoteExecutionFailed(Address address,
Throwable t)
|
void |
remoteTxAlreadyRegistered()
|
void |
retrievingTm(TransactionManager tm)
|
void |
retryWaitTimeIncreaseFactorDeprecated()
|
void |
segmentsRequestedByNodeWithOlderTopology(Address node,
int requestTopologyId,
int localTopologyId)
|
void |
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup()
|
void |
startingJGroupsChannel()
|
void |
stateRetrievalConfigurationDeprecated()
|
void |
stopBeforeDestroyFailed(CacheException e)
|
void |
stoppingRpcDispatcher()
|
void |
transactionsRequestedByNodeWithOlderTopology(Address node,
int requestTopologyId,
int localTopologyId)
|
void |
tryingToBringOnlineNonexistentSite(String siteName)
|
void |
unableToAcquireLockToPurgeStore()
|
void |
unableToApplyPrepare(PrepareCommand pc,
Throwable t)
|
void |
unableToClearAsyncStore()
|
void |
unableToConvertStringPropertyToBoolean(String value,
boolean defaultValue)
|
void |
unableToConvertStringPropertyToInt(String value,
int defaultValue)
|
void |
unableToConvertStringPropertyToLong(String value,
long defaultValue)
|
void |
unableToCopyEntryForUpdate(Object key)
|
void |
unableToInvokeGetterOnConfiguration(Method getter,
Exception e)
|
void |
unableToInvokeListenerMethod(Method m,
Object target,
Throwable e)
|
void |
unableToInvokeWebsphereStaticGetTmMethod(Exception ex,
String className)
|
void |
unableToLoadClass(String classname,
String classloaders,
Throwable cause)
|
void |
unableToLoadFromCacheLoader(Object key,
CacheLoaderException cle)
|
void |
unableToLockToInvalidate(Object key,
Address address)
|
void |
unableToPassivateEntry(Object key,
Exception e)
|
void |
unableToProcessAsyncModifications(int retries)
|
void |
unableToReadVersionId()
|
void |
unableToRegisterCacheManagerMBeans()
|
void |
unableToRegisterMBeans()
|
void |
unableToRegisterMBeans(String cacheName)
|
void |
unableToRemoveEntryAfterActivation(Object key,
Exception e)
|
void |
unableToRollbackGlobalTx(GlobalTransaction gtx,
Throwable e)
|
void |
unableToSetValue(Exception e)
|
void |
unableToUnlockRebalancedKeys(GlobalTransaction gtx,
List<Object> keys,
Address self,
Throwable t)
|
void |
unableToUnregisterMBeanWithPattern(String pattern,
MBeanRegistrationException e)
|
void |
unableToUseJGroupsPropertiesProvided(TypedProperties props)
|
void |
unbindingDummyTmFailed(NamingException e)
|
void |
unexpectedErrorFromResourceManager(Throwable t)
|
void |
unexpectedErrorInAsyncProcessor(Throwable t)
|
void |
unexpectedErrorInAsyncStoreCoordinator(Throwable t)
|
void |
unexpectedErrorReplicating(Throwable t)
|
void |
unfinishedTransactionsRemain(int localTransactions,
int remoteTransactions)
|
Exception |
unknownMigrator(String migratorName)
|
void |
unknownResponsesFromRemoteCache(Collection<Response> responses)
|
void |
unprocessedTxLogEntries(int size)
|
void |
unsupportedTransactionConfiguration(boolean dldEnabled,
boolean recoveryEnabled,
boolean xa)
|
void |
usingBatchModeTransactionManager()
|
void |
version(String version)
|
void |
waitForCacheToStart(String cacheName)
|
void |
warnStrictPeerToPeerWithInjectedChannel()
|
void |
warnXsiteBackupFailed(String cacheName,
String key,
Object value)
|
void |
writeManagedAttributeAlreadyPresent(String methodName)
|
void |
wrongTypeForJGroupsChannelLookup(String channelLookupClassName,
Exception e)
|
Methods inherited from interface org.jboss.logging.BasicLogger |
debug, debug, debug, debug, 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, 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 |
unableToLoadFromCacheLoader
@LogMessage(level=WARN)
@Message(value="Unable to load %s from cache loader",
id=1)
void unableToLoadFromCacheLoader(Object key,
@Cause
CacheLoaderException cle)
fieldNotFound
@LogMessage(level=WARN)
@Message(value="Field %s not found!!",
id=2)
void fieldNotFound(String fieldName)
propertyCouldNotBeReplaced
@LogMessage(level=WARN)
@Message(value="Property %s could not be replaced as intended!",
id=3)
void propertyCouldNotBeReplaced(String line)
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)
distributionManagerNotJoined
@LogMessage(level=INFO)
@Message(value="DistributionManager not yet joined the cluster. Cannot do anything about other concurrent joiners.",
id=14)
void distributionManagerNotJoined()
distributionManagerNotStarted
@LogMessage(level=WARN)
@Message(value="DistributionManager not started after waiting up to 5 minutes! Not rehashing!",
id=15)
void distributionManagerNotStarted()
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)
unableToApplyPrepare
@LogMessage(level=WARN)
@Message(value="Unable to apply prepare %s",
id=18)
void unableToApplyPrepare(PrepareCommand pc,
@Cause
Throwable t)
couldNotAcquireSharedLock
@LogMessage(level=INFO)
@Message(value="Couldn\'t acquire shared lock",
id=19)
void couldNotAcquireSharedLock()
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
Exception e)
couldNotAcquireLockForEviction
@LogMessage(level=WARN)
@Message(value="Could not acquire lock for eviction of %s",
id=27)
void couldNotAcquireLockForEviction(Object key,
@Cause
Exception 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(int numEntries,
String duration)
mbeansSuccessfullyRegistered
@LogMessage(level=INFO)
@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)
cacheManagerAlreadyRegistered
@LogMessage(level=ERROR)
@Message(value="There\'s already an cache manager instance 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)
void cacheManagerAlreadyRegistered(String jmxDomain)
couldNotFindDescriptionField
@LogMessage(level=WARN)
@Message(value="Could not reflect field description of this class. Was it removed?",
id=35)
void couldNotFindDescriptionField()
couldNotFindAttribute
@LogMessage(level=WARN)
@Message(value="Did not find attribute %s",
id=36)
void couldNotFindAttribute(String name)
failedToUpdateAtribute
@LogMessage(level=WARN)
@Message(value="Failed to update attribute name %s with value %s",
id=37)
void failedToUpdateAtribute(String name,
Object value)
ignoringManagedAttribute
@LogMessage(level=WARN)
@Message(value="Method name %s doesn\'t start with \"get\", \"set\", or \"is\" but is annotated with @ManagedAttribute: will be ignored",
id=38)
void ignoringManagedAttribute(String methodName)
invalidManagedAttributeMethod
@LogMessage(level=WARN)
@Message(value="Method %s must have a valid return type and zero parameters",
id=39)
void invalidManagedAttributeMethod(String methodName)
readManagedAttributeAlreadyPresent
@LogMessage(level=WARN)
@Message(value="Not adding annotated method %s since we already have read attribute",
id=40)
void readManagedAttributeAlreadyPresent(Method m)
writeManagedAttributeAlreadyPresent
@LogMessage(level=WARN)
@Message(value="Not adding annotated method %s since we already have writable attribute",
id=41)
void writeManagedAttributeAlreadyPresent(String methodName)
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)
problemPurgingExpired
@LogMessage(level=ERROR)
@Message(value="Problems encountered while purging expired",
id=45)
void problemPurgingExpired(@Cause
Exception e)
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 AsyncStore worker threads to push all state to the decorated store",
id=48)
void interruptedWaitingAsyncStorePush(@Cause
InterruptedException e)
unexpectedErrorInAsyncProcessor
@LogMessage(level=ERROR)
@Message(value="Unexpected error",
id=51)
void unexpectedErrorInAsyncProcessor(@Cause
Throwable t)
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)
asyncStoreCoordinatorInterrupted
@LogMessage(level=ERROR)
@Message(value="AsyncStoreCoordinator interrupted",
id=54)
void asyncStoreCoordinatorInterrupted(@Cause
InterruptedException e)
unexpectedErrorInAsyncStoreCoordinator
@LogMessage(level=ERROR)
@Message(value="Unexpected error in AsyncStoreCoordinator thread. AsyncStore is dead!",
id=55)
void unexpectedErrorInAsyncStoreCoordinator(@Cause
Throwable t)
errorModifyingAsyncStore
@LogMessage(level=ERROR)
@Message(value="Error while handling Modification in AsyncStore",
id=56)
void errorModifyingAsyncStore(@Cause
Exception e)
unableToClearAsyncStore
@LogMessage(level=ERROR)
@Message(value="Clear() operation in async store could not be performed",
id=57)
void unableToClearAsyncStore()
errorChangingSingletonStoreStatus
@LogMessage(level=ERROR)
@Message(value="Exception reported changing cache active status",
id=58)
void errorChangingSingletonStoreStatus(@Cause
SingletonStore.PushStateException e)
problemsRemovingFile
@LogMessage(level=WARN)
@Message(value="Had problems removing file %s",
id=59)
void problemsRemovingFile(File f)
problemsPurgingFile
@LogMessage(level=WARN)
@Message(value="Problems purging file %s",
id=60)
void problemsPurgingFile(File buckedFile,
@Cause
CacheLoaderException e)
unableToAcquireLockToPurgeStore
@LogMessage(level=WARN)
@Message(value="Unable to acquire global lock to purge cache store",
id=61)
void unableToAcquireLockToPurgeStore()
errorReadingFromFile
@LogMessage(level=ERROR)
@Message(value="Error while reading from file: %s",
id=62)
void errorReadingFromFile(File f,
@Cause
Exception e)
errorSavingBucket
@LogMessage(level=ERROR)
@Message(value="Exception while saving bucket %s",
id=63)
void errorSavingBucket(Bucket b,
@Cause
IOException ex)
problemsCreatingDirectory
@LogMessage(level=WARN)
@Message(value="Problems creating the directory: %s",
id=64)
void problemsCreatingDirectory(File dir)
errorMarshallingObject
@LogMessage(level=ERROR)
@Message(value="Exception while marshalling object",
id=65)
void errorMarshallingObject(@Cause
IOException ioe)
unableToReadVersionId
@LogMessage(level=ERROR)
@Message(value="Unable to read version id from first two bytes of stream, barfing.",
id=66)
void unableToReadVersionId()
waitForCacheToStart
@LogMessage(level=INFO)
@Message(value="Will try and wait for the cache %s to start",
id=67)
void waitForCacheToStart(String cacheName)
namedCacheDoesNotExist
@LogMessage(level=INFO)
@Message(value="Cache named %s does not exist on this cache manager!",
id=68)
void namedCacheDoesNotExist(String cacheName)
exceptionHandlingCommand
@LogMessage(level=WARN)
@Message(value="Caught exception when handling command %s",
id=71)
void exceptionHandlingCommand(ReplicableCommand cmd,
@Cause
Throwable t)
failedReplicatingQueue
@LogMessage(level=ERROR)
@Message(value="Failed replicating %d elements in replication queue",
id=72)
void failedReplicatingQueue(int size,
@Cause
Throwable t)
unexpectedErrorReplicating
@LogMessage(level=ERROR)
@Message(value="Unexpected error while replicating",
id=73)
void unexpectedErrorReplicating(@Cause
Throwable t)
msgOrMsgBufferEmpty
@LogMessage(level=ERROR)
@Message(value="Message or message buffer is null or empty.",
id=77)
void msgOrMsgBufferEmpty()
startingJGroupsChannel
@LogMessage(level=INFO)
@Message(value="Starting JGroups Channel",
id=78)
void startingJGroupsChannel()
localAndPhysicalAddress
@LogMessage(level=INFO)
@Message(value="Cache local address is %s, physical addresses are %s",
id=79)
void localAndPhysicalAddress(Address address,
List<Address> physicalAddresses)
disconnectAndCloseJGroups
@LogMessage(level=INFO)
@Message(value="Disconnecting and closing JGroups Channel",
id=80)
void disconnectAndCloseJGroups()
problemClosingChannel
@LogMessage(level=ERROR)
@Message(value="Problem closing channel; setting it to null",
id=81)
void problemClosingChannel(@Cause
Exception e)
stoppingRpcDispatcher
@LogMessage(level=INFO)
@Message(value="Stopping the RpcDispatcher",
id=82)
void stoppingRpcDispatcher()
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
@LogMessage(level=ERROR)
@Message(value="Error while trying to create a channel using config files: %s",
id=85)
void errorCreatingChannelFromConfigFile(String cfg)
errorCreatingChannelFromXML
@LogMessage(level=ERROR)
@Message(value="Error while trying to create a channel using config XML: %s",
id=86)
void errorCreatingChannelFromXML(String cfg)
errorCreatingChannelFromConfigString
@LogMessage(level=ERROR)
@Message(value="Error while trying to create a channel using config string: %s",
id=87)
void errorCreatingChannelFromConfigString(String cfg)
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(TypedProperties props)
interruptedWaitingForCoordinator
@LogMessage(level=ERROR)
@Message(value="getCoordinator(): Interrupted while waiting for members to be set",
id=89)
void interruptedWaitingForCoordinator(@Cause
InterruptedException e)
channelNotSetUp
@LogMessage(level=WARN)
@Message(value="Channel not set up properly!",
id=92)
void channelNotSetUp()
receivedMergedView
@LogMessage(level=INFO)
@Message(value="Received new, MERGED cluster view: %s",
id=93)
void receivedMergedView(org.jgroups.View newView)
receivedClusterView
@LogMessage(level=INFO)
@Message(value="Received new cluster view: %s",
id=94)
void receivedClusterView(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 while rollback",
id=98)
void errorRollingBack(@Cause
Throwable e)
unprocessedTxLogEntries
@LogMessage(level=ERROR)
@Message(value="Unprocessed Transaction Log Entries! = %d",
id=99)
void unprocessedTxLogEntries(int size)
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)
remoteTxAlreadyRegistered
@LogMessage(level=ERROR)
@Message(value="A remote transaction with the given id was already registered!!!",
id=103)
void remoteTxAlreadyRegistered()
fallingBackToDummyTm
@LogMessage(level=WARN)
@Message(value="Falling back to DummyTransactionManager from Infinispan",
id=104)
void fallingBackToDummyTm()
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)
unbindingDummyTmFailed
@LogMessage(level=ERROR)
@Message(value="Unbinding of DummyTransactionManager failed",
id=113)
void unbindingDummyTmFailed(@Cause
NamingException e)
unsupportedTransactionConfiguration
@LogMessage(level=ERROR)
@Message(value="Unsupported combination (dldEnabled, recoveryEnabled, xa) = (%s, %s, %s)",
id=114)
void unsupportedTransactionConfiguration(boolean dldEnabled,
boolean recoveryEnabled,
boolean xa)
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)
couldNotLoadModuleAtUrl
@LogMessage(level=WARN)
@Message(value="Could not load module at URL %s",
id=118)
void couldNotLoadModuleAtUrl(URL url,
@Cause
Exception ex)
couldNotInitializeModule
@LogMessage(level=WARN)
@Message(value="Module %s loaded, but could not be initialized",
id=119)
void couldNotInitializeModule(Object key,
@Cause
Exception ex)
ignoringException
@LogMessage(level=WARN)
@Message(value="Invocation of %s threw an exception %s. Exception is ignored.",
id=120)
void ignoringException(String methodName,
String exceptionName,
@Cause
Throwable t)
unableToSetValue
@LogMessage(level=ERROR)
@Message(value="Unable to set value!",
id=121)
void unableToSetValue(@Cause
Exception e)
unableToConvertStringPropertyToInt
@LogMessage(level=WARN)
@Message(value="Unable to convert string property [%s] to an int! Using default value of %d",
id=122)
void unableToConvertStringPropertyToInt(String value,
int defaultValue)
unableToConvertStringPropertyToLong
@LogMessage(level=WARN)
@Message(value="Unable to convert string property [%s] to a long! Using default value of %d",
id=123)
void unableToConvertStringPropertyToLong(String value,
long defaultValue)
unableToConvertStringPropertyToBoolean
@LogMessage(level=WARN)
@Message(value="Unable to convert string property [%s] to a boolean! Using default value of %b",
id=124)
void unableToConvertStringPropertyToBoolean(String value,
boolean defaultValue)
unableToInvokeGetterOnConfiguration
@LogMessage(level=WARN)
@Message(value="Unable to invoke getter %s on Configuration.class!",
id=125)
void unableToInvokeGetterOnConfiguration(Method getter,
@Cause
Exception e)
failedToCallStopAfterFailure
@LogMessage(level=WARN)
@Message(value="Attempted to stop() from FAILED state, but caught exception; try calling destroy()",
id=126)
void failedToCallStopAfterFailure(@Cause
Throwable t)
stopBeforeDestroyFailed
@LogMessage(level=WARN)
@Message(value="Needed to call stop() before destroying but stop() threw exception. Proceeding to destroy",
id=127)
void stopBeforeDestroyFailed(@Cause
CacheException e)
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()
abortingJoin
@LogMessage(level=ERROR)
@Message(value="Caught exception! Aborting join.",
id=130)
void abortingJoin(@Cause
Exception e)
joinRehashCompleted
@LogMessage(level=INFO)
@Message(value="%s completed join rehash in %s!",
id=131)
void joinRehashCompleted(Address self,
String duration)
joinRehashAborted
@LogMessage(level=INFO)
@Message(value="%s aborted join rehash after %s!",
id=132)
void joinRehashAborted(Address self,
String duration)
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)
unableToInvokeListenerMethod
@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 unableToInvokeListenerMethod(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="Execution error",
id=136)
void executionError(@Cause
Throwable t)
failedInvalidatingRemoteCache
@LogMessage(level=INFO)
@Message(value="Failed invalidating remote cache",
id=137)
void failedInvalidatingRemoteCache(@Cause
Exception e)
couldNotRegisterObjectName
@LogMessage(level=INFO)
@Message(value="Could not register object with name: %s",
id=138)
void couldNotRegisterObjectName(ObjectName objectName,
@Cause
InstanceAlreadyExistsException e)
couldNotResolveConfigurationSchema
@LogMessage(level=WARN)
@Message(value="Infinispan configuration schema could not be resolved locally nor fetched from URL. Local path=%s, schema path=%s, schema URL=%s",
id=139)
void couldNotResolveConfigurationSchema(String localPath,
String schemaPath,
String schemaURL)
lazyDeserializationDeprecated
@LogMessage(level=WARN)
@Message(value="Lazy deserialization configuration is deprecated, please use storeAsBinary instead",
id=140)
void lazyDeserializationDeprecated()
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)
asyncStoreShutdownTimeoutTooHigh
@LogMessage(level=WARN)
@Message(value="The async store shutdown timeout (%d ms) is too high compared to cache stop timeout (%d ms), so instead using %d ms for async store stop wait",
id=142)
void asyncStoreShutdownTimeoutTooHigh(long configuredAsyncStopTimeout,
long cacheStopTimeout,
long asyncStopTimeout)
keyDoesNotMapToLocalNode
@LogMessage(level=WARN)
@Message(value="Received a key that doesn\'t map to this node: %s, mapped to %s",
id=143)
void keyDoesNotMapToLocalNode(Object key,
Collection<Address> nodes)
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)
invalidTimeoutValue
@LogMessage(level=WARN)
@Message(value="Invalid %s value of %s. It can not be higher than %s which is %s",
id=148)
void invalidTimeoutValue(Object configName1,
Object value1,
Object configName2,
Object value2)
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()
rehashCommandReceivedOnNonDistributedCache
@LogMessage(level=FATAL)
@Message(value="Rehash command received on non-distributed cache. All the nodes in the cluster should be using the same configuration.",
id=150)
void rehashCommandReceivedOnNonDistributedCache()
errorFlushingToFileChannel
@LogMessage(level=ERROR)
@Message(value="Error flushing to file: %s",
id=151)
void errorFlushingToFileChannel(FileChannel f,
@Cause
Exception e)
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()
unableToUnlockRebalancedKeys
@LogMessage(level=ERROR)
@Message(value="Unable to unlock keys %2$s for transaction %1$s after they were rebalanced off node %3$s",
id=154)
void unableToUnlockRebalancedKeys(GlobalTransaction gtx,
List<Object> keys,
Address self,
@Cause
Throwable t)
errorUnblockingTransactions
@LogMessage(level=WARN)
@Message(value="Unblocking transactions failed",
id=159)
void errorUnblockingTransactions(@Cause
Exception e)
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)
cacheLoaderIgnoringUnexpectedFile
@LogMessage(level=WARN)
@Message(value="FileCacheStore ignored an unexpected file %2$s in path %1$s. The store path should be dedicated!",
id=163)
void cacheLoaderIgnoringUnexpectedFile(Object parentPath,
String name)
cacheViewRollbackIdMismatch
@LogMessage(level=ERROR)
@Message(value="Rolling back to cache view %d, but last committed view is %d",
id=164)
void cacheViewRollbackIdMismatch(int committedViewId,
int committedView)
warnStrictPeerToPeerWithInjectedChannel
@LogMessage(level=INFO)
@Message(value="Strict peer-to-peer is enabled but the JGroups channel was started externally - this is very likely to result in RPC timeout errors on startup",
id=171)
void warnStrictPeerToPeerWithInjectedChannel()
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)
errorReadingConfiguration
@LogMessage(level=WARN)
@Message(value="Unexpected error reading configuration",
id=174)
void errorReadingConfiguration(@Cause
Exception e)
failedToCloseResource
@LogMessage(level=WARN)
@Message(value="Unexpected error closing resource",
id=175)
void failedToCloseResource(@Cause
Throwable e)
evictionWakeUpIntervalDeprecated
@LogMessage(level=WARN)
@Message(value="The \'wakeUpInterval\' attribute of the \'eviction\' configuration XML element is deprecated. Setting the \'wakeUpInterval\' attribute of the \'expiration\' configuration XML element to %d instead",
id=176)
void evictionWakeUpIntervalDeprecated(Long wakeUpInterval)
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)
alwaysProvideInMemoryStateDeprecated
@LogMessage(level=WARN)
@Message(value="stateRetrieval\'s \'alwaysProvideInMemoryState\' attribute is no longer in use, instead please make sure all instances of this named cache in the cluster have \'fetchInMemoryState\' attribute enabled",
id=178)
void alwaysProvideInMemoryStateDeprecated()
initialRetryWaitTimeDeprecated
@LogMessage(level=WARN)
@Message(value="stateRetrieval\'s \'initialRetryWaitTime\' attribute is no longer in use.",
id=179)
void initialRetryWaitTimeDeprecated()
logFlushTimeoutDeprecated
@LogMessage(level=WARN)
@Message(value="stateRetrieval\'s \'logFlushTimeout\' attribute is no longer in use.",
id=180)
void logFlushTimeoutDeprecated()
maxProgressingLogWritesDeprecated
@LogMessage(level=WARN)
@Message(value="stateRetrieval\'s \'maxProgressingLogWrites\' attribute is no longer in use.",
id=181)
void maxProgressingLogWritesDeprecated()
numRetriesDeprecated
@LogMessage(level=WARN)
@Message(value="stateRetrieval\'s \'numRetries\' attribute is no longer in use.",
id=182)
void numRetriesDeprecated()
retryWaitTimeIncreaseFactorDeprecated
@LogMessage(level=WARN)
@Message(value="stateRetrieval\'s \'retryWaitTimeIncreaseFactor\' attribute is no longer in use.",
id=183)
void retryWaitTimeIncreaseFactorDeprecated()
stateRetrievalConfigurationDeprecated
@LogMessage(level=INFO)
@Message(value="The stateRetrieval configuration element has been deprecated, we\'re assuming you meant stateTransfer. Please see XML schema for more information.",
id=184)
void stateRetrievalConfigurationDeprecated()
hashRehashEnabledDeprecated
@LogMessage(level=INFO)
@Message(value="hash\'s \'rehashEnabled\' attribute has been deprecated. Please use stateTransfer.fetchInMemoryState instead",
id=185)
void hashRehashEnabledDeprecated()
hashRehashRpcTimeoutDeprecated
@LogMessage(level=INFO)
@Message(value="hash\'s \'rehashRpcTimeout\' attribute has been deprecated. Please use stateTransfer.timeout instead",
id=186)
void hashRehashRpcTimeoutDeprecated()
hashRehashWaitDeprecated
@LogMessage(level=INFO)
@Message(value="hash\'s \'rehashWait\' attribute has been deprecated. Please use stateTransfer.timeout instead",
id=187)
void hashRehashWaitDeprecated()
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)
deprecatedLoaderAsStoreConfiguration
@LogMessage(level=WARN)
@Message(value="Use of the \'loader\' element to configure a store is deprecated, please use the \'store\' element instead",
id=190)
void deprecatedLoaderAsStoreConfiguration()
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",
id=195)
void rebalanceError(String cacheName,
Address node,
@Cause
Throwable cause)
failedToRecoverClusterState
@LogMessage(level=ERROR)
@Message(value="Failed to recover cluster state after the current node became the coordinator",
id=196)
void failedToRecoverClusterState(@Cause
Throwable cause)
errorUpdatingMembersList
@LogMessage(level=WARN)
@Message(value="Error updating cluster member list",
id=197)
void errorUpdatingMembersList(@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 cancelation command locally %s",
id=206)
void couldNotExecuteCancellationLocally(String message)
couldNotInterruptThread
@LogMessage(level=WARN)
@Message(value="Could not interrupt as no thread found for command uuid %s",
id=207)
void couldNotInterruptThread(UUID id)
noLiveOwnersFoundForSegment
@LogMessage(level=ERROR)
@Message(value="No live owners found for segment %d of cache %s. Current owners are: %s. Faulty owners: %s",
id=208)
void noLiveOwnersFoundForSegment(int segmentId,
String cacheName,
Collection<Address> owners,
Collection<Address> faultySources)
failedToRetrieveTransactionsForSegments
@LogMessage(level=WARN)
@Message(value="Failed to retrieve transactions for segments %s of cache %s from node %s (node will not be retried)",
id=209)
void failedToRetrieveTransactionsForSegments(Collection<Integer> segments,
String cacheName,
Address source,
@Cause
Exception e)
failedToRequestSegments
@LogMessage(level=WARN)
@Message(value="Failed to request segments %s of cache %s from node %s (node will not be retried)",
id=210)
void failedToRequestSegments(Collection<Integer> segments,
String cacheName,
Address source,
@Cause
Exception e)
transactionsRequestedByNodeWithOlderTopology
@LogMessage(level=WARN)
@Message(value="Transactions were requested by node %s with topology %d, older than the local topology (%d)",
id=211)
void transactionsRequestedByNodeWithOlderTopology(Address node,
int requestTopologyId,
int localTopologyId)
segmentsRequestedByNodeWithOlderTopology
@LogMessage(level=WARN)
@Message(value="Segments were requested by node %s with topology %d, older than the local topology (%d)",
id=212)
void segmentsRequestedByNodeWithOlderTopology(Address node,
int requestTopologyId,
int localTopologyId)
unableToLoadClass
@LogMessage(level=ERROR)
@Message(value="Unable to load %s from any of the following classloaders: %s",
id=213)
void unableToLoadClass(String classname,
String classloaders,
@Cause
Throwable cause)
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
Exception e)
Copyright © 2013 JBoss, a division of Red Hat. All Rights Reserved.