Uses of Class
org.apache.cassandra.io.util.File
-
-
Uses of File in org.apache.cassandra.cache
Methods in org.apache.cassandra.cache that return File Modifier and Type Method Description File
AutoSavingCache. getCacheCrcPath(java.lang.String version)
File
AutoSavingCache. getCacheDataPath(java.lang.String version)
File
AutoSavingCache. getCacheMetadataPath(java.lang.String version)
Methods in org.apache.cassandra.cache with parameters of type File Modifier and Type Method Description DataInputPlus.DataInputStreamPlus
AutoSavingCache.IStreamFactory. getInputStream(File dataPath, File crcPath)
DataOutputStreamPlus
AutoSavingCache.IStreamFactory. getOutputStream(File dataPath, File crcPath)
-
Uses of File in org.apache.cassandra.config
Methods in org.apache.cassandra.config that return File Modifier and Type Method Description static File
DatabaseDescriptor. getHintsDirectory()
static File
DatabaseDescriptor. getSerializedCachePath(CacheService.CacheType cacheType, java.lang.String version, java.lang.String extension)
-
Uses of File in org.apache.cassandra.db
Fields in org.apache.cassandra.db declared as File Modifier and Type Field Description File
Directories.DataDirectory. location
Methods in org.apache.cassandra.db that return File Modifier and Type Method Description static File
Directories. getBackupsDirectory(Descriptor desc)
static File
Directories. getBackupsDirectory(File location)
Returns directory to write a backup to.File
Directories. getDirectoryForNewSSTables()
Basically the same as callingDirectories.getWriteableLocationAsFile(long)
with an unknown size (-1L
), which may return any allowed directory - even a data directory that has no usable space.File
Directories. getLocationForDisk(Directories.DataDirectory dataDirectory)
Returns SSTable location which is inside given data directory.static File
Directories. getSnapshotDirectory(Descriptor desc, java.lang.String snapshotName)
static File
Directories. getSnapshotDirectory(File location, java.lang.String snapshotName)
Returns directory to write snapshot.File
Directories. getSnapshotManifestFile(java.lang.String snapshotName)
static File
Directories. getSnapshotManifestFile(File snapshotDir)
File
Directories. getSnapshotSchemaFile(java.lang.String snapshotName)
static File
Directories. getSnapshotSchemaFile(File snapshotDir)
File
Directories. getTemporaryWriteableDirectoryAsFile(long writeSize)
Returns a temporary subdirectory on allowed data directory that _currently_ haswriteSize
bytes as usable space.File
Directories. getWriteableLocationAsFile(long writeSize)
Returns an allowed directory that _currently_ haswriteSize
bytes as usable space.File
Directories. getWriteableLocationToLoadFile(File sourceFile)
Returns a data directory to load the filesourceFile
.static File
DisallowedDirectories. maybeMarkUnreadable(File path)
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unreadable directories.static File
DisallowedDirectories. maybeMarkUnwritable(File path)
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unwritable directories.Methods in org.apache.cassandra.db that return types with arguments of type File Modifier and Type Method Description static java.util.Optional<File>
Directories. get(File base, java.lang.String... subdirs)
static java.util.Optional<File>
Directories. getBackupsDirectoryIfExists(File location)
Returns directory to write a backup to.java.util.List<File>
Directories. getCFDirectories()
java.util.List<File>
ColumnFamilyStore. getDirectoriesForFiles(java.util.Set<SSTableReader> sstables)
Grabs the global first/last tokens among sstables and returns the range of data directories that start/end with those tokens.static java.util.List<File>
Directories. getKSChildDirectories(java.lang.String ksName)
static java.util.Optional<File>
Directories. getSnapshotDirectoryIfExists(File location, java.lang.String snapshotName)
Returns directory to write a snapshot to.java.util.List<File>
Directories.SSTableLister. listFiles()
java.util.List<File>
Directories.SSTableLister. listFiles(boolean includeForeignTables)
protected java.util.Map<java.lang.String,java.util.Set<File>>
Directories. listSnapshotDirsByTag()
Methods in org.apache.cassandra.db with parameters of type File Modifier and Type Method Description static java.util.Optional<File>
Directories. get(File base, java.lang.String... subdirs)
static File
Directories. getBackupsDirectory(File location)
Returns directory to write a backup to.static java.util.Optional<File>
Directories. getBackupsDirectoryIfExists(File location)
Returns directory to write a backup to.static java.nio.file.FileStore
Directories. getFileStore(File directory)
Gets the filestore for the actual directory where the sstables are stored.static File
Directories. getSnapshotDirectory(File location, java.lang.String snapshotName)
Returns directory to write snapshot.static java.util.Optional<File>
Directories. getSnapshotDirectoryIfExists(File location, java.lang.String snapshotName)
Returns directory to write a snapshot to.static File
Directories. getSnapshotManifestFile(File snapshotDir)
static File
Directories. getSnapshotSchemaFile(File snapshotDir)
long
Directories. getTrueAllocatedSizeIn(File snapshotDir)
File
Directories. getWriteableLocationToLoadFile(File sourceFile)
Returns a data directory to load the filesourceFile
.static boolean
Directories.FileAction. hasPrivilege(File file, Directories.FileAction action)
static boolean
Directories. isSecondaryIndexFolder(File dir)
static boolean
DisallowedDirectories. isUnreadable(File directory)
Tells whether or not the directory is disallowed for reads.static boolean
DisallowedDirectories. isUnwritable(File directory)
Tells whether or not the directory is disallowed for writes.static File
DisallowedDirectories. maybeMarkUnreadable(File path)
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unreadable directories.static File
DisallowedDirectories. maybeMarkUnwritable(File path)
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unwritable directories.Descriptor
ColumnFamilyStore. newSSTableDescriptor(File directory)
Descriptor
ColumnFamilyStore. newSSTableDescriptor(File directory, SSTableFormat<?,?> format)
Descriptor
ColumnFamilyStore. newSSTableDescriptor(File directory, Version version)
static void
Directories. removeSnapshotDirectory(com.google.common.util.concurrent.RateLimiter snapshotRateLimiter, File snapshotDir)
static void
Keyspace. removeUnreadableSSTables(File directory)
Removes every SSTable in the directory from the appropriate Tracker's view.Directories.SSTableLister
Directories. sstableLister(File directory, Directories.OnTxnErr onTxnErr)
static boolean
Directories. verifyFullPermissions(File dir, java.lang.String dataDir)
Checks whether Cassandra has RWX permissions to the specified directory.Method parameters in org.apache.cassandra.db with type arguments of type File Modifier and Type Method Description java.util.Set<java.nio.file.FileStore>
Directories. allFileStores(java.util.function.Function<File,java.nio.file.FileStore> filestoreMapper)
static void
Directories. clearSnapshot(java.lang.String snapshotName, java.util.List<File> tableDirectories, com.google.common.util.concurrent.RateLimiter snapshotRateLimiter)
boolean
Directories. hasDiskSpaceForCompactionsAndStreams(java.util.Map<File,java.lang.Long> expectedNewWriteSizes, java.util.Map<File,java.lang.Long> totalCompactionWriteRemaining)
Sums up the space required for ongoing streams + compactions + expected new write size per FileStore and checks if there is enough space available.static boolean
Directories. hasDiskSpaceForCompactionsAndStreams(java.util.Map<File,java.lang.Long> expectedNewWriteSizes, java.util.Map<File,java.lang.Long> totalCompactionWriteRemaining, java.util.function.Function<File,java.nio.file.FileStore> filestoreMapper)
static boolean
Directories. hasDiskSpaceForCompactionsAndStreams(java.util.Map<File,java.lang.Long> expectedNewWriteSizes, java.util.Map<File,java.lang.Long> totalCompactionWriteRemaining, java.util.function.Function<File,java.nio.file.FileStore> filestoreMapper)
protected static SnapshotManifest
Directories. maybeLoadManifest(java.lang.String keyspace, java.lang.String table, java.lang.String tag, java.util.Set<File> snapshotDirs)
static java.util.Map<java.nio.file.FileStore,java.lang.Long>
Directories. perFileStore(java.util.Map<File,java.lang.Long> perDirectory, java.util.function.Function<File,java.nio.file.FileStore> filestoreMapper)
static java.util.Map<java.nio.file.FileStore,java.lang.Long>
Directories. perFileStore(java.util.Map<File,java.lang.Long> perDirectory, java.util.function.Function<File,java.nio.file.FileStore> filestoreMapper)
Constructors in org.apache.cassandra.db with parameters of type File Constructor Description DataDirectory(File location)
-
Uses of File in org.apache.cassandra.db.commitlog
Methods in org.apache.cassandra.db.commitlog that return File Modifier and Type Method Description File
CommitLogSegment. getCDCFile()
File
CommitLogSegment. getCDCIndexFile()
File[]
CommitLog. getUnmanagedFiles()
static File
CommitLogDescriptor. inferCdcIndexFile(File cdcCommitLogSegment)
Infer the corresponding cdc index file using its cdc commitlog fileMethods in org.apache.cassandra.db.commitlog with parameters of type File Modifier and Type Method Description int
CommitLogSegment.CommitLogSegmentFileComparator. compare(File f, File f2)
static CommitLogDescriptor
CommitLogDescriptor. fromHeader(File file, EncryptionContext encryptionContext)
static File
CommitLogDescriptor. inferCdcIndexFile(File cdcCommitLogSegment)
Infer the corresponding cdc index file using its cdc commitlog filevoid
CommitLogReader. readAllFiles(CommitLogReadHandler handler, File[] files)
Reads all passed in files with no minimum, no start, and no mutation limit.void
CommitLogReader. readAllFiles(CommitLogReadHandler handler, File[] files, CommitLogPosition minPosition)
Reads all passed in files with minPosition, no start, and no mutation limit.void
CommitLogReader. readCommitLogSegment(CommitLogReadHandler handler, File file, boolean tolerateTruncation)
Reads passed in file fullyvoid
CommitLogReader. readCommitLogSegment(CommitLogReadHandler handler, File file, int mutationLimit, boolean tolerateTruncation)
Reads passed in file fully, up to mutationLimit countvoid
CommitLogReader. readCommitLogSegment(CommitLogReadHandler handler, File file, CommitLogPosition minPosition, boolean tolerateTruncation)
Reads all mutations from passed in file from minPositionvoid
CommitLogReader. readCommitLogSegment(CommitLogReadHandler handler, File file, CommitLogPosition minPosition, int mutationLimit, boolean tolerateTruncation)
Reads mutations from file, handing them off to handlerint
CommitLog. recoverFiles(File... clogs)
Perform recovery on a list of commit log files.void
CommitLogReplayer. replayFiles(File[] clogs)
void
CommitLogReplayer. replayPath(File file, boolean tolerateTruncation)
-
Uses of File in org.apache.cassandra.db.compaction
Methods in org.apache.cassandra.db.compaction that return types with arguments of type File Modifier and Type Method Description java.util.Map<File,java.lang.Long>
ActiveCompactions. estimatedRemainingWriteBytes()
Get the estimated number of bytes remaining to write per sstable directoryjava.util.List<File>
CompactionInfo. getTargetDirectories()
Get the directories this compaction could possibly write to.Methods in org.apache.cassandra.db.compaction with parameters of type File Modifier and Type Method Description static SSTableWriter
CompactionManager. createWriter(ColumnFamilyStore cfs, File compactionFileLocation, long expectedBloomFilterSize, long repairedAt, TimeUUID pendingRepair, boolean isTransient, SSTableReader sstable, LifecycleTransaction txn)
static SSTableWriter
CompactionManager. createWriterForAntiCompaction(ColumnFamilyStore cfs, File compactionFileLocation, int expectedBloomFilterSize, long repairedAt, TimeUUID pendingRepair, boolean isTransient, java.util.Collection<SSTableReader> sstables, ILifecycleTransaction txn)
-
Uses of File in org.apache.cassandra.db.compaction.writers
Methods in org.apache.cassandra.db.compaction.writers that return File Modifier and Type Method Description File
CompactionAwareWriter. getSStableDirectory()
-
Uses of File in org.apache.cassandra.db.lifecycle
Methods in org.apache.cassandra.db.lifecycle that return types with arguments of type File Modifier and Type Method Description static java.util.List<File>
LifecycleTransaction. getFiles(java.nio.file.Path folder, java.util.function.BiPredicate<File,Directories.FileType> filter, Directories.OnTxnErr onTxnErr)
Get the files in the folder specified, provided that the filter returns true.Methods in org.apache.cassandra.db.lifecycle with parameters of type File Modifier and Type Method Description void
Tracker. removeUnreadableSSTables(File directory)
Removes every SSTable in the directory from the Tracker's view.Method parameters in org.apache.cassandra.db.lifecycle with type arguments of type File Modifier and Type Method Description static java.util.List<File>
LifecycleTransaction. getFiles(java.nio.file.Path folder, java.util.function.BiPredicate<File,Directories.FileType> filter, Directories.OnTxnErr onTxnErr)
Get the files in the folder specified, provided that the filter returns true. -
Uses of File in org.apache.cassandra.hints
Methods in org.apache.cassandra.hints with parameters of type File Modifier and Type Method Description static ChecksummedDataInput
ChecksummedDataInput. open(File file)
Constructors in org.apache.cassandra.hints with parameters of type File Constructor Description CompressedHintsWriter(File directory, org.apache.cassandra.hints.HintsDescriptor descriptor, File file, java.nio.channels.FileChannel channel, int fd, java.util.zip.CRC32 globalCRC)
EncryptedHintsWriter(File directory, org.apache.cassandra.hints.HintsDescriptor descriptor, File file, java.nio.channels.FileChannel channel, int fd, java.util.zip.CRC32 globalCRC)
-
Uses of File in org.apache.cassandra.index.sai.disk.format
Methods in org.apache.cassandra.index.sai.disk.format that return File Modifier and Type Method Description File
IndexDescriptor. fileFor(IndexComponent indexComponent)
File
IndexDescriptor. fileFor(IndexComponent indexComponent, IndexIdentifier indexIdentifier)
-
Uses of File in org.apache.cassandra.index.sai.disk.io
Methods in org.apache.cassandra.index.sai.disk.io that return File Modifier and Type Method Description File
IndexOutputWriter. getFile()
Methods in org.apache.cassandra.index.sai.disk.io with parameters of type File Modifier and Type Method Description org.apache.lucene.store.IndexInput
IndexFileUtils. openBlockingInput(File file)
IndexOutputWriter
IndexFileUtils. openOutput(File file)
IndexOutputWriter
IndexFileUtils. openOutput(File file, boolean append)
-
Uses of File in org.apache.cassandra.index.sasi
Constructors in org.apache.cassandra.index.sasi with parameters of type File Constructor Description SSTableIndex(ColumnIndex index, File indexFile, SSTableReader referent)
-
Uses of File in org.apache.cassandra.index.sasi.disk
Fields in org.apache.cassandra.index.sasi.disk declared as File Modifier and Type Field Description protected File
PerSSTableIndexWriter.Index. outputFile
Methods in org.apache.cassandra.index.sasi.disk that return File Modifier and Type Method Description File
PerSSTableIndexWriter.Index. file(boolean isFinal)
Methods in org.apache.cassandra.index.sasi.disk with parameters of type File Modifier and Type Method Description protected boolean
OnDiskIndexBuilder. finish(Descriptor descriptor, File file)
protected void
OnDiskIndexBuilder. finish(Descriptor descriptor, Pair<java.nio.ByteBuffer,java.nio.ByteBuffer> range, File file, TermIterator terms)
boolean
OnDiskIndexBuilder. finish(File indexFile)
Finishes up index building process by creating/populating index file.void
OnDiskIndexBuilder. finish(Pair<java.nio.ByteBuffer,java.nio.ByteBuffer> range, File file, TermIterator terms)
Constructors in org.apache.cassandra.index.sasi.disk with parameters of type File Constructor Description OnDiskIndex(File index, AbstractType<?> cmp, com.google.common.base.Function<java.lang.Long,DecoratedKey> keyReader)
-
Uses of File in org.apache.cassandra.io
Constructors in org.apache.cassandra.io with parameters of type File Constructor Description FSError(java.lang.String message, java.lang.Throwable cause, File path)
FSError(java.lang.Throwable cause, File path)
FSReadError(java.lang.String message, java.lang.Throwable cause, File path)
FSReadError(java.lang.Throwable cause, File path)
FSWriteError(java.lang.String message, java.lang.Throwable cause, File path)
FSWriteError(java.lang.Throwable cause, File path)
-
Uses of File in org.apache.cassandra.io.compress
Fields in org.apache.cassandra.io.compress declared as File Modifier and Type Field Description File
CompressionMetadata. chunksIndexFile
Methods in org.apache.cassandra.io.compress with parameters of type File Modifier and Type Method Description static CompressionMetadata
CompressionMetadata. open(File chunksIndexFile, long compressedLength, boolean hasMaxCompressedSize)
static CompressionMetadata.Writer
CompressionMetadata.Writer. open(CompressionParams parameters, File file)
Constructors in org.apache.cassandra.io.compress with parameters of type File Constructor Description CompressedSequentialWriter(File file, File offsetsFile, File digestFile, SequentialWriterOption option, CompressionParams parameters, MetadataCollector sstableMetadataCollector)
Create CompressedSequentialWriter without digest file.CompressionMetadata(File chunksIndexFile, CompressionParams parameters, Memory chunkOffsets, long chunkOffsetsSize, long dataLength, long compressedFileLength)
-
Uses of File in org.apache.cassandra.io.sstable
Fields in org.apache.cassandra.io.sstable declared as File Modifier and Type Field Description File
Descriptor. directory
canonicalized path to the directory where SSTable residesFile
CorruptSSTableException. path
Methods in org.apache.cassandra.io.sstable that return File Modifier and Type Method Description File
Descriptor. baseFile()
File
Descriptor. fileFor(Component component)
File
Descriptor. tmpFileFor(Component component)
File
Descriptor. tmpFileForStreaming(Component component)
Methods in org.apache.cassandra.io.sstable that return types with arguments of type File Modifier and Type Method Description java.util.List<File>
Descriptor. getTemporaryFiles()
Return any temporary files found in the directoryMethods in org.apache.cassandra.io.sstable with parameters of type File Modifier and Type Method Description static Component
Descriptor. componentFromFile(File file)
static Descriptor
Descriptor. fromFile(File file)
Parse a sstable filename into a Descriptor.static Pair<Descriptor,Component>
Descriptor. fromFileWithComponent(File file)
Parse a sstable filename, extracting both theDescriptor
andComponent
part.static Pair<Descriptor,Component>
Descriptor. fromFileWithComponent(File file, boolean validateDirs)
static Pair<Descriptor,Component>
Descriptor. fromFileWithComponent(File file, java.lang.String keyspace, java.lang.String table)
Parse a sstable filename, extracting both theDescriptor
andComponent
part.CQLSSTableWriter.Builder
CQLSSTableWriter.Builder. inDirectory(File directory)
The directory where to write the sstables (mandatory option).static boolean
Descriptor. isValidFile(File file)
static Pair<Descriptor,Component>
SSTable. tryComponentFromFilename(File file)
Parse a sstable filename into both aDescriptor
andComponent
object.static Pair<Descriptor,Component>
SSTable. tryComponentFromFilename(File file, java.lang.String keyspace, java.lang.String table)
Parse a sstable filename into both aDescriptor
andComponent
object.static Descriptor
SSTable. tryDescriptorFromFile(File file)
Parse a sstable filename into aDescriptor
object.Constructors in org.apache.cassandra.io.sstable with parameters of type File Constructor Description CorruptSSTableException(java.lang.Throwable cause, File path)
Descriptor(java.lang.String version, File directory, java.lang.String ksname, java.lang.String cfname, SSTableId id, SSTableFormat<?,?> format)
Descriptor(Version version, File directory, java.lang.String ksname, java.lang.String cfname, SSTableId id)
Descriptor(File directory, java.lang.String ksname, java.lang.String cfname, SSTableId id)
A descriptor that assumes CURRENT_VERSION.Descriptor(File directory, java.lang.String ksname, java.lang.String cfname, SSTableId id, SSTableFormat<?,?> format)
Constructor for sstable writers only.SSTableLoader(File directory, SSTableLoader.Client client, OutputHandler outputHandler)
SSTableLoader(File directory, SSTableLoader.Client client, OutputHandler outputHandler, int connectionsPerHost, java.lang.String targetKeyspace)
SSTableLoader(File directory, SSTableLoader.Client client, OutputHandler outputHandler, int connectionsPerHost, java.lang.String targetKeyspace, java.lang.String targetTable)
-
Uses of File in org.apache.cassandra.io.sstable.format
Fields in org.apache.cassandra.io.sstable.format declared as File Modifier and Type Field Description protected File
SortedTableScrubber. destination
Methods in org.apache.cassandra.io.sstable.format with parameters of type File Modifier and Type Method Description static FileHandle.Builder
IndexComponent. fileBuilder(File file, IOOptions ioOptions, ChunkCache chunkCache)
-
Uses of File in org.apache.cassandra.io.sstable.format.big
Methods in org.apache.cassandra.io.sstable.format.big with parameters of type File Modifier and Type Method Description static IndexSummaryComponent
IndexSummaryComponent. load(File summaryFile, TableMetadata metadata)
Load index summary, first key and last key from Summary.db file if it exists.static Pair<DecoratedKey,DecoratedKey>
IndexSummaryComponent. loadFirstAndLastKey(File summaryFile, IPartitioner partitioner)
static IndexSummaryComponent
IndexSummaryComponent. loadOrDeleteCorrupted(File summaryFile, TableMetadata metadata)
void
IndexSummaryComponent. save(File summaryFile, boolean deleteOnFailure)
Save index summary to Summary.db file. -
Uses of File in org.apache.cassandra.io.sstable.format.bti
Methods in org.apache.cassandra.io.sstable.format.bti with parameters of type File Modifier and Type Method Description static Pair<DecoratedKey,DecoratedKey>
PartitionIndex. readFirstAndLastKey(File file, IPartitioner partitioner)
-
Uses of File in org.apache.cassandra.io.util
Fields in org.apache.cassandra.io.util declared as File Modifier and Type Field Description File
FileHandle.Builder. file
File
FileInputStreamPlus. file
Methods in org.apache.cassandra.io.util that return File Modifier and Type Method Description static File
FileUtils. createDeletableTempFile(java.lang.String prefix, java.lang.String suffix)
static File
FileUtils. createTempFile(java.lang.String prefix, java.lang.String suffix)
static File
FileUtils. createTempFile(java.lang.String prefix, java.lang.String suffix, File directory)
Pretty much likeFile.createTempFile(String, String, java.io.File)
, but with the guarantee that the "random" part of the generated file name betweenprefix
andsuffix
is a positive, increasinglong
value.File
ChannelProxy. file()
File
FileHandle. file()
File
SequentialWriter. getFile()
static File
FileUtils. getTempDir()
File[]
File. list()
File[]
File. list(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. list(java.util.function.Predicate<File> filter)
File[]
File. listUnchecked()
File[]
File. listUnchecked(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. listUnchecked(java.util.function.Predicate<File> filter)
File
File. parent()
File
File. toAbsolute()
File
File. toCanonical()
File[]
File. tryList()
File[]
File. tryList(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. tryList(java.util.function.Predicate<File> filter)
File
File. withSuffix(java.lang.String suffix)
Methods in org.apache.cassandra.io.util with parameters of type File Modifier and Type Method Description static void
FileUtils. append(File file, java.lang.String... lines)
static void
FileUtils. appendAndSync(File file, java.lang.String... lines)
int
File. compareTo(File that)
static void
FileUtils. copyWithConfirm(File from, File to)
static void
FileUtils. copyWithOutConfirm(File from, File to)
static void
FileUtils. createDirectory(File directory)
Deprecated.See CASSANDRA-16926static void
FileUtils. createHardLink(File from, File to)
static void
FileUtils. createHardLinkWithConfirm(File from, File to)
static void
FileUtils. createHardLinkWithoutConfirm(File from, File to)
static File
FileUtils. createTempFile(java.lang.String prefix, java.lang.String suffix, File directory)
Pretty much likeFile.createTempFile(String, String, java.io.File)
, but with the guarantee that the "random" part of the generated file name betweenprefix
andsuffix
is a positive, increasinglong
value.static void
FileUtils. delete(File... files)
Deprecated.See CASSANDRA-16926static void
FileUtils. deleteRecursive(File dir)
Deprecated.See CASSANDRA-16926static void
FileUtils. deleteRecursiveOnExit(File dir)
Deprecated.See CASSANDRA-16926static void
FileUtils. deleteRecursiveWithThrottle(File dir, com.google.common.util.concurrent.RateLimiter rateLimiter)
Deprecated.See CASSANDRA-16926static void
FileUtils. deleteWithConfirm(File file)
Deprecated.See CASSANDRA-16926static java.lang.Throwable
FileUtils. deleteWithConfirm(File file, java.lang.Throwable accumulate)
Deprecated.See CASSANDRA-16926static java.lang.Throwable
FileUtils. deleteWithConfirm(File file, java.lang.Throwable accumulate, com.google.common.util.concurrent.RateLimiter rateLimiter)
Deprecated.See CASSANDRA-16926static long
FileUtils. folderSize(File folder)
Get the size of a directory in bytesstatic int
FileUtils. getBlockSize(File directory)
static java.lang.String
FileUtils. getCanonicalPath(File file)
boolean
File. isAncestorOf(File child)
static boolean
FileUtils. isContained(File folder, File file)
Return true if file is contained in folderstatic boolean
FileUtils. isSubDirectory(File parent, File child)
Deprecated.See CASSANDRA-16926void
File. move(File to)
Atomically (if supported) rename/move this file toto
static RandomAccessReader
ChecksummedRandomAccessReader. open(File file, File crcFile)
static RandomAccessReader
RandomAccessReader. open(File file)
Open a RandomAccessReader (not compressed, not mmapped, no read throttling) that will own its channel.static java.nio.channels.FileChannel
ChannelProxy. openChannel(File file)
static java.util.List<java.lang.String>
FileUtils. readLines(File file)
static void
FileUtils. renameWithConfirm(File from, File to)
Deprecated.See CASSANDRA-16926static void
FileUtils. replace(File file, java.lang.String... lines)
boolean
File. tryMove(File to)
Try to rename the file atomically, if the system supports it.static void
FileUtils. write(File file, java.util.List<java.lang.String> lines, java.nio.file.StandardOpenOption... options)
Write lines to a file adding a newline to the end of each supplied line using the provided open options.void
ChecksumWriter. writeFullChecksum(File digestFile)
Method parameters in org.apache.cassandra.io.util with type arguments of type File Modifier and Type Method Description FileHandle
FileHandle.Builder. complete(java.util.function.Function<File,ChannelProxy> channelProxyFactory)
void
File. forEach(java.util.function.Consumer<File> forEach)
void
File. forEachRecursive(java.util.function.Consumer<File> forEach)
File[]
File. list(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. list(java.util.function.Predicate<File> filter)
java.lang.String[]
File. listNames(java.util.function.BiPredicate<File,java.lang.String> filter)
java.lang.String[]
File. listNamesUnchecked(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. listUnchecked(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. listUnchecked(java.util.function.Predicate<File> filter)
File[]
File. tryList(java.util.function.BiPredicate<File,java.lang.String> filter)
File[]
File. tryList(java.util.function.Predicate<File> filter)
java.lang.String[]
File. tryListNames(java.util.function.BiPredicate<File,java.lang.String> filter)
<T extends java.lang.Throwable>
java.lang.String[]File. tryListNames(java.util.function.BiPredicate<File,java.lang.String> filter, net.openhft.chronicle.core.util.ThrowingFunction<java.io.IOException,java.lang.String[],T> orElse)
Constructors in org.apache.cassandra.io.util with parameters of type File Constructor Description Builder(File file)
ChannelProxy(File file)
ChannelProxy(File file, java.nio.channels.FileChannel channel)
ChecksummedSequentialWriter(File file, File crcPath, File digestFile, SequentialWriterOption option)
ChecksumValidator(File dataFile, File crcFile)
File(File parent, java.lang.String child)
Construct a File representing the childchild
ofparent
FileDigestValidator(File dataFile, File digestFile)
FileInputStreamPlus(File file)
FileInputStreamPlus(File file, int bufferSize)
FileOutputStreamPlus(File file)
FileOutputStreamPlus(File file, File.WriteMode mode)
FileReader(File file)
FileWriter(File file)
FileWriter(File file, File.WriteMode mode)
SequentialWriter(File file)
Create heap-based, non-compressed SequenialWriter with default buffer size(64k).SequentialWriter(File file, SequentialWriterOption option)
Create SequentialWriter for given file with specific writer option.SequentialWriter(File file, SequentialWriterOption option, boolean strictFlushing)
Create SequentialWriter for given file with specific writer option. -
Uses of File in org.apache.cassandra.service
Methods in org.apache.cassandra.service with parameters of type File Modifier and Type Method Description static DataResurrectionCheck.Heartbeat
DataResurrectionCheck.Heartbeat. deserializeFromJsonFile(File file)
void
DataResurrectionCheck.Heartbeat. serializeToJsonFile(File outputFile)
-
Uses of File in org.apache.cassandra.service.paxos.uncommitted
Methods in org.apache.cassandra.service.paxos.uncommitted that return File Modifier and Type Method Description File
PaxosBallotTracker. getDirectory()
File
PaxosUncommittedTracker. getDirectory()
Methods in org.apache.cassandra.service.paxos.uncommitted with parameters of type File Modifier and Type Method Description static PaxosStateTracker
PaxosStateTracker. create(File[] directories)
static UncommittedDataFile
UncommittedDataFile. create(TableId tableId, File file, File crcFile, long generation)
static PaxosBallotTracker
PaxosBallotTracker. load(File directory)
static PaxosUncommittedTracker
PaxosUncommittedTracker. load(File dataDirectory)
static void
PaxosBallotTracker. truncate(File directory)
static void
PaxosUncommittedTracker. truncate(File dataDirectory)
Constructors in org.apache.cassandra.service.paxos.uncommitted with parameters of type File Constructor Description PaxosUncommittedTracker(File dataDirectory)
PaxosUncommittedTracker(File dataDirectory, com.google.common.collect.ImmutableMap<TableId,UncommittedTableData> tableStates)
-
Uses of File in org.apache.cassandra.service.snapshot
Methods in org.apache.cassandra.service.snapshot that return types with arguments of type File Modifier and Type Method Description java.util.Collection<File>
TableSnapshot. getDirectories()
java.util.Optional<File>
TableSnapshot. getManifestFile()
java.util.Optional<File>
TableSnapshot. getSchemaFile()
Methods in org.apache.cassandra.service.snapshot with parameters of type File Modifier and Type Method Description static SnapshotManifest
SnapshotManifest. deserializeFromJsonFile(File file)
void
SnapshotManifest. serializeToJsonFile(File outputFile)
Constructor parameters in org.apache.cassandra.service.snapshot with type arguments of type File Constructor Description TableSnapshot(java.lang.String keyspaceName, java.lang.String tableName, java.util.UUID tableId, java.lang.String tag, java.time.Instant createdAt, java.time.Instant expiresAt, java.util.Set<File> snapshotDirs, boolean ephemeral)
-
Uses of File in org.apache.cassandra.tools
Fields in org.apache.cassandra.tools declared as File Modifier and Type Field Description File
LoaderOptions. directory
-
Uses of File in org.apache.cassandra.triggers
Methods in org.apache.cassandra.triggers with parameters of type File Modifier and Type Method Description void
CustomClassLoader. addClassPath(File dir)
Constructors in org.apache.cassandra.triggers with parameters of type File Constructor Description CustomClassLoader(java.lang.ClassLoader parent, File classPathDir)
-
Uses of File in org.apache.cassandra.utils
Methods in org.apache.cassandra.utils that return File Modifier and Type Method Description static File
FBUtilities. cassandraTriggerDir()
static File
FBUtilities. getToolsOutputDirectory()
Methods in org.apache.cassandra.utils with parameters of type File Modifier and Type Method Description static <T> T
JsonUtils. deserializeFromJsonFile(java.lang.Class<T> tClass, File file)
static void
Throwables. perform(File against, Throwables.FileOpType opType, Throwables.DiscreteAction<? extends java.io.IOException>... actions)
static void
JsonUtils. serializeToJsonFile(java.lang.Object object, File outputFile)
static void
SyncUtil. trySyncDir(File dir)
-
Uses of File in org.apache.cassandra.utils.binlog
Methods in org.apache.cassandra.utils.binlog with parameters of type File Modifier and Type Method Description static java.lang.Throwable
BinLog. cleanDirectory(File directory, java.lang.Throwable accumulate)
-