Modifier and Type | Method and Description |
---|---|
File |
AutoSavingCache.getCacheCrcPath(java.lang.String version) |
File |
AutoSavingCache.getCacheDataPath(java.lang.String version) |
Modifier and Type | Method and Description |
---|---|
java.io.InputStream |
AutoSavingCache.IStreamFactory.getInputStream(File dataPath,
File crcPath) |
java.io.OutputStream |
AutoSavingCache.IStreamFactory.getOutputStream(File dataPath,
File crcPath) |
Modifier and Type | Method and Description |
---|---|
static File |
DatabaseDescriptor.getHintsDirectory() |
static File |
DatabaseDescriptor.getSerializedCachePath(CacheService.CacheType cacheType,
java.lang.String version,
java.lang.String extension) |
Modifier and Type | Field and Description |
---|---|
File |
Directories.DataDirectory.location |
Modifier and Type | Method and Description |
---|---|
static File |
Directories.getBackupsDirectory(Descriptor desc) |
static File |
Directories.getBackupsDirectory(File location) |
File |
Directories.getDirectoryForNewSSTables()
Basically the same as calling
Directories.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.
|
File |
Directories.getNewEphemeralSnapshotMarkerFile(java.lang.String snapshotName) |
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.
|
static File |
Directories.getSnapshotManifestFile(File snapshotDir) |
File |
Directories.getSnapshotManifestFile(java.lang.String snapshotName) |
static File |
Directories.getSnapshotSchemaFile(File snapshotDir) |
File |
Directories.getSnapshotSchemaFile(java.lang.String snapshotName) |
File |
Directories.getTemporaryWriteableDirectoryAsFile(long writeSize)
Returns a temporary subdirectory on allowed data directory
that _currently_ has
writeSize bytes as usable space. |
File |
Directories.getWriteableLocationAsFile(long writeSize)
Returns an allowed directory that _currently_ has
writeSize bytes as usable space. |
File |
Directories.getWriteableLocationToLoadFile(File sourceFile)
Returns a data directory to load the file
sourceFile . |
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.
|
Modifier and Type | Method and Description |
---|---|
java.util.List<File> |
Directories.getCFDirectories() |
static java.util.List<File> |
Directories.getKSChildDirectories(java.lang.String ksName) |
java.util.List<File> |
Directories.SSTableLister.listFiles() |
protected java.util.Map<java.lang.String,java.util.Set<File>> |
Directories.listSnapshotDirsByTag() |
Modifier and Type | Method and Description |
---|---|
static File |
Directories.getBackupsDirectory(File location) |
static File |
Directories.getSnapshotDirectory(File location,
java.lang.String snapshotName)
Returns directory to write snapshot.
|
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 file
sourceFile . |
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.Type format) |
Descriptor |
ColumnFamilyStore.newSSTableDescriptor(File directory,
Version version,
SSTableFormat.Type format) |
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.
|
Modifier and Type | Method and Description |
---|---|
protected TableSnapshot |
Directories.buildSnapshot(java.lang.String tag,
SnapshotManifest manifest,
java.util.Set<File> snapshotDirs) |
static void |
Directories.clearSnapshot(java.lang.String snapshotName,
java.util.List<File> tableDirectories,
com.google.common.util.concurrent.RateLimiter snapshotRateLimiter) |
protected static SnapshotManifest |
Directories.maybeLoadManifest(java.lang.String keyspace,
java.lang.String table,
java.lang.String tag,
java.util.Set<File> snapshotDirs) |
Constructor and Description |
---|
DataDirectory(File location) |
Modifier and Type | Method and Description |
---|---|
File |
CommitLogSegment.getCDCFile() |
File |
CommitLogSegment.getCDCIndexFile() |
static File |
CommitLogDescriptor.inferCdcIndexFile(File cdcCommitLogSegment)
Infer the corresponding cdc index file using its cdc commitlog file
|
Modifier and Type | Method and 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 file
|
void |
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 fully
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
File file,
CommitLogPosition minPosition,
boolean tolerateTruncation)
Reads all mutations from passed in file from minPosition
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
File file,
CommitLogPosition minPosition,
int mutationLimit,
boolean tolerateTruncation)
Reads mutations from file, handing them off to handler
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
File file,
int mutationLimit,
boolean tolerateTruncation)
Reads passed in file fully, up to mutationLimit count
|
int |
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) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
void |
Tracker.removeUnreadableSSTables(File directory)
Removes every SSTable in the directory from the Tracker's view.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
static ChecksummedDataInput |
ChecksummedDataInput.open(File file) |
Constructor and 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) |
Constructor and Description |
---|
SSTableIndex(ColumnIndex index,
File indexFile,
SSTableReader referent) |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
OnDiskIndex(File index,
AbstractType<?> cmp,
com.google.common.base.Function<java.lang.Long,DecoratedKey> keyReader) |
Constructor and 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) |
Constructor and Description |
---|
CompressedSequentialWriter(File file,
java.lang.String offsetsPath,
File digestFile,
SequentialWriterOption option,
CompressionParams parameters,
MetadataCollector sstableMetadataCollector)
Create CompressedSequentialWriter without digest file.
|
Modifier and Type | Field and Description |
---|---|
File |
Descriptor.directory
canonicalized path to the directory where SSTable resides
|
File |
CorruptSSTableException.path |
Modifier and Type | Method and Description |
---|---|
File |
Descriptor.fileFor(Component component) |
Modifier and Type | Method and Description |
---|---|
java.util.List<File> |
Descriptor.getTemporaryFiles()
Return any temporary files found in the directory
|
Modifier and Type | Method and Description |
---|---|
static Descriptor |
Descriptor.fromFilename(File file)
Parse a sstable filename into a Descriptor.
|
static Pair<Descriptor,Component> |
Descriptor.fromFilenameWithComponent(File file)
Parse a sstable filename, extracting both the
Descriptor and Component 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 a
Descriptor and Component object. |
static Descriptor |
SSTable.tryDescriptorFromFilename(File file)
Parse a sstable filename into a
Descriptor object. |
Constructor and Description |
---|
CorruptSSTableException(java.lang.Throwable cause,
File path) |
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.Type formatType)
Constructor for sstable writers only.
|
Descriptor(java.lang.String version,
File directory,
java.lang.String ksname,
java.lang.String cfname,
SSTableId id,
SSTableFormat.Type formatType) |
Descriptor(Version version,
File directory,
java.lang.String ksname,
java.lang.String cfname,
SSTableId id,
SSTableFormat.Type formatType) |
SSTableLoader(File directory,
SSTableLoader.Client client,
OutputHandler outputHandler) |
SSTableLoader(File directory,
SSTableLoader.Client client,
OutputHandler outputHandler,
int connectionsPerHost,
java.lang.String targetKeyspace) |
Modifier and Type | Method and 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 like
File.createTempFile(String, String, java.io.File) , but with
the guarantee that the "random" part of the generated file name between
prefix and suffix is a positive, increasing long value. |
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) |
Modifier and Type | Method and 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.createDirectory(File directory)
Deprecated.
|
static void |
FileUtils.createHardLink(File from,
File to) |
static void |
FileUtils.createHardLinkWithConfirm(File from,
File to) |
static File |
FileUtils.createTempFile(java.lang.String prefix,
java.lang.String suffix,
File directory)
Pretty much like
File.createTempFile(String, String, java.io.File) , but with
the guarantee that the "random" part of the generated file name between
prefix and suffix is a positive, increasing long value. |
static void |
FileUtils.delete(File... files)
Deprecated.
|
static void |
FileUtils.deleteRecursive(File dir)
Deprecated.
|
static void |
FileUtils.deleteRecursiveOnExit(File dir)
Deprecated.
|
static void |
FileUtils.deleteRecursiveWithThrottle(File dir,
com.google.common.util.concurrent.RateLimiter rateLimiter)
Deprecated.
|
static void |
FileUtils.deleteWithConfirm(File file)
Deprecated.
|
static java.lang.Throwable |
FileUtils.deleteWithConfirm(File file,
java.lang.Throwable accumulate)
Deprecated.
|
static java.lang.Throwable |
FileUtils.deleteWithConfirm(File file,
java.lang.Throwable accumulate,
com.google.common.util.concurrent.RateLimiter rateLimiter)
Deprecated.
|
static long |
FileUtils.folderSize(File folder)
Get the size of a directory in bytes
|
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 folder
|
static boolean |
FileUtils.isSubDirectory(File parent,
File child)
Deprecated.
|
void |
File.move(File to)
Atomically (if supported) rename/move this file to
to |
static RandomAccessReader |
RandomAccessReader.open(File file)
Open a RandomAccessReader (not compressed, not mmapped, no read throttling) that will own its channel.
|
static RandomAccessReader |
ChecksummedRandomAccessReader.open(File file,
File crcFile) |
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.
|
static 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) |
Modifier and Type | Method and Description |
---|---|
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> |
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) |
Constructor and Description |
---|
ChannelProxy(File file) |
ChecksummedSequentialWriter(File file,
File crcPath,
File digestFile,
SequentialWriterOption option) |
File(File parent,
java.lang.String child)
Construct a File representing the child
child of parent |
FileInputStreamPlus(File file) |
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.
|
Modifier and Type | Method and Description |
---|---|
static DataResurrectionCheck.Heartbeat |
DataResurrectionCheck.Heartbeat.deserializeFromJsonFile(File file) |
void |
DataResurrectionCheck.Heartbeat.serializeToJsonFile(File outputFile) |
Modifier and Type | Method and Description |
---|---|
File |
PaxosBallotTracker.getDirectory() |
File |
PaxosUncommittedTracker.getDirectory() |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
PaxosUncommittedTracker(File dataDirectory) |
PaxosUncommittedTracker(File dataDirectory,
com.google.common.collect.ImmutableMap<TableId,UncommittedTableData> tableStates) |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<File> |
TableSnapshot.getDirectories() |
java.util.Optional<File> |
TableSnapshot.getManifestFile() |
java.util.Optional<File> |
TableSnapshot.getSchemaFile() |
Modifier and Type | Method and Description |
---|---|
static SnapshotManifest |
SnapshotManifest.deserializeFromJsonFile(File file) |
void |
SnapshotManifest.serializeToJsonFile(File outputFile) |
Constructor and 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) |
Modifier and Type | Field and Description |
---|---|
File |
LoaderOptions.directory |
Modifier and Type | Method and Description |
---|---|
void |
CustomClassLoader.addClassPath(File dir) |
Constructor and Description |
---|
CustomClassLoader(java.lang.ClassLoader parent,
File classPathDir) |
Modifier and Type | Method and Description |
---|---|
static File |
FBUtilities.cassandraTriggerDir() |
static File |
FBUtilities.getToolsOutputDirectory() |
Modifier and Type | Method and Description |
---|---|
static <T> T |
FBUtilities.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 |
FBUtilities.serializeToJsonFile(java.lang.Object object,
File outputFile) |
static void |
SyncUtil.trySyncDir(File dir) |
Modifier and Type | Method and Description |
---|---|
static java.lang.Throwable |
BinLog.cleanDirectory(File directory,
java.lang.Throwable accumulate) |
Copyright © 2009-2022 The Apache Software Foundation