Modifier and Type | Field and Description |
---|---|
static CFMetaData |
CFMetaData.BatchlogCf |
static CFMetaData |
CFMetaData.CompactionHistoryCf |
static CFMetaData |
CFMetaData.CompactionLogCf |
static CFMetaData |
CFMetaData.HintsCf |
static CFMetaData |
CFMetaData.IndexCf |
static CFMetaData |
CFMetaData.LocalCf |
static CFMetaData |
CFMetaData.PaxosCf |
static CFMetaData |
CFMetaData.PeerEventsCf |
static CFMetaData |
CFMetaData.PeersCf |
static CFMetaData |
CFMetaData.RangeXfersCf |
static CFMetaData |
CFMetaData.SchemaColumnFamiliesCf |
static CFMetaData |
CFMetaData.SchemaColumnsCf |
static CFMetaData |
CFMetaData.SchemaKeyspacesCf |
static CFMetaData |
CFMetaData.SchemaTriggersCf |
static CFMetaData |
CFMetaData.SchemaUserTypesCf |
static CFMetaData |
CFMetaData.SizeEstimatesCf |
static CFMetaData |
CFMetaData.SSTableActivityCF |
static CFMetaData |
CFMetaData.TraceEventsCf |
static CFMetaData |
CFMetaData.TraceSessionsCf |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
CFMetaData.addAllColumnDefinitions(java.util.Collection<ColumnDefinition> defs) |
CFMetaData |
CFMetaData.addColumnDefinition(ColumnDefinition def) |
CFMetaData |
CFMetaData.addOrReplaceColumnDefinition(ColumnDefinition def) |
CFMetaData |
CFMetaData.bloomFilterFpChance(java.lang.Double prop) |
CFMetaData |
CFMetaData.caching(CachingOptions prop) |
CFMetaData |
CFMetaData.comment(java.lang.String prop) |
CFMetaData |
CFMetaData.compactionStrategyClass(java.lang.Class<? extends AbstractCompactionStrategy> prop) |
CFMetaData |
CFMetaData.compactionStrategyOptions(java.util.Map<java.lang.String,java.lang.String> prop) |
static CFMetaData |
CFMetaData.compile(java.lang.String cql,
java.lang.String keyspace) |
CFMetaData |
CFMetaData.compressionParameters(CompressionParameters prop) |
CFMetaData |
CFMetaData.copy() |
CFMetaData |
CFMetaData.copy(java.util.UUID newCfId)
Clones the CFMetaData, but sets a different cfId
|
CFMetaData |
CFMetaData.dcLocalReadRepairChance(double prop) |
CFMetaData |
CFMetaData.defaultTimeToLive(int prop) |
CFMetaData |
CFMetaData.defaultValidator(AbstractType<?> prop) |
static CFMetaData |
CFMetaData.denseCFMetaData(java.lang.String keyspace,
java.lang.String name,
AbstractType<?> comp) |
static CFMetaData |
CFMetaData.denseCFMetaData(java.lang.String keyspace,
java.lang.String name,
AbstractType<?> comp,
AbstractType<?> subcc) |
CFMetaData |
CFMetaData.droppedColumns(java.util.Map<ColumnIdentifier,java.lang.Long> cols) |
static CFMetaData |
CFMetaData.fromSchema(UntypedResultSet.Row result)
Deserialize CF metadata from low-level representation
|
static CFMetaData |
CFMetaData.fromThrift(CfDef cf_def) |
static CFMetaData |
CFMetaData.fromThriftCqlRow(CqlRow cf,
CqlResult columnsRes)
Create CFMetaData from thrift
CqlRow that contains columns from schema_columnfamilies. |
static CFMetaData |
CFMetaData.fromThriftForUpdate(CfDef cf_def,
CFMetaData toUpdate) |
CFMetaData |
CFMetaData.gcGraceSeconds(int prop) |
CFMetaData |
Schema.getCFMetaData(Descriptor descriptor) |
CFMetaData |
Schema.getCFMetaData(java.lang.String keyspaceName,
java.lang.String cfName)
Given a keyspace name & column family name, get the column family
meta data.
|
CFMetaData |
Schema.getCFMetaData(java.util.UUID cfId)
Get ColumnFamily metadata by its identifier
|
CFMetaData |
CFMetaData.isDense(java.lang.Boolean prop) |
CFMetaData |
CFMetaData.keyValidator(AbstractType<?> prop) |
CFMetaData |
CFMetaData.maxCompactionThreshold(int prop) |
CFMetaData |
CFMetaData.maxIndexInterval(int prop) |
CFMetaData |
CFMetaData.memtableFlushPeriod(int prop) |
CFMetaData |
CFMetaData.minCompactionThreshold(int prop) |
CFMetaData |
CFMetaData.minIndexInterval(int prop) |
static CFMetaData |
CFMetaData.newIndexMetadata(CFMetaData parent,
ColumnDefinition info,
CellNameType indexComparator)
Creates CFMetaData for secondary index CF.
|
CFMetaData |
CFMetaData.readRepairChance(double prop) |
CFMetaData |
CFMetaData.rebuild() |
CFMetaData |
CFMetaData.reloadSecondaryIndexMetadata(CFMetaData parent) |
static CFMetaData |
CFMetaData.sparseCFMetaData(java.lang.String keyspace,
java.lang.String name,
AbstractType<?> comp) |
CFMetaData |
CFMetaData.speculativeRetry(CFMetaData.SpeculativeRetry prop) |
CFMetaData |
CFMetaData.triggers(java.util.Map<java.lang.String,TriggerDefinition> prop) |
CFMetaData |
CFMetaData.validate() |
Modifier and Type | Method and Description |
---|---|
java.util.Map<java.lang.String,CFMetaData> |
KSMetaData.cfMetaData() |
static java.util.Map<java.lang.String,CFMetaData> |
KSMetaData.deserializeColumnFamilies(Row row)
Deserialize ColumnFamilies from low-level schema representation, all of them belong to the same keyspace
|
java.util.Map<java.lang.String,CFMetaData> |
Schema.getKeyspaceMetaData(java.lang.String keyspaceName)
Get metadata about keyspace inner ColumnFamilies
|
Modifier and Type | Method and Description |
---|---|
static ColumnDefinition |
ColumnDefinition.clusteringKeyDef(CFMetaData cfm,
java.nio.ByteBuffer name,
AbstractType<?> validator,
java.lang.Integer componentIndex) |
static ColumnDefinition |
ColumnDefinition.compactValueDef(CFMetaData cfm,
java.nio.ByteBuffer name,
AbstractType<?> validator) |
static KSMetaData |
KSMetaData.fromThrift(KsDef ksd,
CFMetaData... cfDefs) |
static CFMetaData |
CFMetaData.fromThriftForUpdate(CfDef cf_def,
CFMetaData toUpdate) |
void |
Schema.load(CFMetaData cfm)
Load individual ColumnFamily Definition to the schema
(to make ColumnFamily lookup faster)
|
static CFMetaData |
CFMetaData.newIndexMetadata(CFMetaData parent,
ColumnDefinition info,
CellNameType indexComparator)
Creates CFMetaData for secondary index CF.
|
static ColumnDefinition |
ColumnDefinition.partitionKeyDef(CFMetaData cfm,
java.nio.ByteBuffer name,
AbstractType<?> validator,
java.lang.Integer componentIndex) |
void |
Schema.purge(CFMetaData cfm)
Used for ColumnFamily data eviction out from the schema
|
static ColumnDefinition |
ColumnDefinition.regularDef(CFMetaData cfm,
java.nio.ByteBuffer name,
AbstractType<?> validator,
java.lang.Integer componentIndex) |
CFMetaData |
CFMetaData.reloadSecondaryIndexMetadata(CFMetaData parent) |
static ColumnDefinition |
ColumnDefinition.staticDef(CFMetaData cfm,
java.nio.ByteBuffer name,
AbstractType<?> validator,
java.lang.Integer componentIndex) |
static KSMetaData |
KSMetaData.testMetadata(java.lang.String name,
java.lang.Class<? extends AbstractReplicationStrategy> strategyClass,
java.util.Map<java.lang.String,java.lang.String> strategyOptions,
CFMetaData... cfDefs) |
static KSMetaData |
KSMetaData.testMetadataNotDurable(java.lang.String name,
java.lang.Class<? extends AbstractReplicationStrategy> strategyClass,
java.util.Map<java.lang.String,java.lang.String> strategyOptions,
CFMetaData... cfDefs) |
Mutation |
CFMetaData.toSchemaUpdate(CFMetaData newState,
long modificationTimestamp,
boolean fromThrift)
Create schema mutations to update this metadata to provided new state.
|
void |
CFMetaData.validateCompatility(CFMetaData cfm) |
Modifier and Type | Method and Description |
---|---|
static KSMetaData |
KSMetaData.cloneWith(KSMetaData ksm,
java.lang.Iterable<CFMetaData> cfDefs) |
static KSMetaData |
KSMetaData.fromSchema(Row row,
java.lang.Iterable<CFMetaData> cfms,
UTMetaData userTypes)
Deserialize only Keyspace attributes without nested ColumnFamilies
|
static KSMetaData |
KSMetaData.newKeyspace(java.lang.String name,
java.lang.Class<? extends AbstractReplicationStrategy> strategyClass,
java.util.Map<java.lang.String,java.lang.String> options,
boolean durablesWrites,
java.lang.Iterable<CFMetaData> cfDefs) |
Constructor and Description |
---|
ColumnDefinition(CFMetaData cfm,
java.nio.ByteBuffer name,
AbstractType<?> validator,
java.lang.Integer componentIndex,
ColumnDefinition.Kind kind) |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
DropIndexStatement.generateCFMetadataUpdate() |
CFMetaData |
AlterTableStatement.getCFMetaData(java.lang.String keyspace) |
CFMetaData |
CreateColumnFamilyStatement.getCFMetaData(java.lang.String keyspace,
java.util.List<java.nio.ByteBuffer> variables)
Returns a CFMetaData instance based on the parameters parsed from this
CREATE statement, or defaults where applicable. |
Modifier and Type | Method and Description |
---|---|
static void |
AlterTableStatement.applyPropertiesToCFMetadata(CFMetaData cfm,
CFPropDefs cfProps) |
void |
SelectStatement.extractKeyAliasFromColumns(CFMetaData cfm) |
void |
WhereClause.extractKeysFromColumns(CFMetaData cfm) |
Mutation |
DeleteStatement.mutationForKey(java.nio.ByteBuffer key,
java.lang.String keyspace,
java.lang.Long timestamp,
ThriftClientState clientState,
java.util.List<java.nio.ByteBuffer> variables,
CFMetaData metadata) |
static void |
QueryProcessor.validateColumn(CFMetaData metadata,
CellName name,
java.nio.ByteBuffer value) |
static void |
QueryProcessor.validateKeyAlias(CFMetaData cfm,
java.lang.String key) |
Modifier and Type | Field and Description |
---|---|
CFMetaData |
UpdateParameters.metadata |
Modifier and Type | Method and Description |
---|---|
int |
Attributes.getTimeToLive(QueryOptions options,
CFMetaData metadata) |
static void |
Attributes.maybeApplyExpirationDateOverflowPolicy(CFMetaData metadata,
int ttl,
boolean isDefaultTTL) |
ColumnIdentifier |
ColumnIdentifier.Raw.prepare(CFMetaData cfm) |
Constructor and Description |
---|
UpdateParameters(CFMetaData metadata,
QueryOptions options,
long timestamp,
int ttl,
java.util.Map<java.nio.ByteBuffer,CQL3Row> prefetchedLists) |
Constructor and Description |
---|
TokenFct(CFMetaData cfm) |
Modifier and Type | Field and Description |
---|---|
CFMetaData |
ModificationStatement.cfm |
CFMetaData |
SelectStatement.cfm |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
CreateTableStatement.getCFMetaData()
Returns a CFMetaData instance based on the parameters parsed from this
CREATE statement, or defaults where applicable. |
Modifier and Type | Method and Description |
---|---|
void |
CreateTableStatement.applyPropertiesTo(CFMetaData cfmd) |
void |
CFPropDefs.applyToCFMetadata(CFMetaData cfm) |
protected static SelectionColumnMapping |
SelectionColumnMapping.countMapping(CFMetaData cfm,
ColumnIdentifier countAlias) |
static Selection |
Selection.fromSelectors(CFMetaData cfm,
java.util.List<RawSelector> rawSelectors) |
IndexTarget |
IndexTarget.Raw.prepare(CFMetaData cfm) |
Selectable |
Selectable.Raw.prepare(CFMetaData cfm) |
Selectable.WritetimeOrTTL |
Selectable.WritetimeOrTTL.Raw.prepare(CFMetaData cfm) |
Selectable.WithFunction |
Selectable.WithFunction.Raw.prepare(CFMetaData cfm) |
Selectable.WithFieldSelection |
Selectable.WithFieldSelection.Raw.prepare(CFMetaData cfm) |
protected ModificationStatement |
DeleteStatement.Parsed.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected abstract ModificationStatement |
ModificationStatement.Parsed.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedInsert.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedUpdate.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
static Selection |
Selection.wildcard(CFMetaData cfm,
boolean isCount,
ColumnIdentifier countAlias) |
Constructor and Description |
---|
CQL3CasRequest(CFMetaData cfm,
java.nio.ByteBuffer key,
boolean isBatch) |
ModificationStatement(ModificationStatement.StatementType type,
int boundTerms,
CFMetaData cfm,
Attributes attrs) |
SelectStatement(CFMetaData cfm,
int boundTerms,
SelectStatement.Parameters parameters,
Selection selection,
Term limit) |
Modifier and Type | Field and Description |
---|---|
protected CFMetaData |
ColumnFamily.metadata |
CFMetaData |
ColumnFamilyStore.metadata |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
ColumnFamily.metadata() |
Modifier and Type | Method and Description |
---|---|
ColumnFamily |
Mutation.addOrGet(CFMetaData cfm) |
CellName |
AbstractNativeCell.copy(CFMetaData cfm,
AbstractAllocator allocator) |
ColumnIdentifier |
AbstractNativeCell.cql3ColumnName(CFMetaData metadata) |
static Cell |
AbstractCell.create(CellName name,
java.nio.ByteBuffer value,
long timestamp,
int ttl,
CFMetaData metadata) |
T |
ColumnFamily.Factory.create(CFMetaData metadata) |
T |
ColumnFamily.Factory.create(CFMetaData metadata,
boolean insertReversed) |
abstract T |
ColumnFamily.Factory.create(CFMetaData metadata,
boolean insertReversed,
int initialCapacity)
Returns a (initially empty) column map whose columns are sorted
according to the provided comparator.
|
static ColumnFamilyStore |
ColumnFamilyStore.createColumnFamilyStore(Keyspace keyspace,
java.lang.String columnFamily,
IPartitioner partitioner,
CFMetaData metadata) |
static AbstractType<?> |
SuperColumns.getComparatorFor(CFMetaData metadata,
boolean subColumn) |
static AbstractType<?> |
SuperColumns.getComparatorFor(CFMetaData metadata,
java.nio.ByteBuffer superColumn) |
static PaxosState |
SystemKeyspace.loadPaxosState(java.nio.ByteBuffer key,
CFMetaData metadata,
long now) |
Cell |
BufferCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
CounterCell |
BufferCounterCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
Cell |
BufferCounterUpdateCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
DeletedCell |
BufferDeletedCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
ExpiringCell |
BufferExpiringCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
Cell |
Cell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
CounterCell |
CounterCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
DeletedCell |
DeletedCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
ExpiringCell |
ExpiringCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
Cell |
NativeCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
CounterCell |
NativeCounterCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
DeletedCell |
NativeDeletedCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
ExpiringCell |
NativeExpiringCell.localCopy(CFMetaData metadata,
AbstractAllocator allocator) |
Cell |
BufferCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
CounterCell |
BufferCounterCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
Cell |
BufferCounterUpdateCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
DeletedCell |
BufferDeletedCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
ExpiringCell |
BufferExpiringCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
Cell |
Cell.localCopy(CFMetaData metaData,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
CounterCell |
CounterCell.localCopy(CFMetaData metaData,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
DeletedCell |
DeletedCell.localCopy(CFMetaData metaData,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
ExpiringCell |
ExpiringCell.localCopy(CFMetaData metaData,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
Cell |
NativeCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
CounterCell |
NativeCounterCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
DeletedCell |
NativeDeletedCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
ExpiringCell |
NativeExpiringCell.localCopy(CFMetaData metadata,
MemtableAllocator allocator,
OpOrder.Group opGroup) |
static int |
SystemKeyspace.paxosTtl(CFMetaData metadata) |
static void |
ColumnFamilyStore.removeUnfinishedCompactionLeftovers(CFMetaData metadata,
java.util.Map<java.lang.Integer,java.util.UUID> unfinishedCompactions)
Replacing compacted sstables is atomic as far as observers of DataTracker are concerned, but not on the
filesystem: first the new sstables are renamed to "live" status (i.e., the tmp marker is removed), then
their ancestors are removed.
|
static void |
ColumnFamilyStore.scrubDataDirectories(CFMetaData metadata)
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files
and compacted sstables.
|
void |
ConsistencyLevel.validateCounterForWrite(CFMetaData metadata) |
void |
AbstractCell.validateFields(CFMetaData metadata) |
void |
BufferCounterCell.validateFields(CFMetaData metadata) |
void |
BufferDeletedCell.validateFields(CFMetaData metadata) |
void |
BufferExpiringCell.validateFields(CFMetaData metadata) |
void |
NativeCounterCell.validateFields(CFMetaData metadata) |
void |
NativeDeletedCell.validateFields(CFMetaData metadata) |
void |
NativeExpiringCell.validateFields(CFMetaData metadata) |
void |
OnDiskAtom.validateFields(CFMetaData metadata) |
void |
RangeTombstone.validateFields(CFMetaData metadata) |
void |
AbstractCell.validateName(CFMetaData metadata) |
Constructor and Description |
---|
ArrayBackedSortedColumns(CFMetaData metadata,
boolean reversed) |
ColumnFamily(CFMetaData metadata) |
Directories(CFMetaData metadata)
Create Directories of given ColumnFamily.
|
Paging(AbstractBounds<RowPosition> range,
SliceQueryFilter filter,
Composite columnStart,
Composite columnFinish,
CFMetaData cfm) |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
CompactionInfo.getCFMetaData() |
Modifier and Type | Method and Description |
---|---|
void |
WrappingCompactionStrategy.maybeReloadCompactionStrategy(CFMetaData metadata) |
void |
WrappingCompactionStrategy.reloadCompactionStrategy(CFMetaData metadata) |
Modifier and Type | Method and Description |
---|---|
void |
CompactionManager.interruptCompactionFor(java.lang.Iterable<CFMetaData> columnFamilies,
boolean interruptValidation)
Try to stop all of the compactions for given ColumnFamilies.
|
Constructor and Description |
---|
CompactionInfo(CFMetaData cfm,
OperationType tasktype,
long bytesComplete,
long totalBytes) |
CompactionInfo(CFMetaData cfm,
OperationType tasktype,
long completed,
long total,
java.lang.String unit) |
Modifier and Type | Method and Description |
---|---|
Composite |
BoundedComposite.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
CellName.copy(CFMetaData cfm,
AbstractAllocator allocator) |
Composite |
Composite.copy(CFMetaData cfm,
AbstractAllocator allocator) |
Composite |
CompoundComposite.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
CompoundDenseCellName.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
CompoundSparseCellName.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
CompoundSparseCellName.WithCollection.copy(CFMetaData cfm,
AbstractAllocator allocator) |
Composite |
SimpleComposite.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
SimpleDenseCellName.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
SimpleSparseCellName.copy(CFMetaData cfm,
AbstractAllocator allocator) |
CellName |
SimpleSparseInternedCellName.copy(CFMetaData cfm,
AbstractAllocator allocator) |
ColumnIdentifier |
CellName.cql3ColumnName(CFMetaData metadata)
The name of the CQL3 column this cell represents.
|
ColumnIdentifier |
CompoundDenseCellName.cql3ColumnName(CFMetaData metadata) |
ColumnIdentifier |
CompoundSparseCellName.cql3ColumnName(CFMetaData metadata) |
ColumnIdentifier |
SimpleDenseCellName.cql3ColumnName(CFMetaData metadata) |
ColumnIdentifier |
SimpleSparseCellName.cql3ColumnName(CFMetaData metadata) |
CQL3Row.Builder |
CellNameType.CQL3RowBuilder(CFMetaData metadata,
long now)
Creates a new CQL3Row builder for this type.
|
CQL3Row.Builder |
CompoundDenseCellNameType.CQL3RowBuilder(CFMetaData metadata,
long now) |
CQL3Row.Builder |
CompoundSparseCellNameType.CQL3RowBuilder(CFMetaData metadata,
long now) |
CQL3Row.Builder |
SimpleDenseCellNameType.CQL3RowBuilder(CFMetaData metadata,
long now) |
CQL3Row.Builder |
SimpleSparseCellNameType.CQL3RowBuilder(CFMetaData metadata,
long now) |
protected static CQL3Row.Builder |
AbstractCellNameType.makeSparseCQL3RowBuilder(CFMetaData cfMetaData,
CellNameType type,
long now) |
Modifier and Type | Method and Description |
---|---|
boolean |
SliceQueryFilter.hasStaticSlice(CFMetaData cfm) |
Pair<SliceQueryFilter,SliceQueryFilter> |
SliceQueryFilter.splitOutStaticSlice(CFMetaData cfm)
Splits this filter into two SliceQueryFilters: one that slices only the static columns, and one that slices the
remainder of the normal data.
|
SliceQueryFilter |
SliceQueryFilter.withUpdatedStart(Composite newStart,
CFMetaData cfm) |
Modifier and Type | Method and Description |
---|---|
static CellNameType |
SecondaryIndex.getIndexComparator(CFMetaData baseMetadata,
ColumnDefinition cdef)
Returns the index comparator for index backed by CFS, or null.
|
Modifier and Type | Method and Description |
---|---|
static CellNameType |
CompositesIndexOnClusteringKey.buildIndexComparator(CFMetaData baseMetadata,
ColumnDefinition columnDef) |
static CellNameType |
CompositesIndexOnCollectionKey.buildIndexComparator(CFMetaData baseMetadata,
ColumnDefinition columnDef) |
static CellNameType |
CompositesIndexOnCollectionValue.buildIndexComparator(CFMetaData baseMetadata,
ColumnDefinition columnDef) |
static CellNameType |
CompositesIndexOnPartitionKey.buildIndexComparator(CFMetaData baseMetadata,
ColumnDefinition columnDef) |
static CellNameType |
CompositesIndexOnRegular.buildIndexComparator(CFMetaData baseMetadata,
ColumnDefinition columnDef) |
static CellNameType |
CompositesIndex.getIndexComparator(CFMetaData baseMetadata,
ColumnDefinition cfDef) |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
AbstractBulkRecordWriter.ExternalClient.getCFMetaData(java.lang.String keyspace,
java.lang.String cfName) |
Modifier and Type | Method and Description |
---|---|
protected CFMetaData |
AbstractCassandraStorage.getCFMetaData(java.lang.String ks,
java.lang.String cf,
Cassandra.Client client)
get CFMetaData of a column family
|
Modifier and Type | Method and Description |
---|---|
void |
CompressionParameters.setLiveMetadata(CFMetaData liveMetadata) |
Modifier and Type | Field and Description |
---|---|
protected CFMetaData |
AbstractSSTableSimpleWriter.metadata |
CFMetaData |
SSTable.metadata |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
CQLSSTableWriter.getCFMetaData() |
abstract CFMetaData |
SSTableLoader.Client.getCFMetaData(java.lang.String keyspace,
java.lang.String cfName)
Validate that
keyspace is an existing keyspace and cfName one of its existing column family. |
Modifier and Type | Method and Description |
---|---|
long |
SSTableWriter.appendFromStream(DecoratedKey key,
CFMetaData metadata,
java.io.DataInput in,
Descriptor.Version version) |
static SSTableReader |
SSTableReader.open(Descriptor desc,
CFMetaData metadata) |
static SSTableReader |
SSTableReader.open(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner) |
static SSTableReader |
SSTableReader.open(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner,
boolean validate,
boolean trackHotness) |
static java.util.Collection<SSTableReader> |
SSTableReader.openAll(java.util.Set<java.util.Map.Entry<Descriptor,java.util.Set<Component>>> entries,
CFMetaData metadata,
IPartitioner partitioner) |
static SSTableReader |
SSTableReader.openForBatch(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner)
Open SSTable reader to be used in batch mode(such as sstableloader).
|
static SSTableReader |
SSTableReader.openNoValidation(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata) |
Constructor and Description |
---|
AbstractSSTableSimpleWriter(java.io.File directory,
CFMetaData metadata,
IPartitioner partitioner) |
SSTable(Descriptor descriptor,
CFMetaData metadata,
IPartitioner partitioner) |
SSTable(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner) |
SSTableSimpleUnsortedWriter(java.io.File directory,
CFMetaData metadata,
IPartitioner partitioner,
long bufferSizeInMB) |
SSTableSimpleWriter(java.io.File directory,
CFMetaData metadata,
IPartitioner partitioner) |
SSTableWriter(java.lang.String filename,
long keyCount,
long repairedAt,
CFMetaData metadata,
IPartitioner partitioner,
MetadataCollector sstableMetadataCollector) |
Modifier and Type | Method and Description |
---|---|
static boolean |
MmappedSegmentedFile.maybeRepair(CFMetaData metadata,
Descriptor descriptor,
IndexSummary indexSummary,
SegmentedFile.Builder ibuilder,
SegmentedFile.Builder dbuilder) |
Modifier and Type | Method and Description |
---|---|
static void |
MigrationManager.announceColumnFamilyUpdate(CFMetaData cfm,
boolean fromThrift) |
static void |
MigrationManager.announceColumnFamilyUpdate(CFMetaData cfm,
boolean fromThrift,
boolean announceLocally) |
static void |
MigrationManager.announceNewColumnFamily(CFMetaData cfm) |
static void |
MigrationManager.announceNewColumnFamily(CFMetaData cfm,
boolean announceLocally) |
void |
MigrationManager.notifyCreateColumnFamily(CFMetaData cfm) |
void |
MigrationManager.notifyDropColumnFamily(CFMetaData cfm) |
void |
MigrationManager.notifyUpdateColumnFamily(CFMetaData cfm,
boolean columnsDidChange) |
Modifier and Type | Method and Description |
---|---|
static Commit |
Commit.emptyCommit(java.nio.ByteBuffer key,
CFMetaData metadata) |
static Commit |
Commit.newPrepare(java.nio.ByteBuffer key,
CFMetaData metadata,
java.util.UUID ballot) |
java.lang.Iterable<java.net.InetAddress> |
PrepareCallback.replicasMissingMostRecentCommit(CFMetaData metadata,
long now) |
Constructor and Description |
---|
PaxosState(java.nio.ByteBuffer key,
CFMetaData metadata) |
PrepareCallback(java.nio.ByteBuffer key,
CFMetaData metadata,
int targets,
ConsistencyLevel consistency) |
Modifier and Type | Method and Description |
---|---|
static CFMetaData |
ThriftValidation.validateColumnFamily(java.lang.String keyspaceName,
java.lang.String cfName) |
static CFMetaData |
ThriftValidation.validateColumnFamily(java.lang.String keyspaceName,
java.lang.String cfName,
boolean isCommutativeOp) |
Modifier and Type | Method and Description |
---|---|
static IDiskAtomFilter |
ThriftValidation.asIFilter(SlicePredicate sp,
CFMetaData metadata,
java.nio.ByteBuffer superColumn) |
static void |
ThriftValidation.validateColumnData(CFMetaData metadata,
java.nio.ByteBuffer key,
java.nio.ByteBuffer scName,
Column column)
Validates the data part of the column (everything in the column object but the name, which is assumed to be valid)
|
static void |
ThriftValidation.validateColumnNames(CFMetaData metadata,
ColumnParent column_parent,
java.lang.Iterable<java.nio.ByteBuffer> column_names) |
static void |
ThriftValidation.validateColumnOrSuperColumn(CFMetaData metadata,
java.nio.ByteBuffer key,
ColumnOrSuperColumn cosc) |
static void |
ThriftValidation.validateColumnParent(CFMetaData metadata,
ColumnParent column_parent) |
static void |
ThriftValidation.validateColumnPath(CFMetaData metadata,
ColumnPath column_path)
validates all parts of the path to the column, including the column name
|
static void |
ThriftValidation.validateDeletion(CFMetaData metadata,
Deletion del) |
static boolean |
ThriftValidation.validateFilterClauses(CFMetaData metadata,
java.util.List<IndexExpression> index_clause) |
static void |
ThriftValidation.validateIndexClauses(CFMetaData metadata,
IndexClause index_clause) |
static void |
ThriftValidation.validateKey(CFMetaData metadata,
java.nio.ByteBuffer key) |
static void |
ThriftValidation.validateKeyRange(CFMetaData metadata,
java.nio.ByteBuffer superColumn,
KeyRange range) |
static void |
ThriftValidation.validateMutation(CFMetaData metadata,
java.nio.ByteBuffer key,
Mutation mut) |
static void |
ThriftValidation.validatePredicate(CFMetaData metadata,
ColumnParent column_parent,
SlicePredicate predicate) |
static void |
ThriftValidation.validateRange(CFMetaData metadata,
ColumnParent column_parent,
SliceRange range) |
static void |
ThriftValidation.validateSlicePredicate(CFMetaData metadata,
java.nio.ByteBuffer scName,
SlicePredicate predicate) |
Modifier and Type | Method and Description |
---|---|
CFMetaData |
BulkLoader.ExternalClient.getCFMetaData(java.lang.String keyspace,
java.lang.String cfName) |
Modifier and Type | Method and Description |
---|---|
static void |
SSTableExport.enumeratekeys(Descriptor desc,
java.io.PrintStream outs,
CFMetaData metadata)
Enumerate row keys from an SSTableReader and write the result to a PrintStream.
|
static void |
SSTableExport.export(Descriptor desc,
java.io.PrintStream outs,
java.util.Collection<java.lang.String> toExport,
java.lang.String[] excludes,
CFMetaData metadata)
Export specific rows from an SSTable and write the resulting JSON to a PrintStream.
|
static void |
SSTableExport.export(Descriptor desc,
java.io.PrintStream outs,
java.lang.String[] excludes,
CFMetaData metadata)
Export an SSTable and write the resulting JSON to a PrintStream.
|
static void |
SSTableExport.export(Descriptor desc,
java.lang.String[] excludes,
CFMetaData metadata)
Export an SSTable and write the resulting JSON to standard out.
|
Modifier and Type | Method and Description |
---|---|
abstract Cell |
MemtableAllocator.clone(Cell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
Cell |
MemtableBufferAllocator.clone(Cell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
Cell |
NativeAllocator.clone(Cell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
abstract CounterCell |
MemtableAllocator.clone(CounterCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
CounterCell |
MemtableBufferAllocator.clone(CounterCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
CounterCell |
NativeAllocator.clone(CounterCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
abstract DeletedCell |
MemtableAllocator.clone(DeletedCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
DeletedCell |
MemtableBufferAllocator.clone(DeletedCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
DeletedCell |
NativeAllocator.clone(DeletedCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
abstract ExpiringCell |
MemtableAllocator.clone(ExpiringCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
ExpiringCell |
MemtableBufferAllocator.clone(ExpiringCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
ExpiringCell |
NativeAllocator.clone(ExpiringCell cell,
CFMetaData cfm,
OpOrder.Group writeOp) |
Copyright © 2020 The Apache Software Foundation