Uses of Class
org.infinispan.commons.CacheConfigurationException
Packages that use CacheConfigurationException
Package
Description
Commons Configuration package
Factories are internal components used to create other components based on a cache's
configuration.
Helpers that allow easy exposure of attributes and operations via JMX.
Soft Index
NonBlockingStore.Transports handle the low-level networking, used by the remoting components.
A transport implementation based on JGroups.
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
-
Uses of CacheConfigurationException in org.infinispan.client.hotrod.logging
Methods in org.infinispan.client.hotrod.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.bloomFilterRequiresMaxActiveOneAndWait(int maxActive, ExhaustedAction action) Log.bloomFilterRequiresMaxActiveOneAndWait(int maxActive, ExhaustedAction action) Log_$logger.callbackHandlerAndUsernameMutuallyExclusive()Log_$logger.duplicateClusterDefinition(String siteName) Log.duplicateClusterDefinition(String siteName) Log_$logger.invalidAuthenticationConfiguration()Log_$logger.invalidMaxRetries(int retriesPerServer) Log.invalidMaxRetries(int retriesPerServer) Log_$logger.invalidTransactionManagerLookup()Log_$logger.invalidTransactionMode()Log.invalidTransactionMode()Log_$logger.missingClusterNameDefinition()Log_$logger.missingClusterServersDefinition(String siteName) Log.missingClusterServersDefinition(String siteName) Log_$logger.missingHostDefinition()Log.missingHostDefinition()Log_$logger.missingKeyStorePassword(String keyStore) Log.missingKeyStorePassword(String keyStore) Log_$logger.missingSniHostName()Log.missingSniHostName()Log_$logger.missingTrustStorePassword(String trustStore) Log.missingTrustStorePassword(String trustStore) Log_$logger.nearCacheMaxEntriesPositiveWithBloom(int maxEntries) Log.nearCacheMaxEntriesPositiveWithBloom(int maxEntries) Log_$logger.nearCacheMaxEntriesUndefined()Log_$logger.noSSLTrustManagerConfiguration()Log_$logger.oauthBearerWithoutToken()Log.oauthBearerWithoutToken()Log_$logger.parseErrorServerAddress(String server) Log.parseErrorServerAddress(String server) Log_$logger.remoteCacheTemplateNameXorConfiguration(String name) Log_$logger.trustStoreFileAndPathExclusive()Log_$logger.xorSSLContext()Log.xorSSLContext() -
Uses of CacheConfigurationException in org.infinispan.commons.configuration
Methods in org.infinispan.commons.configuration that throw CacheConfigurationExceptionModifier and TypeMethodDescriptionConfigurationUtils.builderFor(B built) Returns the builder that was used to build this class. -
Uses of CacheConfigurationException in org.infinispan.commons.logging
Methods in org.infinispan.commons.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.attributeMustBeAnInteger(Number value, Enum<?> attribute) Log_$logger.attributeMustBeGreaterThanZero(Number value, Enum<?> attribute) Log_$logger.cannotInstantiateClass(String classname, Throwable t) Log_$logger.errorOnParsingPrometheusURLForTracing(Throwable t) Log_$logger.featureDisabled(String feature) Log_$logger.illegalValueThreadPoolParameter(String parameter, String requirement) Log_$logger.multipleConfigurationValidationErrors()Log_$logger.sslInitializationException(Throwable e) -
Uses of CacheConfigurationException in org.infinispan.configuration.parsing
Methods in org.infinispan.configuration.parsing that return CacheConfigurationExceptionModifier and TypeMethodDescriptionstatic CacheConfigurationExceptionParseUtils.attributeRemoved(ConfigurationReader reader, int attributeIndex) static CacheConfigurationExceptionParseUtils.elementRemoved(ConfigurationReader reader) -
Uses of CacheConfigurationException in org.infinispan.factories
Methods in org.infinispan.factories that throw CacheConfigurationExceptionModifier and TypeMethodDescriptionInternalCacheFactory.createCache(Configuration configuration, GlobalComponentRegistry globalComponentRegistry, String cacheName) This implementation clones the configuration passed in before using it.voidAbstractComponentRegistry.wireDependencies(Object target) Deprecated, for removal: This API element is subject to removal in a future version.Wires an object instance with dependencies annotated with theInjectannotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in theComponentRegistry.voidAbstractComponentRegistry.wireDependencies(Object target, boolean startDependencies) Deprecated, for removal: This API element is subject to removal in a future version.Wires an object instance with dependencies annotated with theInjectannotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in theComponentRegistry. -
Uses of CacheConfigurationException in org.infinispan.jmx
Subclasses of CacheConfigurationException in org.infinispan.jmx -
Uses of CacheConfigurationException in org.infinispan.persistence.jdbc.common.logging
Methods in org.infinispan.persistence.jdbc.common.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.deleteAllCannotHaveParameters(String selectAllStatement) Log.deleteAllCannotHaveParameters(String selectAllStatement) Log_$logger.deleteAndSelectQueryMismatchArguments(String paramName, String upsertStatement, String selectStatement) Log_$logger.deleteAndSelectQueryMismatchArguments(List<String> deleteParams, List<String> selectParams) Log.deleteAndSelectQueryMismatchArguments(String paramName, String upsertStatement, String selectStatement) Log.deleteAndSelectQueryMismatchArguments(List<String> deleteParams, List<String> selectParams) Log_$logger.duplicateFieldInSchema(String fieldName, String schemaName) Log.duplicateFieldInSchema(String fieldName, String schemaName) Log_$logger.existingStoreNoSegmentation()Log_$logger.existingStoreSegmentMismatch(int existing, int cache) Log.existingStoreSegmentMismatch(int existing, int cache) Log_$logger.invalidCharacterInSql(char character, int position, String sqlStatement) Log.invalidCharacterInSql(char character, int position, String sqlStatement) Log_$logger.keyCannotEmbedWithEnum(String schemaName) Log.keyCannotEmbedWithEnum(String schemaName) Log_$logger.keyColumnsNotReturnedFromSelectAll(String keyColumns, String selectAllStatement) Log.keyColumnsNotReturnedFromSelectAll(String keyColumns, String selectAllStatement) Log_$logger.keyColumnsRequired()Log.keyColumnsRequired()Log_$logger.keyNotInSchema(String primaryKeyName, String schemaName) Log.keyNotInSchema(String primaryKeyName, String schemaName) Log_$logger.messageNameRequiredIfEmbeddedKey()Log_$logger.missingConnectionFactory()Log.missingConnectionFactory()Log_$logger.namedParamNotReturnedFromSelect(String paramName, String selectAllStatement, String selectStatement) Log.namedParamNotReturnedFromSelect(String paramName, String selectAllStatement, String selectStatement) Log_$logger.nonTerminatedNamedParamInSql(int position, String sqlStatement) Log.nonTerminatedNamedParamInSql(int position, String sqlStatement) Log_$logger.noPrimaryKeysFoundForTable(String tableName) Log.noPrimaryKeysFoundForTable(String tableName) Log_$logger.noValueColumnForTable(String tableName) Log.noValueColumnForTable(String tableName) Log_$logger.primaryKeyMultipleColumnWithoutSchema()Log_$logger.primaryKeyPresentButNotEmbedded(String fieldName, String schemaName) Log.primaryKeyPresentButNotEmbedded(String fieldName, String schemaName) Log_$logger.repeatedFieldsNotSupported(String fieldName, String schemaName) Log.repeatedFieldsNotSupported(String fieldName, String schemaName) Log_$logger.requiredSchemaFieldNotPresent(String fieldName, String schemaName) Log.requiredSchemaFieldNotPresent(String fieldName, String schemaName) Log_$logger.requiredStatementsForQueryStoreLoader()Log_$logger.requiredStatementsForQueryStoreWriter()Log_$logger.schemaNotFound(String schemaName) Log.schemaNotFound(String schemaName) Log_$logger.selectAllCannotHaveParameters(String selectAllStatement) Log.selectAllCannotHaveParameters(String selectAllStatement) Log_$logger.sizeCannotHaveParameters(String selectAllStatement) Log.sizeCannotHaveParameters(String selectAllStatement) Log_$logger.tableManipulationAttributeNotSet(String groupName, String name) Log.tableManipulationAttributeNotSet(String groupName, String name) Log_$logger.tableNameMissing()Log.tableNameMissing()Log_$logger.tableNotInCorrectFormat(String tableName) Log.tableNotInCorrectFormat(String tableName) Log_$logger.unableToDetectDialect(String supportedDialects) Log.unableToDetectDialect(String supportedDialects) Log_$logger.unnamedParametersNotAllowed(int position, String sqlStatement) Log.unnamedParametersNotAllowed(int position, String sqlStatement) Log_$logger.valueMultipleColumnWithoutSchema()Log_$logger.valueNotInSchema(List<String> columnNames, String schemaName) Log.valueNotInSchema(List<String> columnNames, String schemaName) -
Uses of CacheConfigurationException in org.infinispan.persistence.remote.logging
Methods in org.infinispan.persistence.remote.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.cannotEnableHotRodWrapping()Log_$logger.clusteredRequiresBeingShared()Log_$logger.remoteStoreWithoutContainer()Log_$logger.segmentationNotSupportedInThisVersion(ProtocolVersion version) Log.segmentationNotSupportedInThisVersion(ProtocolVersion version) Log_$logger.segmentationNotSupportedWithGroups()Log_$logger.segmentationRequiresEqualMediaTypes(MediaType cacheMediaType, MediaType serverMediaType) Log.segmentationRequiresEqualMediaTypes(MediaType cacheMediaType, MediaType serverMediaType) Log_$logger.segmentationRequiresEqualSegments(int cacheSegmentCount, Integer serverSegmentCount) Log.segmentationRequiresEqualSegments(int cacheSegmentCount, Integer serverSegmentCount) Log_$logger.shouldUseSameMarshallerWithContainer(Marshaller inUse, Marshaller provided) Log.shouldUseSameMarshallerWithContainer(Marshaller inUse, Marshaller provided) Log_$logger.unknownRemoteCacheManagerContainer(String name) Log.unknownRemoteCacheManagerContainer(String name) -
Uses of CacheConfigurationException in org.infinispan.persistence.rocksdb.logging
Methods in org.infinispan.persistence.rocksdb.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.rocksDBUnknownPropertiesSupplied(String properties) Log.rocksDBUnknownPropertiesSupplied(String properties) -
Uses of CacheConfigurationException in org.infinispan.persistence.sifs
Methods in org.infinispan.persistence.sifs that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.invalidCompactionThreshold(double value) Log.invalidCompactionThreshold(double value) Log_$logger.maxNodeSizeLimitedToShort(int maxNodeSize) Log.maxNodeSizeLimitedToShort(int maxNodeSize) Log_$logger.minNodeSizeMustBeLessOrEqualToMax(int minNodeSize, int maxNodeSize) Log.minNodeSizeMustBeLessOrEqualToMax(int minNodeSize, int maxNodeSize) -
Uses of CacheConfigurationException in org.infinispan.remoting.transport
Methods in org.infinispan.remoting.transport that throw CacheConfigurationExceptionModifier and TypeMethodDescriptionvoidAbstractDelegatingTransport.checkCrossSiteAvailable()voidTransport.checkCrossSiteAvailable()Checks if thisTransportis able to perform cross-site requests. -
Uses of CacheConfigurationException in org.infinispan.remoting.transport.jgroups
Methods in org.infinispan.remoting.transport.jgroups that throw CacheConfigurationException -
Uses of CacheConfigurationException in org.infinispan.rest.logging
Methods in org.infinispan.rest.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.authenticationWithoutAuthenticator()Log_$logger.illegalCompressionLevel(int compressionLevel) Log.illegalCompressionLevel(int compressionLevel) -
Uses of CacheConfigurationException in org.infinispan.server.core.logging
Methods in org.infinispan.server.core.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.cannotRegisterAdminOperationsHandler()Log_$logger.configurationMustContainSingleCache(String name, String configuration) Log.configurationMustContainSingleCache(String name, String configuration) Log_$logger.invalidAllowedMechs(Set<String> allowedMechs, Set<String> allMechs) Log.invalidAllowedMechs(Set<String> allowedMechs, Set<String> allMechs) Log_$logger.missingCacheConfiguration(String name, String configuration) Log.missingCacheConfiguration(String name, String configuration) Log_$logger.missingKeyStorePassword(String keyStore) Log.missingKeyStorePassword(String keyStore) Log_$logger.missingServerName()Log.missingServerName()Log_$logger.missingTrustStorePassword(String trustStore) Log.missingTrustStorePassword(String trustStore) Log_$logger.noSniDomainConfigured()Log.noSniDomainConfigured()Log_$logger.noSSLKeyManagerConfiguration()Log_$logger.saslAuthenticationProvider()Log_$logger.xorSSLContext()Log.xorSSLContext() -
Uses of CacheConfigurationException in org.infinispan.server.hotrod.logging
Methods in org.infinispan.server.hotrod.logging that return CacheConfigurationException -
Uses of CacheConfigurationException in org.infinispan.server.resp.logging
Methods in org.infinispan.server.resp.logging that return CacheConfigurationException -
Uses of CacheConfigurationException in org.infinispan.util.logging
Methods in org.infinispan.util.logging that return CacheConfigurationExceptionModifier and TypeMethodDescriptionLog_$logger.advanceExternalizerTypeClassesUndefined(String className) Log_$logger.attributeNotAllowedInInvalidationMode(String attributeName) Log_$logger.attributeRemoved(String elementName, String attributeName, Location location) Log_$logger.attributeRemovedUseOther(String attributeName, String newAttributeName, Location location) Log_$logger.autoXSiteStateTransferModeNotAvailableInSync()Log_$logger.awaitInitialTransferOnlyForDistOrRepl()Log_$logger.backupForMissingParameters()Log_$logger.backupForNullCache()Log_$logger.backupMissingSite()Log_$logger.cacheExists(String cacheName) Log_$logger.cannotChangeMaxCount()Log_$logger.cannotChangeMaxSize()Log_$logger.cannotProvideBothSizeAndCount()Log_$logger.cannotRenamePersistentFile(String absolutePath, File persistentFile, Throwable cause) Log_$logger.cannotUseDeprecatedAndReplacement(String legacyName) Log_$logger.classNotIndexable(String className) Log_$logger.clusteredTransactionalStoreMustBeShared(String simpleName) Log_$logger.componentFailedToStart(String componentName, Throwable t) Log_$logger.configAlreadyDefined(String cacheName) Log_$logger.configurationNameMatchesMultipleWildcards(String name) Log_$logger.configurationSerializationFailed(String cacheName, Configuration configuration, Exception e) Log_$logger.crossSiteUnavailable()Log_$logger.customInterceptorMissingClass()Log_$logger.customStorageStrategyNotSet()Log_$logger.defaultCacheConfigurationWithoutName()Log_$logger.directoryCannotBeCreated(String path) Log_$logger.duplicateAliasName(String alias, String cacheName) Log_$logger.duplicateCacheName(String name) Log_$logger.duplicateExternalizerIdFound(int externalizerId, Class<?> typeClass, String otherExternalizer, int readerIndex) Log_$logger.duplicateExternalizerIdFound(int externalizerId, String otherExternalizer) Log_$logger.duplicateJGroupsStack(String name) Log_$logger.duplicateRemoteSite(String remoteSite, String name) Log_$logger.elementRemoved(String elementName, Location location) Log_$logger.elementRemovedUseOther(String elementName, String newElementName, Location location) Log_$logger.errorCreatingChannelFromConfigFile(String cfg, Exception e) Log_$logger.errorCreatingChannelFromConfigString(String cfg, Exception e) Log_$logger.errorCreatingChannelFromConfigurator(String configurator, Throwable t) Log_$logger.errorCreatingChannelFromXML(String cfg, Exception e) Log_$logger.errorPersistingGlobalConfiguration(Throwable cause) Log_$logger.exceptionBasedEvictionOnlySupportedInTransactionalCaches()Log_$logger.existingConfigForInternalCache(String name) Log_$logger.expirationNotAllowedWhenStoreDoesNotSupport(String storeImpl) Log_$logger.factoryCannotConstructComponent(String componentName) Log_$logger.failedReadingPersistentState(IOException e, File stateFile) Log_$logger.failedWritingGlobalState(IOException e, File stateFile) Log_$logger.failurePolicyClassNotCompatibleWith(String remoteSite, BackupFailurePolicy policy) Log_$logger.forbiddenStoreLocation(Path location, Path global) Log_$logger.foreignExternalizerUsingNegativeId(AdvancedExternalizer<?> ext, int externalizerId) Log_$logger.foundDifferentIndexConfigPerType()Log_$logger.globalSecurityAuthShouldBeEnabled()Log_$logger.globalStateCannotAcquireLockFile(Throwable cause, FileSystemLock lockFile) Log_$logger.globalStateDisabled()Log_$logger.globalStateLockFilePresent(FileSystemLock lockFile) Log_$logger.groupingOnlyCompatibleWithObjectStorage(MediaType keyMediaType, MediaType valueMediaType) Log_$logger.groupingOnlyCompatibleWithObjectStorage(StorageType storageType) Log_$logger.incompatibleClusterConfiguration(String cacheName, Configuration configuration, Configuration existing) Log_$logger.incompatiblePersistedConfiguration(String cacheName, Configuration configuration, Configuration existing) Log_$logger.indexableClassesDefined()Log_$logger.indexedEntityNameMissing()Log_$logger.interceptorClassAndInstanceDefined(String customInterceptorClassName, String customInterceptor) Log_$logger.internalExternalizerIdLimitExceeded(AdvancedExternalizer<?> ext, int externalizerId, int maxId) Log_$logger.invalidationPartitionHandlingNotSuported()Log_$logger.invalidAttributeEnumValue(String element, String attribute, String value, String world, Location location) Log_$logger.invalidAttributeValue(String element, String attribute, String value, Location location, String message) Log_$logger.invalidChunkSize(int chunkSize) Log_$logger.invalidCompletedTxTimeout(long timeout) Log_$logger.invalidConfigurationIndexingWithInvalidation()Log_$logger.invalidConfigurationIndexingWithoutModule()Log_$logger.invalidEvictionSize()Log_$logger.invalidIndexStartUpMode(String invalidValue) Log_$logger.invalidIndexStorage()Log_$logger.invalidNameSize(String name) Log_$logger.invalidPersistentState(String globalScope) Log_$logger.invalidPolicyWithAsyncStrategy(String remoteSite, BackupFailurePolicy policy) Log_$logger.invalidPrincipalRoleMapper()Log_$logger.invalidReaperWakeUpInterval(long timeout) Log_$logger.invalidScope(String expected, String found) Log_$logger.invalidStateTransferTimeout(String stateTransferTimeout, String remoteTimeout) Log_$logger.invalidTouchMode(CacheMode cacheMode) Log_$logger.invalidTracingCollectorEndpoint(String collectorEndpoint, Throwable e) Log_$logger.invalidXSiteStateTransferMode()Log_$logger.invalidXSiteStateTransferTimeout()Log_$logger.invalidXSiteStateTransferWaitTime()Log_$logger.invocationBatchingCannotBeRecoverable()Log_$logger.invocationBatchingNeedsTransactionalCache()Log_$logger.invocationBatchingNotEnabled()Log_$logger.jgroupsConfigurationNotFound(String cfg) Log_$logger.jgroupsInsertRequiresPosition(String protocolName) Log_$logger.jgroupsNoStackPosition(String combineMode) Log_$logger.jgroupsNoSuchProtocol(String protocolName, String combineMode) Log_$logger.jgroupsRelayWithoutRemoteSites(String name) Log_$logger.jgroupsRemoteSitesWithoutRelay(String name) Log_$logger.l1InvalidLifespan()Log_$logger.l1NotValidWithExpirationEviction()Log_$logger.l1OnlyForDistributedCache(String cacheMode) Log_$logger.loaderConfigurationDoesNotSpecifyLoaderClass(String className) Log_$logger.managerConfigurationStorageUnavailable()Log_$logger.maxIdleNotAllowedWithoutPassivation()Log_$logger.missingBackupFailurePolicyClass(String remoteSite) Log_$logger.missingCustomInterceptorPosition(String customInterceptorClassName) Log_$logger.missingDefaultCacheDeclaration(String defaultCache) Log_$logger.missingJGroupsStack(String name) Log_$logger.missingRequiredProperty(String property, String name, Location location) Log_$logger.missingTransportConfiguration()Log_$logger.missingXSiteEntryMergePolicy()Log_$logger.multipleCustomInterceptorPositions(String customInterceptorClassName) Log_$logger.multipleSitesWithSameName(String site) Log_$logger.noConfiguration(String extend) Log_$logger.noDefaultCache()Log_$logger.nodeNameNotInRaftMembers(String members) Log_$logger.noIndexableClassesDefined()Log_$logger.nonSharedStoreConfiguredAsShared(String storeType) Log_$logger.nonWritableStateFile(File stateFile) Log_$logger.noSuchCacheConfiguration(String name) Log_$logger.noSuchGlobalRoles(Set<String> cacheRoles) Log_$logger.notSupportedInSimpleCache()Log_$logger.offHeapMemoryEvictionNotSupportedWithObject()Log_$logger.onlyOnePreloadStoreAllowed()Log_$logger.parserDoesNotDeclareNamespaces(String name) Log_$logger.passivationStoreCannotBeShared(String name) Log_$logger.preloadAndPurgeOnStartupConflict()Log_$logger.raftGlobalStateDisabled()Log_$logger.recoveryNotSupportedWithNonTxCache()Log_$logger.recoveryNotSupportedWithSynchronization()Log_$logger.requireNodeName()Log_$logger.requireNonNullClusterName()Log_$logger.securityCacheTracing()Log_$logger.segmentedSingleFileStoreDoesNotSupportMaxEntries()Log_$logger.sharedStoreShouldNotBePurged(String name) Log_$logger.sharedStoreWithLocalCache()Log_$logger.singleOwnerNotSetToAllowReadWrites()Log_$logger.storeBothReadAndWriteOnly()Log_$logger.storeConfiguredHasBothReadAndWriteOnly(String storeClassName, NonBlockingStore.Characteristic configured, NonBlockingStore.Characteristic implSpecifies) Log_$logger.storeConfiguredSegmentedButCharacteristicNotPresent(String storeClassName) Log_$logger.storeConfiguredSharedButCharacteristicNotPresent(String storeClassName) Log_$logger.storeConfiguredTransactionalButCharacteristicNotPresent(String storeClassName) Log_$logger.storeDoesNotSupportBeingSegmented(String name) Log_$logger.storeLocationRequired()Log_$logger.storeLocationRequired(String storeType, String attributeName) Log_$logger.storeNotSegmented(Class<?> implementedClass) Log_$logger.storeReadOnlyExceptions()Log_$logger.storeRequiresBeingSegmented(String name) Log_$logger.storeWriteOnlyExceptions()Log_$logger.templateConfigurationStartAttempt(String cacheName) Log_$logger.threadPoolFactoryIsBlocking(String name, String poolName) Log_$logger.transactionalStoreCannotBeAsync(String simpleName) Log_$logger.transactionalStoreInNonTransactionalCache()Log_$logger.transactionalStoreInPassivatedCache()Log_$logger.twoPhaseCommitAsyncBackup()Log_$logger.unableToAddJGroupsStack(String name, Exception e) Log_$logger.unableToInstantiateClass(Class<?> storeConfigurationClass) Log_$logger.unableToInstantiateSerializer(Class<?> storeConfigurationClass) Log_$logger.undeclaredConfiguration(String template, String name) Log_$logger.undefinedThreadPoolName(String name) Log_$logger.unknownTransactionConfiguration(TransactionMode mode, boolean xaEnabled, boolean recoveryEnabled, boolean batchingEnabled) Log_$logger.unsupportedAsyncCacheMode(CacheMode cacheMode) Log_$logger.unsupportedConfiguration(String element, String namespaceUri, Location location, String version) Log_$logger.wildcardsNotAllowedInCacheNames(String name) Log_$logger.xsiteCacheNotFound(String remoteSite, ByteString cacheName) Log_$logger.xsiteInLocalCache()Log_$logger.xsiteInLocalCache(String origin, ByteString cacheName) Methods in org.infinispan.util.logging with parameters of type CacheConfigurationExceptionModifier and TypeMethodDescriptionfinal voidLog_$logger.xsiteInvalidConfigurationRemoteSite(String siteName, CacheConfigurationException exception)