-
cleo.search.store.ArrayStoreConnections.sync()
-
cleo.search.store.ArrayStoreWeights.sync()
-
com.aelitis.azureus.core.pairing.PairingConnectionData.sync()
-
com.alimama.mdrill.hdfsDirectory.FileSystemDirectory.sync()
-
com.arjuna.ats.arjuna.objectstore.ObjectStore.sync()
-
com.attask.jenkins.templates.ImplementationBuildWrapper.sync()
-
com.hp.hpl.jena.tdb.base.objectfile.ObjectFile.sync()
-
com.hp.hpl.jena.tdb.index.Index.sync()
-
com.hp.hpl.jena.tdb.index.bplustree.BPlusTree.sync()
-
com.hp.hpl.jena.tdb.nodetable.NodeTable.sync()
-
com.hp.hpl.jena.tdb.store.DatasetGraphTDB.sync()
-
com.sencha.gxt.widget.core.client.SplitBar.sync()
Updates the spitbar's bounds to match the target widget.
-
com.sleepycat.je.Database.sync()
Flushes any cached information for this database to disk; only applicable for deferred-write databases.
Note that deferred-write databases are automatically flushed to disk when the {@link #close} method is called.
@see DatabaseConfig#setDeferredWrite DatabaseConfig.setDeferredWrite
@throws com.sleepycat.je.rep.DatabasePreemptedException in a replicatedenvironment if the master has truncated, removed or renamed the database.
@throws OperationFailureException if this exception occurred earlier andcaused the transaction to be invalidated.
@throws EnvironmentFailureException if an unexpected, internal orenvironment-wide failure occurs.
@throws UnsupportedOperationException if this is not a deferred-writedatabase, or this database is read-only.
@throws IllegalStateException if the database has been closed.
-
com.sleepycat.je.Environment.sync()
Synchronously flushes database environment databases to stable storage. Calling this method is equivalent to forcing a checkpoint and setting {@link CheckpointConfig#setMinimizeRecoveryTime} to true.
A checkpoint has the side effect of flushing all preceding non-transactional write operations, as well as any preceding transactions that were committed with {@link Durability.SyncPolicy#NO_SYNC no-sync durability}. However, for best performance, checkpoints should be used only to bound recovery time. {@link #flushLog} can be used to write buffered data for durabilitypurposes.
@throws EnvironmentFailureException if an unexpected, internal orenvironment-wide failure occurs.
@throws IllegalStateException if this handle or the underlyingenvironment has been closed.
-
com.sun.messaging.jmq.jmsserver.core.Destination.sync()
-
de.grey.ownsync.OwnSyncStarter.sync()
-
gnu.java.text.AttributedFormatBuffer.sync()
-
io.netty.channel.ChannelFuture.sync()
-
java.awt.Toolkit.sync()
Synchronizes this toolkit's graphics state. Some window systems may do buffering of graphics events.
This method ensures that the display is up-to-date. It is useful for animation.
-
java.io.FileDescriptor.sync()
Ensures that data which is buffered within the underlying implementation is written out to the appropriate device before returning.
@throws SyncFailedException when the operation fails
-
java.util.prefs.Preferences.sync()
Ensures that future reads from this preference node and its descendants reflect any changes that were committed to the persistent store (from any VM) prior to the sync invocation. As a side-effect, forces any changes in the contents of this preference node and its descendants to the persistent store, as if the flush method had been invoked on this node.
@throws BackingStoreException if this operation cannot be completeddue to a failure in the backing store, or inability to communicate with it.
@throws IllegalStateException if this node (or an ancestor) has beenremoved with the {@link #removeNode()} method.
@see #flush()
-
krati.core.array.basic.DynamicIntArray.sync()
-
krati.core.array.basic.DynamicLongArray.sync()
-
krati.core.array.basic.DynamicShortArray.sync()
-
krati.store.AbstractDataArray.sync()
-
krati.store.ArrayStorePartition.sync()
-
krati.store.DynamicDataStore.sync()
-
krati.store.StaticDataSet.sync()
-
models.User.sync()
Update this user with Dropbox credentials
-
org.akubraproject.BlobStoreConnection.sync()
Flush all blobs associated with this connection and fsync. After this method completes all data should be comitted to stable storage (for stores that are backed by stable storage). However, whether this is really the case will depend on the storage used by the store (e.g. for a local filesystem based store it'll depend on the OS config and hardware, i.e. whether the disk's write cache is flushed or not).
This may or may not flush any open output-streams. For reliable results ensure that all output streams are closed before calling sync.
@throws IOException if any error occurred trying to flush and sync
@throws UnsupportedOperationException if the store is not capable of syncing
-
org.apache.activemq.util.RecoverableRandomAccessFile.sync()
-
org.apache.clerezza.rdf.jena.tdb.internals.ModelGraph.sync()
Synchronize the Jena Model with the field system by calling {@link TDB#sync(Model)}
-
org.apache.curator.framework.CuratorFramework.sync()
Perform a sync on the given path - syncs are always in the background
@param path the path
@param backgroundContextObject optional context
@deprecated use {@link #sync()} instead
-
org.apache.cxf.jaxrs.client.WebClient.sync()
-
org.apache.derby.io.StorageRandomAccessFile.sync()
Force any changes out to the persistent store. If the database is to be transient, that is, if the database does not survive a restart, then the sync method implementation need not do anything.
@param metaData If true then this method must force both changes to the file'scontents and metadata to be written to storage; if false, it need only force file content changes to be written. The implementation is allowed to ignore this parameter and always force out metadata changes.
@exception SyncFailedException if a possibly recoverable error occurs.
@exception IOException If an IO error occurs.
-
org.apache.directory.server.core.partition.impl.avl.AvlPartition.sync()
{@inheritDoc}
-
org.apache.directory.server.core.partition.impl.btree.jdbm.JdbmIndex.sync()
@see Index#sync()
-
org.apache.felix.prefs.PreferencesImpl.sync()
@see org.osgi.service.prefs.Preferences#sync()
-
org.apache.hadoop.fs.FSDataOutputStream.sync()
-
org.apache.hadoop.hbase.regionserver.wal.HLog.sync()
-
org.apache.hadoop.io.SequenceFile.Writer.sync()
-
org.apache.jackrabbit.core.cluster.ClusterNode.sync()
Synchronize contents from journal.
@throws ClusterException if an error occurs
-
org.apache.jackrabbit.oak.spi.security.authentication.external.SyncContext.sync()
Synchronizes an external identity with the repository based on the respective configuration.
@param identity the identity to sync.
@return {@code true} if the given identity was synced; {@code false} if for no change.
@throws SyncException if an error occurrs
-
org.apache.jackrabbit.vault.vlt.meta.xml.zip.UpdateableZipFile.sync()
-
org.apache.jetspeed.aggregator.ContentDispatcher.sync()
Sequentially wait on content generation for the given fragment.
@param fragment
-
org.apache.jetspeed.container.state.MutableNavigationalState.sync()
-
org.apache.jetspeed.container.state.NavigationalState.sync()
Synchronize the Navigational State with saved state (if used).
Should be called by the PortalURL impl right after calling {@link #init(String)}
@param context The RequestContext for this Navigational State
-
org.apache.jetspeed.rewriter.rules.Ruleset.sync()
Synchronize the Ruleset
-
org.apache.ldap.server.DirectoryService.sync()
Calls {@link DirectoryPartition#sync()} for all registered {@link DirectoryPartition}s.
@throws NamingException if synchronization failed
-
org.apache.ldap.server.partition.impl.btree.Index.sync()
-
org.apache.lucene.store.Directory.sync()
Ensure that any writes to this file are moved to stable storage. Lucene uses this to properly commit changes to the index, to prevent a machine/OS crash from corrupting the index.
-
org.apache.lucene.store.MockDirectoryWrapper.sync()
-
org.apache.portals.applications.webcontent.rewriter.rules.Ruleset.sync()
Synchronize the Ruleset
-
org.apache.qpid.nclient.Session.sync()
Sync method will block the session until all outstanding commands are executed.
-
org.apache.qpid.server.protocol.v0_8.AMQChannel.sync()
-
org.apache.qpid.transport.Session.sync()
-
org.apache.syncope.core.propagation.Connector.sync()
Sync users from a connector instance.
@param objectClass ConnId's object class
@param token to be passed to the underlying connector
@param handler to be used to handle deltas
@param options ConnId's OperationOptions
-
org.apache.syncope.core.propagation.ConnectorFacadeProxy.sync()
Sync users from a connector instance.
@param token to be passed to the underlying connector
@param handler to be used to handle deltas.
-
org.apache.zookeeper.ZooKeeper.sync()
Asynchronous sync. Flushes channel between process and leader.
-
org.atomojo.app.sync.PullSynchronizer.sync()
-
org.atomojo.app.sync.Synchronizer.sync()
-
org.blinkenlights.jid3.MP3File.sync()
-
org.ethereum.trie.TrieImpl.sync()
-
org.exist.debugger.model.Breakpoint.sync()
-
org.exist.storage.BrokerPool.sync()
Executes a waiting cache synchronization for the database instance.
@param broker A broker responsible for executing the job
@param syncEvent One of {@link org.exist.storage.sync.Sync#MINOR_SYNC} or {@link org.exist.storage.sync.Sync#MINOR_SYNC}
-
org.exist.storage.DBBroker.sync()
Sync dom and collection state data (pages) to disk. In case of {@link org.exist.storage.sync.Sync#MAJOR_SYNC}, sync all states (dom, collection, text and element) to disk.
@param syncEvent Sync.MAJOR_SYNC or Sync.MINOR_SYNC
-
org.exist.storage.cache.Cacheable.sync()
Called before the object is released by the cache. The object should prepare to be garbage collected. All unwritten data should be flushed to disk.
-
org.fusesource.hawtdb.internal.io.MemoryMappedFile.sync()
-
org.h2.store.fs.FileObject.sync()
Force changes to the physical location.
-
org.hornetq.core.journal.SequentialFile.sync()
-
org.hornetq.core.paging.PagingStore.sync()
-
org.hornetq.core.paging.impl.PageImpl.sync()
-
org.hornetq.core.paging.impl.PagingStoreImpl.sync()
-
org.hornetq.core.paging.impl.TestSupportPageStore.sync()
-
org.infinispan.config.FluentConfiguration.sync()
Configure sync sub element. Once this method is invoked users cannot subsequently invoke configureAsync()
as two are mutually exclusive
@return SyncConfig element
-
org.infinispan.notifications.Listener.sync()
-
org.iq80.leveldb.WriteOptions.sync()
-
org.jboss.ejb.BeanLock.sync()
Obtain exclusive access to this lock instance.
-
org.jnode.driver.textscreen.ScrollableTextScreen.sync()
-
org.jredis.ri.alphazero.JRedisPipeline.sync()
Provides a synchronous semantics interface ( {@link JRedis}) to this pipeline. Note that this is not a thread-safe mechanism. If you need a pipeline connection with support for concurrent synchronous semantics, use a {@link JRedisPipelineService}.
@return the {@link JRedis} interface for this pipeline.
-
org.jruby.util.io.Stream.sync()
Flush and sync all writes to the filesystem.
@throws IOException if the sync does not work
-
org.mapdb.Volume.MappedFileVol.sync()
-
org.osgi.service.prefs.Preferences.sync()
Ensures that future reads from this node and its descendants reflect any changes that were committed to the persistent store (from any VM) prior to the {@code sync} invocation. As a side-effect, forces any changes inthe contents of this node and its descendants to the persistent store, as if the {@code flush} method had been invoked on this node.
@throws BackingStoreException if this operation cannot be completed dueto a failure in the backing store, or inability to communicate with it.
@throws IllegalStateException if this node (or an ancestor) has beenremoved with the {@link #removeNode()} method.
@see #flush()
-
org.rocksdb.WriteOptions.sync()
If true, the write will be flushed from the operating system buffer cache (by calling WritableFile::Sync()) before the write is considered complete. If this flag is true, writes will be slower. If this flag is false, and the machine crashes, some recent writes may be lost. Note that if it is just the process that crashes (i.e., the machine does not reboot), no writes will be lost even if sync==false. In other words, a DB write with sync==false has similar crash semantics as the "write()" system call. A DB write with sync==true has similar crash semantics to a "write()" system call followed by "fdatasync()".
@return boolean value indicating if sync is active.
-
org.syncany.tests.util.TestClient.sync()
-
org.w3c.jigsaw.http.Logger.sync()
Flush any in core logger state back to disk. Some loggers may use memory cache before writing any data to the disk this method ensures that there state is saved to stable storage.
-
redis.clients.jedis.Pipeline.sync()
Syncronize pipeline by reading all responses. This operation close the pipeline. In order to get return values from pipelined commands, capture the different Response> of the commands you execute.
-
redis.clients.jedis.ShardedJedisPipeline.sync()
Syncronize pipeline by reading all responses. This operation closes the pipeline. In order to get return values from pipelined commands, capture the different Response<?> of the commands you execute.
-
ucar.nc2.NetcdfFile.sync()
Check if file has changed, and reread metadata if needed. All previous object references (variables, dimensions, etc) may become invalid - you must re-obtain. DO NOT USE THIS ROUTINE YET - NOT FULLY TESTED
@return true if file was changed.
@throws IOException if error
-
vazkii.botania.common.block.tile.TileEnchanter.sync()