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 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
-
Field Summary
Fields -
Method Summary
Modifier and TypeMethodDescriptionvoid
org.infinispan.commons.CacheConfigurationException
advanceExternalizerTypeClassesUndefined
(String className) void
afterCompletionFailed
(javax.transaction.Synchronization s, Throwable t) void
void
attributeDeprecated
(String name, String element, int major, int minor) void
attributeDeprecatedUseOther
(Enum<?> attr, Enum<?> element, Enum<?> other) org.infinispan.commons.CacheConfigurationException
attributeNotAllowedInInvalidationMode
(String attributeName) org.infinispan.commons.CacheConfigurationException
attributeRemoved
(String attributeName, org.infinispan.commons.configuration.io.Location location) org.infinispan.commons.CacheConfigurationException
attributeRemovedUseOther
(String attributeName, String newAttributeName, org.infinispan.commons.configuration.io.Location location) void
void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
beforeCompletionFailed
(javax.transaction.Synchronization s, Throwable t) org.infinispan.commons.CacheConfigurationException
void
cacheBackupsDataToSameSite
(String siteName) org.infinispan.commons.CacheConfigurationException
cacheExists
(String cacheName) org.infinispan.commons.IllegalLifecycleStateException
cacheIsStopping
(String cacheName) org.infinispan.commons.IllegalLifecycleStateException
cacheIsTerminated
(String cacheName, String state) org.infinispan.commons.IllegalLifecycleStateException
void
cacheRecoveredAfterMerge
(String cacheName, CacheTopology currentTopology, AvailabilityMode availabilityMode) void
cancelledConflictResolution
(String cacheName, CacheTopology currentTopology) cannotAddStore
(String cacheName) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.dataconversion.EncodingException
cannotConvertContent
(Object content, org.infinispan.commons.dataconversion.MediaType contentType, org.infinispan.commons.dataconversion.MediaType destination) org.infinispan.commons.dataconversion.EncodingException
cannotFindTranscoder
(org.infinispan.commons.dataconversion.MediaType mediaType, org.infinispan.commons.dataconversion.MediaType another) void
cannotMarshall
(Class<?> aClass, Throwable t) void
cannotObtainFailedCache
(String name, Throwable t) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
cannotRenamePersistentFile
(String absolutePath, File persistentFile, Throwable cause) void
cannotRespondToCommit
(GlobalTransaction globalTransaction, String cacheName) void
cannotRespondToRollback
(GlobalTransaction globalTransaction, String cacheName) org.infinispan.commons.CacheConfigurationException
cannotUseDeprecatedAndReplacement
(String legacyName) org.infinispan.commons.CacheConfigurationException
clusteredTransactionalStoreMustBeShared
(String simpleName) void
org.infinispan.commons.CacheException
clusterListenerRegisteredWithOnlyPreEvents
(Class<?> listenerClass) org.infinispan.commons.CacheConfigurationException
componentFailedToStart
(String componentName, Throwable t) void
org.infinispan.commons.CacheConfigurationException
configAlreadyDefined
(String cacheName) void
configDeprecated
(Enum<?> element) void
configDeprecatedUseOther
(Enum<?> element, Enum<?> other, org.infinispan.commons.configuration.io.Location location) configurationInUse
(String configurationName) org.infinispan.commons.CacheConfigurationException
void
configurationNotFound
(String cacheName, Collection<String> definedConfigurations) org.infinispan.commons.CacheConfigurationException
configurationSerializationFailed
(String cacheName, Configuration configuration, Exception e) containerFull
(long size) coordinatorTimeoutWaitingForView
(int expectedViewId, int currentViewId, Object clusterManagerStatus) corruptDataMigrationFailed
(String cacheName, Throwable cause) void
corruptDataSuccessfulMigrated
(String cacheName, int entries) void
void
couldNotFindAttribute
(String name) void
void
void
couldNotInvokeSetOnAttribute
(String attributeName, Object value) void
couldNotRollbackPrepared1PcTransaction
(LocalTransaction localTransaction, Throwable e1) creatingTmpCacheTimedOut
(String cacheName, Address address) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
degradedModeKeysUnavailable
(Collection<?> keys) void
org.infinispan.commons.CacheConfigurationException
void
disconnectJGroups
(String cluster) org.infinispan.commons.CacheConfigurationException
duplicateCacheName
(String name) org.infinispan.commons.CacheConfigurationException
duplicateExternalizerIdFound
(int externalizerId, Class<?> typeClass, String otherExternalizer, int readerIndex) org.infinispan.commons.CacheConfigurationException
duplicateExternalizerIdFound
(int externalizerId, String otherExternalizer) org.infinispan.commons.dataconversion.EncodingException
duplicateIdEncoder
(short id) org.infinispan.commons.dataconversion.EncodingException
duplicateIdWrapper
(byte id) org.infinispan.commons.CacheConfigurationException
duplicateJGroupsStack
(String name) org.infinispan.commons.CacheConfigurationException
duplicateRemoteSite
(String remoteSite, String name) org.infinispan.commons.CacheConfigurationException
elementRemoved
(String elementName, org.infinispan.commons.configuration.io.Location location) org.infinispan.commons.CacheConfigurationException
elementRemovedUseOther
(String elementName, String newElementName, org.infinispan.commons.configuration.io.Location location) org.infinispan.commons.dataconversion.EncodingException
encoderClassNotFound
(Class<?> wrapperClass) org.infinispan.commons.dataconversion.EncodingException
encoderIdNotFound
(short id) void
entriesMigrated
(long count, String name, String prettyTime) void
void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
errorCreatingChannelFromConfigurator
(String configurator, Throwable t) org.infinispan.commons.CacheConfigurationException
void
errorCreatingForkChannel
(String name, Throwable throwable) org.infinispan.commons.CacheException
errorDeserializing
(String className) void
void
void
void
errorInstantiatingJGroupsChannelLookup
(String channelLookupClassName, Exception e) org.infinispan.commons.CacheConfigurationException
void
void
void
void
errorProcessingRequest
(long requestId, org.jgroups.Address origin, Throwable t) void
errorProcessingResponse
(long requestId, org.jgroups.Address sender, Throwable t) errorReadingFileStore
(String path, long offset) void
errorReadingRebalancingStatus
(Address coordinator, Throwable t) void
void
errorSendingResponse
(long requestId, org.jgroups.Address origin, ReplicableCommand command) org.infinispan.commons.dataconversion.EncodingException
errorTranscoding
(String transcoderName, Throwable cause) void
errorUpdatingMembersList
(int viewId, Throwable cause) void
errorWritingValueForAttribute
(String attributeName, Exception e) void
evictionDisabled
(String cacheName) void
org.infinispan.commons.CacheConfigurationException
void
exceptionDuringClusterListenerRetrieval
(Address address, Throwable cause) void
void
org.infinispan.commons.CacheListenerException
exceptionInvokingListener
(String name, Method m, Object target, Throwable cause) org.infinispan.commons.CacheException
void
void
executionError
(String commandType, String cacheName, String affectedKeys, Throwable t) org.infinispan.commons.CacheConfigurationException
void
org.infinispan.commons.CacheConfigurationException
extraneousMembersJoinRestoredCache
(List<Address> extraneousMembers, String cacheName) org.infinispan.commons.CacheConfigurationException
factoryCannotConstructComponent
(String componentName) void
void
failedConflictResolution
(String cacheName, CacheTopology currentTopology, Throwable t) void
void
void
void
void
void
void
failedPartitionHandlingTxCompletion
(GlobalTransaction globalTransaction, Throwable t) void
org.infinispan.commons.CacheConfigurationException
failedReadingPersistentState
(IOException e, File stateFile) void
void
void
void
void
void
failedToRecoverCacheState
(String cacheName, Throwable cause) void
void
failedToRequestSegments
(String cacheName, Address source, Collection<Integer> segments, Throwable e) void
failedToRestartXSiteStateTransfer
(String siteName, Throwable cause) void
failedToRetrieveTransactionsForSegments
(String cacheName, Address source, Collection<Integer> segments, Throwable t) void
failedToTransferTombstones
(Address requestor, org.infinispan.commons.util.IntSet segments, Throwable t) void
failedToUpdateAttribute
(String name, Object value) failedWaitingForTopology
(int requestTopologyId) org.infinispan.commons.CacheConfigurationException
failedWritingGlobalState
(IOException e, File stateFile) org.infinispan.commons.CacheConfigurationException
failurePolicyClassNotCompatibleWith
(String remoteSite, BackupFailurePolicy policy) void
void
finishedConflictResolution
(String cacheName, CacheTopology currentTopology) void
finishedRebalance
(String cacheName, CacheTopology topology) org.infinispan.commons.CacheConfigurationException
forbiddenStoreLocation
(Path location, Path global) org.infinispan.commons.CacheConfigurationException
foreignExternalizerUsingNegativeId
(org.infinispan.commons.marshall.AdvancedExternalizer<?> ext, int externalizerId) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
getConflictsStateTransferInProgress
(String cacheName) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
globalStateCannotAcquireLockFile
(Throwable cause, File lockFile) org.infinispan.commons.CacheConfigurationException
void
globalStateLoad
(String version, String timestamp) void
globalStateWrite
(String version, String timestamp) org.infinispan.commons.CacheConfigurationException
groupingOnlyCompatibleWithObjectStorage
(org.infinispan.commons.dataconversion.MediaType keyMediaType, org.infinispan.commons.dataconversion.MediaType valueMediaType) org.infinispan.commons.CacheConfigurationException
groupingOnlyCompatibleWithObjectStorage
(StorageType storageType) void
ignoreAttribute
(Object attribute, org.infinispan.commons.configuration.io.Location location) void
ignoredAttribute
(String componentName, String version, String attributeName, int line) void
ignoredReplicationQueueAttribute
(String attributeName, int line) void
ignoreXmlElement
(Object element, org.infinispan.commons.configuration.io.Location location) void
ignoringCacheTopology
(Collection<Address> sender, CacheTopology topology) void
ignoringInvalidateVersionsFromOldTopology
(int invalidationTopology, int currentTopologyId) void
void
ignoringUnsolicitedState
(Address node, int segment, String cacheName) org.infinispan.commons.CacheConfigurationException
incompatibleClusterConfiguration
(String cacheName, Configuration configuration, Configuration existing) org.infinispan.commons.CacheConfigurationException
incompatiblePersistedConfiguration
(String cacheName, Configuration configuration, Configuration existing) void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
indexingPropertiesDeprecated
(Properties properties) void
void
org.infinispan.commons.CacheConfigurationException
indexModeNotSupported
(String indexMode) void
initialStateTransferTimeout
(String cacheName, Address localAddress) org.infinispan.commons.CacheConfigurationException
interceptorClassAndInstanceDefined
(String customInterceptorClassName, String customInterceptor) org.infinispan.commons.CacheConfigurationException
internalExternalizerIdLimitExceeded
(org.infinispan.commons.marshall.AdvancedExternalizer<?> ext, int externalizerId, int maxId) void
interruptedAcquiringLock
(long ms, InterruptedException e) void
void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
invalidAttributeEnumValue
(String element, String attribute, String value, String world, org.infinispan.commons.configuration.io.Location location) org.infinispan.commons.CacheConfigurationException
invalidAttributeValue
(String element, String attribute, String value, org.infinispan.commons.configuration.io.Location location, String message) org.infinispan.commons.CacheConfigurationException
invalidChunkSize
(int chunkSize) org.infinispan.commons.CacheConfigurationException
invalidCompletedTxTimeout
(long timeout) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheException
invalidEncodingClass
(Class<?> configured, Class<?> required) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
invalidIndexStartUpMode
(String invalidValue) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.dataconversion.EncodingException
void
invalidMessageType
(int messageType, org.jgroups.Address origin) org.infinispan.commons.CacheConfigurationException
invalidNameSize
(String name) invalidPermission
(Permission permission) org.infinispan.commons.CacheConfigurationException
invalidPersistentState
(String globalScope) org.infinispan.commons.CacheConfigurationException
invalidPolicyWithAsyncStrategy
(String remoteSite, BackupFailurePolicy policy) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
invalidReaperWakeUpInterval
(long timeout) org.infinispan.commons.CacheConfigurationException
invalidScope
(String expected, String found) org.infinispan.commons.CacheConfigurationException
invalidStateTransferTimeout
(Long stateTransferTimeout, Long remoteTimeout) org.infinispan.commons.CacheConfigurationException
invalidTouchMode
(CacheMode cacheMode) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
issueEncounteredResettingIndex
(String cacheName, Throwable t) void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
jgroupsInsertRequiresPosition
(String protocolName) org.infinispan.commons.CacheConfigurationException
jgroupsNoStackPosition
(String combineMode) org.infinispan.commons.CacheConfigurationException
jgroupsNoSuchProtocol
(String protocolName, String combineMode) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
jmxMBeanAlreadyRegistered
(String jmxDomain, Throwable cause) void
void
keyMigrationFailed
(String key, Throwable cause) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
l1OnlyForDistributedCache
(String cacheMode) org.infinispan.commons.CacheConfigurationException
void
localAndPhysicalAddress
(String cluster, Address address, List<Address> physicalAddresses) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.marshall.MarshallingException
void
org.infinispan.commons.CacheConfigurationException
void
org.infinispan.commons.CacheConfigurationException
missingBackupFailurePolicyClass
(String remoteSite) org.infinispan.commons.CacheConfigurationException
missingCustomInterceptorPosition
(String customInterceptorClassName) org.infinispan.commons.CacheConfigurationException
missingDefaultCacheDeclaration
(String defaultCache) org.infinispan.commons.CacheException
missingForeignExternalizer
(int foreignId) void
org.infinispan.commons.CacheConfigurationException
missingJGroupsStack
(String name) void
missingListPreparedTransactions
(Object key, Object value) org.infinispan.commons.CacheConfigurationException
missingRequiredProperty
(String property, String name, org.infinispan.commons.configuration.io.Location location) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.marshall.MarshallingException
org.infinispan.commons.CacheConfigurationException
void
moduleStopError
(String module, Throwable t) org.infinispan.commons.CacheConfigurationException
multipleCustomInterceptorPositions
(String customInterceptorClassName) org.infinispan.commons.CacheConfigurationException
void
noAnnotateMethodsFoundInListener
(Class<?> listenerClass) org.infinispan.commons.CacheConfigurationException
noConfiguration
(String extend) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
nodeNameNotInRaftMembers
(String members) nodeWithIncompatibleStateJoiningCache
(Address joiner, String cacheName) nodeWithoutPersistentStateJoiningCacheWithState
(Address joiner, String cacheName) nodeWithPersistentStateJoiningClusterWithoutState
(Address joiner, String cacheName) void
noFilterIndexingServiceProviderFound
(String filterClassName) org.infinispan.commons.CacheConfigurationException
void
noLiveOwnersFoundForSegments
(Collection<Integer> segments, String cacheName, Collection<Address> faultySources) org.infinispan.commons.CacheConfigurationException
nonSharedStoreConfiguredAsShared
(String storeType) org.infinispan.commons.CacheConfigurationException
nonWritableStateFile
(File stateFile) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
noSuchGlobalRoles
(Set<String> cacheRoles) void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
parserRootElementAlreadyRegistered
(String qName, String oldParser, String newParser) void
org.infinispan.commons.CacheConfigurationException
void
persistedDataMigrationFailed
(String cacheName, Throwable cause) void
persistedDataSuccessfulMigrated
(String cacheName) void
void
persistenceUnavailable
(String storeImpl) void
void
persistentConsistentHashMismatch
(String hashFactory, String consistentHashClass) org.infinispan.commons.CacheConfigurationException
void
preparedTxAlreadyExists
(RecoveryAwareTransaction previous, RecoveryAwareRemoteTransaction remoteTransaction) void
void
problemClosingChannel
(Exception e, String cluster) problemPreloadingKey
(Object key, Throwable t) void
queriedAttributeNotFound
(String attributeName) org.infinispan.commons.CacheConfigurationException
void
void
raftProtocolUnavailable
(String reason) void
randomCacheModeSynonymsDeprecated
(String candidate, String mode, List<String> synonyms) void
rebalanceError
(String cacheName, Address node, int topologyId, Throwable cause) void
rebalancePhaseConfirmedOnNode
(CacheTopology.Phase phase, String cacheName, Address node, int topologyId) void
rebalanceStartError
(String cacheName, Throwable cause) void
void
void
receivedClusterView
(String cluster, org.jgroups.View newView) void
receivedMergedView
(String cluster, org.jgroups.View newView) void
void
recoverFromStateMissingMembers
(String cacheName, List<Address> members, int total) recoverFromStateMissingMembers
(String cacheName, List<Address> members, String total) void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
remoteException
(Address sender, Throwable t) remoteNodeSuspected
(Address address) remoteNodeTimedOut
(Address address, long time, TimeUnit unit) org.infinispan.commons.CacheException
org.infinispan.commons.CacheException
org.infinispan.commons.CacheException
void
remoteTransactionTimeout
(GlobalTransaction gtx, long ageMilliSeconds) requestTimedOut
(long requestId, String targetsWithoutResponses, String elapsed) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
retrievingTm
(javax.transaction.TransactionManager tm) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
scheduledTaskEncounteredThrowable
(Object identifier, Throwable t) org.infinispan.commons.CacheConfigurationException
void
segmentedStoreUsesManyFileDescriptors
(String storeName) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
siteNotFound
(String siteName) void
void
startFailure
(String registryName, Throwable t) void
startingConflictResolution
(String cacheName, CacheTopology currentTopology) void
startingJGroupsChannel
(String cluster) void
startingJGroupsChannel
(String cluster, String stack) void
startingRebalancePhase
(String cacheName, CacheTopology cacheTopology) void
startingUserMarshaller
(String marshallerClass) void
startMigratingPersistenceData
(String cacheName) void
startRecoveringCorruptPersistenceData
(String cacheName) org.infinispan.commons.CacheConfigurationException
void
org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
storeConfiguredHasBothReadAndWriteOnly
(String storeClassName, NonBlockingStore.Characteristic configured, NonBlockingStore.Characteristic implSpecifies) org.infinispan.commons.CacheConfigurationException
storeConfiguredSegmentedButCharacteristicNotPresent
(String storeClassName) org.infinispan.commons.CacheConfigurationException
storeConfiguredSharedButCharacteristicNotPresent
(String storeClassName) org.infinispan.commons.CacheConfigurationException
storeConfiguredTransactionalButCharacteristicNotPresent
(String storeClassName) org.infinispan.commons.CacheConfigurationException
void
storeIsAvailableCheckThrewException
(Throwable e, String storeImpl) void
storeIsAvailableCompletedExceptionally
(Throwable e, String storeImpl) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
storeLocationRequired
(String storeType, String attributeName) org.infinispan.commons.CacheConfigurationException
storeNotSegmented
(Class<?> implementedClass) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
storeStartupAttemptsExceeded
(String storeName, Throwable t) org.infinispan.commons.CacheConfigurationException
void
suggestCustomInterceptorInheritance
(String customInterceptorClassName) org.infinispan.commons.CacheConfigurationException
templateConfigurationStartAttempt
(String cacheName) thirdPartySuspected
(Address sender, SuspectException e) org.infinispan.commons.CacheConfigurationException
threadPoolFactoryIsBlocking
(String name, String poolName) timeoutWaitingForAcks
(String timeout, String address, long id) timeoutWaitingForInitialNodes
(int initialClusterSize, List<?> members) timeoutWaitingForView
(int expectedViewId, int currentViewId) void
timeoutWaitingUntilTransactionPrepared
(String globalTx) topologyTimeout
(int expectedTopologyId, int currentTopologyId) void
topologyUpdateError
(String cacheName, Throwable cause) org.infinispan.commons.CacheConfigurationException
transactionalStoreCannotBeAsync
(String simpleName) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
void
transactionDataTimeout
(int expectedTopologyId) void
void
tryingToBringOnlineNonexistentSite
(String siteName) org.infinispan.commons.CacheConfigurationException
unableToAcquireLock
(String timeout, Object key, Object requestor, Object owner) org.infinispan.commons.CacheConfigurationException
unableToAddJGroupsStack
(String name, Exception e) void
unableToApplyXSiteState
(Throwable cause) void
unableToCreateInterceptor
(Class<?> type, Exception e) unableToFindLocalTransactionFromRemoteSiteTransaction
(GlobalTransaction globalTransaction) org.infinispan.commons.CacheException
unableToFindRemoteSiteTransaction
(GlobalTransaction globalTransaction) org.infinispan.commons.CacheConfigurationException
unableToInstantiateClass
(Class<?> storeConfigurationClass) org.infinispan.commons.CacheConfigurationException
unableToInstantiateSerializer
(Class<?> storeConfigurationClass) void
unableToInvokeListenerMethod
(Method m, Object target, Throwable e) void
unableToInvokeListenerMethodAndRemoveListener
(Method m, Object target, Throwable e) void
unableToLockToInvalidate
(Object key, Address address) void
unableToPassivateEntry
(Object key, Throwable e) void
unableToProcessAsyncModifications
(int retries) void
void
void
void
unableToSendXSiteState
(String site, Throwable cause) void
void
void
unableToStartXSiteAutStateTransfer
(String cacheName, String targetSite, Throwable t) void
unableToUseJGroupsPropertiesProvided
(org.infinispan.commons.util.TypedProperties props) unauthorizedAccess
(String subject, String permission) org.infinispan.commons.CacheConfigurationException
undeclaredConfiguration
(String template, String name) org.infinispan.commons.CacheConfigurationException
void
void
void
void
unexpectedInitialVersion
(String className) unexpectedResponse
(Address target, Response response) void
unfinishedTransactionsRemain
(int localTransactions, int remoteTransactions) void
unknownEncoding
(String cacheName) org.infinispan.commons.CacheException
unknownExternalizerReaderIndex
(int readerIndex) unknownMigrator
(String migratorName) void
unknownResponsesFromRemoteCache
(Collection<Response> responses) org.infinispan.commons.CacheConfigurationException
unknownTransactionConfiguration
(TransactionMode mode, boolean xaEnabled, boolean recoveryEnabled, boolean batchingEnabled) void
unrecognizedAttribute
(String property) void
unsuccessfulResponseForClusterListeners
(Address address, Response response) void
unsuccessfulResponseRetrievingTransactionsForSegments
(Address address, Response response) org.infinispan.commons.CacheConfigurationException
unsupportedAsyncCacheMode
(CacheMode cacheMode) void
unsupportedAsyncCacheMode
(CacheMode unsupportedCacheMode, CacheMode forcedCacheMode) org.infinispan.commons.CacheConfigurationException
unsupportedConfiguration
(String element, String namespaceUri, org.infinispan.commons.configuration.io.Location location, String version) org.infinispan.commons.dataconversion.EncodingException
unsupportedContent
(String transcoderName, Object content) void
updatingAvailabilityMode
(String cacheName, AvailabilityMode oldMode, AvailabilityMode newMode, CacheTopology topology) void
updatingStableTopology
(String cacheName, CacheTopology currentTopology) void
updatingTopology
(String cacheName, CacheTopology currentTopology, AvailabilityMode availabilityMode) void
void
void
viewHandlingError
(int viewId, Throwable t) void
void
warnCouldNotCommitLocalTx
(Object transactionDescription, Throwable e) void
warnCouldNotRollbackLocalTx
(Object transactionDescription, Throwable e) void
void
void
void
void
void
warnUsingDeprecatedMemoryConfigs
(String element) void
void
warnXsiteBackupFailed
(String cacheName, String siteName, Throwable throwable) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.dataconversion.EncodingException
wrapperClassNotFound
(Class<?> wrapperClass) org.infinispan.commons.dataconversion.EncodingException
wrapperIdNotFound
(byte id) writeSkewOnRead
(Object key, Object key2, EntryVersion lastVersion, EntryVersion remoteVersion) void
wrongTypeForJGroupsChannelLookup
(String channelLookupClassName, Exception e) void
xaResourceEndFailed
(XAResource resource, Throwable t) void
xsiteAdminOperationError
(String operationName, String siteName, Throwable t) org.infinispan.commons.CacheConfigurationException
xsiteCacheNotFound
(String remoteSite, ByteString cacheName) org.infinispan.commons.CacheConfigurationException
xsiteCacheNotStarted
(String origin, ByteString cacheName) void
xsiteCancelReceiveFailed
(Throwable throwable, String localSite, String remoteSite) void
xsiteCancelSendFailed
(Throwable throwable, String remoteSite) org.infinispan.commons.CacheConfigurationException
org.infinispan.commons.CacheConfigurationException
xsiteInLocalCache
(String origin, ByteString cacheName) void
xsiteInvalidConfigurationRemoteSite
(String siteName, org.infinispan.commons.CacheConfigurationException exception) org.infinispan.commons.CacheException
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
-
Field Details
-
LOG_ROOT
- See Also:
-
CONFIG
-
CLUSTER
-
CONTAINER
-
PERSISTENCE
-
SECURITY
-
XSITE
-
-
Method Details
-
problemApplyingStateForKey
-
expectedJustOneResponse
-
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
-
jmxMBeanAlreadyRegistered
@Message(value="The \'%s\' JMX domain is already in use.", id=34) JmxDomainConflictException jmxMBeanAlreadyRegistered(String jmxDomain, @Cause Throwable cause) -
couldNotFindAttribute
@LogMessage(level=WARN) @Message(value="Did not find attribute %s", id=36) void couldNotFindAttribute(String name) -
failedToUpdateAttribute
-
queriedAttributeNotFound
@LogMessage(level=WARN) @Message(value="Did not find queried attribute with name %s", id=42) void queriedAttributeNotFound(String attributeName) -
errorWritingValueForAttribute
-
couldNotInvokeSetOnAttribute
-
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) -
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) -
startingJGroupsChannel
-
localAndPhysicalAddress
-
disconnectJGroups
@LogMessage(level=INFO) @Message(value="Disconnecting JGroups channel `%s`", id=80) void disconnectJGroups(String cluster) -
problemClosingChannel
-
wrongTypeForJGroupsChannelLookup
-
errorInstantiatingJGroupsChannelLookup
-
errorCreatingChannelFromConfigFile
-
errorCreatingChannelFromXML
-
errorCreatingChannelFromConfigString
-
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=INFO) @Message(value="Using EmbeddedTransactionManager", id=104) void fallingBackToEmbeddedTm() -
failedToCreateInitialCtx
@LogMessage(level=ERROR) @Message(value="Failed creating initial JNDI context", id=105) void failedToCreateInitialCtx(@Cause Throwable e) -
retrievingTm
@LogMessage(level=INFO) @Message(value="Retrieving transaction manager %s", id=107) void retrievingTm(javax.transaction.TransactionManager tm) -
errorEnlistingResource
@LogMessage(level=ERROR) @Message(value="Error enlisting resource", id=108) void errorEnlistingResource(@Cause Throwable e) -
beforeCompletionFailed
@LogMessage(level=ERROR) @Message(value="beforeCompletion() failed for %s", id=109) void beforeCompletionFailed(javax.transaction.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(javax.transaction.Synchronization s, @Cause Throwable t) -
errorCommittingTx
@LogMessage(level=WARN) @Message(value="exception while committing", id=112) void errorCommittingTx(@Cause Throwable 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
-
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=DEBUG) @Message(value="Infinispan version: %s", id=128) void version(String version) -
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
-
unableToLockToInvalidate
-
executionError
-
failedInvalidatingRemoteCache
@LogMessage(level=INFO) @Message(value="Failed invalidating remote cache", id=137) void failedInvalidatingRemoteCache(@Cause Throwable 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
-
failedToInvalidateKeys
@LogMessage(level=ERROR) @Message(value="Error invalidating keys from L1 after rehash", id=147) void failedToInvalidateKeys(@Cause Throwable 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) -
randomCacheModeSynonymsDeprecated
-
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) -
failedLoadingKeysFromCacheStore
@LogMessage(level=WARN) @Message(value="Failed loading keys from cache store", id=194) void failedLoadingKeysFromCacheStore(@Cause Throwable t) -
rebalanceError
-
failedToRecoverClusterState
@LogMessage(level=WARN) @Message(value="Failed to recover cluster state after the current node became the coordinator (or after merge), will retry", 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) -
cacheBackupsDataToSameSite
@LogMessage(level=TRACE) @Message(value="This cache is configured to backup to its own site (%s).", id=201) void cacheBackupsDataToSameSite(String siteName) -
warnXsiteBackupFailed
-
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) -
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 Throwable t) -
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
-
unknownMigrator
@Message(value="Unknown migrator %s", id=215) IllegalArgumentException unknownMigrator(String migratorName) -
entriesMigrated
-
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) -
customInterceptorMissingClass
@Message(value="Custom interceptor missing class", id=222) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException multipleCustomInterceptorPositions(String customInterceptorClassName) -
missingCustomInterceptorPosition
@Message(value="Custom interceptor \'%s\' doesn\'t specify a position", id=225) org.infinispan.commons.CacheConfigurationException missingCustomInterceptorPosition(String customInterceptorClassName) -
failedToRecoverCacheState
-
unexpectedInitialVersion
@Message(value="Unexpected initial version type (only NumericVersion instances supported): %s", id=229) IllegalArgumentException unexpectedInitialVersion(String className) -
rebalanceStartError
-
parserRootElementAlreadyRegistered
-
parserDoesNotDeclareNamespaces
@Message(value="Configuration parser %s does not declare any Namespace annotations", id=235) org.infinispan.commons.CacheConfigurationException parserDoesNotDeclareNamespaces(String name) -
directoryCannotBeCreated
@Message(value="Directory %s does not exist and cannot be created!", id=238) org.infinispan.commons.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) org.infinispan.commons.CacheException missingForeignExternalizer(int foreignId) -
unknownExternalizerReaderIndex
@Message(value="Type of data read is unknown. Id=%d is not amongst known reader indexes.", id=243) org.infinispan.commons.CacheException unknownExternalizerReaderIndex(int readerIndex) -
advanceExternalizerTypeClassesUndefined
@Message(value="AdvancedExternalizer\'s getTypeClasses for externalizer %s must return a non-empty set", id=244) org.infinispan.commons.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) org.infinispan.commons.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) org.infinispan.commons.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) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException loaderConfigurationDoesNotSpecifyLoaderClass(String className) -
errorExecutingParallelStoreTask
@LogMessage(level=ERROR) @Message(value="Error executing parallel store task", id=252) void errorExecutingParallelStoreTask(@Cause Throwable cause) -
errorProcessingPrepare
@LogMessage(level=ERROR) @Message(value="Error while processing prepare", id=255) void errorProcessingPrepare(@Cause Throwable 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) -
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
-
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
-
warnCouldNotRollbackLocalTx
-
warnExceptionRemovingRecovery
@LogMessage(level=WARN) @Message(value="Exception removing recovery information", id=272) void warnExceptionRemovingRecovery(@Cause Throwable e) -
invalidConfigurationIndexingWithInvalidation
@Message(value="Indexing can not be enabled on caches in Invalidation mode", id=273) org.infinispan.commons.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() -
keyMigrationFailed
-
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) org.infinispan.commons.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
-
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) org.infinispan.commons.CacheConfigurationException invocationBatchingNeedsTransactionalCache() -
invocationBatchingCannotBeRecoverable
@Message(value="A cache configured with invocation batching can\'t have recovery enabled", id=283) org.infinispan.commons.CacheConfigurationException invocationBatchingCannotBeRecoverable() -
clusterListenerInstallationFailure
@LogMessage(level=WARN) @Message(value="Problem encountered while installing cluster listener", id=284) void clusterListenerInstallationFailure(@Cause Throwable cause) -
unsuccessfulResponseForClusterListeners
-
exceptionDuringClusterListenerRetrieval
-
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) org.infinispan.commons.CacheConfigurationException invalidPrincipalRoleMapper() -
unableToSendXSiteState
-
unableToApplyXSiteState
@LogMessage(level=WARN) @Message(value="Cannot apply cross-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) -
ignoreAttribute
@LogMessage(level=INFO) @Message(value="Ignoring attribute %s at %s, please remove from configuration file", id=293) void ignoreAttribute(Object attribute, org.infinispan.commons.configuration.io.Location location) -
ignoreXmlElement
@LogMessage(level=INFO) @Message(value="Ignoring element %s at %s, please remove from configuration file", id=294) void ignoreXmlElement(Object element, org.infinispan.commons.configuration.io.Location location) -
undefinedThreadPoolName
@Message(value="No thread pool with name \'%s\' found", id=295) org.infinispan.commons.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) org.infinispan.commons.CacheException exceptionProcessingEntryRetrievalValues(@Cause Throwable cause) -
unsuccessfulResponseRetrievingTransactionsForSegments
-
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() -
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
-
cacheIsTerminated
-
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) org.infinispan.commons.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\' at %s. Check that your configuration is up-to-date for Infinispan \'%s\' and you have the proper dependency in the classpath", id=327) org.infinispan.commons.CacheConfigurationException unsupportedConfiguration(String element, String namespaceUri, org.infinispan.commons.configuration.io.Location location, 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
-
unableToInvokeListenerMethod
-
twoPhaseCommitAsyncBackup
@Message(value="Two-phase commit can only be used with synchronous backup strategy.", id=335) org.infinispan.commons.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="Backup configuration must include a \'site\'.", id=337) org.infinispan.commons.CacheConfigurationException backupMissingSite() -
missingBackupFailurePolicyClass
@Message(value="You must specify a \'failure-policy-class\' to use a custom backup failure policy for backup \'%s\'.", id=338) org.infinispan.commons.CacheConfigurationException missingBackupFailurePolicyClass(String remoteSite) -
backupForNullCache
@Message(value="Remote cache name is missing or null in backup configuration.", id=339) org.infinispan.commons.CacheConfigurationException backupForNullCache() -
backupForMissingParameters
@Message(value="Remote cache name and remote site is missing or null in backup configuration.", id=340) org.infinispan.commons.CacheConfigurationException backupForMissingParameters() -
missingTransportConfiguration
@Message(value="Must have a transport set in the global configuration in order to define a clustered cache", id=343) org.infinispan.commons.CacheConfigurationException missingTransportConfiguration() -
invalidReaperWakeUpInterval
@Message(value="reaperWakeUpInterval must be >= 0, we got %d", id=344) org.infinispan.commons.CacheConfigurationException invalidReaperWakeUpInterval(long timeout) -
invalidCompletedTxTimeout
@Message(value="completedTxTimeout must be >= 0, we got %d", id=345) org.infinispan.commons.CacheConfigurationException invalidCompletedTxTimeout(long timeout) -
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) org.infinispan.commons.CacheConfigurationException l1OnlyForDistributedCache(String cacheMode) -
l1InvalidLifespan
@Message(value="Using a L1 lifespan of 0 or a negative value is meaningless", id=351) org.infinispan.commons.CacheConfigurationException l1InvalidLifespan() -
l1NotValidWithExpirationEviction
@Message(value="Enabling the L1 cache is not supported when using EXCEPTION based eviction.", id=352) org.infinispan.commons.CacheConfigurationException l1NotValidWithExpirationEviction() -
interceptorClassAndInstanceDefined
-
unableToInstantiateClass
@Message(value="Unable to instantiate loader/writer instance for StoreConfiguration %s", id=355) org.infinispan.commons.CacheConfigurationException unableToInstantiateClass(Class<?> storeConfigurationClass) -
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) org.infinispan.commons.CacheConfigurationException existingConfigForInternalCache(String name) -
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) org.infinispan.commons.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) org.infinispan.commons.CacheException clusterListenerRegisteredWithOnlyPreEvents(Class<?> listenerClass) -
jgroupsConfigurationNotFound
@Message(value="Could not find the specified JGroups configuration file \'%s\'", id=365) org.infinispan.commons.CacheConfigurationException jgroupsConfigurationNotFound(String cfg) -
unableToAddNullCustomStore
@Message(value="Unable to add a \'null\' Custom Cache Store", id=366) IllegalArgumentException unableToAddNullCustomStore() -
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) org.infinispan.commons.CacheConfigurationException statisticsEnabledNotAvailable() -
templateConfigurationStartAttempt
@Message(value="Attempted to start a cache using configuration template \'%s\'", id=373) org.infinispan.commons.CacheConfigurationException templateConfigurationStartAttempt(String cacheName) -
undeclaredConfiguration
-
noConfiguration
@Message(value="No such template/configuration \'%s\'", id=375) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException invocationBatchingNotEnabled() -
notSupportedInSimpleCache
@Message(value="This configuration is not supported for simple cache", id=381) org.infinispan.commons.CacheConfigurationException notSupportedInSimpleCache() -
missingGlobalStatePersistentLocation
@LogMessage(level=WARN) @Message(value="Global state persistence was enabled without specifying a location", id=382) void missingGlobalStatePersistentLocation() -
unableToBroadcastInvalidation
@Message(value="Unable to broadcast invalidation messages", id=384) RuntimeException unableToBroadcastInvalidation(@Cause Throwable e) -
failedReadingPersistentState
@Message(value="Failed to read persisted state from file %s. Aborting.", id=386) org.infinispan.commons.CacheConfigurationException failedReadingPersistentState(@Cause IOException e, File stateFile) -
failedWritingGlobalState
@Message(value="Failed to write state to file %s.", id=387) org.infinispan.commons.CacheConfigurationException failedWritingGlobalState(@Cause IOException e, File stateFile) -
nonWritableStateFile
@Message(value="The state file %s is not writable. Aborting.", id=388) org.infinispan.commons.CacheConfigurationException nonWritableStateFile(File stateFile) -
globalStateLoad
-
globalStateWrite
-
recoveryNotSupportedWithNonTxCache
@Message(value="Recovery not supported with non transactional cache", id=391) org.infinispan.commons.CacheConfigurationException recoveryNotSupportedWithNonTxCache() -
recoveryNotSupportedWithSynchronization
@Message(value="Recovery not supported with Synchronization", id=392) org.infinispan.commons.CacheConfigurationException recoveryNotSupportedWithSynchronization() -
transactionNotificationsDisabled
@LogMessage(level=INFO) @Message(value="Transaction notifications are disabled. This prevents cluster listeners from working properly!", id=395) void transactionNotificationsDisabled() -
ignoringUnsolicitedState
-
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
@Message(value="No indexable classes were defined for this indexed cache. The configuration must contain classes or protobuf message types annotated with \'@Indexed\'", id=403) org.infinispan.commons.CacheConfigurationException noIndexableClassesDefined() -
failedInvokingCacheManagerListener
@LogMessage(level=ERROR) @Message(value="Caught exception while invoking a cache manager listener!", id=405) void failedInvokingCacheManagerListener(@Cause Throwable 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) -
unknownTransactionConfiguration
@Message(value="Cannot determine a synthetic transaction configuration from mode=%s, xaEnabled=%s, recoveryEnabled=%s, batchingEnabled=%s", id=412) org.infinispan.commons.CacheConfigurationException unknownTransactionConfiguration(TransactionMode mode, boolean xaEnabled, boolean recoveryEnabled, boolean batchingEnabled) -
unableToInstantiateSerializer
@Message(value="Unable to instantiate serializer for %s", id=413) org.infinispan.commons.CacheConfigurationException unableToInstantiateSerializer(Class<?> storeConfigurationClass) -
globalSecurityAuthShouldBeEnabled
@Message(value="Global security authorization should be enabled if cache authorization enabled.", id=414) org.infinispan.commons.CacheConfigurationException globalSecurityAuthShouldBeEnabled() -
ignoredAttribute
-
transactionalStoreInNonTransactionalCache
@Message(value="It is not possible for a store to be transactional in a non-transactional cache. ", id=417) org.infinispan.commons.CacheConfigurationException transactionalStoreInNonTransactionalCache() -
transactionalStoreInPassivatedCache
@Message(value="It is not possible for a store to be transactional when passivation is enabled. ", id=418) org.infinispan.commons.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) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException duplicateExternalizerIdFound(int externalizerId, String otherExternalizer) -
invalidEvictionSize
@Message(value="Memory eviction is enabled, please specify a maximum size or count greater than zero", id=424) org.infinispan.commons.CacheConfigurationException invalidEvictionSize() -
timeoutWaitingForAcks
@Message(value="Timeout after %s waiting for acks (%s). Id=%s", id=427) TimeoutException timeoutWaitingForAcks(String timeout, String address, long id) -
configDeprecatedUseOther
-
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) -
missingDefaultCacheDeclaration
@Message(value="Missing configuration for default cache \'%s\' declared on container", id=432) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException noDefaultCache() -
defaultCacheConfigurationWithoutName
@Message(value="Cache manager initialized with a default cache configuration but without a name for it. Set it in the GlobalConfiguration.", id=435) org.infinispan.commons.CacheConfigurationException defaultCacheConfigurationWithoutName() -
noSuchCacheConfiguration
@Message(value="Cache \'%s\' has been requested, but no matching cache configuration exists", id=436) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException duplicateCacheName(String name) -
receivedXSiteClusterView
@LogMessage(level=INFO) @Message(value="Received new cross-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) org.infinispan.commons.CacheConfigurationException unsupportedAsyncCacheMode(CacheMode cacheMode) -
transactionalStoreCannotBeAsync
@Message(value="Invalid cache loader configuration for \'%s\'. A cache loader cannot be both Asynchronous and transactional.", id=444) org.infinispan.commons.CacheConfigurationException transactionalStoreCannotBeAsync(String simpleName) -
multipleSitesWithSameName
@Message(value="Multiple sites have the same name \'%s\'. This configuration is not valid.", id=446) org.infinispan.commons.CacheConfigurationException multipleSitesWithSameName(String site) -
awaitInitialTransferOnlyForDistOrRepl
@Message(value="\'awaitInitialTransfer\' can be enabled only if cache mode is distributed or replicated.", id=448) org.infinispan.commons.CacheConfigurationException awaitInitialTransferOnlyForDistOrRepl() -
invalidXSiteStateTransferTimeout
@Message(value="Timeout value for cross-site replication state transfer must be equal to or greater than one.", id=449) org.infinispan.commons.CacheConfigurationException invalidXSiteStateTransferTimeout() -
invalidXSiteStateTransferWaitTime
@Message(value="Wait time between retries for cross-site replication state transfer must be equal to or greater than one.", id=450) org.infinispan.commons.CacheConfigurationException invalidXSiteStateTransferWaitTime() -
timeoutWaitingForView
@Message(value="Timed out waiting for view %d, current view is %d", id=451) TimeoutException timeoutWaitingForView(int expectedViewId, int currentViewId) -
topologyUpdateError
-
configAlreadyDefined
@Message(value="Attempt to define configuration for cache %s which already exists", id=453) org.infinispan.commons.CacheConfigurationException configAlreadyDefined(String cacheName) -
transactionCleanupError
@LogMessage(level=ERROR) @Message(value="Failure during leaver transactions cleanup", id=455) void transactionCleanupError(@Cause Throwable e) -
invalidEncodingClass
-
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
-
scatteredCacheNeedsSingleOwner
@Message(value="Scattered cache supports only single owner.", id=467) org.infinispan.commons.CacheConfigurationException scatteredCacheNeedsSingleOwner() -
invalidationBatchSizeAppliesOnNonScattered
@Message(value="Invalidation batch size configuration options applies only to scattered caches.", id=468) org.infinispan.commons.CacheConfigurationException invalidationBatchSizeAppliesOnNonScattered() -
scatteredCacheIsNonTransactional
@Message(value="Scattered cache does not support transactional mode.", id=469) org.infinispan.commons.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) org.infinispan.commons.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 after %s", id=476) TimeoutException requestTimedOut(long requestId, String targetsWithoutResponses, String elapsed) -
xsiteAdminOperationError
-
unableToFindRemoteSiteTransaction
@Message(value="Couldn\'t find a local transaction corresponding to remote site transaction %s", id=478) org.infinispan.commons.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) org.infinispan.commons.CacheException remoteTransactionOriginatorNotInView(GlobalTransaction gtx) -
remoteTransactionAlreadyCompleted
@Message(value="Cannot create remote transaction %s, already completed", id=482) org.infinispan.commons.CacheException remoteTransactionAlreadyCompleted(GlobalTransaction gtx) -
wildcardsNotAllowedInCacheNames
@Message(value="Wildcards not allowed in cache names: \'%s\'", id=484) org.infinispan.commons.CacheConfigurationException wildcardsNotAllowedInCacheNames(String name) -
configurationNameMatchesMultipleWildcards
@Message(value="Configuration \'%s\' matches multiple wildcard templates", id=485) org.infinispan.commons.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) -
errorTranscoding
-
unsupportedContent
-
configurationSerializationFailed
@Message(value="Could not serialize the configuration of cache \'%s\' (%s)", id=499) org.infinispan.commons.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) org.infinispan.commons.CacheConfigurationException incompatibleClusterConfiguration(String cacheName, Configuration configuration, Configuration existing) -
globalStateDisabled
@Message(value="Cannot persist cache configuration as global state is disabled", id=501) org.infinispan.commons.CacheConfigurationException globalStateDisabled() -
errorPersistingGlobalConfiguration
@Message(value="Error while persisting global configuration state", id=502) org.infinispan.commons.CacheConfigurationException errorPersistingGlobalConfiguration(@Cause Throwable cause) -
offHeapMemoryEvictionNotSupportedWithObject
@Message(value="Size (bytes) based eviction needs either off-heap or a binary compatible storage configured in the cache encoding", id=504) org.infinispan.commons.CacheConfigurationException offHeapMemoryEvictionNotSupportedWithObject() -
biasedReadsAppliesOnlyToScattered
@Message(value="Biased reads are supported only in scattered cache. Maybe you were looking for L1?", id=506) org.infinispan.commons.CacheConfigurationException biasedReadsAppliesOnlyToScattered() -
cacheExists
@Message(value="Cache %s already exists", id=507) org.infinispan.commons.CacheConfigurationException cacheExists(String cacheName) -
cannotRenamePersistentFile
-
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) org.infinispan.commons.CacheConfigurationException customStorageStrategyNotSet() -
globalStateCannotAcquireLockFile
-
exceptionBasedEvictionOnlySupportedInTransactionalCaches
@Message(value="Exception based eviction requires a transactional cache that doesn\'t allow for 1 phase commit or synchronizations", id=513) org.infinispan.commons.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) org.infinispan.commons.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=ERROR) @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) -
errorDeserializing
@Message(value="Class \'%s\' blocked by deserialization allow list. Include the class name in the server allow list to authorize.", id=529) org.infinispan.commons.CacheException errorDeserializing(String className) -
unsupportedAsyncCacheMode
-
storeNotSegmented
@Message(value="Store or loader %s must implement SegmentedLoadWriteStore or its config must extend AbstractSegmentedStoreConfiguration if configured as segmented", id=531) org.infinispan.commons.CacheConfigurationException storeNotSegmented(Class<?> implementedClass) -
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) org.infinispan.commons.CacheConfigurationException groupingOnlyCompatibleWithObjectStorage(StorageType storageType) -
groupingOnlyCompatibleWithObjectStorage
@Message(value="Grouping requires application/x-java-object storage type but was: {key=%s, value=%s}", id=535) org.infinispan.commons.CacheConfigurationException groupingOnlyCompatibleWithObjectStorage(org.infinispan.commons.dataconversion.MediaType keyMediaType, org.infinispan.commons.dataconversion.MediaType valueMediaType) -
factoryCannotConstructComponent
@Message(value="Factory doesn\'t know how to construct component %s", id=537) org.infinispan.commons.CacheConfigurationException factoryCannotConstructComponent(String componentName) -
moduleStopError
-
duplicateJGroupsStack
@Message(value="Duplicate JGroups stack \'%s\'", id=539) org.infinispan.commons.CacheConfigurationException duplicateJGroupsStack(String name) -
missingJGroupsStack
@Message(value="No such JGroups stack \'%s\'", id=540) org.infinispan.commons.CacheConfigurationException missingJGroupsStack(String name) -
errorCreatingChannelFromConfigurator
-
invalidScope
-
jgroupsNoStackPosition
@Message(value="Cannot use stack.position when stack.combine is \'%s\'", id=543) org.infinispan.commons.CacheConfigurationException jgroupsNoStackPosition(String combineMode) -
jgroupsNoSuchProtocol
-
jgroupsInsertRequiresPosition
@Message(value="Inserting protocol \'%s\' in a JGroups stack requires the \'stack.position\' attribute", id=545) org.infinispan.commons.CacheConfigurationException jgroupsInsertRequiresPosition(String protocolName) -
duplicateRemoteSite
-
jgroupsRemoteSitesWithoutRelay
@Message(value="JGroups stack \'%s\' declares remote sites but does not include the RELAY2 protocol.", id=547) org.infinispan.commons.CacheConfigurationException jgroupsRemoteSitesWithoutRelay(String name) -
jgroupsRelayWithoutRemoteSites
@Message(value="JGroups stack \'%s\' has a RELAY2 protocol without remote sites.", id=548) org.infinispan.commons.CacheConfigurationException jgroupsRelayWithoutRemoteSites(String name) -
invalidationPartitionHandlingNotSuported
@Message(value="Invalidation mode only supports when-split=ALLOW_READ_WRITES", id=550) org.infinispan.commons.CacheConfigurationException invalidationPartitionHandlingNotSuported() -
customInterceptorsDeprecated
@LogMessage(level=WARN) @Message(value="The custom interceptors configuration has been deprecated and will be ignored in the future", id=551) void customInterceptorsDeprecated() -
marshallersNotSupported
@LogMessage(level=WARN) @Message(value="Ignoring \'marshaller\' attribute. Common marshallers are already available at runtime, and to deploy a custom marshaller, consult the \'Encoding\' section in the user guide", id=553) void marshallersNotSupported() -
jbossMarshallingDetected
@LogMessage(level=WARN) @Message(value="jboss-marshalling is deprecated and planned for removal", id=554) void jbossMarshallingDetected() -
unableToSetAccessible
-
startingUserMarshaller
@LogMessage(level=INFO) @Message(value="Starting user marshaller \'%s\'", id=556) void startingUserMarshaller(String marshallerClass) -
unableToAddJGroupsStack
-
forbiddenStoreLocation
-
cannotMarshall
-
advancedExternalizerDeprecated
@LogMessage(level=WARN) @Message(value="The AdvancedExternalizer configuration has been deprecated and will be removed in the future", id=560) void advancedExternalizerDeprecated() -
invalidChunkSize
@Message(value="Chunk size must be positive, got %d", id=561) org.infinispan.commons.CacheConfigurationException invalidChunkSize(int chunkSize) -
storeDoesNotSupportBeingSegmented
@Message(value="Invalid cache loader configuration for \'%s\'. This implementation does not support being segmented!", id=563) org.infinispan.commons.CacheConfigurationException storeDoesNotSupportBeingSegmented(String name) -
segmentedStoreUsesManyFileDescriptors
@LogMessage(level=WARN) @Message(value="Configured store \'%s\' is segmented and may use a large number of file descriptors", id=564) void segmentedStoreUsesManyFileDescriptors(String storeName) -
indexModeNotSupported
@Message(value="Index.%s is no longer supported. Please update your configuration!", id=565) org.infinispan.commons.CacheConfigurationException indexModeNotSupported(String indexMode) -
threadPoolFactoryIsBlocking
-
warnUnableToPersistInternalCaches
@LogMessage(level=WARN) @Message(value="Unable to persist Infinispan internal caches as no global state enabled", id=569) @Once void warnUnableToPersistInternalCaches() -
unexpectedResponse
@Message(value="Unexpected response from %s: %s", id=570) IllegalArgumentException unexpectedResponse(Address target, Response response) -
indexModeDeprecated
@LogMessage(level=WARN) @Message(value="index mode attribute is deprecated and should no longer be specified because its value is automatically detected. Most previously supported values are no longer supported. Please check the upgrade guide.", id=572) void indexModeDeprecated() -
incompatiblePersistedConfiguration
@Message(value="Cannot recreate persisted configuration for cache \'%s\' because configuration %n%s%n is incompatible with the existing configuration %n%s", id=573) org.infinispan.commons.CacheConfigurationException incompatiblePersistedConfiguration(String cacheName, Configuration configuration, Configuration existing) -
incompleteGlobalState
@LogMessage(level=WARN) @Message(value="Global state cannot persisted because it is incomplete (usually caused by errors at startup).", id=574) void incompleteGlobalState() -
singleOwnerNotSetToAllowReadWrites
@Message(value="PartitionStrategy must be ALLOW_READ_WRITES when numOwners is 1", id=575) org.infinispan.commons.CacheConfigurationException singleOwnerNotSetToAllowReadWrites() -
xsiteInLocalCache
@Message(value="Cross-site replication not available for local cache.", id=576) org.infinispan.commons.CacheConfigurationException xsiteInLocalCache() -
missingTypeForUnwrappedPayload
@Message(value="Converting from unwrapped protostream payload requires the \'type\' parameter to be supplied in the destination MediaType", id=577) org.infinispan.commons.marshall.MarshallingException missingTypeForUnwrappedPayload() -
startMigratingPersistenceData
@LogMessage(level=INFO) @Message(value="Migrating \'%s\' persisted data to new format...", id=578) void startMigratingPersistenceData(String cacheName) -
persistedDataSuccessfulMigrated
@LogMessage(level=INFO) @Message(value="\'%s\' persisted data successfully migrated.", id=579) void persistedDataSuccessfulMigrated(String cacheName) -
persistedDataMigrationFailed
@Message(value="Failed to migrate \'%s\' persisted data.", id=580) PersistenceException persistedDataMigrationFailed(String cacheName, @Cause Throwable cause) -
indexEnabledAndIndexModeAreExclusive
@Message(value="The indexing \'enabled\' and the legacy \'index\' configs attributes are mutually exclusive", id=581) org.infinispan.commons.CacheConfigurationException indexEnabledAndIndexModeAreExclusive() -
foundMultipleDirectoryProviders
@Message(value="A single indexing directory provider is allowed per cache configuration. Setting multiple individual providers for the indexes belonging to a cache is not allowed.", id=582) org.infinispan.commons.CacheConfigurationException foundMultipleDirectoryProviders() -
cannotProvideBothSizeAndCount
@Message(value="Cannot configure both maxCount and maxSize in memory configuration", id=583) org.infinispan.commons.CacheConfigurationException cannotProvideBothSizeAndCount() -
cannotUseDeprecatedAndReplacement
@Message(value="The memory attribute(s) %s have been deprecated and cannot be used in conjunction with the new configuration", id=584) org.infinispan.commons.CacheConfigurationException cannotUseDeprecatedAndReplacement(String legacyName) -
ignoringSpecificMediaTypes
@LogMessage(level=WARN) @Message(value="Single media-type was specified for keys and values, ignoring individual configurations", id=585) void ignoringSpecificMediaTypes() -
warnUsingDeprecatedMemoryConfigs
@LogMessage(level=WARN) @Message(value="The memory configuration element \'%s\' has been deprecated. Please update your configuration", id=586) void warnUsingDeprecatedMemoryConfigs(String element) -
cannotChangeMaxSize
@Message(value="Cannot change max-size since max-count is already defined", id=587) org.infinispan.commons.CacheConfigurationException cannotChangeMaxSize() -
cannotChangeMaxCount
@Message(value="Cannot change max-count since max-size is already defined", id=588) org.infinispan.commons.CacheConfigurationException cannotChangeMaxCount() -
preloadAndPurgeOnStartupConflict
@Message(value="A store cannot be configured with both preload and purgeOnStartup", id=589) org.infinispan.commons.CacheConfigurationException preloadAndPurgeOnStartupConflict() -
storeBothReadAndWriteOnly
@Message(value="Store cannot be configured with both read and write only!", id=590) org.infinispan.commons.CacheConfigurationException storeBothReadAndWriteOnly() -
storeReadOnlyExceptions
@Message(value="Store cannot be configured with purgeOnStartup, shared or passivation if it is read only!", id=591) org.infinispan.commons.CacheConfigurationException storeReadOnlyExceptions() -
storeWriteOnlyExceptions
@Message(value="Store cannot be configured with fetchPersistenceState or preload if it is write only!", id=592) org.infinispan.commons.CacheConfigurationException storeWriteOnlyExceptions() -
storeConfiguredHasBothReadAndWriteOnly
@Message(value="Store %s cannot be configured to be %s as the implementation specifies it is already %s!", id=593) org.infinispan.commons.CacheConfigurationException storeConfiguredHasBothReadAndWriteOnly(String storeClassName, NonBlockingStore.Characteristic configured, NonBlockingStore.Characteristic implSpecifies) -
onlyOnePreloadStoreAllowed
@Message(value="At most one store can be set to \'preload\'!", id=594) org.infinispan.commons.CacheConfigurationException onlyOnePreloadStoreAllowed() -
warnUsingDeprecatedClusterLoader
@LogMessage(level=WARN) @Message(value="ClusterLoader has been deprecated and will be removed in a future version with no direct replacement", id=595) void warnUsingDeprecatedClusterLoader() -
autoConfigDeprecated
@LogMessage(level=WARN) @Message(value="Indexing auto-config attribute is deprecated. Please check the upgrade guide.", id=596) void autoConfigDeprecated() -
storeConfiguredTransactionalButCharacteristicNotPresent
@Message(value="Store %s cannot be configured to be transactional as it does not contain the TRANSACTIONAL characteristic", id=597) org.infinispan.commons.CacheConfigurationException storeConfiguredTransactionalButCharacteristicNotPresent(String storeClassName) -
storeLocationRequired
@Message(value="Store must specify a location when global state is disabled", id=598) org.infinispan.commons.CacheConfigurationException storeLocationRequired() -
storeLocationRequired
-
unknownEncoding
@LogMessage(level=WARN) @Message(value="Configuration for cache \'%s\' does not define the encoding for keys or values. If you use operations that require data conversion or queries, you should configure the cache with a specific MediaType for keys or values.", id=599) void unknownEncoding(String cacheName) -
storeConfiguredSegmentedButCharacteristicNotPresent
@Message(value="Store %s cannot be configured to be segmented as it does not contain the SEGMENTABLE characteristic", id=601) org.infinispan.commons.CacheConfigurationException storeConfiguredSegmentedButCharacteristicNotPresent(String storeClassName) -
jsonObjectConversionDeprecated
@LogMessage(level=WARN) @Message(value="Conversions between JSON and Java Objects are deprecated and will be removed in a future version. To read/write values as JSON, it is recommended to define a protobuf schema and store data in the cache using \'application/x-protostream\' as MediaType", id=602) void jsonObjectConversionDeprecated() -
xsiteCacheNotFound
@Message(value="Cannot handle cross-site request from site \'%s\'. Cache \'%s\' not found.", id=603) org.infinispan.commons.CacheConfigurationException xsiteCacheNotFound(String remoteSite, ByteString cacheName) -
xsiteCacheNotStarted
@Message(value="Cannot handle cross-site request from site \'%s\'. Cache \'%s\' is stopped.", id=604) org.infinispan.commons.CacheConfigurationException xsiteCacheNotStarted(String origin, ByteString cacheName) -
xsiteInLocalCache
@Message(value="Cannot handle cross-site request from site \'%s\'. Cache \'%s\' is not clustered.", id=605) org.infinispan.commons.CacheConfigurationException xsiteInLocalCache(String origin, ByteString cacheName) -
xsiteInvalidConfigurationRemoteSite
@LogMessage(level=ERROR) @Message(value="Remote site \'%s\' has an invalid cache configuration. Taking the backup location offline.", id=606) void xsiteInvalidConfigurationRemoteSite(String siteName, @Cause org.infinispan.commons.CacheConfigurationException exception) -
missingXSiteEntryMergePolicy
@Message(value="The XSiteEntryMergePolicy is missing. The cache configuration must include a merge policy.", id=607) org.infinispan.commons.CacheConfigurationException missingXSiteEntryMergePolicy() -
unexpectedErrorFromIrac
@LogMessage(level=FATAL) @Message(value="[IRAC] Unexpected error occurred.", id=608) void unexpectedErrorFromIrac(@Cause Throwable t) -
cannotObtainFailedCache
-
indexableClassesDefined
@Message(value="Cache configuration must not declare indexed entities if it is not indexed", id=610) org.infinispan.commons.CacheConfigurationException indexableClassesDefined() -
invalidIndexStorage
@Message(value="Invalid index storage", id=611) org.infinispan.commons.CacheConfigurationException invalidIndexStorage() -
indexingPropertiesDeprecated
@LogMessage(level=WARN) @Message(value="Indexing configuration using properties has been deprecated and will be removed in a future version, please consult the docs for the replacements. The following properties have been found: \'%s\'", id=612) @Once void indexingPropertiesDeprecated(Properties properties) -
deprecatedIndexProperties
@LogMessage(level=WARN) @Message(value="Indexing configuration using properties has been deprecated and will be removed in a future version, please use the <index-writer> and <index-reader> elements to configure indexing behavior.", id=613) @Once void deprecatedIndexProperties() -
foundDifferentIndexConfigPerType
@Message(value="It is not allowed to have different indexing configuration for each indexed type in a cache.", id=614) org.infinispan.commons.CacheConfigurationException foundDifferentIndexConfigPerType() -
marshallerMissingFromUserAndGlobalContext
@Message(value="Unable to unmarshall \'%s\' as a marshaller is not present in the user or global SerializationContext", id=615) org.infinispan.commons.marshall.MarshallingException marshallerMissingFromUserAndGlobalContext(String type) -
persistedDataMigrationUnsupportedVersion
@Message(value="Unsupported persisted data version: %s", id=616) PersistenceException persistedDataMigrationUnsupportedVersion(String magic) -
siteNotFound
@Message(value="Site \'%s\' not found.", id=617) IllegalArgumentException siteNotFound(String siteName) -
xsiteCancelSendFailed
-
xsiteCancelReceiveFailed
-
xsiteStateTransferAlreadyInProgress
@Message(value="Cross-site state transfer to \'%s\' already started", id=620) org.infinispan.commons.CacheException xsiteStateTransferAlreadyInProgress(String site) -
elementRemovedUseOther
-
elementRemoved
@Message(value="Element \'%s\' at %s has been removed with no replacement", id=622) org.infinispan.commons.CacheConfigurationException elementRemoved(String elementName, org.infinispan.commons.configuration.io.Location location) -
attributeRemovedUseOther
-
attributeRemoved
@Message(value="Attribute \'%s\' at %s has been removed with no replacement", id=624) org.infinispan.commons.CacheConfigurationException attributeRemoved(String attributeName, org.infinispan.commons.configuration.io.Location location) -
indexLocationWorkingDir
@LogMessage(level=WARN) @Message(value="Index path not provided and global state disabled, will use the current working directory for storage.", id=625) void indexLocationWorkingDir() -
indexRelativeWorkingDir
@LogMessage(level=WARN) @Message(value="Index path \'%s\' is not absolute and global state is disabled, will use a dir relative to the current working directory.", id=626) void indexRelativeWorkingDir(String path) -
storeRequiresBeingSegmented
@Message(value="Invalid cache loader configuration for \'%s\'. This implementation only supports being segmented!", id=627) org.infinispan.commons.CacheConfigurationException storeRequiresBeingSegmented(String name) -
noSuchGlobalRoles
-
failedPartitionHandlingTxCompletion
@LogMessage(level=WARN) @Message(value="Exception completing partial completed transaction %s. Retrying later.", id=629) void failedPartitionHandlingTxCompletion(GlobalTransaction globalTransaction, @Cause Throwable t) -
invalidXSiteStateTransferMode
@Message(value="Cross-site state transfer mode cannot be null.", id=633) org.infinispan.commons.CacheConfigurationException invalidXSiteStateTransferMode() -
autoXSiteStateTransferModeNotAvailableInSync
@Message(value="Cross-site automatic state transfer is not compatible with SYNC backup strategy.", id=634) org.infinispan.commons.CacheConfigurationException autoXSiteStateTransferModeNotAvailableInSync() -
unableToStartXSiteAutStateTransfer
-
invalidStateTransferTimeout
-
topologyTimeout
@Message(value="Timeout waiting for topology %d, current topology is %d", id=637) TimeoutException topologyTimeout(int expectedTopologyId, int currentTopologyId) -
transactionDataTimeout
@Message(value="Timeout waiting for topology %d transaction data", id=638) TimeoutException transactionDataTimeout(int expectedTopologyId) -
warnUsingDeprecatedSingleFileStore
@LogMessage(level=WARN) @Message(value="SingleFileStore has been deprecated and will be removed in a future version, replaced by SoftIndexFileStore", id=640) void warnUsingDeprecatedSingleFileStore() -
transactionAlreadyRolledBack
@Message(value="The transaction %s is already rolled back", id=641) InvalidTransactionException transactionAlreadyRolledBack(GlobalTransaction gtx) -
startRecoveringCorruptPersistenceData
@LogMessage(level=INFO) @Message(value="Attempting to recover possibly corrupted data file %s", id=642) void startRecoveringCorruptPersistenceData(String cacheName) -
corruptDataSuccessfulMigrated
@LogMessage(level=INFO) @Message(value="\'%s\' persisted data successfully recovered %d entries.", id=643) void corruptDataSuccessfulMigrated(String cacheName, int entries) -
corruptDataMigrationFailed
@Message(value="Failed to recover \'%s\' persisted data.", id=644) PersistenceException corruptDataMigrationFailed(String cacheName, @Cause Throwable cause) -
invalidTouchMode
@Message(value="Asynchronous cache modes, such as %s, cannot use SYNC touch mode for maximum idle expiration.", id=645) org.infinispan.commons.CacheConfigurationException invalidTouchMode(CacheMode cacheMode) -
illegalCapacityFactor
@Message(value="capacityFactor must be positive", id=646) IllegalArgumentException illegalCapacityFactor() -
cannotUpdateInternalCache
@Message(value="The configuration for internal cache \'%s\' cannot be modified", id=647) IllegalArgumentException cannotUpdateInternalCache(String name) -
cannotAddStore
@Message(value="Cache \'%s\' is non empty, cannot add store.", id=648) PersistenceException cannotAddStore(String cacheName) -
segmentedSingleFileStoreDoesNotSupportMaxEntries
@Message(value="SingleFileStore does not support max-entries when segmented", id=649) org.infinispan.commons.CacheConfigurationException segmentedSingleFileStoreDoesNotSupportMaxEntries() -
invalidSingleFileStoreData
@Message(value="Read invalid data in SingleFileStore file %s, please remove the file and retry", id=650) PersistenceException invalidSingleFileStoreData(String path) -
maxIdleNotAllowedWithoutPassivation
@Message(value="Max idle is not allowed while using a store without passivation", id=651) org.infinispan.commons.CacheConfigurationException maxIdleNotAllowedWithoutPassivation() -
maxIdleNotTestedWithPassivation
@LogMessage(level=WARN) @Message(value="Max idle is not supported when using a store", id=652) void maxIdleNotTestedWithPassivation() -
attributeDeprecatedUseOther
-
problemPreloadingKey
@Message(value="Problem encountered when preloading key %s!", id=654) PersistenceException problemPreloadingKey(Object key, @Cause Throwable t) -
invalidJson
@Message(value="Unable to convert text content to JSON: \'%s\'", id=655) org.infinispan.commons.dataconversion.EncodingException invalidJson(String s) -
invalidPolicyWithAsyncStrategy
@Message(value="The backup \'%s\' configuration \'failure-policy=%s\' is not valid with an ASYNC backup strategy.", id=656) org.infinispan.commons.CacheConfigurationException invalidPolicyWithAsyncStrategy(String remoteSite, BackupFailurePolicy policy) -
failurePolicyClassNotCompatibleWith
@Message(value="The backup \'%s\' configuration \'failure-policy-class\' is not compatible with \'failure-policy=%s\'. Use \'failure-policy=\"CUSTOM\"\'", id=657) org.infinispan.commons.CacheConfigurationException failurePolicyClassNotCompatibleWith(String remoteSite, BackupFailurePolicy policy) -
initialStateTransferTimeout
@Message(value="Initial state transfer timed out for cache %s on %s", id=658) TimeoutException initialStateTransferTimeout(String cacheName, Address localAddress) -
componentFailedToStart
-
startFailure
-
configDeprecated
@LogMessage(level=WARN) @Message(value="\'%s\' has been deprecated with no replacement.", id=661) void configDeprecated(Enum<?> element) -
failedToTransferTombstones
-
invalidNameSize
@Message(value="Name must be less than 256 bytes, current name \'%s\' exceeds the size.", id=663) org.infinispan.commons.CacheConfigurationException invalidNameSize(String name) -
invalidIndexStartUpMode
@Message(value="Invalid index startup mode: %s", id=664) org.infinispan.commons.CacheConfigurationException invalidIndexStartUpMode(String invalidValue) -
scheduledTaskEncounteredThrowable
-
requireNonNullClusterName
@Message(value="Transport clusterName cannot be null.", id=666) org.infinispan.commons.CacheConfigurationException requireNonNullClusterName() -
requireNodeName
@Message(value="Transport node-name is not set.", id=667) org.infinispan.commons.CacheConfigurationException requireNodeName() -
nodeNameNotInRaftMembers
@Message(value="Transport node-name must be present in raft-members: %s", id=668) org.infinispan.commons.CacheConfigurationException nodeNameNotInRaftMembers(String members) -
forkProtocolRequired
@Message(value="FORK protocol required on JGroups channel.", id=669) IllegalArgumentException forkProtocolRequired() -
errorCreatingForkChannel
-
raftProtocolAvailable
@Message(value="RAFT protocol is available.", id=672) @LogMessage(level=INFO) void raftProtocolAvailable() -
raftGlobalStateDisabled
@Message(value="Cannot persist RAFT data as global state is disabled", id=673) org.infinispan.commons.CacheConfigurationException raftGlobalStateDisabled() -
issueEncounteredResettingIndex
@Message(value="There was an error when resetting the SIFS index for cache %s", id=674) PersistenceException issueEncounteredResettingIndex(String cacheName, @Cause Throwable t) -
failedInvokingEventLoggerListener
@LogMessage(level=ERROR) @Message(value="Caught exception while invoking a event logger listener!", id=675) void failedInvokingEventLoggerListener(@Cause Throwable e) -
storeIsAvailableCheckThrewException
-
storeIsAvailableCompletedExceptionally
-
persistenceAvailable
@LogMessage(level=INFO) @Message(value="Persistence is now available", id=679) void persistenceAvailable() -
expirationNotAllowedWhenStoreDoesNotSupport
@Message(value="Expiration (Max idle or Lifespan) is not allowed while using a store \'%s\' that does not support expiration, unless it is configured as read only", id=680) org.infinispan.commons.CacheConfigurationException expirationNotAllowedWhenStoreDoesNotSupport(String storeImpl) -
missingRequiredProperty
-
invalidAttributeValue
@Message(value="Attribute \'%2$s\' of element \'%1$s\' has an illegal value \'%3$s\' at %4$s: %5$s", id=686) org.infinispan.commons.CacheConfigurationException invalidAttributeValue(String element, String attribute, String value, org.infinispan.commons.configuration.io.Location location, String message) -
invalidAttributeEnumValue
@Message(value="Attribute \'%2$s\' of element \'%1$s\' has an illegal value \'%3$s\' at %5$s. Expecting one of %4$s.", id=687) org.infinispan.commons.CacheConfigurationException invalidAttributeEnumValue(String element, String attribute, String value, String world, org.infinispan.commons.configuration.io.Location location) -
attributeDeprecated
-
recoverFromStateMissingMembers
-
recoverFromStateMissingMembers
MissingMembersException recoverFromStateMissingMembers(String cacheName, List<Address> members, String total) -
configurationNotFound
@LogMessage(level=DEBUG) @Message(value="We cannot find a configuration for the cache \'%s\' in the available configurations: \'%s\'. This cache has been probably removed by another thread. Skip to writing it.", id=690) void configurationNotFound(String cacheName, Collection<String> definedConfigurations) -
indexedEntityNameMissing
@Message(value="Indexed entity name must not be null or empty", id=691) org.infinispan.commons.CacheConfigurationException indexedEntityNameMissing()
-