Package

com.outworkers.phantom

dsl

Permalink

package dsl

Linear Supertypes
DefaultImports, DefaultSASIOps, DeleteImplicits, KeySpaceConstruction, TopologyStrategies, UsingClauseOperations, Operators, SelectImplicits, CreateImplicits, TablePropertyClauses, CompressionStrategies, CompactionStrategies, ImplicitMechanism, ModifyMechanism, ScalaQueryContext, QueryContext[Promise, Future, Duration], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. dsl
  2. DefaultImports
  3. DefaultSASIOps
  4. DeleteImplicits
  5. KeySpaceConstruction
  6. TopologyStrategies
  7. UsingClauseOperations
  8. Operators
  9. SelectImplicits
  10. CreateImplicits
  11. TablePropertyClauses
  12. CompressionStrategies
  13. CompactionStrategies
  14. ImplicitMechanism
  15. ModifyMechanism
  16. ScalaQueryContext
  17. QueryContext
  18. AnyRef
  19. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. type Analyzer[M <: Mode] = builder.query.sasi.Analyzer[M]

    Permalink
    Definition Classes
    DefaultImports
  2. type Ascending = keys.Ascending

    Permalink
    Definition Classes
    DefaultImports
  3. implicit class BatchOps[Status <: ConsistencyBound] extends AnyRef

    Permalink
    Definition Classes
    QueryContext
  4. type CassandraConnection = connectors.CassandraConnection

    Permalink
    Definition Classes
    DefaultImports
  5. type CassandraTable[Owner <: CassandraTable[Owner, Record], Record] = phantom.CassandraTable[Owner, Record]

    Permalink
    Definition Classes
    DefaultImports
  6. implicit class CassandraTableStoreMethods[T <: CassandraTable[T, R], R] extends AnyRef

    Permalink
    Definition Classes
    QueryContext
  7. type ClusteringOrder = keys.ClusteringOrder

    Permalink
    Definition Classes
    DefaultImports
  8. implicit class CounterOperations[Owner <: CassandraTable[Owner, Record], Record] extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  9. implicit class CreateQueryOps[Table <: CassandraTable[Table, Record], Record, Consistency <: ConsistencyBound] extends MultiQueryInterface[Seq, F]

    Permalink
    Definition Classes
    QueryContext
  10. type CustomIndex[M <: Mode] = keys.SASIIndex[M]

    Permalink
    Definition Classes
    DefaultImports
  11. type Database[DB <: Database[DB]] = database.Database[DB]

    Permalink
    Definition Classes
    DefaultImports
  12. implicit class DatabaseOperation[DB <: Database[DB]] extends DbOps[P, F, DB, Timeout]

    Permalink
    Definition Classes
    QueryContext
  13. type DatabaseProvider[DB <: Database[DB]] = database.DatabaseProvider[DB]

    Permalink
    Definition Classes
    DefaultImports
  14. sealed class DateTieredCompactionStrategy extends CompactionProperties[DateTieredCompactionStrategy]

    Permalink
    Definition Classes
    CompactionStrategies
  15. type DateTime = org.joda.time.DateTime

    Permalink
    Definition Classes
    DefaultImports
  16. implicit class DateTimeAugmenter extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  17. class DeflateCompressor extends CompressionStrategy[DeflateCompressor]

    Permalink
    Definition Classes
    CompressionStrategies
  18. type Descending = keys.Descending

    Permalink
    Definition Classes
    DefaultImports
  19. type Entries = keys.Entries

    Permalink
    Definition Classes
    DefaultImports
  20. implicit class ExecutablePrepareQueryOps extends QueryInterface[F]

    Permalink
    Definition Classes
    QueryContext
  21. implicit class ExecutablePreparedSelect[Table <: CassandraTable[Table, _], R, Limit <: LimitBound] extends ResultQueryInterface[F, Table, R, Limit]

    Permalink
    Definition Classes
    QueryContext
  22. implicit final class ExecuteQueries[M[X] <: TraversableOnce[X]] extends AnyVal

    Permalink
  23. type Index = keys.Index

    Permalink
    Definition Classes
    DefaultImports
  24. type IteratorResult[R] = builder.query.execution.IteratorResult[R]

    Permalink
    Definition Classes
    DefaultImports
  25. type KeySpace = connectors.KeySpace

    Permalink
    Definition Classes
    DefaultImports
  26. implicit class KeySpaceAugmenter extends AnyRef

    Permalink

    Used when creating a ContactPoint to allow users to provide a single KeySpace derived query.

    Used when creating a ContactPoint to allow users to provide a single KeySpace derived query. When users want to provide a single argument to the ContactPoint#keySpace method, they can use the following syntax to generate a full keyspace initialisation query.

    KeySpace("test").builder.ifNotExists
    Definition Classes
    DefaultImports
  27. type KeySpaceDef = connectors.CassandraConnection

    Permalink
    Definition Classes
    DefaultImports
  28. type Keys = keys.Keys

    Permalink
    Definition Classes
    DefaultImports
  29. class LZ4Compressor extends CompressionStrategy[LZ4Compressor]

    Permalink
    Definition Classes
    CompressionStrategies
  30. sealed class LeveledCompactionStrategy extends CompactionProperties[LeveledCompactionStrategy]

    Permalink
    Definition Classes
    CompactionStrategies
  31. implicit class ListLikeModifyColumn[Owner <: CassandraTable[Owner, Record], Record, RR] extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  32. type ListResult[R] = builder.query.execution.ListResult[R]

    Permalink
    Definition Classes
    DefaultImports
  33. type ListValue[T] = builder.query.prepared.ListValue[T]

    Permalink
    Definition Classes
    QueryContext
  34. type LocalDate = org.joda.time.LocalDate

    Permalink
    Definition Classes
    DefaultImports
  35. implicit class MapKeyConditionals[T <: CassandraTable[T, R], R, K, V] extends AnyRef

    Permalink

    Definition used to cast an index map column with keys indexed to a query-able definition.

    Definition used to cast an index map column with keys indexed to a query-able definition. This will allow users to use "CONTAINS KEY" clauses to search for matches based on map keys.

    T

    The Cassandra table inner type.

    R

    The record type of the table.

    K

    The type of the key held in the map.

    V

    The type of the value held in the map.

    returns

    A MapConditionals class with CONTAINS KEY support.

    Definition Classes
    DefaultImports
  36. implicit class MapLikeModifyColumn[Owner <: CassandraTable[Owner, Record], Record, A, B] extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  37. sealed class NetworkTopologyStrategy extends ReplicationStrategy[NetworkTopologyStrategy]

    Permalink
    Definition Classes
    TopologyStrategies
  38. type NonTokenizingAnalyzer[M <: Mode] = builder.query.sasi.Analyzer.NonTokenizingAnalyzer[M]

    Permalink
    Definition Classes
    DefaultImports
  39. type PartitionKey = keys.PartitionKey

    Permalink
    Definition Classes
    DefaultImports
  40. implicit class PartitionTokenHelper[T] extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  41. type PrimaryKey = keys.PrimaryKey

    Permalink
    Definition Classes
    DefaultImports
  42. type Primitive[RR] = builder.primitives.Primitive[RR]

    Permalink
    Definition Classes
    DefaultImports
  43. implicit class QueryCollectionOps[M[X] <: TraversableOnce[X]] extends AnyRef

    Permalink
    Definition Classes
    QueryContext
  44. type QueryNotExecuted = ops.QueryNotExecuted

    Permalink
    Definition Classes
    QueryContext
  45. type RecordResult[R] = builder.query.execution.RecordResult[R]

    Permalink
    Definition Classes
    DefaultImports
  46. type ResultSet = phantom.ResultSet

    Permalink
    Definition Classes
    DefaultImports
  47. implicit class RichNumber extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  48. type RootConnector = connectors.RootConnector

    Permalink
    Definition Classes
    DefaultImports
  49. implicit class RootQueryOps[Table <: CassandraTable[Table, _], Record, Status <: ConsistencyBound] extends AnyRef

    Permalink
    Definition Classes
    QueryContext
  50. implicit class RootSelectBlockOps[Table <: CassandraTable[Table, _], Record] extends ResultQueryInterface[F, Table, Record, Unlimited]

    Permalink
    Definition Classes
    QueryContext
  51. type Row = phantom.Row

    Permalink
    Definition Classes
    DefaultImports
  52. type SASIIndex[M <: Mode] = keys.SASIIndex[M]

    Permalink
    Definition Classes
    DefaultImports
  53. implicit class SelectColumnOptional[Owner <: CassandraTable[Owner, Record], Record, T] extends SelectColumn[Option[T]]

    Permalink
    Definition Classes
    DefaultImports
  54. implicit class SelectColumnRequired[Owner <: CassandraTable[Owner, Record], Record, T] extends SelectColumn[T]

    Permalink
    Definition Classes
    DefaultImports
  55. implicit class SelectOps[Table <: CassandraTable[Table, _], Record, Limit <: LimitBound, Order <: OrderBound, Status <: ConsistencyBound, Chain <: WhereBound, PS <: HList] extends SelectQueryOps[Nothing, F, Table, Record, Limit, Order, Status, Chain, PS, Nothing]

    Permalink
    Definition Classes
    QueryContext
  56. type Session = datastax.driver.core.Session

    Permalink
    Definition Classes
    DefaultImports
  57. implicit class SetConditionals[T <: CassandraTable[T, R], R, RR] extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  58. implicit class SetLikeModifyColumn[Owner <: CassandraTable[Owner, Record], Record, RR] extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  59. sealed class SimpleStrategy extends ReplicationStrategy[SimpleStrategy]

    Permalink
    Definition Classes
    TopologyStrategies
  60. sealed class SizeTieredCompactionStrategy extends CompactionProperties[SizeTieredCompactionStrategy]

    Permalink
    Definition Classes
    CompactionStrategies
  61. class SnappyCompressor extends CompressionStrategy[SnappyCompressor]

    Permalink
    Definition Classes
    CompressionStrategies
  62. type StandardAnalyzer[M <: Mode] = builder.query.sasi.Analyzer.StandardAnalyzer[M]

    Permalink
    Definition Classes
    DefaultImports
  63. type StaticColumn = keys.StaticColumn

    Permalink
    Definition Classes
    DefaultImports
  64. type Table[Owner <: Table[Owner, Record], Record] = phantom.Table[Owner, Record]

    Permalink
    Definition Classes
    DefaultImports
  65. sealed class TimeWindowCompactionStrategy extends CompactionProperties[TimeWindowCompactionStrategy]

    Permalink
    Definition Classes
    CompactionStrategies
  66. type UUID = java.util.UUID

    Permalink
    Definition Classes
    DefaultImports
  67. implicit class UUIDAugmenter extends AnyRef

    Permalink
    Definition Classes
    DefaultImports
  68. implicit class VersionAugmenter extends AnyRef

    Permalink

    Augments Cassandra VersionNumber descriptors to support simple comparison of versions.

    Augments Cassandra VersionNumber descriptors to support simple comparison of versions. This allows for operations that can differ based on the Cassandra version used by the session.

    Definition Classes
    DefaultImports

Abstract Value Members

  1. abstract def blockAwait[T](f: F[T], timeout: Timeout): T

    Permalink

    An abstract implementation for blockingly waiting for future completion.

    An abstract implementation for blockingly waiting for future completion. We need this for synchronously prepared statements and other instances and a mechanism to abstract over the various future backends.

    T

    the type of the underlying future.

    f

    The underlying future to wait for.

    timeout

    The amount of time to wait for.

    returns

    The underlying value if the future is successfully completed, or an error thrown otherwise.

    Definition Classes
    QueryContext

Concrete Value Members

  1. object ? extends PrepareMark

    Permalink
    Definition Classes
    DefaultImports
  2. val Analyzer: builder.query.sasi.Analyzer.type

    Permalink
    Definition Classes
    DefaultImports
  3. object Batch extends Batcher with Product with Serializable

    Permalink
    Definition Classes
    DefaultImports
  4. val Cache: CachingStrategies

    Permalink
    Definition Classes
    CreateImplicits
  5. object Caching extends CachingStrategies

    Permalink
    Definition Classes
    TablePropertyClauses
  6. object ConsistencyLevel

    Permalink
    Definition Classes
    DefaultImports
  7. val ContactPoint: connectors.ContactPoint.type

    Permalink
    Definition Classes
    DefaultImports
  8. val ContactPoints: connectors.ContactPoints.type

    Permalink
    Definition Classes
    DefaultImports
  9. object DateTieredCompactionStrategy extends DateTieredCompactionStrategy with Product with Serializable

    Permalink
    Definition Classes
    CompactionStrategies
  10. object DeflateCompressor extends DeflateCompressor

    Permalink
    Definition Classes
    CompressionStrategies
  11. val KeySpace: connectors.KeySpace.type

    Permalink
    Definition Classes
    DefaultImports
  12. object LZ4Compressor extends LZ4Compressor

    Permalink
    Definition Classes
    CompressionStrategies
  13. object LeveledCompactionStrategy extends LeveledCompactionStrategy with Product with Serializable

    Permalink
    Definition Classes
    CompactionStrategies
  14. val ListValue: builder.query.prepared.ListValue.type

    Permalink
    Definition Classes
    QueryContext
  15. val Mode: builder.query.sasi.Mode.type

    Permalink
    Definition Classes
    DefaultImports
  16. object NetworkTopologyStrategy extends NetworkTopologyStrategy

    Permalink
    Definition Classes
    TopologyStrategies
  17. val Primitive: builder.primitives.Primitive.type

    Permalink
    Definition Classes
    DefaultImports
  18. object SimpleStrategy extends SimpleStrategy

    Permalink
    Definition Classes
    TopologyStrategies
  19. object SizeTieredCompactionStrategy extends SizeTieredCompactionStrategy with Product with Serializable

    Permalink
    Definition Classes
    CompactionStrategies
  20. object SnappyCompressor extends SnappyCompressor

    Permalink
    Definition Classes
    CompressionStrategies
  21. object Storage

    Permalink
    Definition Classes
    TablePropertyClauses
  22. object TimeWindowCompactionStrategy extends TimeWindowCompactionStrategy with Product with Serializable

    Permalink
    Definition Classes
    CompactionStrategies
  23. val Version: DefaultVersions.type

    Permalink
    Definition Classes
    DefaultImports
  24. implicit val adapter: GuavaAdapter[F]

    Permalink
    Definition Classes
    QueryContext
  25. def apply[T <: phantom.CassandraTable[T, _], R](root: RootCreateQuery[T, R])(implicit keySpace: connectors.KeySpace): Default[T, R]

    Permalink
    Definition Classes
    CreateImplicits
  26. implicit def assignmentUpdateOps[T <: phantom.CassandraTable[T, _], R, L <: LimitBound, O <: OrderBound, S <: ConsistencyBound, Chain <: WhereBound, PS <: HList, MP <: HList](query: AssignmentsQuery[T, R, L, O, S, Chain, PS, MP]): UpdateIncompleteQueryOps[P, F]

    Permalink
    Definition Classes
    QueryContext
  27. object avg extends AvgCqlFunction

    Permalink
    Definition Classes
    Operators
  28. final val bloom_filter_fp_chance: BloomFilterFpChanceBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  29. final val caching: CachingBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  30. implicit def columnClauseToDeleteCondition(col: AbstractColumn[_]): Condition

    Permalink
    Definition Classes
    DeleteImplicits
  31. implicit final def columnToCasCompareColumn[RR](col: AbstractColumn[RR])(implicit ev: <:!<[col.type, Indexed]): CasConditionalOperators[RR]

    Permalink
    Definition Classes
    ImplicitMechanism
    Annotations
    @implicitNotFound( ... )
  32. implicit final def columnToDropColumn[T](col: AbstractColumn[T])(implicit ev: <:!<[col.type, Undroppable]): DropColumn[T]

    Permalink
    Definition Classes
    ImplicitMechanism
    Annotations
    @implicitNotFound( ... )
  33. implicit def columnToModifyColumn[RR](col: AbstractColumn[RR])(implicit ev: <:!<[col.type, Unmodifiable], ev2: <:!<[col.type, CollectionValueDefinition[RR]]): ModifyColumn[RR]

    Permalink
    Definition Classes
    ModifyMechanism
    Annotations
    @implicitNotFound( ... )
  34. implicit def columnUpdateClauseToDeleteCondition(clause: MapKeyUpdateClause[_, _]): Condition

    Permalink
    Definition Classes
    DeleteImplicits
  35. final val comment: CommentClauseBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  36. final val compaction: CompactionBuilder

    Permalink

    Table creation clause allowing specification of CQL compaction strategies.

    Table creation clause allowing specification of CQL compaction strategies.

    • SizeTieredCompactionStrategy
    • LeveledCompactionStrategy
    • DateTieredCompactionStrategy
    import com.outworkers.phantom.dsl._
    
    SomeTable.create.`with`(compaction eqs SnappyCompressor)
    Definition Classes
    TablePropertyClauses
  37. final val compression: CompressionBuilder

    Permalink

    Helper object used to specify the compression strategy for a table.

    Helper object used to specify the compression strategy for a table. According to the Cassandra specification, the available strategies are:

    • SnappyCompressor
    • LZ4Compressor
    • DeflateCompressor

    A simple way to define a strategy is by using the {{eqs}} method.

    import com.outworkers.phantom.dsl._
    
    SomeTable.create.with(compression eqs SnappyCompressor)

    Using a compression strategy also allows using the API methods of controlling compressor behaviour:

    import com.outworkers.phantom.dsl._
    import com.twitter.conversions.storage._
    
    SomeTable.create.`with`(compression eqs SnappyCompressor.chunk_length_kb(50.kilobytes))
    Definition Classes
    TablePropertyClauses
  38. implicit def conditionalUpdateOps[T <: phantom.CassandraTable[T, _], R, L <: LimitBound, O <: OrderBound, S <: ConsistencyBound, Chain <: WhereBound, PS <: HList, MP <: HList](query: ConditionalQuery[T, R, L, O, S, Chain, PS, MP]): UpdateIncompleteQueryOps[P, F]

    Permalink
    Definition Classes
    QueryContext
  39. object contains

    Permalink
    Definition Classes
    DefaultSASIOps
  40. implicit val context: ExecutionContextExecutor

    Permalink
    Definition Classes
    DefaultImports
  41. object count extends CountCqlFunction

    Permalink
    Definition Classes
    Operators
  42. def cql(str: String, options: QueryOptions = QueryOptions.empty): QueryInterface[Future]

    Permalink

    Method that allows executing a simple query straight from text, by-passing the entire mapping layer but leveraging the execution layer.

    Method that allows executing a simple query straight from text, by-passing the entire mapping layer but leveraging the execution layer.

    str

    The input CQLQuery to execute.

    options

    The QueryOptions to pass alongside the query.

    returns

    A future wrapping a database result set.

  43. def cql(str: CQLQuery, options: QueryOptions): QueryInterface[Future]

    Permalink

    Method that allows executing a simple query straight from text, by-passing the entire mapping layer but leveraging the execution layer.

    Method that allows executing a simple query straight from text, by-passing the entire mapping layer but leveraging the execution layer.

    str

    The input CQLQuery to execute.

    options

    The QueryOptions to pass alongside the query.

    returns

    A future wrapping a database result set.

  44. object dateOf extends DateOfCqlFunction

    Permalink
    Definition Classes
    Operators
  45. final val dclocal_read_repair_chance: DcLocalReadRepairChanceBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  46. final val default_time_to_live: TimeToLiveBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  47. val durable_writes: AnyRef { def eqs(clause: Boolean): com.outworkers.phantom.builder.serializers.BuilderClause }

    Permalink
    Definition Classes
    TopologyStrategies
  48. def executeStatements[M[X] <: TraversableOnce[X]](col: QueryCollection[M]): ExecutableStatements[F, M]

    Permalink
    Definition Classes
    QueryContext
  49. implicit val futureMonad: FutureMonad[Future]

    Permalink
  50. final val gc_grace_seconds: GcGraceSecondsBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  51. object ignoreNulls extends Condition

    Permalink
    Definition Classes
    UsingClauseOperations
  52. implicit def keyspaceToKeyspaceQuery(k: KeySpace): RootSerializer

    Permalink

    Used as a secondary option when creating a ContactPoint to allow users to provide a single KeySpace derived query.

    Used as a secondary option when creating a ContactPoint to allow users to provide a single KeySpace derived query. When users want to provide a single argument to the ContactPoint#keySpace method, they can use the following syntax to generate a full keyspace initialisation query. The KeySpace will implicitly convert to a RootSerializer.

    KeySpace("test").ifNotExists
    Definition Classes
    DefaultImports
  53. implicit def mapColumnDefinitionToEntriesQueryColumn[K, V](cond: MapKeyUpdateClause[K, V])(implicit arg0: builder.primitives.Primitive[K], arg1: builder.primitives.Primitive[V]): MapEntriesConditionals[K, V]

    Permalink

    Definition used to cast a comparison clause to Map entry lookup based on a secondary index.

    Definition used to cast a comparison clause to Map entry lookup based on a secondary index.

    K

    The type of the key inside the MapColumn.

    V

    The type of the value held inside the MapColumn.

    cond

    The column update clause generated from MapColumn.apply(keyValue)

    returns

    A MapEntriesConditionals query that allows secondary index operators on map entries.

    Definition Classes
    ImplicitMechanism
  54. implicit def mapColumnToQueryColumn[T <: phantom.CassandraTable[T, R], R, K, V](col: AbstractMapColumn[T, R, K, V] with keys.Index)(implicit ev: <:!<[col, keys.Keys]): MapConditionals[T, R, K, V]

    Permalink

    Definition used to cast an index map column with values indexed to a query-able definition.

    Definition used to cast an index map column with values indexed to a query-able definition. This will allow users to use "CONTAINS" clauses to search for matches based on map values.

    T

    The Cassandra table inner type.

    R

    The record type of the table.

    K

    The type of the key held in the map.

    V

    The type of the value held in the map.

    col

    The map column to cast to a Map column secondary index query.

    returns

    A MapConditionals class with CONTAINS support.

    Definition Classes
    ImplicitMechanism
  55. implicit def mapColumnToRemoveKeysQuery[T <: phantom.CassandraTable[T, R], R, K, V](col: AbstractMapColumn[T, R, K, V])(implicit ev: <:!<[col.type, keys.Keys]): MapRemoveKeyQueries[T, R, K, V]

    Permalink

    Definition used to allow removing keys from a map column using UPDATE query syntax.

    Definition used to allow removing keys from a map column using UPDATE query syntax. Keys are serialised to their CQL value and passed along using SET syntax.

    Example:

    UPDATE db.table WHERE a = b SET mapColumn -= { "a", "b", "c" }
    T

    The Cassandra table inner type.

    R

    The record type of the table.

    K

    The type of the key held in the map.

    V

    The type of the value held in the map.

    col

    The map column to cast to a Map column secondary index query.

    returns

    A MapConditionals class with CONTAINS support.

    Definition Classes
    ImplicitMechanism
  56. object max extends MaxCqlFunction

    Permalink
    Definition Classes
    Operators
  57. object maxTimeuuid extends MaxTimeUUID

    Permalink
    Definition Classes
    Operators
  58. object min extends MinCqlFunction

    Permalink
    Definition Classes
    Operators
  59. object minTimeuuid extends MinTimeUUID

    Permalink
    Definition Classes
    Operators
  60. object now extends NowCqlFunction

    Permalink
    Definition Classes
    Operators
  61. implicit def optionalColumnToModifyColumn[Table <: phantom.CassandraTable[Table, Rec], Rec, RR](col: OptionalColumn[Table, Rec, RR])(implicit ev: <:!<[col.type, Unmodifiable], ev2: <:!<[col.type, CollectionValueDefinition[RR]]): ModifyColumnOptional[RR]

    Permalink
    Definition Classes
    ModifyMechanism
    Annotations
    @implicitNotFound( ... )
  62. implicit def orderingColumn[RR](col: AbstractColumn[RR] with keys.PrimaryKey): OrderingColumn[RR]

    Permalink
    Definition Classes
    ImplicitMechanism
  63. implicit def partitionColumnQueries[RR](col: AbstractColumn[RR] with keys.PartitionKey)(implicit arg0: builder.primitives.Primitive[RR]): PartitionQueryColumn[RR]

    Permalink
    Definition Classes
    ImplicitMechanism
  64. object prefix

    Permalink
    Definition Classes
    DefaultSASIOps
  65. implicit val promiseInterface: PromiseInterface[P, F]

    Permalink
    Definition Classes
    QueryContext
  66. final val read_repair_chance: ReadRepairChanceBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  67. final val replicate_on_write: ReplicateOnWriteBuilder

    Permalink
    Definition Classes
    TablePropertyClauses
  68. val replication: AnyRef { def eqs(strategy: com.outworkers.phantom.builder.serializers.ReplicationStrategy[_]): com.outworkers.phantom.builder.serializers.BuilderClause }

    Permalink
    Definition Classes
    TopologyStrategies
  69. implicit def rootCreateQueryToCreateQuery[T <: phantom.CassandraTable[T, _], R](root: RootCreateQuery[T, R])(implicit keySpace: connectors.KeySpace): Default[T, R]

    Permalink
    Definition Classes
    CreateImplicits
  70. implicit final def rootSelectBlockToSelectQuery[T <: phantom.CassandraTable[T, _], R](root: RootSelectBlock[T, R])(implicit keySpace: connectors.KeySpace): Default[T, R]

    Permalink
    Definition Classes
    SelectImplicits
    Annotations
    @implicitNotFound( ... )
  71. implicit def rootSerializerToKeySpaceSerializer(serializer: RootSerializer): KeySpaceSerializer

    Permalink
    Definition Classes
    KeySpaceConstruction
  72. implicit def sasiGenericOps[RR](col: AbstractColumn[RR] with keys.SASIIndex[_ <: Mode])(implicit arg0: builder.primitives.Primitive[RR]): QueryColumn[RR]

    Permalink
    Definition Classes
    ImplicitMechanism
  73. implicit def sasiTextOps[M <: Mode](col: AbstractColumn[String] with keys.SASIIndex[M])(implicit ev: builder.primitives.Primitive[String]): SASITextOps[M]

    Permalink
    Definition Classes
    ImplicitMechanism
  74. object suffix

    Permalink
    Definition Classes
    DefaultSASIOps
  75. object sum extends SumCqlFunction

    Permalink
    Definition Classes
    Operators
  76. object token extends TokenCqlFunction

    Permalink
    Definition Classes
    Operators
  77. object ttl extends TTLOfFunction

    Permalink
    Definition Classes
    Operators
  78. object unixTimestampOf extends UnixTimestampOfCqlFunction

    Permalink
    Definition Classes
    Operators
  79. implicit def updateOps[T <: phantom.CassandraTable[T, _], R, L <: LimitBound, O <: OrderBound, S <: ConsistencyBound, Chain <: WhereBound, PS <: HList](query: UpdateQuery[T, R, L, O, S, Chain, PS]): UpdateIncompleteQueryOps[P, F]

    Permalink
    Definition Classes
    QueryContext
  80. object writetime extends WritetimeCqlFunction

    Permalink
    Definition Classes
    Operators

Inherited from DefaultImports

Inherited from DefaultSASIOps

Inherited from DeleteImplicits

Inherited from KeySpaceConstruction

Inherited from TopologyStrategies

Inherited from UsingClauseOperations

Inherited from Operators

Inherited from SelectImplicits

Inherited from CreateImplicits

Inherited from TablePropertyClauses

Inherited from CompressionStrategies

Inherited from CompactionStrategies

Inherited from ImplicitMechanism

Inherited from ModifyMechanism

Inherited from ScalaQueryContext

Inherited from QueryContext[Promise, Future, Duration]

Inherited from AnyRef

Inherited from Any

Ungrouped