Package | Description |
---|---|
org.apache.ignite |
Contains entry-point Ignite & HPC APIs.
|
org.apache.ignite.cache |
Contains main Data Grid APIs.
|
org.apache.ignite.cache.hibernate |
Contains implementation of Hibernate L2 cache.
|
org.apache.ignite.cache.store.jdbc |
Contains reference JDBC-based cache store implementation.
|
org.apache.ignite.cluster |
Contains cluster-related classes.
|
org.apache.ignite.failure |
Contains Failure handling public API with standard FailureHandler implementations.
|
org.apache.ignite.messaging |
Contains Topic-based Messaging functionality.
|
org.apache.ignite.ml.dataset |
Base package for machine learning dataset classes.
|
org.apache.ignite.ml.dataset.impl.cache |
Base package for cache based implementation of machine learning dataset.
|
org.apache.ignite.ml.dataset.impl.cache.util |
Contains util classes used in cache based implementation of dataset.
|
org.apache.ignite.ml.genetic |
Root GA package (GA Grid)
|
org.apache.ignite.ml.genetic.utils |
Contains utils for GA Grid
|
org.apache.ignite.ml.inference |
Root package for model inference functionality.
|
org.apache.ignite.ml.inference.builder |
Root package for model inference builders.
|
org.apache.ignite.ml.inference.storage.descriptor |
Root package for inference model descriptor storages.
|
org.apache.ignite.ml.inference.storage.model |
Root package for inference model storages.
|
org.apache.ignite.ml.pipeline |
Contains Pipeline API.
|
org.apache.ignite.ml.preprocessing |
Base package for machine learning preprocessing classes.
|
org.apache.ignite.ml.selection.cv |
Root package for cross-validation algorithms.
|
org.apache.ignite.ml.sql |
Contains util classes that help to work with machine learning models in SQL and train models on data from SQL tables.
|
org.apache.ignite.ml.trainers |
Contains model trainers.
|
org.apache.ignite.ml.util |
Contains some utils for ML module.
|
org.apache.ignite.plugin |
Contains plugins management API.
|
org.apache.ignite.spi |
Contains common classes and interfaces for SPI implementations.
|
org.apache.ignite.spi.communication.tcp |
Contains default TCP/IP-based implementation for communication SPI.
|
org.apache.ignite.spi.discovery.isolated |
Contains implementation of special "isolated" mode for single-node cluster.
|
org.apache.ignite.spi.discovery.tcp |
Contains default TCP/IP implementation for discovery SPI.
|
org.apache.ignite.spi.discovery.tcp.ipfinder |
Contains IP finder interface and adapter.
|
org.apache.ignite.springdata.proxy |
Contains classes that provide client-independent access to the Ignite operations required by Spring Data.
|
org.apache.ignite.springdata22.repository |
Package contains Apache Ignite Spring Data integration.
|
org.apache.ignite.springdata22.repository.support |
Package contains supporting files required by Spring Data framework.
|
org.apache.ignite.stream |
Contains Ignite Streamer classes.
|
org.apache.ignite.tensorflow.cluster |
TensorFlow integration API that allows to start and maintain TensorFlow cluster using infrastructure tools from
package
org.apache.ignite.tensorflow.core . |
org.apache.ignite.tensorflow.cluster.spec |
Contains specifications that describes TensorFlow cluster configuration.
|
org.apache.ignite.tensorflow.cluster.tfrunning |
Additional "running" layer on top of Python running layer of infrastructure.
|
org.apache.ignite.tensorflow.cluster.util |
Util components that are used in TensorFlow cluster package.
|
org.apache.ignite.tensorflow.core.longrunning |
The part of TensorFlow integration infrastructure that allows to start and maintain abstract long-running processes.
|
org.apache.ignite.tensorflow.core.nativerunning |
The part of TensorFlow integration infrastructure that allows to start and maintain abstract native processes.
|
org.apache.ignite.tensorflow.core.util |
Util classes used in other
org.apache.ignite.tensorflow.core classes. |
org.apache.ignite.tensorflow.submitter.command |
This package contains commands that command line tool provides.
|
org.gridgain.grid.cache.store.local |
Contains cache file local store API classes.
|
Modifier and Type | Class and Description |
---|---|
class |
IgniteSpringBean
Ignite Spring bean allows to bypass
Ignition methods. |
Modifier and Type | Method and Description |
---|---|
static Ignite |
Ignition.getOrStart(IgniteConfiguration cfg)
Gets or starts new grid instance if it hasn't been started yet.
|
static Ignite |
Ignition.ignite()
Gets an instance of default no-name grid.
|
static Ignite |
Ignition.ignite(String name)
Gets a named Ignite instance.
|
static Ignite |
Ignition.ignite(UUID locNodeId)
Gets a grid instance for given local node ID.
|
static Ignite |
Ignition.localIgnite()
This method is used to address a local
Ignite instance, principally from closure. |
static Ignite |
Ignition.start()
Starts grid with default configuration.
|
static Ignite |
IgniteSpring.start(@Nullable org.springframework.context.ApplicationContext springCtx)
Starts grid with default configuration.
|
static Ignite |
Ignition.start(IgniteConfiguration cfg)
Starts grid with given configuration.
|
static Ignite |
IgniteSpring.start(IgniteConfiguration cfg,
@Nullable org.springframework.context.ApplicationContext springCtx)
Starts grid with given configuration.
|
static Ignite |
Ignition.start(InputStream springCfgStream)
Starts all grids specified within given Spring XML configuration input stream.
|
static Ignite |
Ignition.start(String springCfgPath)
Starts all grids specified within given Spring XML configuration file.
|
static Ignite |
IgniteSpring.start(String springCfgPath,
@Nullable org.springframework.context.ApplicationContext springCtx)
Starts all grids specified within given Spring XML configuration file.
|
static Ignite |
Ignition.start(URL springCfgUrl)
Starts all grids specified within given Spring XML configuration file URL.
|
static Ignite |
IgniteSpring.start(URL springCfgUrl,
@Nullable org.springframework.context.ApplicationContext springCtx)
Starts all grids specified within given Spring XML configuration file URL.
|
Modifier and Type | Method and Description |
---|---|
static List<Ignite> |
Ignition.allGrids()
Gets a list of all grids started so far.
|
Modifier and Type | Method and Description |
---|---|
javax.cache.CacheManager |
CachingProvider.findManager(Ignite ignite) |
Modifier and Type | Field and Description |
---|---|
protected Ignite |
HibernateRegion.ignite
Grid instance.
|
protected Ignite |
HibernateAccessStrategyAdapter.ignite
Grid.
|
Modifier and Type | Method and Description |
---|---|
Ignite |
HibernateAccessStrategyFactory.node() |
Modifier and Type | Method and Description |
---|---|
static void |
HibernateAccessStrategyAdapter.evict(Ignite ignite,
HibernateCacheProxy cache,
Object key)
Called to remove object from cache without regard to transaction.
|
Constructor and Description |
---|
HibernateAccessStrategyAdapter(Ignite ignite,
HibernateCacheProxy cache,
HibernateExceptionConverter eConverter) |
HibernateAccessStrategyFactory(HibernateKeyTransformer keyTransformer,
HibernateExceptionConverter eConverter,
Ignite ignite) |
HibernateCollectionRegion(HibernateRegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache,
CacheDataDescription dataDesc) |
HibernateEntityRegion(HibernateRegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache,
CacheDataDescription dataDesc) |
HibernateNaturalIdRegion(HibernateRegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache,
CacheDataDescription dataDesc) |
HibernateQueryResultsRegion(HibernateRegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache) |
HibernateReadOnlyAccessStrategy(Ignite ignite,
HibernateCacheProxy cache,
HibernateExceptionConverter eConverter) |
HibernateReadWriteAccessStrategy(Ignite ignite,
HibernateCacheProxy cache,
ThreadLocal txCtx,
HibernateExceptionConverter eConverter) |
HibernateRegion(org.hibernate.cache.spi.RegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache) |
HibernateTimestampsRegion(HibernateRegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache) |
IgniteCachedDomainDataAccess(HibernateAccessStrategyAdapter stgy,
org.hibernate.cache.spi.RegionFactory regionFactory,
org.hibernate.cache.spi.DomainDataRegion domainDataRegion,
Ignite ignite,
HibernateCacheProxy cache) |
IgniteCollectionDataAccess(HibernateAccessStrategyAdapter stgy,
org.hibernate.cache.spi.access.AccessType accessType,
org.hibernate.cache.spi.RegionFactory regionFactory,
org.hibernate.cache.spi.DomainDataRegion domainDataRegion,
Ignite ignite,
HibernateCacheProxy cache) |
IgniteEntityDataAccess(HibernateAccessStrategyAdapter stgy,
org.hibernate.cache.spi.access.AccessType accessType,
org.hibernate.cache.spi.RegionFactory regionFactory,
org.hibernate.cache.spi.DomainDataRegion domainDataRegion,
Ignite ignite,
HibernateCacheProxy cache) |
IgniteNaturalIdDataAccess(HibernateAccessStrategyAdapter stgy,
org.hibernate.cache.spi.access.AccessType accessType,
org.hibernate.cache.spi.RegionFactory regionFactory,
org.hibernate.cache.spi.DomainDataRegion domainDataRegion,
Ignite ignite,
HibernateCacheProxy cache) |
IgniteQueryResultsRegion(HibernateRegionFactory factory,
String name,
Ignite ignite,
HibernateCacheProxy cache) |
IgniteTimestampsRegion(org.hibernate.cache.spi.RegionFactory factory,
String regionName,
Ignite ignite,
HibernateCacheProxy cache) |
Modifier and Type | Field and Description |
---|---|
protected Ignite |
CacheAbstractJdbcStore.ignite
Auto injected ignite instance.
|
Modifier and Type | Method and Description |
---|---|
protected Ignite |
CacheAbstractJdbcStore.ignite() |
Modifier and Type | Method and Description |
---|---|
Ignite |
ClusterGroup.ignite()
Gets instance of grid.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
RestartProcessFailureHandler.handle(Ignite ignite,
FailureContext failureCtx)
Actual failure handling.
|
protected boolean |
NoOpFailureHandler.handle(Ignite ignite,
FailureContext failureCtx)
Actual failure handling.
|
protected abstract boolean |
AbstractFailureHandler.handle(Ignite ignite,
FailureContext failureCtx)
Actual failure handling.
|
protected boolean |
StopNodeOrHaltFailureHandler.handle(Ignite ignite,
FailureContext failureCtx)
Actual failure handling.
|
boolean |
StopNodeFailureHandler.handle(Ignite ignite,
FailureContext failureCtx)
Actual failure handling.
|
boolean |
FailureHandler.onFailure(Ignite ignite,
FailureContext failureCtx)
Handles failure occurred on
ignite instance. |
boolean |
AbstractFailureHandler.onFailure(Ignite ignite,
FailureContext failureCtx)
Handles failure occurred on
ignite instance. |
Modifier and Type | Method and Description |
---|---|
protected Ignite |
MessagingListenActor.ignite()
Gets grid instance associated with this actor.
|
Modifier and Type | Method and Description |
---|---|
static <K,V,C extends Serializable,D extends AutoCloseable> |
DatasetFactory.create(Ignite ignite,
IgniteCache<K,V> upstreamCache,
LearningEnvironmentBuilder envBuilder,
PartitionContextBuilder<K,V,C> partCtxBuilder,
PartitionDataBuilder<K,V,C,D> partDataBuilder,
LearningEnvironment environment)
Creates a new instance of distributed dataset using the specified
partCtxBuilder and partDataBuilder . |
static <K,V,C extends Serializable,D extends AutoCloseable> |
DatasetFactory.create(Ignite ignite,
IgniteCache<K,V> upstreamCache,
PartitionContextBuilder<K,V,C> partCtxBuilder,
PartitionDataBuilder<K,V,C,D> partDataBuilder)
Creates a new instance of distributed dataset using the specified
partCtxBuilder and partDataBuilder . |
static <K,V,C extends Serializable,CO extends Serializable> |
DatasetFactory.createSimpleDataset(Ignite ignite,
IgniteCache<K,V> upstreamCache,
LearningEnvironmentBuilder envBuilder,
PartitionContextBuilder<K,V,C> partCtxBuilder,
Preprocessor<K,V> featureExtractor)
Creates a new instance of distributed
SimpleDataset using the specified partCtxBuilder and featureExtractor . |
static <K,V,CO extends Serializable> |
DatasetFactory.createSimpleDataset(Ignite ignite,
IgniteCache<K,V> upstreamCache,
LearningEnvironmentBuilder envBuilder,
Preprocessor<K,V> featureExtractor)
Creates a new instance of distributed
SimpleDataset using the specified featureExtractor . |
static <K,V,CO extends Serializable> |
DatasetFactory.createSimpleDataset(Ignite ignite,
IgniteCache<K,V> upstreamCache,
Preprocessor<K,V> featureExtractor)
Creates a new instance of distributed
SimpleDataset using the specified featureExtractor . |
static <K,V,C extends Serializable,CO extends Serializable> |
DatasetFactory.createSimpleLabeledDataset(Ignite ignite,
IgniteCache<K,V> upstreamCache,
LearningEnvironmentBuilder envBuilder,
PartitionContextBuilder<K,V,C> partCtxBuilder,
Preprocessor<K,V> vectorizer)
Creates a new instance of distributed
SimpleLabeledDataset using the specified partCtxBuilder ,
featureExtractor and lbExtractor . |
static <K,V,CO extends Serializable> |
DatasetFactory.createSimpleLabeledDataset(Ignite ignite,
LearningEnvironmentBuilder envBuilder,
IgniteCache<K,V> upstreamCache,
Preprocessor<K,V> vectorizer)
Creates a new instance of distributed
SimpleLabeledDataset using the specified featureExtractor
and lbExtractor . |
Constructor and Description |
---|
CacheBasedDataset(Ignite ignite,
IgniteCache<K,V> upstreamCache,
IgniteBiPredicate<K,V> filter,
UpstreamTransformerBuilder upstreamTransformerBuilder,
IgniteCache<Integer,C> datasetCache,
LearningEnvironmentBuilder envBuilder,
PartitionDataBuilder<K,V,C,D> partDataBuilder,
UUID datasetId,
boolean upstreamKeepBinary,
LearningEnvironment localLearningEnv,
int retriesCnt)
Constructs a new instance of dataset based on Ignite Cache, which is used as
upstream and as reliable storage for
partition context as well. |
CacheBasedDatasetBuilder(Ignite ignite,
IgniteCache<K,V> upstreamCache)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset with default
predicate that passes all upstream entries to dataset. |
CacheBasedDatasetBuilder(Ignite ignite,
IgniteCache<K,V> upstreamCache,
IgniteBiPredicate<K,V> filter)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset . |
CacheBasedDatasetBuilder(Ignite ignite,
IgniteCache<K,V> upstreamCache,
IgniteBiPredicate<K,V> filter,
UpstreamTransformerBuilder transformerBuilder)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset . |
CacheBasedDatasetBuilder(Ignite ignite,
IgniteCache<K,V> upstreamCache,
IgniteBiPredicate<K,V> filter,
UpstreamTransformerBuilder transformerBuilder,
Boolean isKeepBinary,
int retries)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset . |
Modifier and Type | Method and Description |
---|---|
static <R> Collection<R> |
ComputeUtils.affinityCallWithRetries(Ignite ignite,
Collection<String> cacheNames,
IgniteFunction<Integer,R> fun,
int retries,
DeployingContext deployingContext)
Calls the specified
fun function on all partitions so that is't guaranteed that partitions with the same
index of all specified caches will be placed on the same node and will not be moved before computation is
finished. |
static <R> Collection<R> |
ComputeUtils.affinityCallWithRetries(Ignite ignite,
Collection<String> cacheNames,
IgniteFunction<Integer,R> fun,
int retries,
int interval,
DeployingContext deployingContext)
Calls the specified
fun function on all partitions so that is't guaranteed that partitions with the same
index of all specified caches will be placed on the same node and will not be moved before computation is
finished. |
static <C extends Serializable> |
ComputeUtils.getContext(Ignite ignite,
String datasetCacheName,
int part)
Extracts partition
context from the Ignite Cache. |
static <K,V,C extends Serializable,D extends AutoCloseable> |
ComputeUtils.getData(Ignite ignite,
String upstreamCacheName,
IgniteBiPredicate<K,V> filter,
UpstreamTransformerBuilder transformerBuilder,
String datasetCacheName,
UUID datasetId,
PartitionDataBuilder<K,V,C,D> partDataBuilder,
LearningEnvironment env,
boolean isKeepBinary)
Extracts partition
data from the local storage, if it's not found in local storage recovers this data from a partition upstream and context . |
static LearningEnvironment |
ComputeUtils.getLearningEnvironment(Ignite ignite,
UUID datasetId,
int part,
LearningEnvironmentBuilder envBuilder)
Gets learning environment for given partition.
|
static <K,V,C extends Serializable> |
ComputeUtils.initContext(Ignite ignite,
String upstreamCacheName,
UpstreamTransformerBuilder transformerBuilder,
IgniteBiPredicate<K,V> filter,
String datasetCacheName,
PartitionContextBuilder<K,V,C> ctxBuilder,
LearningEnvironmentBuilder envBuilder,
int retries,
int interval,
boolean isKeepBinary,
DeployingContext deployingContext)
Initializes partition
context by loading it from a partition upstream . |
static void |
ComputeUtils.removeData(Ignite ignite,
UUID datasetId)
Remove data from local cache by Dataset ID.
|
static void |
ComputeUtils.removeLearningEnv(Ignite ignite,
UUID datasetId)
Remove learning environment from local cache by Dataset ID.
|
static <C extends Serializable> |
ComputeUtils.saveContext(Ignite ignite,
String datasetCacheName,
int part,
C ctx)
Saves the specified partition
context into the Ignite Cache. |
Constructor and Description |
---|
GAGrid(GAConfiguration cfg,
Ignite ignite) |
Modifier and Type | Method and Description |
---|---|
static List<Chromosome> |
GAGridUtils.getChromosomes(Ignite ignite,
String qry)
Retrieve chromosomes
|
static List<Gene> |
GAGridUtils.getGenesInOrderForChromosome(Ignite ignite,
Chromosome chromosome)
Retrieve genes in order
|
Modifier and Type | Method and Description |
---|---|
static Model<Vector,Future<Double>> |
IgniteModelStorageUtil.getAsyncModel(Ignite ignite,
String name,
AsyncModelBuilder mdlBldr)
Retrieves Ignite model by name using asynchronous model builder.
|
static <I extends Serializable,O extends Serializable> |
IgniteModelStorageUtil.getModel(Ignite ignite,
String name)
Retrieves Ignite model by name using
SingleModelBuilder . |
static <I extends Serializable,O extends Serializable> |
IgniteModelStorageUtil.getSyncModel(Ignite ignite,
String name,
SyncModelBuilder mdlBldr)
Retrieves Ignite model by name using synchronous model builder.
|
static void |
IgniteModelStorageUtil.removeModel(Ignite ignite,
String name)
Removes model with specified name.
|
static <I extends Serializable,O extends Serializable> |
IgniteModelStorageUtil.saveModel(Ignite ignite,
IgniteModel<I,O> mdl,
String name)
Saved specified model with specified name.
|
Constructor and Description |
---|
IgniteDistributedModelBuilder(Ignite ignite,
int instances,
int maxPerNode)
Constructs a new instance of Ignite distributed inference model builder.
|
Modifier and Type | Method and Description |
---|---|
ModelDescriptorStorage |
ModelDescriptorStorageFactory.getModelDescriptorStorage(Ignite ignite)
Returns model descriptor storage based on Apache Ignite cache.
|
Modifier and Type | Method and Description |
---|---|
ModelStorage |
ModelStorageFactory.getModelStorage(Ignite ignite)
Returns model storage based on Apache Ignite cache.
|
Modifier and Type | Method and Description |
---|---|
PipelineMdl<K,V> |
Pipeline.fit(Ignite ignite,
IgniteCache<K,V> cache)
Fits the pipeline to the input cache.
|
Modifier and Type | Method and Description |
---|---|
default Preprocessor<K,V> |
PreprocessingTrainer.fit(Ignite ignite,
IgniteCache<K,V> cache,
Preprocessor<K,V> basePreprocessor)
Fits preprocessor.
|
default Preprocessor<K,V> |
PreprocessingTrainer.fit(LearningEnvironmentBuilder envBuilder,
Ignite ignite,
IgniteCache<K,V> cache,
Preprocessor<K,V> basePreprocessor)
Fits preprocessor.
|
Modifier and Type | Method and Description |
---|---|
CrossValidation<M,L,K,V> |
CrossValidation.withIgnite(Ignite ignite) |
Constructor and Description |
---|
SqlDatasetBuilder(Ignite ignite,
String upstreamCache)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset with default
predicate that passes all upstream entries to dataset. |
SqlDatasetBuilder(Ignite ignite,
String upstreamCache,
IgniteBiPredicate<Object,BinaryObject> filter)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset . |
SqlDatasetBuilder(Ignite ignite,
String upstreamCache,
IgniteBiPredicate<Object,BinaryObject> filter,
UpstreamTransformerBuilder transformerBuilder)
Constructs a new instance of cache based dataset builder that makes
CacheBasedDataset . |
Modifier and Type | Method and Description |
---|---|
<K,V> M |
DatasetTrainer.fit(Ignite ignite,
IgniteCache<K,V> cache,
IgniteBiPredicate<K,V> filter,
Preprocessor<K,V> preprocessor)
Trains model based on the specified data.
|
<K,V> M |
DatasetTrainer.fit(Ignite ignite,
IgniteCache<K,V> cache,
Preprocessor<K,V> preprocessor)
Trains model based on the specified data.
|
<K,V> M |
DatasetTrainer.update(M mdl,
Ignite ignite,
IgniteCache<K,V> cache,
IgniteBiPredicate<K,V> filter,
Preprocessor<K,V> preprocessor)
Gets state of model in arguments, update in according to new data and return new model.
|
<K,V> M |
DatasetTrainer.update(M mdl,
Ignite ignite,
IgniteCache<K,V> cache,
Preprocessor<K,V> preprocessor)
Gets state of model in arguments, update in according to new data and return new model.
|
Constructor and Description |
---|
SandboxMLCache(Ignite ignite) |
Modifier and Type | Method and Description |
---|---|
Ignite |
CachePluginContext.grid() |
Ignite |
PluginContext.grid() |
Modifier and Type | Field and Description |
---|---|
protected Ignite |
IgniteSpiAdapter.ignite
Ignite instance.
|
Modifier and Type | Method and Description |
---|---|
Ignite |
IgniteSpiAdapter.ignite()
Gets ignite instance.
|
Modifier and Type | Method and Description |
---|---|
protected void |
IgniteSpiAdapter.injectResources(Ignite ignite)
Inject ignite instance.
|
Constructor and Description |
---|
TcpCommunicationMetricsListener(Ignite ignite,
IgniteSpiContext spiCtx) |
Modifier and Type | Method and Description |
---|---|
protected void |
IsolatedDiscoverySpi.injectResources(Ignite ignite)
Inject ignite instance.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TcpDiscoverySpi.injectResources(Ignite ignite)
Inject resources
|
Modifier and Type | Field and Description |
---|---|
protected Ignite |
TcpDiscoveryIpFinderAdapter.ignite
Deprecated.
Since 2.8. May contain an invalid Ignite instance when multiple nodes shares same
TcpDiscoveryIpFinder instance. |
Modifier and Type | Method and Description |
---|---|
Ignite |
IgniteProxyImpl.delegate() |
Constructor and Description |
---|
IgniteProxyImpl(Ignite ignite) |
Modifier and Type | Method and Description |
---|---|
Ignite |
IgniteRepository.ignite()
Returns the Ignite instance bound to the repository
|
Modifier and Type | Method and Description |
---|---|
Ignite |
IgniteRepositoryImpl.ignite()
Returns the Ignite instance bound to the repository
|
Modifier and Type | Field and Description |
---|---|
protected Ignite |
StreamAdapter.ignite
Ignite.
|
Modifier and Type | Method and Description |
---|---|
Ignite |
StreamAdapter.getIgnite() |
Modifier and Type | Method and Description |
---|---|
void |
StreamAdapter.setIgnite(Ignite ignite) |
Constructor and Description |
---|
TensorFlowClusterGatewayManager(Ignite ignite)
Constructs a new instance of TensorFlow cluster manager with maintenance.
|
TensorFlowClusterManager(Ignite ignite)
Constructs a new instance of TensorFlow cluster manager.
|
Modifier and Type | Method and Description |
---|---|
String |
TensorFlowServerAddressSpec.format(Ignite ignite)
Formats Server Address specification so that TensorFlow accepts it.
|
String |
TensorFlowClusterSpec.format(Ignite ignite)
Formats cluster specification so that TensorFlow accepts it.
|
Modifier and Type | Method and Description |
---|---|
String |
TensorFlowServerScriptFormatter.format(TensorFlowServer srv,
boolean join,
Ignite ignite)
Formats TensorFlow server specification so that it's available to be passed into а python script.
|
Constructor and Description |
---|
TensorFlowServerManager(Ignite ignite)
Constructs a new instance of TensorFlow server manager.
|
Constructor and Description |
---|
ClusterPortManager(Ignite ignite,
String poolName,
int from,
int cnt)
Constructs a new instance of cluster port manager.
|
TensorFlowChiefRunner(Ignite ignite,
ExecutorService executor,
TensorFlowClusterSpec spec,
Consumer<String> out,
Consumer<String> err)
Constructs a new instance of TensorFlow chief runner.
|
TensorFlowClusterResolver(Ignite ignite,
String portPoolName,
int portFrom,
int portCnt)
Constructs a new instance of TensorFlow cluster resolver.
|
TensorFlowUserScriptRunner(Ignite ignite,
ExecutorService executor,
TensorFlowJobArchive jobArchive,
TensorFlowClusterSpec clusterSpec,
Consumer<String> out,
Consumer<String> err)
Constructs a new instance of TensorFlow user script runner.
|
Constructor and Description |
---|
LongRunningProcessManager(Ignite ignite)
Constructs a new instance of long running process manager.
|
Constructor and Description |
---|
NativeProcessManager(Ignite ignite)
Constructs a new native process manager.
|
Constructor and Description |
---|
AsyncNativeProcessRunner(Ignite ignite,
ExecutorService executor)
Constructs a new asynchronous native process runner.
|
Modifier and Type | Method and Description |
---|---|
protected Ignite |
AbstractCommand.getIgnite()
Returns Ignite instance based on configuration specified in
AbstractCommand.cfg field. |
Modifier and Type | Field and Description |
---|---|
protected Ignite |
CacheFileLocalStore.ignite |
GridGain In-Memory Computing Platform : ver. 8.9.14 Release Date : November 5 2024